A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 
All Classes All Packages

A

a - Variable in class org.h2.expression.condition.BetweenPredicate
 
AbbaDetector - Class in org.h2.util
Utility to detect AB-BA deadlocks.
AbbaDetector() - Constructor for class org.h2.util.AbbaDetector
 
AbbaLockingDetector - Class in org.h2.util
Utility to detect AB-BA deadlocks.
AbbaLockingDetector() - Constructor for class org.h2.util.AbbaLockingDetector
 
abort(Executor) - Method in class org.h2.jdbc.JdbcConnection
[Not supported]
ABORT - org.h2.mvstore.MVMap.Decision
 
ABORT_SESSION - Static variable in class org.h2.expression.function.SessionControlFunction
ABORT_SESSION().
ABS - Static variable in class org.h2.expression.function.MathFunction
ABS().
absolute(int) - Method in class org.h2.jdbc.JdbcResultSet
Moves the current position to a specific row.
absolute(int) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
absoluteDay - Variable in class org.h2.mode.ToDateParser
 
absoluteDay(long, int, int) - Static method in class org.h2.util.DateTimeUtils
Calculate the absolute day.
absoluteDayFromDateValue(long) - Static method in class org.h2.util.DateTimeUtils
Calculate the absolute day from an encoded date value.
absoluteDayFromYear(long) - Static method in class org.h2.util.DateTimeUtils
Calculate the absolute day for a January, 1 of the specified year.
absoluteDayValid - Variable in class org.h2.mode.ToDateParser
 
absorb(byte[], int) - Method in class org.h2.security.SHA3
 
absorbQueue() - Method in class org.h2.security.SHA3
 
AbstractAggregate - Class in org.h2.expression.aggregate
A base class for aggregate functions.
AbstractAggregate(Select, Expression[], boolean) - Constructor for class org.h2.expression.aggregate.AbstractAggregate
 
accept(BnfVisitor) - Method in class org.h2.bnf.context.DbContextRule
 
accept(BnfVisitor) - Method in interface org.h2.bnf.Rule
Call the visit method in the given visitor.
accept(BnfVisitor) - Method in class org.h2.bnf.RuleElement
 
accept(BnfVisitor) - Method in class org.h2.bnf.RuleExtension
 
accept(BnfVisitor) - Method in class org.h2.bnf.RuleFixed
 
accept(BnfVisitor) - Method in class org.h2.bnf.RuleList
 
accept(BnfVisitor) - Method in class org.h2.bnf.RuleOptional
 
accept(BnfVisitor) - Method in class org.h2.bnf.RuleRepeat
 
accept(TableFilter) - Method in class org.h2.table.TableFilter.MapColumnsVisitor
 
accept(TableFilter) - Method in interface org.h2.table.TableFilter.TableFilterVisitor
This method is called for each nested or joined table filter.
acceptChunkOccupancyChanges(long, long) - Method in class org.h2.mvstore.MVStore
Apply the freed space to the chunk metadata.
acceptsURL(String) - Method in class org.h2.Driver
Check if the driver understands this URL.
access(CacheLongKeyLIRS.Entry<V>) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
Access an item, moving the entry to the top of the stack or front of the queue if found.
ACCESS_DENIED_TO_CLASS_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90134 is thrown when trying to load a Java class that is not part of the allowed classes.
accountForRemovedPage(int, int, boolean, long, long) - Method in class org.h2.mvstore.Chunk
Modifies internal state to reflect the fact that one the pages within this chunk was removed from the map.
accountForRemovedPage(long, long, boolean, int) - Method in class org.h2.mvstore.MVStore
Remove a page.
accountForWrittenPage(int, boolean) - Method in class org.h2.mvstore.Chunk
Modifies internal state to reflect the fact that one more page is stored within this chunk.
ACOS - Static variable in class org.h2.expression.function.MathFunction1
ACOS().
actionPerformed(ActionEvent) - Method in class org.h2.tools.GUIConsole
INTERNAL
actions - Variable in class org.h2.command.dml.SetClauseList
 
activeConnections - Variable in class org.h2.jdbcx.JdbcConnectionPool
 
activeRequest - Variable in class org.h2.server.pg.PgServerThread
 
ADAPTER - Static variable in class org.h2.message.TraceSystem
This trace level means all type of messages should be written, but instead of using the trace file the messages should be written to SLF4J.
add(int) - Method in class org.h2.command.ddl.Analyze.SelectivityData
 
add(int) - Method in class org.h2.util.IntArray
Append a value.
add(int, int, DataType, String...) - Static method in class org.h2.value.DataType
 
add(Object) - Method in interface org.h2.api.Aggregate
This method is called once for each row.
add(Object) - Method in interface org.h2.api.AggregateFunction
This method is called once for each row.
add(Object) - Method in class org.h2.schema.UserAggregate.AggregateWrapper
 
add(String) - Method in class org.h2.command.dml.Explain
 
add(String, boolean) - Method in class org.h2.command.dml.ScriptCommand
 
add(String, String, int) - Method in class org.h2.bnf.Sentence
Add a word to the set of next tokens.
add(ArrayList<T>, T) - Static method in class org.h2.table.Table
 
add(Mode) - Static method in class org.h2.engine.Mode
 
add(SessionLocal, ArrayList<Row>, Object...) - Method in class org.h2.table.MetaTable
Add a row to a list.
add(SessionLocal, Row) - Method in class org.h2.index.Index
Add a row to the index.
add(SessionLocal, Row) - Method in class org.h2.index.LinkedIndex
 
add(SessionLocal, Row) - Method in class org.h2.index.MetaIndex
 
add(SessionLocal, Row) - Method in class org.h2.index.ViewIndex
 
add(SessionLocal, Row) - Method in class org.h2.index.VirtualTableIndex
 
add(SessionLocal, Row) - Method in class org.h2.mvstore.db.MVDelegateIndex
 
add(SessionLocal, Row) - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
add(SessionLocal, Row) - Method in class org.h2.mvstore.db.MVSecondaryIndex
 
add(SessionLocal, Row) - Method in class org.h2.mvstore.db.MVSpatialIndex
 
add(SessionLocal, Value) - Method in class org.h2.expression.aggregate.AggregateData
Add a value to this aggregate.
add(SessionLocal, Value) - Method in class org.h2.expression.aggregate.AggregateDataAvg
 
add(SessionLocal, Value) - Method in class org.h2.expression.aggregate.AggregateDataBinarySet
 
add(SessionLocal, Value) - Method in class org.h2.expression.aggregate.AggregateDataCollecting
 
add(SessionLocal, Value) - Method in class org.h2.expression.aggregate.AggregateDataCount
 
add(SessionLocal, Value) - Method in class org.h2.expression.aggregate.AggregateDataDefault
 
add(SessionLocal, Value) - Method in class org.h2.expression.aggregate.AggregateDataDistinctWithCounts
 
add(SessionLocal, Value) - Method in class org.h2.expression.aggregate.AggregateDataEnvelope
 
add(SessionLocal, Value) - Method in class org.h2.expression.aggregate.AggregateDataStdVar
 
add(SessionLocal, Value, Value) - Method in class org.h2.expression.aggregate.AggregateDataBinarySet
 
add(SessionLocal, Value, Value) - Method in class org.h2.expression.aggregate.AggregateDataCorr
 
add(SessionLocal, Value, Value) - Method in class org.h2.expression.aggregate.AggregateDataCovar
 
add(Spatial, V) - Method in class org.h2.mvstore.rtree.MVRTreeMap
Add a given key-value pair.
add(ResultInterface) - Method in class org.h2.result.MergedResult
Appends a result.
add(SchemaObject) - Method in class org.h2.schema.Schema
Add an object to this schema.
add(Column) - Method in class org.h2.command.query.AllColumnsForPlan
Called by ExpressionVisitor.
add(Value) - Method in class org.h2.command.ddl.Analyze.SelectivityData
 
add(Value) - Method in class org.h2.value.Value
Add a value and return the result.
add(Value) - Method in class org.h2.value.ValueBigint
 
add(Value) - Method in class org.h2.value.ValueDecfloat
 
add(Value) - Method in class org.h2.value.ValueDouble
 
add(Value) - Method in class org.h2.value.ValueEnumBase
 
add(Value) - Method in class org.h2.value.ValueInteger
 
add(Value) - Method in class org.h2.value.ValueInterval
 
add(Value) - Method in class org.h2.value.ValueNumeric
 
add(Value) - Method in class org.h2.value.ValueReal
 
add(Value) - Method in class org.h2.value.ValueSmallint
 
add(Value) - Method in class org.h2.value.ValueTime
 
add(Value) - Method in class org.h2.value.ValueTimestamp
 
add(Value) - Method in class org.h2.value.ValueTinyint
 
add(Value, SessionLocal) - Method in class org.h2.expression.condition.ConditionInConstantSet
 
ADD_MONTHS - Static variable in class org.h2.mode.FunctionsOracle
 
ADD_PLAN_INFORMATION - Static variable in interface org.h2.util.HasSQL
Add execution plan information.
addAfter - Variable in class org.h2.command.ddl.AlterTableAlterColumn
 
addAggregate(String, AggregateType) - Static method in class org.h2.expression.aggregate.Aggregate
 
addAlias(String, String) - Method in class org.h2.bnf.Bnf
Add an alias for a rule.
addAlias(String, DbTableOrView) - Method in class org.h2.bnf.Sentence
Add an alias name and object
addAll(Collection<Schema>, int, ArrayList<SchemaObject>) - Static method in class org.h2.command.ddl.DropDatabase
 
addAssignmentForDuplicate(Column, Expression) - Method in class org.h2.command.dml.Insert
Keep a collection of the columns to pass to update if a duplicate key happens, for MySQL-style INSERT ...
addAsterisk(String, int) - Static method in class org.h2.util.StringUtils
Add an asterisk ('[*]') at the given position.
addAttribute(SessionLocal, ArrayList<Row>, int, int, Table, Column, int) - Method in class org.h2.mode.PgCatalogTable
 
addBatch() - Method in class org.h2.jdbc.JdbcPreparedStatement
Adds the current settings to the batch.
addBatch(String) - Method in class org.h2.jdbc.JdbcPreparedStatement
Calling this method is not legal on a PreparedStatement.
addBatch(String) - Method in class org.h2.jdbc.JdbcStatement
Adds a statement to the batch.
addBefore - Variable in class org.h2.command.ddl.AlterTableAlterColumn
 
addBufferedRows(List<String>) - Method in class org.h2.mvstore.db.MVDelegateIndex
 
addBufferedRows(List<String>) - Method in class org.h2.mvstore.db.MVIndex
Add all the index data from the buffers to the index.
addBufferedRows(List<String>) - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
addBufferedRows(List<String>) - Method in class org.h2.mvstore.db.MVSecondaryIndex
 
addBufferedRows(List<String>) - Method in class org.h2.mvstore.db.MVSpatialIndex
 
addClass(SessionLocal, ArrayList<Row>, int, String, int, String, boolean, int) - Method in class org.h2.mode.PgCatalogTable
 
addClassFactory(Utils.ClassFactory) - Static method in class org.h2.util.JdbcUtils
Add a class factory in order to manage more than one class loader.
addColumn(String, int, int, int) - Method in class org.h2.tools.SimpleResultSet
Adds a column to the result set.
addColumn(String, int, String, int, int) - Method in class org.h2.tools.SimpleResultSet
Adds a column to the result set.
addColumn(String, String, int, long, int) - Method in class org.h2.result.SimpleResult
Add column to the result.
addColumn(String, String, TypeInfo) - Method in class org.h2.result.SimpleResult
Add column to the result.
addColumn(String, TypeInfo) - Method in class org.h2.result.SimpleResult
Add column to the result.
addColumn(SimpleResult.Column) - Method in class org.h2.result.SimpleResult
Add column to the result.
addColumn(Column) - Method in class org.h2.command.ddl.AlterTableAlterColumn
 
addColumn(Column) - Method in class org.h2.command.ddl.CommandWithColumns
Add a column to this table.
addColumn(Column) - Method in class org.h2.command.ddl.CreateTable
 
addColumn(Column, StringBuilder, StringBuilder) - Static method in class org.h2.command.ddl.AlterTableAlterColumn
 
addColumn1(Column) - Method in class org.h2.expression.ExpressionVisitor
Add a new column to the set of columns.
addColumn2(Column) - Method in class org.h2.expression.ExpressionVisitor
Add a new column to the set of columns.
addColumnData(SessionLocal, ArrayList<String>, ArrayList<String>, Expression) - Static method in class org.h2.fulltext.FullText
 
addColumns(boolean, DbTableOrView, StringBuilder, int, boolean, StringBuilder) - Static method in class org.h2.server.web.WebApp
 
addCommand(String) - Method in class org.h2.server.web.WebSession
Add a SQL statement to the history.
addCommonJoinColumns(Column, Column, TableFilter) - Method in class org.h2.table.TableFilter
Add a column to the common join column list for a left table filter.
addCommonJoinColumnToExclude(Column) - Method in class org.h2.table.TableFilter
Add an excluded column to the common join column list.
addCondition(Expression) - Method in class org.h2.command.query.Select
Add a condition to the list of conditions.
addConnection(int, String, String) - Method in class org.h2.server.TcpServer
Add a connection to the management database.
addConnectionEventListener(ConnectionEventListener) - Method in class org.h2.jdbcx.JdbcXAConnection
Register a new listener for the connection.
addConstraint(Constraint) - Method in class org.h2.table.Table
Add a constraint to the table.
addConstraint(ConstraintDomain) - Method in class org.h2.schema.Domain
Add a constraint to the domain.
addConstraintColumnUsage(SessionLocal, ArrayList<Row>, String, Constraint, Column) - Method in class org.h2.table.InformationSchemaTable
 
addConstraintColumnUsage(SessionLocal, ArrayList<Row>, String, Constraint, Column) - Method in class org.h2.table.InformationSchemaTableLegacy
 
addConstraintCommand(AlterDomainAddConstraint) - Method in class org.h2.command.ddl.CreateDomain
Add a constraint command.
addConstraintCommand(DefineCommand) - Method in class org.h2.command.ddl.CommandWithColumns
Add a constraint statement to this statement.
addConstraintToTable(Database, Table, Constraint) - Method in class org.h2.command.ddl.AlterTableAddConstraint
 
addCoordinate(double, double, double, double, int, int) - Method in class org.h2.util.geometry.EWKBUtils.EWKBTarget
 
addCoordinate(double, double, double, double, int, int) - Method in class org.h2.util.geometry.EWKTUtils.EWKTTarget
 
addCoordinate(double, double, double, double, int, int) - Method in class org.h2.util.geometry.GeoJsonUtils.GeoJsonTarget
 
addCoordinate(double, double, double, double, int, int) - Method in class org.h2.util.geometry.GeometryUtils.DimensionSystemTarget
 
addCoordinate(double, double, double, double, int, int) - Method in class org.h2.util.geometry.GeometryUtils.EnvelopeTarget
 
addCoordinate(double, double, double, double, int, int) - Method in class org.h2.util.geometry.GeometryUtils.Target
Invoked to add a coordinate to a geometry.
addCoordinate(double, double, double, double, int, int) - Method in class org.h2.util.geometry.JTSUtils.GeometryTarget
 
addCoordinate(EWKBUtils.EWKBSource, GeometryUtils.Target, boolean, boolean, int, int) - Static method in class org.h2.util.geometry.EWKBUtils
 
addCoordinate(EWKTUtils.EWKTSource, GeometryUtils.Target, int, int, int) - Static method in class org.h2.util.geometry.EWKTUtils
 
addCoordinate(CoordinateSequence, GeometryUtils.Target, int, int) - Static method in class org.h2.util.geometry.JTSUtils
 
addCoordinate(CoordinateSequence, GeometryUtils.Target, int, int, double, double) - Static method in class org.h2.util.geometry.JTSUtils
 
addCrossReferenceResult(SimpleResult, Value, String, Table, String, Table, ConstraintReferential) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
addDatabaseMetaData(SimpleResultSet, DatabaseMetaData) - Static method in class org.h2.util.JdbcUtils
 
addDatabaseObject(SessionLocal, DbObject) - Method in class org.h2.engine.Database
Add an object to the database.
addDataModificationId(long) - Method in class org.h2.expression.ExpressionVisitor
Update the field maxDataModificationId if this value is higher than the current value.
addDependencies(HashSet<DbObject>) - Method in class org.h2.table.Table
Add all objects that this table depends on to the hash set.
addDependencies(HashSet<DbObject>) - Method in class org.h2.table.TableView
 
addDependency(DbObject) - Method in class org.h2.expression.ExpressionVisitor
Add a new dependency to the set of dependencies.
addDependentView(TableView) - Method in class org.h2.table.Table
Add a view to this table.
addDependentViewToTables() - Method in class org.h2.table.TableView
 
addDomain(Domain) - Method in class org.h2.command.dml.ScriptCommand
 
added - Variable in class org.h2.expression.condition.ConditionAndOr
Additional condition for index only.
added - Variable in class org.h2.expression.condition.ConditionAndOrN
Additional conditions for index only.
addedToFilter - Variable in class org.h2.expression.Expression
 
addElement(JSONValue) - Method in class org.h2.util.json.JSONArray
Add a value to the array.
addExpandedColumn(TableFilter, int, HashMap<Column, ExpressionColumn>, String, String, Column) - Method in class org.h2.command.query.Select
 
addExpected(int) - Method in class org.h2.command.Parser
 
addExpected(String) - Method in class org.h2.command.Parser
 
addExplicitNullOrdering(int) - Method in enum org.h2.mode.DefaultNullOrdering
Returns a sort type bit mask with SortOrder.NULLS_FIRST or SortOrder.NULLS_LAST explicitly set
addFile(Object, Object) - Method in class org.h2.util.TempFileDeleter
Add a file or a closeable to the list of temporary objects to delete.
addFilterCondition(Expression, boolean) - Method in class org.h2.table.TableFilter
Add a filter condition.
addFilterConditions(TableFilter) - Method in class org.h2.expression.condition.ConditionAndOr
 
addFilterConditions(TableFilter) - Method in class org.h2.expression.condition.ConditionAndOrN
 
addFilterConditions(TableFilter) - Method in class org.h2.expression.condition.ConditionLocalAndGlobal
 
addFilterConditions(TableFilter) - Method in class org.h2.expression.Expression
Add conditions to a table filter if they can be evaluated.
addFirst - Variable in class org.h2.command.ddl.AlterTableAlterColumn
 
addFirst(Expression) - Method in class org.h2.expression.condition.ConditionAndOrN
Add the expression at the beginning of the list.
addFixedRule(String, int) - Method in class org.h2.bnf.Bnf
 
addGlobalCondition(Expression, Expression) - Static method in class org.h2.command.query.Select
 
addGlobalCondition(Parameter, int, int) - Method in class org.h2.command.query.Query
Add a condition to the query.
addGlobalCondition(Parameter, int, int) - Method in class org.h2.command.query.Select
 
addGlobalCondition(Parameter, int, int) - Method in class org.h2.command.query.SelectUnion
 
addGlobalCondition(Parameter, int, int) - Method in class org.h2.command.query.TableValueConstructor
 
addIgnored(Iterable<String>) - Method in class org.h2.fulltext.FullTextSettings
Amend set of ignored words
addIndex(List<Column>, int, IndexType) - Method in class org.h2.table.TableLink
 
addIndex(SessionLocal, String, int, IndexColumn[], int, IndexType, boolean, String) - Method in class org.h2.mvstore.db.MVTable
 
addIndex(SessionLocal, String, int, IndexColumn[], int, IndexType, boolean, String) - Method in class org.h2.table.MetaTable
 
addIndex(SessionLocal, String, int, IndexColumn[], int, IndexType, boolean, String) - Method in class org.h2.table.Table
Create an index for this table
addIndex(SessionLocal, String, int, IndexColumn[], int, IndexType, boolean, String) - Method in class org.h2.table.TableLink
 
addIndex(SessionLocal, String, int, IndexColumn[], int, IndexType, boolean, String) - Method in class org.h2.table.TableView
 
addIndex(SessionLocal, String, int, IndexColumn[], int, IndexType, boolean, String) - Method in class org.h2.table.VirtualTable
 
addIndexCondition(IndexCondition) - Method in class org.h2.table.TableFilter
Add an index condition.
addIndexes(boolean, DatabaseMetaData, String, String, StringBuilder, int) - Static method in class org.h2.server.web.WebApp
 
addIndexInfo(IndexInfo) - Method in class org.h2.fulltext.FullTextSettings
Add an index.
addInterval(int) - Static method in class org.h2.value.DataType
 
ADDITIONAL_AVG_SCALE - Static variable in class org.h2.expression.aggregate.Aggregate
The additional precision and scale in decimal digits for an AVG aggregate function.
ADDITIONAL_SUM_PRECISION - Static variable in class org.h2.expression.aggregate.Aggregate
The additional result precision in decimal digits for a SUM aggregate function.
addJoin(TableFilter, boolean, Expression) - Method in class org.h2.table.TableFilter
Add a joined table.
addJoin(TableFilter, TableFilter, boolean, Expression) - Method in class org.h2.command.Parser
Add one join to another.
addJoinColumn(Expression, TableFilter, TableFilter, Column, Column, boolean) - Method in class org.h2.command.Parser
 
addLocalTempTable(Table) - Method in class org.h2.engine.SessionLocal
Add a local temporary table to this session.
addLocalTempTableConstraint(Constraint) - Method in class org.h2.engine.SessionLocal
Add a local temporary constraint to this session.
addLocalTempTableIndex(Index) - Method in class org.h2.engine.SessionLocal
Add a local temporary index to this session.
addLockToDebugList(DebuggingThreadLocal<ArrayList<String>>) - Method in class org.h2.mvstore.db.MVTable
 
addMember(String, JSONValue) - Method in class org.h2.util.json.JSONObject
Add a key-value pair.
addMemory(int) - Method in class org.h2.mvstore.Page
Increase estimated memory used in persistent case.
addMeta(SessionLocal, DbObject) - Method in class org.h2.engine.Database
 
addMortonRanges(ArrayList<long[]>, int[], int[], int, int) - Method in class org.h2.tools.MultiDimension
 
addMultiple(ArrayList<Column>, Expression) - Method in class org.h2.command.dml.SetClauseList
Add multiple columns.
addMultipleExpected(int...) - Method in class org.h2.command.Parser
 
addNodeKeys(ArrayList<Spatial>, Page<Spatial, V>) - Method in class org.h2.mvstore.rtree.MVRTreeMap
Add all node keys (including internal bounds) to the given list.
addNullOrdering(Database, int[]) - Static method in class org.h2.result.SortOrder
Add explicit SortOrder.NULLS_FIRST or SortOrder.NULLS_LAST where they aren't already specified.
addObject(int, Object) - Method in class org.h2.util.SmallMap
Add an object to the map.
addOrUpdateSetting(String, String, int) - Method in class org.h2.command.dml.Set
 
addOrUpdateSetting(SessionLocal, String, String, int) - Method in class org.h2.command.dml.Set
 
addParameter(StringBuilder, Column) - Method in class org.h2.index.LinkedIndex
 
addParameter(Expression) - Method in interface org.h2.expression.ExpressionWithVariableParameters
Adds the parameter expression.
addParameter(Expression) - Method in class org.h2.expression.function.table.TableFunction
 
addParameter(Expression) - Method in class org.h2.expression.OperationN
 
addParameter(Parameter) - Method in class org.h2.command.query.Query
Add a parameter to the parameter list.
addPrecision(long, long) - Static method in class org.h2.value.DataType
Performs saturated addition of precision values.
addPrivilege(SessionLocal, ArrayList<Row>, DbObject, String, Table, String, String) - Method in class org.h2.table.InformationSchemaTable
 
addPrivilege(SessionLocal, ArrayList<Row>, DbObject, String, Table, String, String) - Method in class org.h2.table.InformationSchemaTableLegacy
 
addPrivilege(SimpleResult, Value, Value, Value, Value, String, boolean, CompareLike, Column[]) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
addPrivileges(SessionLocal, ArrayList<Row>, DbObject, String, Table, String, int) - Method in class org.h2.table.InformationSchemaTable
 
addPrivileges(SessionLocal, ArrayList<Row>, DbObject, String, Table, String, int) - Method in class org.h2.table.InformationSchemaTableLegacy
 
addPrivileges(SimpleResult, Value, String, String, DbObject, int, CompareLike, Column[]) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
addProcedure(Procedure) - Method in class org.h2.engine.SessionLocal
Add a procedure to this session.
addRealm(String, CredentialsValidator) - Method in class org.h2.security.auth.DefaultAuthenticator
Add an authentication realm.
addRight(int) - Method in class org.h2.command.ddl.GrantRevoke
Add the specified right bit to the rights bitmap.
addRing(ArrayList<double[]>, GeometryUtils.Target) - Static method in class org.h2.util.geometry.EWKTUtils
 
addRing(EWKBUtils.EWKBSource, GeometryUtils.Target, boolean, boolean, int) - Static method in class org.h2.util.geometry.EWKBUtils
 
addRing(CoordinateSequence, GeometryUtils.Target, int) - Static method in class org.h2.util.geometry.JTSUtils
 
addRoleName(String) - Method in class org.h2.command.ddl.GrantRevoke
Add the specified role to the list of roles.
addRoleOrRight(GrantRevoke) - Method in class org.h2.command.Parser
 
addRow(Object...) - Method in class org.h2.tools.SimpleResultSet
Add a new row to the result set.
addRow(SessionLocal, Row) - Method in class org.h2.mvstore.db.MVTable
 
addRow(SessionLocal, Row) - Method in class org.h2.table.MetaTable
 
addRow(SessionLocal, Row) - Method in class org.h2.table.Table
Add a row to the table and all indexes.
addRow(SessionLocal, Row) - Method in class org.h2.table.TableLink
 
addRow(SessionLocal, Row) - Method in class org.h2.table.TableView
 
addRow(SessionLocal, Row) - Method in class org.h2.table.VirtualTable
 
addRow(Expression[]) - Method in class org.h2.command.dml.CommandWithValues
Add a row to this command.
addRow(Value...) - Method in class org.h2.command.CommandContainer.GeneratedKeysCollector
 
addRow(Value...) - Method in class org.h2.command.dml.Insert
 
addRow(Value...) - Method in class org.h2.expression.condition.UniquePredicate.Target
 
addRow(Value[]) - Method in class org.h2.mvstore.db.MVPlainTempResult
 
addRow(Value[]) - Method in class org.h2.mvstore.db.MVSortedTempResult
 
addRow(Value...) - Method in class org.h2.result.LocalResult
Add a row to this object.
addRow(Value[]) - Method in interface org.h2.result.ResultExternal
Add a row to this object.
addRow(Value...) - Method in interface org.h2.result.ResultTarget
Add the row to the result set.
addRow(Value...) - Method in class org.h2.result.SimpleResult
 
addRowForTable(Row) - Method in class org.h2.result.LocalResult
Add a row for a table.
addRowInternal(Value...) - Method in class org.h2.result.LocalResult
 
addRows(Collection<Value[]>) - Method in class org.h2.mvstore.db.MVTempResult
 
addRows(Collection<Value[]>) - Method in interface org.h2.result.ResultExternal
Add a number of rows to the result.
addRowsToBuffer(List<Row>, String) - Method in class org.h2.mvstore.db.MVDelegateIndex
 
addRowsToBuffer(List<Row>, String) - Method in class org.h2.mvstore.db.MVIndex
Add the rows to a temporary storage (not to the index yet).
addRowsToBuffer(List<Row>, String) - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
addRowsToBuffer(List<Row>, String) - Method in class org.h2.mvstore.db.MVSecondaryIndex
 
addRowsToBuffer(List<Row>, String) - Method in class org.h2.mvstore.db.MVSpatialIndex
 
addRowsToDisk() - Method in class org.h2.result.LocalResult
 
addRowsToIndex(SessionLocal, ArrayList<Row>, Index) - Static method in class org.h2.mvstore.db.MVTable
Appends the specified rows to the specified index.
addRule(String, String, Rule) - Method in class org.h2.bnf.Bnf
 
addSavepoint(String) - Method in class org.h2.engine.SessionLocal
Create a savepoint that is linked to the current log position.
addSchemaObject(SessionLocal, SchemaObject) - Method in class org.h2.engine.Database
Add a schema object to the database.
addSequence(Sequence) - Method in class org.h2.table.Table
Add a sequence to this table.
addSession(Connection) - Method in class org.h2.server.web.WebServer
Create a session with a given connection.
addSign(StringBuilder, int, boolean, boolean, boolean, boolean, boolean) - Static method in class org.h2.expression.function.ToCharFunction
 
addSingle(Column, Expression) - Method in class org.h2.command.dml.SetClauseList
Add a single column.
addSQL(String) - Method in exception org.h2.message.DbException
Set the SQL statement of the given exception.
addStatementEventListener(StatementEventListener) - Method in class org.h2.jdbcx.JdbcXAConnection
[Not supported] Add a statement event listener.
addString(StringBuilder) - Method in class org.h2.value.ValueUuid
 
addSynonym(TableSynonym) - Method in class org.h2.table.Table
Add a synonym to this table.
addTable(DbTableOrView) - Method in class org.h2.bnf.Sentence
Add a table.
addTable(Schema, String) - Method in class org.h2.command.ddl.DropTable
Add a table to drop.
addTable(Table) - Method in class org.h2.command.ddl.GrantRevoke
Add the specified table to the list of tables.
addTableFilter(TableFilter, boolean) - Method in class org.h2.command.query.Select
Add a table to the query.
addTableOrView(DbSchema, boolean, StringBuilder, int, DatabaseMetaData, boolean, String, boolean, boolean, DbTableOrView, boolean, PreparedStatement, String) - Static method in class org.h2.server.web.WebApp
 
addTablesAndViews(DbSchema, boolean, StringBuilder, int) - Method in class org.h2.server.web.WebApp
 
addTableToDependencies(MVTable, HashSet<MVMap<Object, VersionedValue<Object>>>) - Static method in class org.h2.engine.SessionLocal
 
addTableToDependencies(MVTable, HashSet<MVMap<Object, VersionedValue<Object>>>, HashSet<MVTable>) - Static method in class org.h2.engine.SessionLocal
 
addTemporaryLob(ValueLob) - Method in class org.h2.engine.Session
Add a temporary LOB, which is closed when the session commits.
addTemporaryLob(ValueLob) - Method in class org.h2.engine.SessionLocal
 
addTemporaryLob(ValueLob) - Method in class org.h2.engine.SessionRemote
 
addTo(JSONTarget<?>) - Method in class org.h2.util.json.JSONArray
 
addTo(JSONTarget<?>) - Method in class org.h2.util.json.JSONBoolean
 
addTo(JSONTarget<?>) - Method in class org.h2.util.json.JSONNull
 
addTo(JSONTarget<?>) - Method in class org.h2.util.json.JSONNumber
 
addTo(JSONTarget<?>) - Method in class org.h2.util.json.JSONObject
 
addTo(JSONTarget<?>) - Method in class org.h2.util.json.JSONString
 
addTo(JSONTarget<?>) - Method in class org.h2.util.json.JSONValue
Appends this value to the specified target.
addToCompressLaterCache(int) - Method in class org.h2.store.fs.niomem.FileNioMemData
 
addToFront(CacheObject) - Method in class org.h2.util.CacheLRU
 
addToMap(CacheLongKeyLIRS.Entry<V>) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
 
addToQueue(CacheLongKeyLIRS.Entry<V>, CacheLongKeyLIRS.Entry<V>) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
 
addToStack(CacheLongKeyLIRS.Entry<V>) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
 
addToStackBottom(CacheLongKeyLIRS.Entry<V>) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
 
addToStats(String, int, long) - Method in class org.h2.tools.ConvertTraceFile
 
addToTimeZone(int, long, Value, int, long, long) - Static method in class org.h2.expression.function.DateTimeFunction
 
addTrigger(TriggerObject) - Method in class org.h2.table.Table
Add a trigger to this table.
addType(int, int) - Static method in class org.h2.value.Transfer
 
addUndoLogRecord(int, long, Record<?, ?>) - Method in class org.h2.mvstore.tx.TransactionStore
Add an undo log entry.
addWhen(MergeUsing.When) - Method in class org.h2.command.dml.MergeUsing
Adds WHEN command.
addWindow(String, Window) - Method in class org.h2.command.query.Select
Adds a named window definition.
addWord(String, Integer) - Method in class org.h2.fulltext.FullTextSettings
Register searchable word
addWords(FullTextSettings, Set<String>, Reader) - Static method in class org.h2.fulltext.FullText
Add all words in the given text to the hash set.
addWords(FullTextSettings, Set<String>, String) - Static method in class org.h2.fulltext.FullText
Add all words in the given text to the hash set.
addYearsMonths(int, boolean, long, Value, int, long, long) - Static method in class org.h2.expression.function.DateTimeFunction
 
adjustSize(RootReference<Long, Record<?, ?>>[], RootReference<K, VersionedValue<V>>, BitSet, long, long) - Method in class org.h2.mvstore.tx.TransactionMap
 
admin - Variable in class org.h2.command.ddl.AlterUser
 
admin - Variable in class org.h2.command.ddl.CreateUser
 
admin - Variable in class org.h2.engine.User
 
admin() - Method in class org.h2.server.web.WebApp
 
ADMIN_RIGHTS_REQUIRED - Static variable in class org.h2.api.ErrorCode
The error with code 90040 is thrown when a user that is not administrator tries to execute a statement that requires admin privileges.
adminLogin() - Method in class org.h2.server.web.WebApp
 
adminPassword - Variable in class org.h2.server.web.WebServer
 
adminSave() - Method in class org.h2.server.web.WebApp
 
adminShutdown() - Method in class org.h2.server.web.WebApp
Stop the application and the server.
adminShutdown() - Method in class org.h2.server.web.WebThread
 
adminStartTranslate() - Method in class org.h2.server.web.WebApp
 
AES - Class in org.h2.security
An implementation of the AES block cipher algorithm, also known as Rijndael.
AES() - Constructor for class org.h2.security.AES
 
AF - Static variable in class org.h2.bnf.RuleFixed
 
AFTER_LAST - Static variable in class org.h2.table.TableFilter
 
afterLast - Variable in class org.h2.result.FetchedResult
 
afterLast() - Method in class org.h2.jdbc.JdbcResultSet
Moves the current position to after the last row, that means after the end.
afterLast() - Method in class org.h2.tools.SimpleResultSet
INTERNAL
afterName - Variable in class org.h2.util.json.JSONByteArrayTarget
 
afterName - Variable in class org.h2.util.json.JSONStringTarget
 
afterName - Variable in class org.h2.util.json.JSONValidationTargetWithoutUniqueKeys
 
afterValue() - Method in class org.h2.util.json.JSONByteArrayTarget
 
afterValue() - Method in class org.h2.util.json.JSONStringTarget
 
afterValue(JSONItemType) - Method in class org.h2.util.json.JSONValidationTargetWithoutUniqueKeys
 
afterValue(JSONItemType) - Method in class org.h2.util.json.JSONValidationTargetWithUniqueKeys
 
afterValue(JSONValue) - Method in class org.h2.util.json.JSONValueTarget
 
Aggregate - Class in org.h2.expression.aggregate
Implements the integrated aggregate functions, such as COUNT, MAX, SUM.
Aggregate - Interface in org.h2.api
A user-defined aggregate function needs to implement this interface.
Aggregate(AggregateType, Expression[], Select, boolean) - Constructor for class org.h2.expression.aggregate.Aggregate
Create a new aggregate object.
AGGREGATE - Static variable in class org.h2.engine.DbObject
This object is a user-defined aggregate function.
AGGREGATE_NOT_FOUND_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90132 is thrown when trying to drop a user-defined aggregate function that doesn't exist.
AggregateData - Class in org.h2.expression.aggregate
Abstract class for the computation of an aggregate.
AggregateData() - Constructor for class org.h2.expression.aggregate.AggregateData
 
AggregateDataAvg - Class in org.h2.expression.aggregate
Data stored while calculating an AVG aggregate.
AggregateDataAvg(TypeInfo) - Constructor for class org.h2.expression.aggregate.AggregateDataAvg
 
AggregateDataBinarySet - Class in org.h2.expression.aggregate
Aggregate data of binary set functions.
AggregateDataBinarySet() - Constructor for class org.h2.expression.aggregate.AggregateDataBinarySet
 
AggregateDataCollecting - Class in org.h2.expression.aggregate
Data stored while calculating an aggregate that needs collecting of all values or a distinct aggregate.
AggregateDataCollecting(boolean, boolean, AggregateDataCollecting.NullCollectionMode) - Constructor for class org.h2.expression.aggregate.AggregateDataCollecting
Creates new instance of data for collecting aggregates.
AggregateDataCollecting.NullCollectionMode - Enum in org.h2.expression.aggregate
NULL values collection mode.
AggregateDataCorr - Class in org.h2.expression.aggregate
Data stored while calculating a CORR, REG_SLOPE, REG_INTERCEPT, or REGR_R2 aggregate.
AggregateDataCorr(AggregateType) - Constructor for class org.h2.expression.aggregate.AggregateDataCorr
 
AggregateDataCount - Class in org.h2.expression.aggregate
Data stored while calculating a COUNT aggregate.
AggregateDataCount(boolean) - Constructor for class org.h2.expression.aggregate.AggregateDataCount
 
AggregateDataCovar - Class in org.h2.expression.aggregate
Data stored while calculating a COVAR_POP, COVAR_SAMP, or REGR_SXY aggregate.
AggregateDataCovar(AggregateType) - Constructor for class org.h2.expression.aggregate.AggregateDataCovar
 
AggregateDataDefault - Class in org.h2.expression.aggregate
Data stored while calculating an aggregate.
AggregateDataDefault(AggregateType, TypeInfo) - Constructor for class org.h2.expression.aggregate.AggregateDataDefault
 
AggregateDataDistinctWithCounts - Class in org.h2.expression.aggregate
Data stored while calculating an aggregate that needs distinct values with their counts.
AggregateDataDistinctWithCounts(boolean, int) - Constructor for class org.h2.expression.aggregate.AggregateDataDistinctWithCounts
Creates new instance of data for aggregate that needs distinct values with their counts.
AggregateDataEnvelope - Class in org.h2.expression.aggregate
Data stored while calculating an aggregate.
AggregateDataEnvelope() - Constructor for class org.h2.expression.aggregate.AggregateDataEnvelope
 
AggregateDataStdVar - Class in org.h2.expression.aggregate
Data stored while calculating a STDDEV_POP, STDDEV_SAMP, VAR_SAMP, VAR_POP, REGR_SXX, or REGR_SYY aggregate.
AggregateDataStdVar(AggregateType) - Constructor for class org.h2.expression.aggregate.AggregateDataStdVar
 
aggregateFastPartition(SessionLocal, HashMap<Integer, Value>, ArrayList<Value[]>, int, boolean) - Method in class org.h2.expression.aggregate.AbstractAggregate
 
aggregateFastPartitionInReverse(SessionLocal, HashMap<Integer, Value>, ArrayList<Value[]>, int, boolean) - Method in class org.h2.expression.aggregate.AbstractAggregate
 
aggregateFunction - Variable in class org.h2.schema.UserAggregate.AggregateWrapper
 
AggregateFunction - Interface in org.h2.api
A user-defined aggregate function needs to implement this interface.
AGGREGATES - Static variable in class org.h2.expression.aggregate.Aggregate
 
aggregateType - Variable in class org.h2.expression.aggregate.Aggregate
 
aggregateType - Variable in class org.h2.expression.aggregate.AggregateDataCorr
 
aggregateType - Variable in class org.h2.expression.aggregate.AggregateDataCovar
 
aggregateType - Variable in class org.h2.expression.aggregate.AggregateDataDefault
 
aggregateType - Variable in class org.h2.expression.aggregate.AggregateDataStdVar
 
AggregateType - Enum in org.h2.expression.aggregate
The type of an aggregate function.
AggregateType() - Constructor for enum org.h2.expression.aggregate.AggregateType
 
aggregateWholePartition(SessionLocal, HashMap<Integer, Value>, ArrayList<Value[]>, int) - Method in class org.h2.expression.aggregate.AbstractAggregate
 
AggregateWrapper(AggregateFunction) - Constructor for class org.h2.schema.UserAggregate.AggregateWrapper
 
aggressiveLastModified(String) - Static method in class org.h2.store.FileLock
Aggressively read last modified time, to work-around remote filesystems.
alias - Variable in class org.h2.expression.Alias
 
alias - Variable in class org.h2.result.ResultColumn
The column alias.
alias - Variable in class org.h2.result.SimpleResult.Column
Column alias.
alias - Variable in class org.h2.table.TableFilter
 
Alias - Class in org.h2.expression
A column alias as in SELECT 'Hello' AS NAME ...
Alias(Expression, String, boolean) - Constructor for class org.h2.expression.Alias
 
ALIAS - Static variable in class org.h2.table.RangeTable
The PostgreSQL alias for the range table.
aliasColumnName - Variable in class org.h2.engine.Mode
When enabled, aliased columns (as in SELECT ID AS I FROM TEST) return the alias (I in this case) in ResultSetMetaData.getColumnName() and 'null' in getTableName().
aliasColumnName - Variable in class org.h2.expression.Alias
 
aliases - Variable in class org.h2.bnf.Sentence
 
aliasName - Variable in class org.h2.command.ddl.CreateFunctionAlias
 
aliasName - Variable in class org.h2.command.ddl.DropFunctionAlias
 
ALIGN - Static variable in interface org.h2.security.BlockCipher
Blocks sizes are always multiples of this number.
all - Variable in class org.h2.expression.aggregate.AggregateDataCount
 
all - Variable in class org.h2.expression.condition.ConditionInQuery
 
ALL - Static variable in class org.h2.engine.Right
The right bit mask that means: select, insert, update, delete, and update for this object is allowed.
ALL - Static variable in class org.h2.util.ParserUtil
The token "ALL".
AllColumnsForPlan - Class in org.h2.command.query
This information is expensive to compute for large queries, so do so on-demand.
AllColumnsForPlan(TableFilter[]) - Constructor for class org.h2.command.query.AllColumnsForPlan
 
allColumnsForTableFilters(TableFilter[], AllColumnsForPlan) - Static method in class org.h2.expression.ExpressionVisitor
Get the set of columns of all tables.
allColumnsSet - Variable in class org.h2.command.query.Optimizer
 
allConditions - Variable in class org.h2.table.Plan
 
allFilters - Variable in class org.h2.table.Plan
 
allNumericTypesHavePrecision - Variable in class org.h2.engine.Mode
If true all numeric data types may have precision and 'UNSIGNED' clause.
allocate(int) - Method in class org.h2.mvstore.FreeSpaceBitSet
Allocate a number of blocks and mark them as used.
allocate(int, int, int, boolean) - Method in class org.h2.mvstore.FreeSpaceBitSet
 
allocate(int, long, long) - Method in class org.h2.mvstore.FileStore
Allocate a number of blocks and mark them as used.
allocate(int, long, long) - Method in class org.h2.mvstore.FreeSpaceBitSet
Allocate a number of blocks and mark them as used.
allocateObjectId() - Method in class org.h2.engine.Database
Allocate a new object id.
allow() - Method in class org.h2.server.web.WebThread
 
allow(HttpServletRequest) - Method in class org.h2.server.web.JakartaWebServlet
 
allow(Socket) - Method in class org.h2.server.pg.PgServer
 
allow(Socket) - Method in class org.h2.server.TcpServer
Check if this socket may connect to this server.
allow(HttpServletRequest) - Method in class org.h2.server.web.WebServlet
 
ALLOW_DUPLICATES_WITH_ALL_NULLS - org.h2.engine.Mode.UniqueIndexNullsHandling
Multiple rows with identical values in indexed columns with all indexed NULL values are allowed in unique index.
ALLOW_DUPLICATES_WITH_ANY_NULL - org.h2.engine.Mode.UniqueIndexNullsHandling
Multiple rows with identical values in indexed columns with at least one indexed NULL value are allowed in unique index.
ALLOW_LITERALS - Static variable in class org.h2.command.dml.SetTypes
The type of a SET ALLOW_LITERALS statement.
ALLOW_LITERALS_ALL - Static variable in class org.h2.engine.Constants
Constant meaning both numbers and text is allowed in SQL statements.
ALLOW_LITERALS_NONE - Static variable in class org.h2.engine.Constants
Constant meaning no literals are allowed in SQL statements.
ALLOW_LITERALS_NUMBERS - Static variable in class org.h2.engine.Constants
Constant meaning only numbers are allowed in SQL statements (but no texts).
allowAllClasses - Static variable in class org.h2.util.JdbcUtils
 
allowBuiltinAliasOverride - Variable in class org.h2.engine.Database
 
allowChunked - Variable in class org.h2.server.web.WebServer
 
allowDB2TimestampFormat - Variable in class org.h2.engine.Mode
Whether DB2 TIMESTAMP formats are allowed.
ALLOWED_CLASSES - Static variable in class org.h2.engine.SysProperties
System property h2.allowedClasses (default: *).
allowedClassNamePrefixes - Static variable in class org.h2.util.JdbcUtils
 
allowedClassNames - Static variable in class org.h2.util.JdbcUtils
 
allowedIndexes - Variable in class org.h2.table.IndexHints
 
allowEmptyInPredicate - Variable in class org.h2.engine.Mode
Whether IN predicate may have an empty value list.
allowEmptySchemaValuesAsDefaultSchema - Variable in class org.h2.engine.Mode
If true constructs like 'CREATE TABLE CATALOG..TABLE_NAME' are allowed, the default schema is used.
allowGlobalConditions() - Method in class org.h2.command.query.Query
Check whether adding condition to the query is allowed.
allowGlobalConditions() - Method in class org.h2.command.query.Select
 
allowGlobalConditions() - Method in class org.h2.command.query.SelectUnion
 
allowGlobalConditions() - Method in class org.h2.command.query.TableValueConstructor
 
allowIndex(Index) - Method in class org.h2.table.IndexHints
Allow an index to be used.
allowLiterals - Variable in class org.h2.engine.Database
 
allowLiterals - Variable in class org.h2.engine.SessionLocal
 
allowNonRepeatableRead() - Method in enum org.h2.engine.IsolationLevel
Returns whether a non-repeatable read phenomena is allowed.
allowNonRepeatableRead() - Method in class org.h2.mvstore.tx.Transaction
Whether this transaction has isolation level READ_COMMITTED or below.
allowNonRepeatableRead() - Method in class org.h2.mvstore.tx.TxDecisionMaker
 
allowOthers - Variable in class org.h2.server.pg.PgServer
 
allowOthers - Variable in class org.h2.server.TcpServer
 
allowOthers - Variable in class org.h2.server.web.WebServer
 
allowPlusForStringConcat - Variable in class org.h2.engine.Mode
Text can be concatenated using '+'.
allowRecursive - Variable in class org.h2.table.TableView
 
allowSecureCreation - Variable in class org.h2.server.web.WebServer
 
allowUnrelatedOrderByExpressionsInDistinctQueries - Variable in class org.h2.engine.Mode
If true unrelated ORDER BY expression are allowed in DISTINCT queries, if false they are disallowed.
allowUserRegistration - Variable in class org.h2.security.auth.DefaultAuthenticator
 
allowUserRegistration - Variable in class org.h2.security.auth.H2AuthConfig
 
allowUsingFromClauseInUpdateStatement - Variable in class org.h2.engine.Mode
If true, allow using from clause in update statement.
allProceduresAreCallable() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Checks if all procedures callable.
allTablesAreSelectable() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Checks if it possible to query all tables returned by getTables.
ALTER_ANY_SCHEMA - Static variable in class org.h2.engine.Right
The right bit mask that means: create/alter/drop schema is allowed.
ALTER_DOMAIN_ADD_CONSTRAINT - Static variable in interface org.h2.command.CommandInterface
The type of ALTER DOMAIN ADD CONSTRAINT statement.
ALTER_DOMAIN_DEFAULT - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER DOMAIN SET DEFAULT and ALTER DOMAIN DROP DEFAULT statements.
ALTER_DOMAIN_DROP_CONSTRAINT - Static variable in interface org.h2.command.CommandInterface
The type of ALTER DOMAIN DROP CONSTRAINT statement.
ALTER_DOMAIN_ON_UPDATE - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER DOMAIN SET ON UPDATE and ALTER DOMAIN DROP ON UPDATE statements.
ALTER_DOMAIN_RENAME - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER DOMAIN RENAME statement.
ALTER_DOMAIN_RENAME_CONSTRAINT - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER DOMAIN RENAME CONSTRAINT statement.
ALTER_INDEX_RENAME - Static variable in interface org.h2.command.CommandInterface
The type of a ALTER INDEX RENAME statement.
ALTER_SCHEMA_RENAME - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER SCHEMA RENAME statement.
ALTER_SEQUENCE - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER SEQUENCE statement.
ALTER_TABLE_ADD_COLUMN - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER TABLE ADD statement.
ALTER_TABLE_ADD_CONSTRAINT_CHECK - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER TABLE ADD CHECK statement.
ALTER_TABLE_ADD_CONSTRAINT_PRIMARY_KEY - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER TABLE ADD PRIMARY KEY statement.
ALTER_TABLE_ADD_CONSTRAINT_REFERENTIAL - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER TABLE ADD FOREIGN KEY statement.
ALTER_TABLE_ADD_CONSTRAINT_UNIQUE - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER TABLE ADD UNIQUE statement.
ALTER_TABLE_ALTER_COLUMN_CHANGE_TYPE - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER TABLE ALTER COLUMN statement that changes the column data type.
ALTER_TABLE_ALTER_COLUMN_DEFAULT - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER TABLE ALTER COLUMN SET DEFAULT and ALTER TABLE ALTER COLUMN DROP DEFAULT statements.
ALTER_TABLE_ALTER_COLUMN_DEFAULT_ON_NULL - Static variable in interface org.h2.command.CommandInterface
The type of ALTER TABLE ALTER COLUMN SET DEFAULT ON NULL and ALTER TABLE ALTER COLUMN DROP DEFAULT ON NULL statements.
ALTER_TABLE_ALTER_COLUMN_DROP_EXPRESSION - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER TABLE ALTER COLUMN DROP EXPRESSION statement.
ALTER_TABLE_ALTER_COLUMN_DROP_IDENTITY - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER TABLE ALTER COLUMN DROP IDENTITY statement.
ALTER_TABLE_ALTER_COLUMN_DROP_NOT_NULL - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER TABLE ALTER COLUMN DROP NOT NULL statement.
ALTER_TABLE_ALTER_COLUMN_NOT_NULL - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER TABLE ALTER COLUMN SET NOT NULL statement.
ALTER_TABLE_ALTER_COLUMN_ON_UPDATE - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER TABLE ALTER COLUMN SET ON UPDATE statement.
ALTER_TABLE_ALTER_COLUMN_RENAME - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER TABLE ALTER COLUMN RENAME statement.
ALTER_TABLE_ALTER_COLUMN_SELECTIVITY - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER TABLE ALTER COLUMN SELECTIVITY statement.
ALTER_TABLE_ALTER_COLUMN_VISIBILITY - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER TABLE ALTER COLUMN SET INVISIBLE statement.
ALTER_TABLE_DROP_COLUMN - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER TABLE DROP COLUMN statement.
ALTER_TABLE_DROP_CONSTRAINT - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER TABLE DROP CONSTRAINT statement.
ALTER_TABLE_RENAME - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER TABLE RENAME statement.
ALTER_TABLE_RENAME_CONSTRAINT - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER TABLE RENAME CONSTRAINT statement.
ALTER_TABLE_SET_REFERENTIAL_INTEGRITY - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER TABLE SET REFERENTIAL_INTEGRITY statement.
ALTER_USER_ADMIN - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER USER ADMIN statement.
ALTER_USER_RENAME - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER USER RENAME statement.
ALTER_USER_SET_PASSWORD - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER USER SET PASSWORD statement.
ALTER_VIEW - Static variable in interface org.h2.command.CommandInterface
The type of an ALTER VIEW statement.
AlterDomain - Class in org.h2.command.ddl
The base class for ALTER DOMAIN commands.
AlterDomain(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.AlterDomain
 
AlterDomainAddConstraint - Class in org.h2.command.ddl
This class represents the statement ALTER DOMAIN ADD CONSTRAINT
AlterDomainAddConstraint(SessionLocal, Schema, boolean) - Constructor for class org.h2.command.ddl.AlterDomainAddConstraint
 
AlterDomainDropConstraint - Class in org.h2.command.ddl
This class represents the statement ALTER DOMAIN DROP CONSTRAINT
AlterDomainDropConstraint(SessionLocal, Schema, boolean) - Constructor for class org.h2.command.ddl.AlterDomainDropConstraint
 
AlterDomainExpressions - Class in org.h2.command.ddl
This class represents the statements ALTER DOMAIN SET DEFAULT ALTER DOMAIN DROP DEFAULT ALTER DOMAIN SET ON UPDATE ALTER DOMAIN DROP ON UPDATE
AlterDomainExpressions(SessionLocal, Schema, int) - Constructor for class org.h2.command.ddl.AlterDomainExpressions
 
AlterDomainRename - Class in org.h2.command.ddl
This class represents the statement ALTER DOMAIN RENAME
AlterDomainRename(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.AlterDomainRename
 
AlterDomainRenameConstraint - Class in org.h2.command.ddl
This class represents the statement ALTER DOMAIN RENAME CONSTRAINT
AlterDomainRenameConstraint(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.AlterDomainRenameConstraint
 
AlterIndexRename - Class in org.h2.command.ddl
This class represents the statement ALTER INDEX RENAME
AlterIndexRename(SessionLocal) - Constructor for class org.h2.command.ddl.AlterIndexRename
 
AlterSchemaRename - Class in org.h2.command.ddl
This class represents the statement ALTER SCHEMA RENAME
AlterSchemaRename(SessionLocal) - Constructor for class org.h2.command.ddl.AlterSchemaRename
 
AlterSequence - Class in org.h2.command.ddl
This class represents the statement ALTER SEQUENCE.
AlterSequence(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.AlterSequence
 
AlterTable - Class in org.h2.command.ddl
The base class for ALTER TABLE commands.
AlterTable(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.AlterTable
 
AlterTableAddConstraint - Class in org.h2.command.ddl
This class represents the statement ALTER TABLE ADD CONSTRAINT
AlterTableAddConstraint(SessionLocal, Schema, int, boolean) - Constructor for class org.h2.command.ddl.AlterTableAddConstraint
 
AlterTableAlterColumn - Class in org.h2.command.ddl
This class represents the statements ALTER TABLE ADD, ALTER TABLE ADD IF NOT EXISTS, ALTER TABLE ALTER COLUMN, ALTER TABLE ALTER COLUMN SELECTIVITY, ALTER TABLE ALTER COLUMN SET DEFAULT, ALTER TABLE ALTER COLUMN DROP DEFAULT, ALTER TABLE ALTER COLUMN DROP EXPRESSION, ALTER TABLE ALTER COLUMN SET NULL, ALTER TABLE ALTER COLUMN DROP NULL, ALTER TABLE ALTER COLUMN SET VISIBLE, ALTER TABLE ALTER COLUMN SET INVISIBLE, ALTER TABLE DROP COLUMN
AlterTableAlterColumn(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.AlterTableAlterColumn
 
AlterTableDropConstraint - Class in org.h2.command.ddl
This class represents the statement ALTER TABLE DROP CONSTRAINT
AlterTableDropConstraint(SessionLocal, Schema, boolean) - Constructor for class org.h2.command.ddl.AlterTableDropConstraint
 
alterTableExtensionsMySQL - Variable in class org.h2.engine.Mode
If true some additional non-standard ALTER TABLE commands are allowed.
alterTableModifyColumn - Variable in class org.h2.engine.Mode
If true non-standard ALTER TABLE MODIFY COLUMN is allowed.
AlterTableRename - Class in org.h2.command.ddl
This class represents the statement ALTER TABLE RENAME
AlterTableRename(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.AlterTableRename
 
AlterTableRenameColumn - Class in org.h2.command.ddl
This class represents the statement ALTER TABLE ALTER COLUMN RENAME
AlterTableRenameColumn(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.AlterTableRenameColumn
 
AlterTableRenameConstraint - Class in org.h2.command.ddl
This class represents the statement ALTER TABLE RENAME CONSTRAINT
AlterTableRenameConstraint(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.AlterTableRenameConstraint
 
AlterTableSet - Class in org.h2.command.dml
This class represents the statement ALTER TABLE SET
AlterTableSet(SessionLocal, Schema, int, boolean) - Constructor for class org.h2.command.dml.AlterTableSet
 
AlterUser - Class in org.h2.command.ddl
This class represents the statements ALTER USER ADMIN, ALTER USER RENAME, ALTER USER SET PASSWORD
AlterUser(SessionLocal) - Constructor for class org.h2.command.ddl.AlterUser
 
AlterView - Class in org.h2.command.ddl
This class represents the statement ALTER VIEW
AlterView(SessionLocal) - Constructor for class org.h2.command.ddl.AlterView
 
always - Variable in class org.h2.command.ddl.AlterSequence
 
ALWAYS - org.h2.engine.Mode.CharPadding
CHAR values are always right-padded with spaces.
ALWAYS_FALSE - Static variable in class org.h2.index.IndexCondition
A bit of a search mask meaning 'the condition is always false'.
alwaysClose - Variable in class org.h2.store.FileStoreInputStream
 
alwaysFalse - Variable in class org.h2.index.IndexCursor
 
AM_PM - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
AM_PM - Static variable in class org.h2.expression.function.ToCharFunction
The AM / PM field.
AMBIGUOUS_COLUMN_NAME_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90059 is thrown when a query contains a column that could belong to multiple tables.
Analyze - Class in org.h2.command.ddl
This class represents the statements ANALYZE and ANALYZE TABLE
Analyze(SessionLocal) - Constructor for class org.h2.command.ddl.Analyze
 
ANALYZE - Static variable in interface org.h2.command.CommandInterface
The type of an ANALYZE statement.
Analyze.SelectivityData - Class in org.h2.command.ddl
 
analyzeAuto - Variable in class org.h2.engine.DbSettings
Database setting ANALYZE_AUTO (default: 2000).
analyzeIfRequired(SessionLocal) - Method in class org.h2.mvstore.db.MVTable
 
analyzeSample - Variable in class org.h2.engine.DbSettings
Database setting ANALYZE_SAMPLE (default: 10000).
analyzeTable(SessionLocal, Table, int, boolean) - Static method in class org.h2.command.ddl.Analyze
Analyze this table.
analyzeTables() - Method in class org.h2.engine.SessionLocal
 
AND - Static variable in class org.h2.expression.condition.ConditionAndOr
The AND condition type as in ID=1 AND NAME='Hello'.
AND - Static variable in class org.h2.util.ParserUtil
The token "AND".
andCondition - Variable in class org.h2.command.dml.MergeUsing.When
AND condition of the command.
andOrType - Variable in class org.h2.expression.condition.ConditionAndOr
 
andOrType - Variable in class org.h2.expression.condition.ConditionAndOrN
 
ANY - org.h2.expression.aggregate.AggregateType
The aggregate type for ANY(expression).
ANY - Static variable in class org.h2.expression.condition.CompareLike
 
ANY - Static variable in class org.h2.util.ParserUtil
The token "ANY".
ANY_EXCEPT_2_DOLLAR - Static variable in class org.h2.bnf.RuleFixed
 
ANY_EXCEPT_DOUBLE_QUOTE - Static variable in class org.h2.bnf.RuleFixed
 
ANY_EXCEPT_SINGLE_QUOTE - Static variable in class org.h2.bnf.RuleFixed
 
ANY_UNTIL_END - Static variable in class org.h2.bnf.RuleFixed
 
ANY_UNTIL_EOL - Static variable in class org.h2.bnf.RuleFixed
 
ANY_WORD - Static variable in class org.h2.bnf.RuleFixed
 
append(K, V) - Method in class org.h2.mvstore.MVMap
Appends entry to this map.
append(K, V) - Method in class org.h2.mvstore.tx.TransactionMap
Appends entry to underlying map.
appendChar(char, boolean) - Method in class org.h2.util.json.JSONTextSource
 
appendColumnList(StringBuilder, boolean) - Method in class org.h2.result.UpdatableRow
 
appendCounter - Variable in class org.h2.mvstore.RootReference
Size of the occupied part of the append buffer.
appendDate(StringBuilder, long) - Static method in class org.h2.util.DateTimeUtils
Append a date to the string builder.
appendEndOfQueryToSQL(StringBuilder, int, Expression[]) - Method in class org.h2.command.query.Query
Appends ORDER BY, OFFSET, and FETCH clauses to the plan.
appendFilterCondition(StringBuilder, int) - Method in class org.h2.command.dml.FilteredDataChangeStatement
 
appendHex(StringBuilder, long, int) - Static method in class org.h2.util.StringUtils
Appends specified number of trailing bytes from unsigned long value to a specified string builder.
appendInterval(StringBuilder, IntervalQualifier, boolean, long, long) - Static method in class org.h2.util.IntervalUtils
Formats interval as a string and appends it to a specified string builder.
appendKeyCondition(StringBuilder) - Method in class org.h2.result.UpdatableRow
 
appendMap(StringBuilder, String, int) - Static method in class org.h2.mvstore.DataUtils
Append a key-value pair to the string builder.
appendMap(StringBuilder, String, long) - Static method in class org.h2.mvstore.DataUtils
Append a key-value pair to the string builder.
appendMap(StringBuilder, String, String) - Static method in class org.h2.mvstore.DataUtils
Append a key-value pair to the string builder.
appendMap(StringBuilder, HashMap<String, ?>) - Static method in class org.h2.mvstore.DataUtils
Append a map to the string builder, sorted by key.
appendMapKey(StringBuilder, String) - Static method in class org.h2.mvstore.DataUtils
 
appendNanos(StringBuilder, int) - Static method in class org.h2.util.DateTimeUtils
Append nanoseconds of time, if any.
appendNonSurrogate(char, boolean) - Method in class org.h2.util.json.JSONTextSource
 
appendOrderBy(StringBuilder, ArrayList<QueryOrderBy>, int, boolean) - Static method in class org.h2.expression.analysis.Window
Appends ORDER BY clause to the specified builder.
appendOrderByStart(StringBuilder) - Static method in class org.h2.expression.analysis.Window
 
appendRight(StringBuilder, int, int, String, boolean) - Static method in class org.h2.engine.Right
 
appendTableName(StringBuilder) - Method in class org.h2.result.UpdatableRow
 
appendTailConditions(StringBuilder, int, boolean) - Method in class org.h2.expression.aggregate.AbstractAggregate
 
appendTailConditions(StringBuilder, int, boolean) - Method in class org.h2.expression.analysis.DataAnalysisOperation
Used to create SQL for the OVER and FILTER clauses.
appendTime(StringBuilder, long) - Static method in class org.h2.util.DateTimeUtils
Append a time to the string builder.
appendTimeZone(StringBuilder, int) - Static method in class org.h2.util.DateTimeUtils
Append a time zone to the string builder.
appendTop(StringBuilder, HashMap<String, Integer>, int, int, boolean) - Static method in class org.h2.util.Profiler
 
appendTwoDigits(StringBuilder, int) - Static method in class org.h2.util.StringUtils
Append a zero-padded number from 00 to 99 to a string builder.
appendUpdate(StringBuilder) - Method in class org.h2.constraint.ConstraintReferential
 
appendWhere(StringBuilder) - Method in class org.h2.constraint.ConstraintReferential
 
appendZeroPadded(StringBuilder, int, long) - Static method in class org.h2.util.StringUtils
Append a zero-padded number to a string builder.
apply(String) - Method in enum org.h2.expression.function.ToCharFunction.Capitalization
Applies this capitalization strategy to the specified string.
applyOffsetAndLimit() - Method in class org.h2.result.LocalResult
 
appName - Variable in class org.h2.security.auth.impl.JaasCredentialsValidator
 
areAllValues(ExpressionVisitor) - Method in class org.h2.expression.condition.ConditionIn
 
areComparable(TypeInfo, TypeInfo) - Static method in class org.h2.value.TypeInfo
Determines whether two specified types are comparable.
areEqual(Value, Value) - Method in class org.h2.engine.SessionLocal
Check if two values are equal with the current comparison mode.
areSameTypes(TypeInfo, TypeInfo) - Static method in class org.h2.value.TypeInfo
Determines whether two specified types are the same data types without taking precision or scale into account.
areStableComparable(TypeInfo, TypeInfo) - Static method in class org.h2.value.DataType
Returns whether values of the specified data types have session-independent compare results.
areValuesEqual(DataType<X>, X, X) - Static method in class org.h2.mvstore.MVMap
Check whether the two values are equal.
arg - Variable in class org.h2.expression.function.Function0_1
The argument of the operation.
arg - Variable in class org.h2.expression.Operation1
The argument of the operation.
args - Variable in class org.h2.expression.aggregate.AbstractAggregate
The arguments.
args - Variable in class org.h2.expression.analysis.WindowFunction
 
args - Variable in class org.h2.expression.function.JavaFunction
 
args - Variable in class org.h2.expression.function.table.TableFunction
 
args - Variable in class org.h2.expression.OperationN
The array of arguments.
argsCount - Variable in class org.h2.expression.function.table.TableFunction
 
argsCount - Variable in class org.h2.expression.OperationN
The number of arguments.
argTypes - Variable in class org.h2.expression.aggregate.JavaAggregate
 
array - Variable in class org.h2.expression.function.JsonConstructorFunction
 
array - Variable in class org.h2.util.ByteStack
 
array(H2Type) - Static method in class org.h2.api.H2Type
Returns ARRAY data type with the specified component type.
ARRAY - org.h2.util.json.JSONItemType
JSON array.
ARRAY - Static variable in class org.h2.message.TraceObject
The trace type id for array objects.
ARRAY - Static variable in class org.h2.mvstore.db.ValueDataType
 
ARRAY - Static variable in class org.h2.util.json.JSONStringTarget
A JSON array.
ARRAY - Static variable in class org.h2.util.json.JSONValidationTargetWithoutUniqueKeys
 
ARRAY - Static variable in class org.h2.util.ParserUtil
The token "ARRAY".
ARRAY - Static variable in class org.h2.value.Transfer
 
ARRAY - Static variable in class org.h2.value.Value
The value type for ARRAY values.
ARRAY_AGG - org.h2.expression.aggregate.AggregateType
The aggregate type for ARRAY_AGG(expression).
ARRAY_CONTAINS - Static variable in class org.h2.expression.function.ArrayFunction
ARRAY_CONTAINS() (non-standard).
ARRAY_ELEMENT_ERROR_2 - Static variable in class org.h2.api.ErrorCode
The error with code 22034 is thrown when an attempt is made to read non-existing element of an array.
ARRAY_SLICE - Static variable in class org.h2.expression.function.ArrayFunction
ARRAY_SLICE() (non-standard).
ARRAY_TO_STRING - Static variable in class org.h2.mode.FunctionsPostgreSQL
 
arrayCombine(String[], char) - Static method in class org.h2.util.StringUtils
Combine an array of strings to one array using the given separator character.
ArrayConstructorByQuery - Class in org.h2.expression
Array value constructor by query.
ArrayConstructorByQuery(Query) - Constructor for class org.h2.expression.ArrayConstructorByQuery
Creates new instance of array value constructor by query.
ArrayElementReference - Class in org.h2.expression
Array element reference.
ArrayElementReference(Expression, Expression) - Constructor for class org.h2.expression.ArrayElementReference
 
ArrayFunction - Class in org.h2.expression.function
An array function.
ArrayFunction(Expression, Expression, Expression, int) - Constructor for class org.h2.expression.function.ArrayFunction
 
arraySplit(String, char, boolean) - Static method in class org.h2.util.StringUtils
Split a string into an array of strings using the given separator.
ArrayTableFunction - Class in org.h2.expression.function.table
A table value function.
ArrayTableFunction(int) - Constructor for class org.h2.expression.function.table.ArrayTableFunction
 
arrayToValue(Session, Object) - Static method in class org.h2.value.ValueToObjectConverter
 
AS - Static variable in class org.h2.util.ParserUtil
The token "AS".
AS_IS - org.h2.engine.Mode.ViewExpressionNames
Use both specified and generated names as is.
ASCENDING - Static variable in class org.h2.result.SortOrder
This bit mask means the values should be sorted in ascending order.
ASCII - Static variable in class org.h2.expression.function.StringFunction1
ASCII() (non-standard).
asciiPrintableOnly - Variable in class org.h2.util.json.JSONStringTarget
 
asIdentifier() - Method in class org.h2.command.Token
 
asIdentifier() - Method in class org.h2.command.Token.IdentifierToken
 
asIdentifier() - Method in class org.h2.command.Token.KeywordOrIdentifierToken
 
asIdentifier() - Method in class org.h2.command.Token.KeywordToken
 
asIdentifier() - Method in class org.h2.command.Token.ParameterToken
 
ASIN - Static variable in class org.h2.expression.function.MathFunction1
ASIN().
asInputStream(Object) - Static method in class org.h2.tools.SimpleResultSet
 
asQuery - Variable in class org.h2.command.ddl.CreateTable
 
asReader(Object) - Static method in class org.h2.tools.SimpleResultSet
 
ASSERT - Static variable in class org.h2.engine.Database
 
ASSERT - Static variable in class org.h2.store.FileStore
 
ASSIGN_TO - Static variable in class org.h2.value.Value
Cast a value to the specified type for assignment.
assignParameterIndex(ArrayList<Token>, int) - Static method in class org.h2.command.Tokenizer
 
AssignRealmNameRole - Class in org.h2.security.auth.impl
Assign to user a role based on realm name *
AssignRealmNameRole() - Constructor for class org.h2.security.auth.impl.AssignRealmNameRole
 
AssignRealmNameRole(String) - Constructor for class org.h2.security.auth.impl.AssignRealmNameRole
 
asString() - Method in class org.h2.mvstore.Chunk
Get the chunk data as a string.
asString(Object, int) - Static method in class org.h2.fulltext.FullText
INTERNAL.
asString(String) - Method in class org.h2.mvstore.MVMap
Get the map metadata as a string.
asString(String) - Method in class org.h2.mvstore.tx.TransactionStore.TxMapBuilder.TMVMap
 
ASTERISK - Static variable in class org.h2.command.Token
The token "*".
ASYMMETRIC - Static variable in class org.h2.util.ParserUtil
The token "ASYMMETRIC".
AT - Static variable in class org.h2.command.Token
The token "@".
ATAN - Static variable in class org.h2.expression.function.MathFunction1
ATAN().
ATAN2 - Static variable in class org.h2.expression.function.MathFunction2
ATAN2() (non-standard).
ATTR_BLOCK - Static variable in class org.h2.mvstore.Chunk
 
ATTR_CHUNK - Static variable in class org.h2.mvstore.Chunk
 
ATTR_FLETCHER - Static variable in class org.h2.mvstore.Chunk
 
ATTR_LEN - Static variable in class org.h2.mvstore.Chunk
 
ATTR_LIVE_MAX - Static variable in class org.h2.mvstore.Chunk
 
ATTR_LIVE_PAGES - Static variable in class org.h2.mvstore.Chunk
 
ATTR_MAP - Static variable in class org.h2.mvstore.Chunk
 
ATTR_MAX - Static variable in class org.h2.mvstore.Chunk
 
ATTR_NEXT - Static variable in class org.h2.mvstore.Chunk
 
ATTR_OCCUPANCY - Static variable in class org.h2.mvstore.Chunk
 
ATTR_PAGES - Static variable in class org.h2.mvstore.Chunk
 
ATTR_PIN_COUNT - Static variable in class org.h2.mvstore.Chunk
 
ATTR_ROOT - Static variable in class org.h2.mvstore.Chunk
 
ATTR_TIME - Static variable in class org.h2.mvstore.Chunk
 
ATTR_TOC - Static variable in class org.h2.mvstore.Chunk
 
ATTR_UNUSED - Static variable in class org.h2.mvstore.Chunk
 
ATTR_UNUSED_AT_VERSION - Static variable in class org.h2.mvstore.Chunk
 
ATTR_VERSION - Static variable in class org.h2.mvstore.Chunk
 
attributes - Variable in class org.h2.server.web.WebApp
The session attributes
AUTH_CONFIG_FILE - Static variable in class org.h2.engine.SysProperties
System property h2.authConfigFile (default: null).
AuthConfigException - Exception in org.h2.security.auth
Exception thrown when an issue occurs during the authentication configuration
AuthConfigException() - Constructor for exception org.h2.security.auth.AuthConfigException
 
AuthConfigException(String) - Constructor for exception org.h2.security.auth.AuthConfigException
 
AuthConfigException(String, Throwable) - Constructor for exception org.h2.security.auth.AuthConfigException
 
AuthConfigException(Throwable) - Constructor for exception org.h2.security.auth.AuthConfigException
 
authenticate(AuthenticationInfo, Database) - Method in interface org.h2.security.auth.Authenticator
Perform user authentication.
authenticate(AuthenticationInfo, Database) - Method in class org.h2.security.auth.DefaultAuthenticator
 
AuthenticationException - Exception in org.h2.security.auth
Exception thrown in case of errors during authentication
AuthenticationException() - Constructor for exception org.h2.security.auth.AuthenticationException
 
AuthenticationException(String) - Constructor for exception org.h2.security.auth.AuthenticationException
 
AuthenticationException(String, Throwable) - Constructor for exception org.h2.security.auth.AuthenticationException
 
AuthenticationException(Throwable) - Constructor for exception org.h2.security.auth.AuthenticationException
 
authenticationInfo - Variable in class org.h2.security.auth.impl.JaasCredentialsValidator.AuthenticationInfoCallbackHandler
 
AuthenticationInfo - Class in org.h2.security.auth
Input data for authenticators; it wraps ConnectionInfo
AuthenticationInfo(ConnectionInfo) - Constructor for class org.h2.security.auth.AuthenticationInfo
 
AuthenticationInfoCallbackHandler(AuthenticationInfo) - Constructor for class org.h2.security.auth.impl.JaasCredentialsValidator.AuthenticationInfoCallbackHandler
 
authenticator - Variable in class org.h2.engine.Database
 
Authenticator - Interface in org.h2.security.auth
Low level interface to implement full authentication process.
AUTHENTICATOR - Static variable in class org.h2.command.dml.SetTypes
The type of a SET AUTHENTICATOR statement.
AUTHENTICATOR_NOT_AVAILABLE - Static variable in class org.h2.api.ErrorCode
The error with code 90144 is thrown when user trying to login into a database with AUTHREALM set and the target database doesn't have an authenticator defined
AuthenticatorFactory - Class in org.h2.security.auth
Authenticator factory
AuthenticatorFactory() - Constructor for class org.h2.security.auth.AuthenticatorFactory
 
authorization - Variable in class org.h2.command.ddl.CreateSchema
 
AUTHORIZATION - Static variable in class org.h2.util.ParserUtil
The token "AUTHORIZATION".
AUTO - Static variable in class org.h2.engine.GeneratedKeysMode
Generated keys should be configured automatically.
AUTO_PARENTHESES - Static variable in class org.h2.expression.Expression
Wrap expression in parentheses only if it can't be safely included into other expressions without them.
autoClose - Variable in class org.h2.tools.SimpleResultSet
 
autocommit - Variable in class org.h2.command.ddl.CreateLinkedTable
 
autocommit - Variable in class org.h2.table.TableLink
 
autocommit - Variable in class org.h2.table.TableLinkConnection
 
autoCommit - Variable in class org.h2.engine.SessionLocal
 
autoCommit - Variable in class org.h2.engine.SessionRemote
 
AUTOCOMMIT - Static variable in class org.h2.expression.function.SysInfoFunction
AUTOCOMMIT().
autoCommitAtTransactionEnd - Variable in class org.h2.engine.SessionLocal
 
autoCommitBufferSize(int) - Method in class org.h2.mvstore.MVStore.Builder
Set the size of the write buffer, in KB disk space (for file-based stores).
autoCommitDelay - Variable in class org.h2.mvstore.MVStore
The delay in milliseconds to automatically commit and write changes.
autoCommitDisabled() - Method in class org.h2.mvstore.MVStore.Builder
Disable auto-commit, by setting the auto-commit delay and auto-commit buffer size to 0.
autoCommitFailureClosesAllResultSets() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether an exception while auto commit is on closes all result sets.
autoCommitIfCluster() - Method in class org.h2.engine.SessionRemote
Calls COMMIT if the session is in cluster mode.
autoCommitMemory - Variable in class org.h2.mvstore.MVStore
 
autoCompactFillRate - Variable in class org.h2.engine.DbSettings
Database setting AUTO_COMPACT_FILL_RATE (default: 90, which means 90%, 0 disables auto-compacting).
autoCompactFillRate - Variable in class org.h2.mvstore.MVStore
 
autoCompactFillRate(int) - Method in class org.h2.mvstore.MVStore.Builder
Set the auto-compact target fill rate.
autoCompactLastFileOpCount - Variable in class org.h2.mvstore.MVStore
 
autoComplete(Sentence) - Method in class org.h2.bnf.context.DbContextRule
 
autoComplete(Sentence) - Method in interface org.h2.bnf.Rule
Add the next possible token(s).
autoComplete(Sentence) - Method in class org.h2.bnf.RuleElement
 
autoComplete(Sentence) - Method in class org.h2.bnf.RuleExtension
 
autoComplete(Sentence) - Method in class org.h2.bnf.RuleFixed
 
autoComplete(Sentence) - Method in class org.h2.bnf.RuleList
 
autoComplete(Sentence) - Method in class org.h2.bnf.RuleOptional
 
autoComplete(Sentence) - Method in class org.h2.bnf.RuleRepeat
 
autoCompleteList() - Method in class org.h2.server.web.WebApp
 
autoCompleteProcedure(Sentence) - Method in class org.h2.bnf.context.DbContextRule
 
autoCompleteTableAlias(Sentence, boolean) - Static method in class org.h2.bnf.context.DbContextRule
 
autoDelete() - Method in class org.h2.store.FileStore
Automatically delete the file once it is no longer in use.
autoDeleteReference - Variable in class org.h2.store.FileStore
 
AutoDetectDataType(int) - Constructor for class org.h2.mvstore.type.ObjectDataType.AutoDetectDataType
 
AutoDetectDataType(ObjectDataType, int) - Constructor for class org.h2.mvstore.type.ObjectDataType.AutoDetectDataType
 
autoIncrementClause - Variable in class org.h2.engine.Mode
Whether MySQL-style AUTO_INCREMENT clause is supported.
autoReconnect - Variable in class org.h2.engine.SessionRemote
 
autoReconnect(int) - Method in class org.h2.engine.SessionRemote
Automatically re-connect if necessary and if configured to do so.
autoServerMode - Variable in class org.h2.engine.Database
 
autoServerPort - Variable in class org.h2.engine.Database
 
available() - Method in class org.h2.store.FileStoreInputStream
 
available() - Method in class org.h2.store.RangeInputStream
 
averageSize - Variable in class org.h2.mvstore.type.ObjectDataType.SerializedObjectType
 
AVG - org.h2.expression.aggregate.AggregateType
The aggregate type for AVG(expression).
avgKeySize - Variable in class org.h2.mvstore.MVMap
 
avgValSize - Variable in class org.h2.mvstore.MVMap
 
AZ_UNDERSCORE - Static variable in class org.h2.bnf.RuleFixed
 

B

b - Variable in class org.h2.expression.condition.BetweenPredicate
 
backgroundException - Variable in class org.h2.engine.Database
 
backgroundExceptionHandler - Variable in class org.h2.mvstore.MVStore
 
backgroundExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.h2.mvstore.MVStore.Builder
Set the listener to be used for exceptions that occur when writing in the background thread.
backgroundWriterThread - Variable in class org.h2.mvstore.MVStore
Reference to a background thread, which is expected to be running, if any.
BackgroundWriterThread(MVStore, int, String) - Constructor for class org.h2.mvstore.MVStore.BackgroundWriterThread
 
BACKSLASH - Static variable in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
Backup - Class in org.h2.tools
Creates a backup of a database.
Backup() - Constructor for class org.h2.tools.Backup
 
BACKUP - Static variable in interface org.h2.command.CommandInterface
The type of a BACKUP statement.
BackupCommand - Class in org.h2.command.dml
This class represents the statement BACKUP
BackupCommand(SessionLocal) - Constructor for class org.h2.command.dml.BackupCommand
 
backupFile(ZipOutputStream, String, String, InputStream) - Static method in class org.h2.command.dml.BackupCommand
 
backupTo(String) - Method in class org.h2.command.dml.BackupCommand
 
baos - Variable in class org.h2.util.json.JSONByteArrayTarget
 
base - Variable in class org.h2.mvstore.cache.FilePathCache.FileCache
 
base - Variable in class org.h2.mvstore.type.ObjectDataType.AutoDetectDataType
 
base - Variable in class org.h2.store.fs.encrypt.FileEncrypt
 
base - Variable in class org.h2.store.fs.FilePathWrapper
 
base - Variable in class org.h2.store.fs.retry.FileRetryOnInterrupt.FileLockRetry
The base lock.
baseCache - Variable in class org.h2.util.CacheSecondLevel
 
baseDir - Variable in class org.h2.server.pg.PgServer
 
baseDir - Variable in class org.h2.server.TcpServer
 
baseValue - Variable in class org.h2.schema.Sequence
 
BasicBuilder() - Constructor for class org.h2.mvstore.MVMap.BasicBuilder
Create a new builder with the default key and value data types.
BasicDataType<T> - Class in org.h2.mvstore.type
The base class for data type implementations.
BasicDataType() - Constructor for class org.h2.mvstore.type.BasicDataType
 
batchCommands - Variable in class org.h2.jdbc.JdbcStatement
 
batchIdentities - Variable in class org.h2.jdbc.JdbcPreparedStatement
 
batchParameters - Variable in class org.h2.jdbc.JdbcPreparedStatement
 
bc - Variable in class org.h2.mode.ToDateParser
 
BC_AD - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
BD_NANOS_PER_SECOND - Static variable in class org.h2.expression.function.DateTimeFunction
 
BD_SECONDS_PER_DAY - Static variable in class org.h2.expression.function.DateTimeFunction
 
before - Variable in class org.h2.command.ddl.CreateTrigger
 
before - Variable in class org.h2.schema.TriggerObject
 
before - Variable in class org.h2.tools.TriggerAdapter
Whether the fire method is called before or after the operation is performed.
BEFORE_FIRST - Static variable in class org.h2.table.TableFilter
 
beforeCommitOrRollback() - Method in class org.h2.engine.SessionLocal
 
beforeFirst - Variable in class org.h2.index.RangeCursor
 
beforeFirst() - Method in class org.h2.jdbc.JdbcResultSet
Moves the current position to before the first row, that means resets the result set.
beforeFirst() - Method in class org.h2.tools.SimpleResultSet
Moves the current position to before the first row, that means the result set is reset.
beforeValue() - Method in class org.h2.util.json.JSONByteArrayTarget
 
beforeValue() - Method in class org.h2.util.json.JSONStringTarget
 
beforeValue() - Method in class org.h2.util.json.JSONValidationTargetWithoutUniqueKeys
 
beforeValue() - Method in class org.h2.util.json.JSONValidationTargetWithUniqueKeys
 
beforeValue() - Method in class org.h2.util.json.JSONValueTarget
 
beforeWrite() - Method in class org.h2.mvstore.MVMap
This method is called before writing to the map.
beforeWrite(MVMap<?, ?>) - Method in class org.h2.mvstore.MVStore
This method is called before writing to a map.
begin() - Method in class org.h2.engine.SessionLocal
Begin a transaction.
begin() - Method in class org.h2.mvstore.tx.TransactionStore
Begin a new transaction.
begin(Object) - Static method in class org.h2.util.AbbaDetector
This method is called just before or just after an object is synchronized.
begin(TransactionStore.RollbackListener, int, int, IsolationLevel) - Method in class org.h2.mvstore.tx.TransactionStore
Begin a new transaction.
BEGIN - Static variable in interface org.h2.command.CommandInterface
The type of a BEGIN {WORK|TRANSACTION} statement.
belongsToConstraint - Variable in class org.h2.index.IndexType
 
belongsToTable - Variable in class org.h2.command.ddl.CreateSequence
 
belongsToTable - Variable in class org.h2.schema.Sequence
 
BEST_ROW_NOT_PSEUDO - Static variable in class org.h2.jdbc.meta.DatabaseMetaLocal
 
BEST_ROW_SESSION - Static variable in class org.h2.jdbc.meta.DatabaseMetaLocal
 
bestPlan - Variable in class org.h2.command.query.Optimizer
 
BETWEEN - Static variable in class org.h2.util.ParserUtil
The token "BETWEEN".
BetweenPredicate - Class in org.h2.expression.condition
BETWEEN predicate.
BetweenPredicate(Expression, boolean, boolean, boolean, Expression, Expression) - Constructor for class org.h2.expression.condition.BetweenPredicate
 
BI_SECONDS_PER_DAY - Static variable in class org.h2.expression.function.DateTimeFunction
 
BigDecimalType() - Constructor for class org.h2.mvstore.type.ObjectDataType.BigDecimalType
 
bigEndian - Variable in class org.h2.util.geometry.EWKBUtils.EWKBSource
Whether current byte order is big-endian.
BIGGER - Static variable in class org.h2.command.Token
The token ">".
BIGGER - Static variable in class org.h2.expression.condition.Comparison
The comparison type meaning > as in ID>1.
BIGGER_EQUAL - Static variable in class org.h2.command.Token
The token ">=".
BIGGER_EQUAL - Static variable in class org.h2.expression.condition.Comparison
The comparison type meaning >= as in ID>=1.
BIGINT - Static variable in class org.h2.api.H2Type
The BIGINT data type.
BIGINT - Static variable in class org.h2.mvstore.db.ValueDataType
 
BIGINT - Static variable in class org.h2.value.Transfer
 
BIGINT - Static variable in class org.h2.value.Value
The value type for BIGINT values.
BIGINT_0_7 - Static variable in class org.h2.mvstore.db.ValueDataType
 
BIGINT_NEG - Static variable in class org.h2.mvstore.db.ValueDataType
 
BigIntegerType() - Constructor for class org.h2.mvstore.type.ObjectDataType.BigIntegerType
 
BigintToken(int, long) - Constructor for class org.h2.command.Token.BigintToken
 
biIterator(ArrayList<Value[]>, int, int, int, int, boolean) - Static method in class org.h2.expression.analysis.WindowFrame
 
BiItr(ArrayList<Value[]>, int, int, int, int) - Constructor for class org.h2.expression.analysis.WindowFrame.BiItr
 
BINARY - Static variable in class org.h2.api.H2Type
The BINARY data type.
BINARY - Static variable in class org.h2.mvstore.db.ValueDataType
 
BINARY - Static variable in class org.h2.value.Transfer
 
BINARY - Static variable in class org.h2.value.Value
The value type for BINARY values.
BinaryOperation - Class in org.h2.expression
A mathematical expression, or string concatenation.
BinaryOperation(BinaryOperation.OpType, Expression, Expression) - Constructor for class org.h2.expression.BinaryOperation
 
BinaryOperation.OpType - Enum in org.h2.expression
 
binarySearch(long, Long[], int, int, int) - Static method in class org.h2.mvstore.type.LongDataType
 
binarySearch(Long, Object, int, int) - Method in class org.h2.mvstore.type.LongDataType
 
binarySearch(String, Object, int, int) - Method in class org.h2.mvstore.type.StringDataType
 
binarySearch(K) - Method in class org.h2.mvstore.Page
Search the key in this page using a binary search.
binarySearch(SearchRow, Object, int, int) - Method in class org.h2.mvstore.db.RowDataType
 
binarySearch(SearchRow, SearchRow[], int, int) - Method in class org.h2.mvstore.db.RowDataType
 
binarySearch(Value, Object, int, int) - Method in class org.h2.mvstore.db.NullValueDataType
 
binarySearch(T, Object, int, int) - Method in class org.h2.mvstore.type.BasicDataType
 
binarySearch(T, Object, int, int) - Method in interface org.h2.mvstore.type.DataType
Perform binary search for the key within the storage
BinaryStringToken(int, byte[]) - Constructor for class org.h2.command.Token.BinaryStringToken
 
BIND_ADDRESS - Static variable in class org.h2.engine.SysProperties
System property h2.bindAddress (default: null).
bindDnPattern - Variable in class org.h2.security.auth.impl.LdapCredentialsValidator
 
BiReverseItr(ArrayList<Value[]>, int, int, int, int) - Constructor for class org.h2.expression.analysis.WindowFrame.BiReverseItr
 
BIT_AND_AGG - org.h2.expression.aggregate.AggregateType
The aggregate type for BIT_AND_AGG(expression).
BIT_LENGTH - Static variable in class org.h2.expression.function.LengthFunction
BIT_LENGTH() (non-standard).
BIT_NAND_AGG - org.h2.expression.aggregate.AggregateType
The aggregate type for BIT_NAND_AGG(expression).
BIT_NOR_AGG - org.h2.expression.aggregate.AggregateType
The aggregate type for BIT_NOR_AGG(expression).
BIT_OR_AGG - org.h2.expression.aggregate.AggregateType
The aggregate type for BIT_OR_AGG(expression).
BIT_XNOR_AGG - org.h2.expression.aggregate.AggregateType
The aggregate type for BIT_XNOR_AGG(expression).
BIT_XOR_AGG - org.h2.expression.aggregate.AggregateType
The aggregate type for BIT_XOR_AGG(expression).
BITAND - Static variable in class org.h2.expression.function.BitFunction
BITAND() (non-standard).
bitCount(Value) - Static method in class org.h2.expression.function.BitFunction
 
BITCOUNT - Static variable in class org.h2.expression.function.BitFunction
BITCOUNT() (non-standard).
BitFunction - Class in org.h2.expression.function
A bitwise function.
BitFunction(Expression, Expression, int) - Constructor for class org.h2.expression.function.BitFunction
 
bitGet(Value, Value) - Static method in class org.h2.expression.function.BitFunction
 
BITGET - Static variable in class org.h2.expression.function.BitFunction
BITGET() (non-standard).
BITNAND - Static variable in class org.h2.expression.function.BitFunction
BITNAND() (non-standard).
BITNOR - Static variable in class org.h2.expression.function.BitFunction
BITNOR() (non-standard).
BITNOT - Static variable in class org.h2.expression.function.BitFunction
BITNOT() (non-standard).
BITOR - Static variable in class org.h2.expression.function.BitFunction
BITOR() (non-standard).
Bits - Class in org.h2.util
Manipulations with bytes and arrays.
Bits() - Constructor for class org.h2.util.Bits
 
BITXNOR - Static variable in class org.h2.expression.function.BitFunction
BITXNOR() (non-standard).
BITXOR - Static variable in class org.h2.expression.function.BitFunction
BITXOR() (non-standard).
BLOB - Static variable in class org.h2.api.H2Type
The BINARY LARGE OBJECT data type.
BLOB - Static variable in class org.h2.message.TraceObject
The trace type id for blobs.
BLOB - Static variable in class org.h2.mvstore.db.ValueDataType
 
BLOB - Static variable in class org.h2.value.Transfer
 
BLOB - Static variable in class org.h2.value.Value
The value type for BINARY LARGE OBJECT values.
BLOB_SEARCH - Static variable in class org.h2.engine.Constants
Whether searching in Blob values should be supported.
BlobMeta(byte[], int, long, long) - Constructor for class org.h2.mvstore.db.LobStorageMap.BlobMeta
 
BlobReference(byte[], long) - Constructor for class org.h2.mvstore.db.LobStorageMap.BlobReference
 
block - Variable in class org.h2.mvstore.Chunk
The start block number within the file.
BLOCK_COMPARISON_SIZE - Static variable in class org.h2.value.ValueLob
 
BLOCK_SIZE - Static variable in class org.h2.mvstore.MVStore
The block size (physical sector size) of the disk.
BLOCK_SIZE - Static variable in class org.h2.store.fs.encrypt.FileEncrypt
The block size.
BLOCK_SIZE - Static variable in class org.h2.store.fs.mem.FileMemData
 
BLOCK_SIZE - Static variable in class org.h2.store.fs.niomem.FileNioMemData
 
BLOCK_SIZE_MASK - Static variable in class org.h2.store.fs.encrypt.FileEncrypt
The block size bit mask.
BLOCK_SIZE_MASK - Static variable in class org.h2.store.fs.mem.FileMemData
 
BLOCK_SIZE_MASK - Static variable in class org.h2.store.fs.niomem.FileNioMemData
 
BLOCK_SIZE_SHIFT - Static variable in class org.h2.store.fs.mem.FileMemData
 
BLOCK_SIZE_SHIFT - Static variable in class org.h2.store.fs.niomem.FileNioMemData
 
BlockCipher - Interface in org.h2.security
A block cipher is a data encryption algorithm that operates on blocks.
BLOCKED - org.h2.engine.SessionLocal.State
 
blockingKey - Variable in class org.h2.mvstore.tx.Transaction
Key in blockingMap on which this transaction is blocked.
blockingMapName - Variable in class org.h2.mvstore.tx.Transaction
Map on which this transaction is blocked.
blockingTransaction - Variable in class org.h2.mvstore.tx.Transaction
Blocking transaction, if any
blockingTransaction - Variable in class org.h2.mvstore.tx.TxDecisionMaker
 
blockRemark - Variable in class org.h2.util.ScriptReader
Only valid if insideRemark is true.
blockSize - Variable in class org.h2.mvstore.FreeSpaceBitSet
The block size in bytes.
bmaxxd - Variable in class org.h2.mvstore.db.MVSpatialIndex.FindBoundsCursor
 
bmaxxf - Variable in class org.h2.mvstore.db.MVSpatialIndex.FindBoundsCursor
 
bmaxyd - Variable in class org.h2.mvstore.db.MVSpatialIndex.FindBoundsCursor
 
bmaxyf - Variable in class org.h2.mvstore.db.MVSpatialIndex.FindBoundsCursor
 
bminxd - Variable in class org.h2.mvstore.db.MVSpatialIndex.FindBoundsCursor
 
bminxf - Variable in class org.h2.mvstore.db.MVSpatialIndex.FindBoundsCursor
 
bminyd - Variable in class org.h2.mvstore.db.MVSpatialIndex.FindBoundsCursor
 
bminyf - Variable in class org.h2.mvstore.db.MVSpatialIndex.FindBoundsCursor
 
bnf - Variable in class org.h2.server.web.WebSession
 
Bnf - Class in org.h2.bnf
This class can read a file that is similar to BNF (Backus-Naur form).
Bnf() - Constructor for class org.h2.bnf.Bnf
 
BnfVisitor - Interface in org.h2.bnf
The visitor interface for BNF rules.
BOOLEAN - Static variable in class org.h2.api.H2Type
The BOOLEAN data type
BOOLEAN - Static variable in class org.h2.value.Transfer
 
BOOLEAN - Static variable in class org.h2.value.Value
The value type for BOOLEAN values.
BOOLEAN_FALSE - Static variable in class org.h2.mvstore.db.ValueDataType
 
BOOLEAN_TRUE - Static variable in class org.h2.mvstore.db.ValueDataType
 
booleanFlag - Variable in class org.h2.command.ddl.AlterTableAlterColumn
 
BooleanTest - Class in org.h2.expression.condition
Boolean test (IS [NOT] { TRUE | FALSE | UNKNOWN }).
BooleanTest(Expression, boolean, boolean, Boolean) - Constructor for class org.h2.expression.condition.BooleanTest
 
BooleanType() - Constructor for class org.h2.mvstore.type.ObjectDataType.BooleanType
 
bounds - Variable in class org.h2.command.ddl.SequenceOptions
 
BOX_VERTICAL - Static variable in class org.h2.tools.Shell
 
branchQualifier - Variable in class org.h2.jdbcx.JdbcXid
 
buf - Variable in class org.h2.security.SHA3
 
buf - Variable in class org.h2.util.geometry.EWKBUtils.EWKBTarget
 
bufcnt - Variable in class org.h2.security.SHA3
 
buff - Variable in class org.h2.mvstore.WriteBuffer
The current buffer (may be replaced if it is too small).
buffer - Variable in class org.h2.command.dml.ScriptCommand
 
buffer - Variable in class org.h2.compress.LZFInputStream
 
buffer - Variable in class org.h2.compress.LZFOutputStream
 
buffer - Variable in class org.h2.mvstore.StreamStore.Stream
 
buffer - Variable in class org.h2.security.SecureFileStore
 
buffer - Variable in class org.h2.store.FileStoreOutputStream
 
buffer - Variable in class org.h2.store.fs.FileChannelInputStream
 
buffer - Variable in class org.h2.tools.CompressTool
 
buffer - Variable in class org.h2.util.ScriptReader
 
BUFFER - Static variable in class org.h2.store.fs.mem.FileMemData
 
BUFFER_SIZE - Static variable in class org.h2.value.Transfer
 
bufferEnd - Variable in class org.h2.util.ScriptReader
The position in the buffer of the last available char
bufferForInitVector - Variable in class org.h2.security.SecureFileStore
 
bufferLength - Variable in class org.h2.compress.LZFInputStream
 
bufferPos - Variable in class org.h2.util.ScriptReader
The position in the buffer of the next char to be read
buffers - Variable in class org.h2.store.fs.niomem.FileNioMemData
 
bufferSaveExecutor - Variable in class org.h2.mvstore.MVStore
Single-threaded executor for saving ByteBuffer as a new Chunk
bufferStart - Variable in class org.h2.util.ScriptReader
The position in the buffer of the statement start
BUILD_DATE - Static variable in class org.h2.engine.Constants
The build date is updated for each public release.
BUILD_ID - Static variable in class org.h2.engine.Constants
Sequential version number.
BUILD_SNAPSHOT - Static variable in class org.h2.engine.Constants
Whether this is a snapshot version.
BUILD_VENDOR_AND_VERSION - Static variable in class org.h2.engine.Constants
If H2 is compiled to be included in a product, this should be set to a unique vendor id (to distinguish from official releases).
buildDeleteSQL() - Method in class org.h2.constraint.ConstraintReferential
 
builder - Variable in class org.h2.util.json.JSONStringTarget
 
builder - Variable in class org.h2.util.json.JSONTextSource
 
Builder() - Constructor for class org.h2.mvstore.MVMap.Builder
 
Builder() - Constructor for class org.h2.mvstore.MVStore.Builder
Creates new instance of MVStore.Builder.
Builder() - Constructor for class org.h2.mvstore.rtree.MVRTreeMap.Builder
Create a new builder for maps with 2 dimensions.
Builder(HashMap<String, Object>) - Constructor for class org.h2.mvstore.MVStore.Builder
 
buildMessageForException(JdbcException) - Static method in exception org.h2.message.DbException
Builds message for an exception.
buildTableFilter(Table, String, ArrayList<String>, IndexHints) - Method in class org.h2.command.Parser
 
buildUpdateSQL() - Method in class org.h2.constraint.ConstraintReferential
 
buildUser(AuthenticationInfo, Database, boolean) - Static method in class org.h2.engine.UserBuilder
Build the database user starting from authentication informations.
BUILTIN_ALIAS_OVERRIDE - Static variable in class org.h2.command.dml.SetTypes
The type of SET BUILTIN_ALIAS_OVERRIDE statement.
BuiltinFunctions - Class in org.h2.expression.function
Maintains the list of built-in functions.
BuiltinFunctions() - Constructor for class org.h2.expression.function.BuiltinFunctions
 
BY_NAME_COMPARATOR - Static variable in class org.h2.command.dml.ScriptCommand
 
ByteArrayDataType - Class in org.h2.mvstore.type
Class ByteArrayDataType.
ByteArrayDataType() - Constructor for class org.h2.mvstore.type.ByteArrayDataType
 
byteArrayOutputStreamToString(ByteArrayOutputStream, Charset) - Static method in class org.h2.util.Utils10
Converts the buffer's contents into a string by decoding the bytes using the specified charset.
byteBuffer - Variable in class org.h2.store.CountingReaderInputStream
 
byteCount - Variable in class org.h2.mvstore.db.LobStorageMap.BlobMeta
 
bytes - Variable in class org.h2.util.json.JSONBytesSource
 
bytes - Variable in class org.h2.value.CharsetCollator.CharsetCollationKey
 
ByteStack - Class in org.h2.util
The stack of byte values.
ByteStack() - Constructor for class org.h2.util.ByteStack
Creates a new empty instance.
ByteType() - Constructor for class org.h2.mvstore.type.ObjectDataType.ByteType
 

C

C_NUMBER - org.h2.engine.Mode.ExpressionNames
Use ordinal number of a column with C prefix.
cache - Variable in class org.h2.fulltext.FullTextSettings
The prepared statement cache.
cache - Variable in class org.h2.mvstore.cache.FilePathCache.FileCache
 
cache - Variable in class org.h2.mvstore.MVStore
The page cache.
cache - Variable in class org.h2.mvstore.type.MetaType
 
cache - Variable in class org.h2.server.TcpServerThread
 
cache - Variable in class org.h2.server.web.WebApp
Whether the response can be cached.
cache - Variable in class org.h2.util.SmallMap
 
cache(String) - Static method in class org.h2.util.StringUtils
Get the string from the cache if possible.
cache(Value) - Static method in class org.h2.value.Value
Check if a value is in the cache that is equal to this value.
Cache - Interface in org.h2.util
The cache keeps frequently used objects in the main memory.
Cache(int) - Constructor for class org.h2.store.fs.mem.FileMemData.Cache
 
CACHE - Static variable in class org.h2.expression.function.DateTimeFormatFunction
 
CACHE - Static variable in class org.h2.util.TimeZoneProvider
A small cache for timezone providers.
CACHE_BLOCK_SIZE - Static variable in class org.h2.mvstore.cache.FilePathCache.FileCache
 
CACHE_MILLIS - Static variable in class org.h2.util.NetUtils
 
CACHE_MIN_RECORDS - Static variable in class org.h2.engine.Constants
The minimum number of entries to keep in the cache.
CACHE_MIN_SIZE - Static variable in class org.h2.store.fs.niomem.FileNioMemData
 
CACHE_SIZE - Static variable in class org.h2.command.dml.SetTypes
The type of a SET CACHE_SIZE statement.
CACHE_SIZE - Static variable in class org.h2.store.fs.mem.FileMemData
 
CACHE_SIZE - Static variable in class org.h2.util.TimeZoneProvider
The number of cache elements (needs to be a power of 2).
CACHE_TYPE_DEFAULT - Static variable in class org.h2.engine.Constants
The default cache type.
cacheableChecked - Variable in class org.h2.command.query.Query
 
cacheChained - Variable in class org.h2.util.CacheObject
The next element in the hash chain.
cacheConcurrency(int) - Method in class org.h2.mvstore.MVStore.Builder
Set the read cache concurrency.
CACHED - Static variable in class org.h2.expression.ExpressionVisitor
Count of cached INDEPENDENT and EVALUATABLE visitors with different query level.
cachedBindAddress - Static variable in class org.h2.util.NetUtils
 
cachedColumnLabelMap - Variable in class org.h2.jdbc.JdbcPreparedStatement
 
cachedCompare - Variable in class org.h2.mvstore.Page
The last result of a find operation is cached.
cachedHashTable - Variable in class org.h2.compress.CompressLZF
Hash table for matching byte sequences (reused for performance).
CachedInputStream(InputStream) - Constructor for class org.h2.server.TcpServerThread.CachedInputStream
 
cachedLocalAddress - Static variable in class org.h2.util.NetUtils
 
cachedLocalAddressTime - Static variable in class org.h2.util.NetUtils
 
CacheHead - Class in org.h2.util
The head element of the linked list.
CacheHead() - Constructor for class org.h2.util.CacheHead
 
cacheId - Variable in class org.h2.util.SmallMap
 
CacheKey(int[], TableView) - Constructor for class org.h2.table.TableView.CacheKey
 
CacheKey(String, String, String) - Constructor for class org.h2.expression.function.DateTimeFormatFunction.CacheKey
 
CacheLongKeyLIRS<V> - Class in org.h2.mvstore.cache
A scan resistant cache that uses keys of type long.
CacheLongKeyLIRS(CacheLongKeyLIRS.Config) - Constructor for class org.h2.mvstore.cache.CacheLongKeyLIRS
Create a new cache with the given memory size.
CacheLongKeyLIRS.Config - Class in org.h2.mvstore.cache
The cache configuration.
CacheLongKeyLIRS.Entry<V> - Class in org.h2.mvstore.cache
A cache entry.
CacheLongKeyLIRS.Segment<V> - Class in org.h2.mvstore.cache
A cache segment
CacheLRU - Class in org.h2.util
A cache implementation based on the last recently used (LRU) algorithm.
CacheLRU(CacheWriter, int, boolean) - Constructor for class org.h2.util.CacheLRU
 
cacheNext - Variable in class org.h2.util.CacheObject
The next element in the LRU linked list.
CacheObject - Class in org.h2.util
The base object for all cached objects.
CacheObject() - Constructor for class org.h2.util.CacheObject
 
cachePage(Page<?, ?>) - Method in class org.h2.mvstore.MVStore
Put the page in the cache.
cachePrevious - Variable in class org.h2.util.CacheObject
The previous element in the LRU linked list.
CacheSecondLevel - Class in org.h2.util
Cache which wraps another cache (proxy pattern) and adds caching using map.
CacheSecondLevel(Cache, Map<Integer, CacheObject>) - Constructor for class org.h2.util.CacheSecondLevel
 
cacheSize - Variable in class org.h2.command.ddl.SequenceOptions
 
cacheSize - Variable in class org.h2.schema.Sequence
 
cacheSize(int) - Method in class org.h2.mvstore.MVStore.Builder
Set the read cache size in MB.
CacheTQ - Class in org.h2.util
An alternative cache implementation.
CacheTQ(CacheWriter, int) - Constructor for class org.h2.util.CacheTQ
 
cacheType - Variable in class org.h2.engine.Database
 
CacheValue(DateTimeFormatter, ZoneId) - Constructor for class org.h2.expression.function.DateTimeFormatFunction.CacheValue
 
CacheWriter - Interface in org.h2.util
The cache writer is called by the cache to persist changed data that needs to be removed from the cache.
calculateBestPlan() - Method in class org.h2.command.query.Optimizer
 
calculateBruteForceAll() - Method in class org.h2.command.query.Optimizer
 
calculateBruteForceSome() - Method in class org.h2.command.query.Optimizer
 
calculateCost(SessionLocal, AllColumnsForPlan) - Method in class org.h2.table.Plan
Calculate the cost of this query plan.
calculateFakePlan() - Method in class org.h2.command.query.Optimizer
 
calculateGenetic() - Method in class org.h2.command.query.Optimizer
 
calculateLobMac(long) - Method in class org.h2.value.Transfer
 
calculateMagnitude(long, long) - Static method in class org.h2.util.MemoryEstimator
 
calculateMemory() - Method in class org.h2.mvstore.Page
Calculate estimated memory used in persistent case.
calculateMemory() - Method in class org.h2.mvstore.Page.Leaf
 
calculateMemory() - Method in class org.h2.mvstore.Page.NonLeaf
 
calculateMemory() - Method in class org.h2.result.DefaultRow
Calculate the estimated memory used for this row, in bytes.
calculateMemory(DataType<T>, T[], int) - Static method in class org.h2.mvstore.MVMap
 
calculatePageNo(long) - Method in class org.h2.mvstore.MVStore
 
calculateScale(String, int) - Static method in class org.h2.expression.function.ToCharFunction
 
calculateTotalCount() - Method in class org.h2.mvstore.Page.NonLeaf
 
calculateUndoLogsTotalSize(RootReference<Long, Record<?, ?>>[]) - Static method in class org.h2.mvstore.tx.TransactionStore
Calculate the size for undo log entries.
call() - Method in class org.h2.util.Task
The method to be implemented.
Call - Class in org.h2.command.dml
This class represents the statement CALL.
Call(SessionLocal) - Constructor for class org.h2.command.dml.Call
 
CALL - Static variable in interface org.h2.command.CommandInterface
The type of a CALL statement.
CALLABLE_STATEMENT - Static variable in class org.h2.message.TraceObject
The trace type id for callable statements.
callMethod(Object, Class<?>, String, Object...) - Static method in class org.h2.util.Utils
 
callMethod(Object, String, Object...) - Static method in class org.h2.util.Utils
Calls an instance method via reflection.
callStaticMethod(String, Object...) - Static method in class org.h2.util.Utils
Calls a static method via reflection.
CAN_ONLY_ASSIGN_TO_VARIABLE_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90137 is thrown when trying to assign a value to something that is not a variable.
CAN_USE_ICU4J - Static variable in class org.h2.value.CompareMode
 
cancel - Variable in class org.h2.command.Command
If this query was canceled.
cancel() - Method in class org.h2.command.Command
 
cancel() - Method in interface org.h2.command.CommandInterface
Cancel the statement if it is still processing.
cancel() - Method in class org.h2.command.CommandRemote
Cancel this current statement.
cancel() - Method in class org.h2.engine.Session
Cancel the current or next command (called when closing a connection).
cancel() - Method in class org.h2.engine.SessionLocal
 
cancel() - Method in class org.h2.engine.SessionRemote
 
cancel() - Method in class org.h2.jdbc.JdbcStatement
Cancels a currently running statement.
CANCEL_SESSION - Static variable in class org.h2.expression.function.SessionControlFunction
CANCEL_SESSION().
cancelAtNs - Variable in class org.h2.engine.SessionLocal
 
cancelled - Variable in class org.h2.jdbc.JdbcStatement
 
cancelRequest() - Method in class org.h2.server.pg.PgServerThread
Kill a currently running query on this thread.
cancelRowUpdates() - Method in class org.h2.jdbc.JdbcResultSet
Cancels updating a row.
cancelRowUpdates() - Method in class org.h2.tools.SimpleResultSet
INTERNAL
cancelStatement(int) - Method in class org.h2.engine.SessionRemote
Cancel the statement with the given id.
cancelStatement(String, int) - Method in class org.h2.server.TcpServer
Cancel a running statement.
cancelStatement(String, int) - Method in class org.h2.server.TcpServerThread
Cancel a running statement.
canDrop() - Method in class org.h2.mvstore.db.MVTable
 
canDrop() - Method in class org.h2.schema.Schema
Check if this schema can be dropped.
canDrop() - Method in class org.h2.table.MetaTable
 
canDrop() - Method in class org.h2.table.Table
Check if this table can be dropped.
canDrop() - Method in class org.h2.table.TableLink
 
canDrop() - Method in class org.h2.table.TableView
 
canDrop() - Method in class org.h2.table.VirtualTable
 
canFindNext() - Method in class org.h2.index.Index
Check if the index can get the next higher value.
canFindNext() - Method in class org.h2.mvstore.db.MVSecondaryIndex
 
canGetFirstOrLast() - Method in class org.h2.index.DualIndex
 
canGetFirstOrLast() - Method in class org.h2.index.Index
Check if the index can directly look up the lowest or highest value of a column.
canGetFirstOrLast() - Method in class org.h2.index.RangeIndex
 
canGetFirstOrLast() - Method in class org.h2.mvstore.db.MVDelegateIndex
 
canGetFirstOrLast() - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
canGetFirstOrLast() - Method in class org.h2.mvstore.db.MVSecondaryIndex
 
canGetRowCount(SessionLocal) - Method in class org.h2.mvstore.db.MVTable
 
canGetRowCount(SessionLocal) - Method in class org.h2.table.DataChangeDeltaTable
 
canGetRowCount(SessionLocal) - Method in class org.h2.table.DualTable
 
canGetRowCount(SessionLocal) - Method in class org.h2.table.FunctionTable
 
canGetRowCount(SessionLocal) - Method in class org.h2.table.InformationSchemaTable
 
canGetRowCount(SessionLocal) - Method in class org.h2.table.MetaTable
 
canGetRowCount(SessionLocal) - Method in class org.h2.table.RangeTable
 
canGetRowCount(SessionLocal) - Method in class org.h2.table.Table
Check if the row count can be retrieved quickly.
canGetRowCount(SessionLocal) - Method in class org.h2.table.TableLink
 
canGetRowCount(SessionLocal) - Method in class org.h2.table.TableValueConstructorTable
 
canGetRowCount(SessionLocal) - Method in class org.h2.table.TableView
 
CANNOT_CHANGE_SETTING_WHEN_OPEN_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90133 is thrown when trying to change a specific database property while the database is already open.
CANNOT_DROP_2 - Static variable in class org.h2.api.ErrorCode
The error with code 90107 is thrown when trying to drop an object because another object would become invalid.
CANNOT_DROP_CURRENT_USER - Static variable in class org.h2.api.ErrorCode
The error with code 90019 is thrown when trying to drop the current user, if there are no other admin users.
CANNOT_DROP_LAST_COLUMN - Static variable in class org.h2.api.ErrorCode
The error with code 90084 is thrown when trying to drop the last column of a table.
CANNOT_DROP_TABLE_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90118 is thrown when trying to drop a table can not be dropped.
CANNOT_MIX_INDEXED_AND_UNINDEXED_PARAMS - Static variable in class org.h2.api.ErrorCode
The error with code 90123 is thrown when trying mix regular parameters and indexed parameters in the same statement.
CANNOT_TRUNCATE_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90106 is thrown when trying to truncate a table that can not be truncated.
canOptimizeCast(int, int) - Static method in class org.h2.expression.function.CastSpecification
 
canOverwriteChunk(Chunk, long) - Static method in class org.h2.mvstore.MVStore
 
canReference() - Method in class org.h2.table.MetaTable
 
canReference() - Method in class org.h2.table.Table
Check if this table can be referenced.
canReference() - Method in class org.h2.table.TableView
 
canReference() - Method in class org.h2.table.VirtualTable
 
canRemove() - Method in class org.h2.util.CacheHead
 
canRemove() - Method in class org.h2.util.CacheObject
Check if the object can be removed from the cache.
canReuse - Variable in class org.h2.command.Command
 
canReuse() - Method in class org.h2.command.Command
Whether the command is already closed (in which case it can be re-used).
canReuse() - Method in class org.h2.command.CommandContainer
 
canScan() - Method in class org.h2.index.Index
Can this index iterate over all rows?
canScan() - Method in class org.h2.index.VirtualConstructedTableIndex
 
canStop(int) - Method in class org.h2.command.query.Optimizer
 
canTruncate() - Method in class org.h2.mvstore.db.MVTable
 
canTruncate() - Method in class org.h2.table.Table
Check if this table can be truncated.
canUpdate() - Method in class org.h2.mvstore.RootReference
 
canUseIndex(Index, Table, IndexColumn[], boolean) - Static method in class org.h2.command.ddl.AlterTableAddConstraint
 
canUseIndexFor(Column) - Method in class org.h2.index.IndexCursor
 
canUseIndexForIn(Column) - Method in class org.h2.index.IndexCursor
 
canWrite() - Method in class org.h2.store.fs.disk.FilePathDisk
 
canWrite() - Method in class org.h2.store.fs.FilePath
Check if the file is writable.
canWrite() - Method in class org.h2.store.fs.FilePathWrapper
 
canWrite() - Method in class org.h2.store.fs.mem.FileMemData
Check whether writing is allowed.
canWrite() - Method in class org.h2.store.fs.mem.FilePathMem
 
canWrite() - Method in class org.h2.store.fs.niomem.FileNioMemData
Check whether writing is allowed.
canWrite() - Method in class org.h2.store.fs.niomem.FilePathNioMem
 
canWrite() - Method in class org.h2.store.fs.zip.FilePathZip
 
canWrite(String) - Static method in class org.h2.store.fs.FileUtils
Check if the file is writable.
capacity() - Method in class org.h2.mvstore.WriteBuffer
Get the capacity.
Capitalization() - Constructor for enum org.h2.expression.function.ToCharFunction.Capitalization
 
CAPITALIZE - org.h2.expression.function.ToCharFunction.Capitalization
The string is capitalized (first letter uppercased, subsequent letters lowercased).
CardinalityExpression - Class in org.h2.expression.function
Cardinality expression.
CardinalityExpression(Expression, boolean) - Constructor for class org.h2.expression.function.CardinalityExpression
Creates new instance of cardinality expression.
CASCADE - org.h2.constraint.ConstraintActionType
The action is to cascade the operation.
CASE - Static variable in class org.h2.util.ParserUtil
The token "CASE".
caseInsensitive - Variable in class org.h2.value.CompareModeDefault
 
caseInsensitive - Variable in class org.h2.value.CompareModeIcu4J
 
CaseInsensitiveConcurrentMap<V> - Class in org.h2.value
A concurrent hash map with case-insensitive string keys.
CaseInsensitiveConcurrentMap() - Constructor for class org.h2.value.CaseInsensitiveConcurrentMap
 
caseInsensitiveIdentifiers - Variable in class org.h2.engine.DbSettings
Database setting CASE_INSENSITIVE_IDENTIFIERS (default: false).
caseInsensitiveIdentifiers - Variable in class org.h2.engine.Session.StaticSettings
Whether all identifiers are case insensitive.
CaseInsensitiveMap<V> - Class in org.h2.value
A hash map with a case-insensitive string key.
CaseInsensitiveMap() - Constructor for class org.h2.value.CaseInsensitiveMap
Creates new instance of case-insensitive map.
CaseInsensitiveMap(int) - Constructor for class org.h2.value.CaseInsensitiveMap
Creates new instance of case-insensitive map with specified initial capacity.
caseSensitive - Variable in class org.h2.value.DataType
If this data type is case sensitive.
caseSensitiveColumnNames - Variable in class org.h2.tools.Csv
 
cast(Object) - Method in class org.h2.mvstore.type.BasicDataType
Cast the storage object to an array of type T.
CAST - Static variable in class org.h2.util.ParserUtil
The token "CAST".
CAST_TO - Static variable in class org.h2.value.Value
Cast a value to the specified type.
CastDataProvider - Interface in org.h2.engine
Provides information for type casts and comparison operations.
CastSpecification - Class in org.h2.expression.function
A cast specification.
CastSpecification(Expression, Column) - Constructor for class org.h2.expression.function.CastSpecification
 
CastSpecification(Expression, TypeInfo) - Constructor for class org.h2.expression.function.CastSpecification
 
castTo(TypeInfo, CastDataProvider) - Method in class org.h2.value.Value
Cast a value to the specified type.
castToBoolean(SessionLocal, Expression) - Static method in class org.h2.expression.condition.Condition
Add a cast around the expression (if necessary) so that the type is boolean.
catalog - Variable in class org.h2.jdbc.JdbcConnection
 
catalog - Variable in class org.h2.jdbc.JdbcResultSetMetaData
 
CATALOG - Static variable in class org.h2.command.dml.SetTypes
The type of a SET CATALOG statement.
CATALOGS - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
CC - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
CEIL - Static variable in class org.h2.expression.function.MathFunction
CEIL() or CEILING().
ceilingEntry(K) - Method in class org.h2.mvstore.tx.TransactionMap
Get the entry with smallest key that is larger than or equal to this key, or null if no such key exists.
ceilingKey(K) - Method in class org.h2.mvstore.MVMap
Get the smallest key that is larger or equal to this key.
ceilingKey(K) - Method in class org.h2.mvstore.tx.TransactionMap
Get the smallest key that is larger than or equal to this key, or null if no such key exists.
century(int) - Static method in class org.h2.expression.function.DateTimeFunction
 
CENTURY - Static variable in class org.h2.expression.function.DateTimeFunction
Century.
Change(String, Object, Object) - Constructor for class org.h2.mvstore.tx.TransactionStore.Change
 
CHANGE_ID - Static variable in class org.h2.engine.SessionRemote
 
changed - Variable in class org.h2.util.CacheObject
 
ChangeFileEncryption - Class in org.h2.tools
Allows changing the database file encryption password or algorithm.
ChangeFileEncryption() - Constructor for class org.h2.tools.ChangeFileEncryption
 
changeLength(long) - Method in class org.h2.store.fs.mem.FileMemData
 
changeLength(long) - Method in class org.h2.store.fs.niomem.FileNioMemData
 
changePrimaryKeysToNotNull(ArrayList<Column>) - Method in class org.h2.command.ddl.CommandWithColumns
For the given list of columns, disable "nullable" for those columns that are primary key columns.
changesUntilAnalyze - Variable in class org.h2.mvstore.db.MVTable
 
channel - Variable in class org.h2.store.fs.async.FileAsync
 
channel - Variable in class org.h2.store.fs.FileChannelInputStream
 
channel - Variable in class org.h2.store.fs.niomapped.FileNioMapped
 
channel - Variable in class org.h2.store.fs.rec.FileRec
 
channel - Variable in class org.h2.store.fs.retry.FileRetryOnInterrupt
 
CHAR - Static variable in class org.h2.api.H2Type
The CHARACTER data type.
CHAR - Static variable in class org.h2.expression.function.StringFunction1
CHAR() (non-standard).
CHAR - Static variable in class org.h2.mvstore.db.ValueDataType
 
CHAR - Static variable in class org.h2.value.Transfer
 
CHAR - Static variable in class org.h2.value.Value
The value type for CHARACTER values.
CHAR_LENGTH - Static variable in class org.h2.expression.function.LengthFunction
CHAR_LENGTH().
CHARACTER_SET_NAME - Static variable in class org.h2.table.InformationSchemaTable
 
CHARACTER_SET_NAME - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
characterPrecision - Variable in class org.h2.table.InformationSchemaTable.DataTypeInformation
CHARACTER_MAXIMUM_LENGTH and CHARACTER_OCTET_LENGTH.
characterSet - Variable in class org.h2.tools.Csv
 
CharacterStringToken(int, String, boolean) - Constructor for class org.h2.command.Token.CharacterStringToken
 
CharacterType() - Constructor for class org.h2.mvstore.type.ObjectDataType.CharacterType
 
charAndByteLengthUnits - Variable in class org.h2.engine.Mode
If true 'CHAR' and 'BYTE' length units are allowed.
charBuffer - Variable in class org.h2.store.CountingReaderInputStream
 
CHARINDEX - Static variable in class org.h2.mode.FunctionsMSSQLServer
 
charLength - Variable in class org.h2.value.ValueLob
Length in characters.
charLength() - Method in class org.h2.value.Value
Returns length of this value in characters.
charLength() - Method in class org.h2.value.ValueBlob
 
charLength() - Method in class org.h2.value.ValueClob
 
charLength() - Method in class org.h2.value.ValueUuid
 
charPadding - Variable in class org.h2.engine.Mode
How to pad or trim CHAR values.
CharPadding() - Constructor for enum org.h2.engine.Mode.CharPadding
 
charset - Variable in class org.h2.command.dml.RunScriptCommand
 
charset - Variable in class org.h2.command.dml.ScriptCommand
 
charset - Variable in class org.h2.value.CharsetCollator
 
CHARSET - Static variable in class org.h2.value.CompareMode
This constant means the charset specified should be used.
CharsetCollationKey(String) - Constructor for class org.h2.value.CharsetCollator.CharsetCollationKey
 
CharsetCollator - Class in org.h2.value
The charset collator sorts strings according to the order in the given charset.
CharsetCollator(Charset) - Constructor for class org.h2.value.CharsetCollator
 
CharsetCollator.CharsetCollationKey - Class in org.h2.value
 
check(boolean, Spatial, Spatial) - Method in class org.h2.mvstore.db.MVSpatialIndex.FindBoundsCursor
 
check(boolean, Spatial, Spatial) - Method in class org.h2.mvstore.rtree.MVRTreeMap.ContainsRTreeCursor
 
check(boolean, Spatial, Spatial) - Method in class org.h2.mvstore.rtree.MVRTreeMap.IntersectsRTreeCursor
 
check(boolean, Spatial, Spatial) - Method in class org.h2.mvstore.rtree.MVRTreeMap.RTreeCursor
Check a given key.
check(byte[], String, String) - Static method in class org.h2.tools.Upgrade
 
check(Long) - Method in class org.h2.command.ddl.SequenceOptions
 
check(SessionLocal, Value) - Method in class org.h2.constraint.ConstraintDomain
Check the specified value.
CHECK - org.h2.constraint.Constraint.Type
The constraint type for check constraints.
CHECK - Static variable in class org.h2.engine.SysProperties
System property h2.check (default: true for JDK/JRE, false for Android).
CHECK - Static variable in class org.h2.util.ParserUtil
The token "CHECK".
CHECK_CONSTRAINT_INVALID - Static variable in class org.h2.api.ErrorCode
The error with code 23514 is thrown when evaluation of a check constraint resulted in an error.
CHECK_CONSTRAINT_VIOLATED_1 - Static variable in class org.h2.api.ErrorCode
The error with code 23513 is thrown when a check constraint is violated.
CHECK_CONSTRAINTS - Static variable in class org.h2.table.InformationSchemaTable
 
CHECK_CONSTRAINTS - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
CHECK_SIZE_EACH_WRITES - Static variable in class org.h2.message.TraceSystem
 
checkAdmin() - Method in class org.h2.engine.User
Checks if this user has admin rights.
checkAdmin(String) - Method in class org.h2.server.web.WebApp
 
checkAdminPassword(String) - Method in class org.h2.server.web.WebServer
Check the admin password.
checkArgType(Expression) - Static method in class org.h2.expression.function.BitFunction
checkArgument(boolean, String, Object...) - Static method in class org.h2.mvstore.DataUtils
Throw an IllegalArgumentException if the argument is invalid.
checkCanceled() - Method in class org.h2.command.Command
Check if this command has been canceled, and throw an exception if yes.
checkCanceled() - Method in class org.h2.command.Prepared
Check if this statement was canceled.
checkCanceled() - Method in class org.h2.engine.SessionLocal
Check if the current transaction is canceled by calling Statement.cancel() or because a session timeout was set and expired.
checkCapacity(int) - Method in class org.h2.store.Data
Check if there is still enough capacity in the buffer.
checkCatalogName(String) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
checkClosed() - Method in class org.h2.engine.SessionRemote
Check if this session is closed and throws an exception if so.
checkClosed() - Method in class org.h2.jdbc.JdbcArray
 
checkClosed() - Method in class org.h2.jdbc.JdbcConnection
INTERNAL.
checkClosed() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
 
checkClosed() - Method in class org.h2.jdbc.JdbcLob
Check that connection and LOB is not closed, otherwise throws exception with error code ErrorCode.OBJECT_CLOSED.
checkClosed() - Method in class org.h2.jdbc.JdbcParameterMetaData
 
checkClosed() - Method in class org.h2.jdbc.JdbcResultSet
Check if this result set is closed.
checkClosed() - Method in class org.h2.jdbc.JdbcResultSetMetaData
 
checkClosed() - Method in class org.h2.jdbc.JdbcStatement
Check if this connection is closed.
checkClosed() - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
checkClosed() - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
checkClosed() - Method in class org.h2.jdbc.meta.DatabaseMetaLocalBase
 
checkClosed() - Method in class org.h2.jdbcx.JdbcXAConnection.PooledJdbcConnection
 
checkClosed() - Method in class org.h2.tools.SimpleResultSet
 
checkClusterDisableAutoCommit(String) - Method in class org.h2.engine.SessionRemote
 
checkClustering(ConnectionInfo, Database) - Static method in class org.h2.engine.Engine
 
checkClustering(Column) - Method in class org.h2.command.ddl.AlterTableAlterColumn
 
checkColumn(Domain, Column) - Method in class org.h2.constraint.ConstraintDomain.CheckExistingData
 
checkColumnIndex(int) - Method in class org.h2.jdbc.JdbcResultSet
 
checkColumnIndex(int) - Method in class org.h2.tools.SimpleResultSet
 
checkComparable(TypeInfo, TypeInfo) - Static method in class org.h2.value.TypeInfo
Checks whether two specified types are comparable and throws an exception otherwise.
checkConstraints(SessionLocal, ArrayList<Row>, String, Constraint, String) - Method in class org.h2.table.InformationSchemaTable
 
checkConstraints(SessionLocal, Value) - Method in class org.h2.schema.Domain
Check the specified value.
checkConstraints(SessionLocal, Value, Value, ArrayList<Row>, String) - Method in class org.h2.table.InformationSchemaTable
 
checkDatabaseName(String) - Method in class org.h2.command.Parser
 
checkDeadlock(SessionLocal, SessionLocal, Set<SessionLocal>) - Method in class org.h2.mvstore.db.MVTable
 
checkDeadlock(SessionLocal, SessionLocal, Set<SessionLocal>) - Method in class org.h2.table.Table
Check if a deadlock occurred.
checkDefaultReferencesTable(Table, Expression) - Static method in class org.h2.command.ddl.AlterTableAlterColumn
 
checkDomain(Domain, Domain) - Method in class org.h2.constraint.ConstraintDomain.CheckExistingData
 
checkEditable() - Method in class org.h2.jdbc.JdbcLob
Check the state of the LOB and throws the exception when check failed (set is supported only for a new LOB).
checkedWriting - Variable in class org.h2.store.FileStore
 
checkExisting - Variable in class org.h2.command.ddl.AlterDomainAddConstraint
 
checkExisting - Variable in class org.h2.command.ddl.AlterTableAddConstraint
 
checkExisting - Variable in class org.h2.command.dml.AlterTableSet
 
checkExistingData(SessionLocal) - Method in class org.h2.constraint.Constraint
Check the existing data.
checkExistingData(SessionLocal) - Method in class org.h2.constraint.ConstraintCheck
 
checkExistingData(SessionLocal) - Method in class org.h2.constraint.ConstraintDomain
 
checkExistingData(SessionLocal) - Method in class org.h2.constraint.ConstraintReferential
 
checkExistingData(SessionLocal) - Method in class org.h2.constraint.ConstraintUnique
 
CheckExistingData(SessionLocal, Domain) - Constructor for class org.h2.constraint.ConstraintDomain.CheckExistingData
 
checkExpression - Variable in class org.h2.command.ddl.AlterDomainAddConstraint
 
checkExpression - Variable in class org.h2.command.ddl.AlterTableAddConstraint
 
checkFileSizeLimit(long) - Static method in class org.h2.store.fs.niomapped.FileNioMapped
 
checkFinite(double) - Static method in class org.h2.util.geometry.GeometryUtils
Throw exception if param is not finite value (ie.
checkForDeadlocks() - Method in class org.h2.util.ThreadDeadlockDetector
Checks if any threads are deadlocked.
checkForeignKeyConstraints - Variable in class org.h2.table.Table
Is foreign key constraint checking enabled for this table.
checkHoldability(int) - Static method in class org.h2.jdbc.JdbcConnection
 
checkHost(String) - Method in class org.h2.server.web.WebThread
 
checkIndex(SessionLocal, String, Value, Value) - Method in class org.h2.table.MetaTable
Checks index conditions.
checkIndexBounds(int) - Method in class org.h2.jdbc.JdbcCallableStatement
 
checkIndexColumnTypes(IndexColumn[]) - Static method in class org.h2.index.Index
Check that the index columns are not CLOB or BLOB.
checkInit - Variable in class org.h2.command.query.Query
 
checkKeyAndGetDatabaseName(String) - Method in class org.h2.server.pg.PgServer
If no key is set, return the original database name.
checkKeyAndGetDatabaseName(String) - Method in class org.h2.server.TcpServer
If no key is set, return the original database name.
checkLetter(boolean, boolean, char) - Static method in class org.h2.util.ParserUtil
 
checkLiterals() - Method in class org.h2.command.Parser
 
checkMap(Map<String, Class<?>>) - Static method in class org.h2.jdbc.JdbcConnection
Check that the given type map is either null or empty.
checkMetaFree(SessionLocal, int) - Method in class org.h2.engine.Database
 
checkNoNullValues(Table) - Method in class org.h2.command.ddl.AlterTableAlterColumn
 
checkNotClosed() - Method in class org.h2.mvstore.tx.Transaction
Check whether this transaction is open or prepared.
checkNullable(Table) - Method in class org.h2.command.ddl.AlterTableAlterColumn
 
checkOnValidRow() - Method in class org.h2.jdbc.JdbcResultSet
 
checkOpen() - Method in class org.h2.jdbcx.JdbcXAConnection
 
checkOpen() - Method in class org.h2.mvstore.MVStore
 
checkOpen(int) - Method in class org.h2.mvstore.tx.Transaction
Check whether this transaction is open.
checkOptions(long, long, long, long, long, long, boolean) - Method in class org.h2.schema.Sequence
Validates the specified prospective base value, start value, min value, max value, increment, and cache size relative to each other, since each of their respective validities are contingent on the values of the other parameters.
checkOrderBy(WindowFrameUnits, int) - Method in class org.h2.expression.analysis.DataAnalysisOperation
 
checkOrderOther(SessionLocal, Expression, ArrayList<String>) - Static method in class org.h2.command.query.Query
An additional check for expression in ORDER BY list for DISTINCT selects that was not matched with selected expressions in regular way.
checkOwnsNoSchemas() - Method in class org.h2.engine.RightOwner
Check that this right owner does not own any schema.
checkParameterCount(int) - Method in class org.h2.mode.FunctionsMSSQLServer
 
checkParameterCount(int) - Method in class org.h2.mode.FunctionsMySQL
 
checkParameterCount(int) - Method in class org.h2.mode.FunctionsOracle
 
checkParameterCount(int) - Method in class org.h2.mode.FunctionsPostgreSQL
 
checkParameterCount(int) - Method in class org.h2.mode.ModeFunction
Check if the parameter count is correct.
checkParameters() - Method in class org.h2.command.CommandRemote
 
checkParameters() - Method in class org.h2.command.ddl.PrepareProcedure
 
checkParameters() - Method in class org.h2.command.dml.Explain
 
checkParameters() - Method in class org.h2.command.Prepared
Check if all parameters have been set.
checkParamLength(int, int) - Static method in class org.h2.server.pg.PgServerThread
 
checkpoint() - Method in class org.h2.engine.Database
Flush all changes and open a new transaction log.
CHECKPOINT - Static variable in interface org.h2.command.CommandInterface
The type of a CHECKPOINT statement.
CHECKPOINT_SYNC - Static variable in interface org.h2.command.CommandInterface
The type of a CHECKPOINT SYNC statement.
checkPowerOff() - Method in class org.h2.engine.Database
 
checkPowerOff() - Method in class org.h2.engine.SessionRemote
 
checkPowerOff() - Method in interface org.h2.store.DataHandler
Check if the simulated power failure occurred.
checkPowerOff() - Method in class org.h2.store.FileStore
 
checkPowerOff() - Method in class org.h2.tools.Recover
INTERNAL
checkPowerOff2() - Method in class org.h2.engine.Database
 
checkPrecision(long) - Method in class org.h2.value.ValueInterval
Check if the precision is smaller or equal than the given precision.
checkQuotes(String, int, int) - Static method in class org.h2.jdbc.JdbcStatement
 
checkRange(int) - Static method in class org.h2.value.ValueSmallint
 
checkRange(int) - Static method in class org.h2.value.ValueTinyint
 
checkRange(long) - Static method in class org.h2.value.ValueInteger
 
checkRange(long, int, int) - Static method in class org.h2.jdbc.JdbcArray
 
checkReadable() - Method in class org.h2.jdbc.JdbcLob
Check the state of the LOB and throws the exception when check failed (the LOB must be set completely before read).
checkReadable() - Method in class org.h2.jdbc.JdbcSQLXML
 
checkReadOnly() - Method in class org.h2.table.TableLink
 
checkRegistered(int) - Method in class org.h2.jdbc.JdbcCallableStatement
 
checkRename() - Method in class org.h2.engine.Comment
 
checkRename() - Method in class org.h2.engine.DbObject
Check if renaming is allowed.
checkRename() - Method in class org.h2.engine.Right
 
checkRename() - Method in class org.h2.engine.Setting
 
checkRename() - Method in class org.h2.index.LinkedIndex
 
checkRename() - Method in class org.h2.index.MetaIndex
 
checkRename() - Method in class org.h2.index.ViewIndex
 
checkRename() - Method in class org.h2.index.VirtualTableIndex
 
checkRename() - Method in class org.h2.schema.UserDefinedFunction
 
checkRename() - Method in class org.h2.table.MetaTable
 
checkRename() - Method in class org.h2.table.TableSynonym
 
checkRename() - Method in class org.h2.table.VirtualTable
 
checkResults - Variable in class org.h2.tools.RunScript
 
checkRights() - Method in class org.h2.command.dml.MergeUsing
 
checkRights() - Method in class org.h2.command.dml.MergeUsing.When
Checks user's INSERT, UPDATE, DELETE permission in appropriate cases.
checkRights() - Method in class org.h2.command.dml.MergeUsing.WhenMatchedThenDelete
 
checkRights() - Method in class org.h2.command.dml.MergeUsing.WhenMatchedThenUpdate
 
checkRights() - Method in class org.h2.command.dml.MergeUsing.WhenNotMatched
 
checkRow(SessionLocal, Row) - Method in class org.h2.constraint.ConstraintReferential
 
checkRow(SessionLocal, Table, Row, Row) - Method in class org.h2.constraint.Constraint
Check if this row fulfils the constraint.
checkRow(SessionLocal, Table, Row, Row) - Method in class org.h2.constraint.ConstraintCheck
 
checkRow(SessionLocal, Table, Row, Row) - Method in class org.h2.constraint.ConstraintDomain
 
checkRow(SessionLocal, Table, Row, Row) - Method in class org.h2.constraint.ConstraintReferential
 
checkRow(SessionLocal, Table, Row, Row) - Method in class org.h2.constraint.ConstraintUnique
 
checkRowOwnTable(SessionLocal, Row, Row) - Method in class org.h2.constraint.ConstraintReferential
 
checkRowRefTable(SessionLocal, Row, Row) - Method in class org.h2.constraint.ConstraintReferential
 
checkRunOver(int, int, String) - Static method in class org.h2.jdbc.JdbcConnection
 
checkSchema(String, Schema) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
checkSchema(Schema) - Method in class org.h2.command.Parser
 
checkSchemaAdmin() - Method in class org.h2.engine.User
Checks if this user has schema admin rights for every schema.
checkSchemaOwner(Schema) - Method in class org.h2.engine.User
Checks if this user has schema owner rights for the specified schema.
checkServer() - Method in class org.h2.store.FileLock
 
checkSet() - Method in class org.h2.expression.Parameter
 
checkSet() - Method in interface org.h2.expression.ParameterInterface
Check if the value is set.
checkSet() - Method in class org.h2.expression.ParameterRemote
 
checkSize - Variable in class org.h2.message.TraceSystem
Starts at -1 so that we check the file size immediately upon open.
checkStringEnd(int) - Method in class org.h2.util.geometry.EWKTUtils.EWKTSource
 
CHECKSUMS - Static variable in class org.h2.tools.Upgrade
 
checkSupportAlter() - Method in class org.h2.mvstore.db.MVTable
 
checkSupportAlter() - Method in class org.h2.table.MetaTable
 
checkSupportAlter() - Method in class org.h2.table.Table
Check if this table supports ALTER TABLE.
checkSupportAlter() - Method in class org.h2.table.TableLink
 
checkSupportAlter() - Method in class org.h2.table.TableView
 
checkSupportAlter() - Method in class org.h2.table.VirtualTable
 
checkSuspended(SessionLocal.State) - Method in class org.h2.engine.SessionLocal
 
checkTableRight(Table, int) - Method in class org.h2.engine.User
Checks that this user has the given rights for the specified table.
checkTimeout() - Method in class org.h2.table.TableFilter
 
checkType(int) - Method in class org.h2.server.pg.PgServer
Check whether a data type is supported.
checkTypeConcurrency(int, int) - Static method in class org.h2.jdbc.JdbcConnection
 
checkUnique(boolean, TransactionMap<SearchRow, Value>, SearchRow, long) - Method in class org.h2.mvstore.db.MVSecondaryIndex
 
checkUpdatable() - Method in class org.h2.jdbc.JdbcResultSet
 
checkValid() - Method in class org.h2.jdbc.JdbcSavepoint
 
checkVariableBounds(WindowFrame, ArrayList<Value[]>) - Static method in class org.h2.expression.aggregate.AbstractAggregate
 
checkViews(SchemaObject, SchemaObject) - Method in class org.h2.command.ddl.AlterTableAlterColumn
Check that all views and other dependent objects.
checkViewsAreValid(DbObject) - Method in class org.h2.command.ddl.AlterTableAlterColumn
Check that a table or view is still valid.
checkWritingAllowed() - Method in class org.h2.engine.Database
 
checkWritingAllowed() - Method in class org.h2.engine.SessionRemote
 
checkWritingAllowed() - Method in interface org.h2.store.DataHandler
Check if writing is allowed.
checkWritingAllowed() - Method in class org.h2.store.FileStore
 
checkWritingAllowed() - Method in class org.h2.table.Table
Tests if the table can be written.
checkWritingAllowed() - Method in class org.h2.table.TableLink
Linked tables don't know if they are readonly.
checkWritingAllowed() - Method in class org.h2.tools.Recover
INTERNAL
childCount - Variable in class org.h2.mvstore.db.MVTempResult
Count of child results.
children - Variable in class org.h2.mvstore.Page.NonLeaf
The child page references.
chooseIterator(K, K, boolean, boolean) - Method in class org.h2.mvstore.tx.TransactionMap
 
Chunk - Class in org.h2.mvstore
A chunk of data, containing one or multiple pages.
Chunk(int) - Constructor for class org.h2.mvstore.Chunk
 
Chunk(String) - Constructor for class org.h2.mvstore.Chunk
 
Chunk(Map<String, String>) - Constructor for class org.h2.mvstore.Chunk
 
Chunk(Map<String, String>, boolean) - Constructor for class org.h2.mvstore.Chunk
 
Chunk.PositionComparator - Class in org.h2.mvstore
 
chunks - Variable in class org.h2.mvstore.MVStore
The map of chunks.
chunksToC - Variable in class org.h2.mvstore.MVStore
Cache for chunks "Table of Content" used to translate page's sequential number within containing chunk into byte position within chunk's image.
cipher - Variable in class org.h2.command.dml.ScriptBase
 
cipher - Variable in class org.h2.engine.Database
 
cipher - Variable in class org.h2.engine.SessionRemote
 
cipher - Variable in class org.h2.security.SecureFileStore
 
cipher - Variable in class org.h2.store.fs.encrypt.XTS
 
CIPHER_BLOCK_SIZE - Static variable in class org.h2.store.fs.encrypt.XTS
The AES encryption block size.
CipherFactory - Class in org.h2.security
A factory to create new block cipher objects.
CipherFactory() - Constructor for class org.h2.security.CipherFactory
 
cipherForInitVector - Variable in class org.h2.security.SecureFileStore
 
cipherType - Variable in class org.h2.tools.ChangeFileEncryption
 
CLASS_NOT_FOUND_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90086 is thrown when a class can not be loaded because it is not in the classpath or because a related class is not in the classpath.
ClassFileManager(StandardJavaFileManager) - Constructor for class org.h2.util.SourceCompiler.ClassFileManager
 
classLoader - Variable in class org.h2.util.SourceCompiler.ClassFileManager
 
className - Variable in class org.h2.schema.UserDefinedFunction
 
className - Variable in class org.h2.security.auth.UserToRolesMapperConfig
 
classObjectsByName - Variable in class org.h2.util.SourceCompiler.ClassFileManager
We use map because there can be nested, anonymous etc classes.
CLASSPATH_PREFIX - Static variable in class org.h2.store.fs.disk.FilePathDisk
 
classToType(Class<?>) - Static method in class org.h2.value.ValueToObjectConverter2
Get the type information for the given Java class.
clean() - Method in class org.h2.security.auth.AuthenticationInfo
Clean authentication data.
cleanAuthenticationInfo() - Method in class org.h2.engine.ConnectionInfo
Clear authentication properties.
cleaned - Variable in class org.h2.value.ExtTypeInfoEnum
 
cleanTempTables(boolean) - Method in class org.h2.engine.SessionLocal
 
cleanupOrder() - Method in class org.h2.command.query.Query
Removes constant expressions from the sort order.
clear() - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Remove all entries.
clear() - Method in class org.h2.mvstore.FileStore
Mark the file as empty.
clear() - Method in class org.h2.mvstore.FreeSpaceBitSet
Reset the list.
clear() - Method in class org.h2.mvstore.MVMap
Remove all entries.
clear() - Method in class org.h2.mvstore.tx.TransactionMap
Clear the map.
clear() - Method in class org.h2.mvstore.WriteBuffer
Clear the buffer after use.
clear() - Method in interface org.h2.util.Cache
Clear the cache.
clear() - Method in class org.h2.util.CacheLRU
 
clear() - Method in class org.h2.util.CacheSecondLevel
 
clear() - Method in class org.h2.util.CacheTQ
 
clear() - Method in class org.h2.util.SoftValuesHashMap
 
clearBatch() - Method in class org.h2.jdbc.JdbcPreparedStatement
Clears the batch.
clearBatch() - Method in class org.h2.jdbc.JdbcStatement
Clears the batch.
clearCache() - Static method in class org.h2.util.StringUtils
Clear the cache.
clearCache() - Static method in class org.h2.value.Value
Clear the value cache.
clearCache(ByteBuffer, long) - Method in class org.h2.mvstore.cache.FilePathCache.FileCache
 
clearCaches() - Method in class org.h2.mvstore.MVStore
 
clearCTE() - Method in class org.h2.command.CommandContainer
Clean up any associated CTE.
clearCTE(SessionLocal, List<TableView>) - Static method in class org.h2.command.CommandContainer
Clears CTE views.
clearCTE(SessionLocal, Prepared) - Static method in class org.h2.command.CommandContainer
Clears CTE views for a specified statement.
clearIgnored() - Method in class org.h2.fulltext.FullTextSettings
Clear set of ignored words
clearIndexCaches(Database) - Static method in class org.h2.table.TableView
Clear the cached indexes for all sessions.
clearIt() - Method in class org.h2.mvstore.MVMap
Remove all entries and return the root reference.
clearNames() - Static method in class org.h2.expression.function.ToCharFunction
Used for testing.
clearPageReference() - Method in class org.h2.mvstore.Page.PageReference
Clear if necessary, reference to the actual child Page object, so it can be garbage collected if not actively used elsewhere.
clearParameters() - Method in class org.h2.jdbc.JdbcPreparedStatement
Clears all parameters.
clearRemark() - Method in class org.h2.util.ScriptReader
 
clearViewIndexCache() - Method in class org.h2.engine.SessionLocal
Clear the view cache for this session.
clearWarnings() - Method in class org.h2.jdbc.JdbcConnection
Clears all warnings.
clearWarnings() - Method in class org.h2.jdbc.JdbcResultSet
Clears all warnings.
clearWarnings() - Method in class org.h2.jdbc.JdbcStatement
Clears all warnings.
clearWarnings() - Method in class org.h2.tools.SimpleResultSet
INTERNAL
clearWordList() - Method in class org.h2.fulltext.FullTextSettings
Clear set of searchable words
CLIENT_TRACE_DIRECTORY - Static variable in class org.h2.engine.SysProperties
System property h2.clientTraceDirectory (default: trace.db/).
clientAddr - Variable in class org.h2.util.NetworkConnectionInfo
 
clientEncoding - Variable in class org.h2.server.pg.PgServerThread
 
clientInfo - Variable in class org.h2.jdbc.JdbcConnection
 
clientInfo - Variable in class org.h2.util.NetworkConnectionInfo
 
clientPort - Variable in class org.h2.util.NetworkConnectionInfo
 
clientVersion - Variable in class org.h2.engine.SessionRemote
 
clientVersion - Variable in class org.h2.server.TcpServerThread
 
CLOB - Static variable in class org.h2.api.H2Type
The CHARACTER LARGE OBJECT data type.
CLOB - Static variable in class org.h2.message.TraceObject
The trace type id for clobs.
CLOB - Static variable in class org.h2.mvstore.db.ValueDataType
 
CLOB - Static variable in class org.h2.value.Transfer
 
CLOB - Static variable in class org.h2.value.Value
The value type for CHARACTER LARGE OBJECT values.
clone() - Method in class org.h2.command.Token
 
clone() - Method in class org.h2.engine.ConnectionInfo
 
clone() - Method in class org.h2.mvstore.Page
 
clone() - Method in class org.h2.mvstore.tx.VersionedBitSet
 
clone(long) - Method in class org.h2.mvstore.db.SpatialKey
 
clone(long) - Method in class org.h2.mvstore.rtree.DefaultSpatial
 
clone(long) - Method in interface org.h2.mvstore.rtree.Spatial
Creates a copy of this Spatial object with different id.
cloneByteArray(byte[]) - Static method in class org.h2.util.Utils
Create a new byte array and copy all the data.
cloneCharArray(char[]) - Static method in class org.h2.util.StringUtils
Create a new char array and copy all the data.
cloneIt() - Method in class org.h2.mvstore.MVMap
Clone the current map.
cloneIt() - Method in class org.h2.mvstore.rtree.MVRTreeMap
 
cloneIt() - Method in class org.h2.mvstore.tx.TransactionStore.TxMapBuilder.TMVMap
 
cloneLobs(Value[]) - Method in class org.h2.result.LocalResult
 
cloneTableStructure(Table, Column[], Database, String, ArrayList<Column>) - Method in class org.h2.command.ddl.AlterTableAlterColumn
 
closable - Variable in class org.h2.jdbc.JdbcSQLXML
Underlying stream for SAXResult, StAXResult, and StreamResult.
close() - Method in interface org.h2.api.Trigger
This method is called when the database is closed.
close() - Method in class org.h2.command.Command
 
close() - Method in interface org.h2.command.CommandInterface
Close the statement.
close() - Method in class org.h2.command.CommandRemote
 
close() - Method in class org.h2.command.query.SelectUnion.LazyResultUnion
 
close() - Method in class org.h2.compress.LZFInputStream
 
close() - Method in class org.h2.compress.LZFOutputStream
 
close() - Method in class org.h2.engine.Session
Roll back pending transactions and close the session.
close() - Method in class org.h2.engine.SessionLocal
 
close() - Method in class org.h2.engine.SessionRemote
 
close() - Method in class org.h2.fulltext.FullText.FullTextTrigger
INTERNAL
close() - Method in class org.h2.fulltext.FullTextLucene.FullTextTrigger
INTERNAL
close() - Method in class org.h2.fulltext.FullTextLucene.IndexAccess
Close the index.
close() - Method in class org.h2.jdbc.JdbcConnection
Closes this connection.
close() - Method in class org.h2.jdbc.JdbcLob.LobPipedOutputStream
 
close() - Method in class org.h2.jdbc.JdbcPreparedStatement
Closes this statement.
close() - Method in class org.h2.jdbc.JdbcResultSet
Closes the result set.
close() - Method in class org.h2.jdbc.JdbcStatement
Closes this statement.
close() - Method in class org.h2.jdbcx.JdbcXAConnection
Close the physical connection.
close() - Method in class org.h2.jdbcx.JdbcXAConnection.PooledJdbcConnection
 
close() - Method in class org.h2.message.TraceSystem
Close the writers, and the files if required.
close() - Method in class org.h2.mvstore.db.MVTempResult
 
close() - Method in class org.h2.mvstore.db.MVTempResult.CloseImpl
 
close() - Method in class org.h2.mvstore.FileStore
Close this store.
close() - Method in class org.h2.mvstore.MVMap
Close the map.
close() - Method in class org.h2.mvstore.MVStore
Close the file and the store.
close() - Method in class org.h2.mvstore.OffHeapStore
 
close() - Method in class org.h2.mvstore.StreamStore.Stream
 
close() - Method in class org.h2.mvstore.tx.TransactionStore
Close the transaction store.
close() - Method in class org.h2.result.LazyResult
 
close() - Method in class org.h2.result.LocalResult
 
close() - Method in interface org.h2.result.ResultExternal
Close this object and delete the temporary file.
close() - Method in interface org.h2.result.ResultInterface
Close the result and delete any temporary files
close() - Method in class org.h2.result.ResultRemote
 
close() - Method in class org.h2.result.ResultWithPaddedStrings
 
close() - Method in class org.h2.result.SimpleResult
 
close() - Method in class org.h2.schema.Sequence
Flush the current value to disk and close this object.
close() - Method in class org.h2.schema.TriggerObject
Close the trigger.
close() - Method in class org.h2.server.pg.PgServerThread
Close this connection.
close() - Method in class org.h2.server.pg.PgServerThread.Prepared
Closes prepared statement and result, if any.
close() - Method in class org.h2.server.TcpServerThread
Close a connection.
close() - Method in class org.h2.server.web.WebSession
Close the connection and stop the statement if one is currently executing.
close() - Method in class org.h2.store.CountingReaderInputStream
 
close() - Method in class org.h2.store.DataReader
 
close() - Method in class org.h2.store.FileStore
Close the file.
close() - Method in class org.h2.store.FileStoreInputStream
 
close() - Method in class org.h2.store.FileStoreOutputStream
 
close() - Method in class org.h2.store.fs.FileChannelInputStream
 
close() - Method in class org.h2.store.RangeInputStream
 
close() - Method in class org.h2.store.RangeReader
 
close() - Method in class org.h2.tools.Csv
INTERNAL
close() - Method in class org.h2.tools.SimpleResultSet
Closes the result set and releases the resources.
close() - Method in interface org.h2.tools.SimpleRowSource
Close the row source.
close() - Method in class org.h2.util.ScriptReader
Close the underlying reader.
close() - Method in class org.h2.value.Transfer
Close the transfer object and the socket.
close(boolean) - Method in class org.h2.engine.Database
Close the database.
close(boolean) - Method in class org.h2.table.TableLinkConnection
Closes the connection if this is the last link to it.
close(int) - Method in class org.h2.mvstore.db.Store
Close the store.
close(int) - Method in class org.h2.mvstore.MVStore
Close the file and the store.
close(String) - Static method in class org.h2.engine.Engine
Called after a database has been closed, to remove the object from the list of open databases.
close(SessionLocal) - Method in class org.h2.index.Index
Close this index.
close(SessionLocal) - Method in class org.h2.index.LinkedIndex
 
close(SessionLocal) - Method in class org.h2.index.MetaIndex
 
close(SessionLocal) - Method in class org.h2.index.ViewIndex
 
close(SessionLocal) - Method in class org.h2.index.VirtualTableIndex
 
close(SessionLocal) - Method in class org.h2.mvstore.db.MVDelegateIndex
 
close(SessionLocal) - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
close(SessionLocal) - Method in class org.h2.mvstore.db.MVSecondaryIndex
 
close(SessionLocal) - Method in class org.h2.mvstore.db.MVSpatialIndex
 
close(SessionLocal) - Method in class org.h2.mvstore.db.MVTable
 
close(SessionLocal) - Method in class org.h2.table.MetaTable
 
close(SessionLocal) - Method in class org.h2.table.Table
Close the table object and flush changes.
close(SessionLocal) - Method in class org.h2.table.TableLink
 
close(SessionLocal) - Method in class org.h2.table.TableView
 
close(SessionLocal) - Method in class org.h2.table.VirtualTable
 
CLOSE_BRACE - Static variable in class org.h2.command.Token
The token "}".
CLOSE_BRACKET - Static variable in class org.h2.bnf.RuleFixed
 
CLOSE_BRACKET - Static variable in class org.h2.command.Token
The token "]".
CLOSE_PAREN - Static variable in class org.h2.command.Token
The token ")".
closeable - Variable in class org.h2.mvstore.db.MVTempResult
Closeable to close the storage.
closeable - Variable in class org.h2.util.CloseWatcher
The closeable object.
closeAll() - Static method in class org.h2.fulltext.FullText
INTERNAL Close all fulltext settings, freeing up memory.
closeAll() - Static method in class org.h2.fulltext.FullTextSettings
Close all fulltext settings, freeing up memory.
closeAllSessionsExcept(SessionLocal) - Method in class org.h2.engine.Database
 
closeAndDeleteSilently() - Method in class org.h2.store.FileStore
Close the file (ignoring exceptions) and delete the file.
closeAndSetNull(CommandInterface) - Static method in class org.h2.jdbc.JdbcConnection
 
closeAndThrow(int, FileChannel[], FileChannel, long) - Method in class org.h2.store.fs.split.FilePathSplit
 
closeChannel - Variable in class org.h2.store.fs.FileChannelInputStream
 
closeChild() - Method in class org.h2.mvstore.db.MVTempResult
 
closeConnection(PooledConnection) - Method in class org.h2.jdbcx.JdbcConnectionPool
 
closed - Variable in class org.h2.message.TraceSystem
 
closed - Variable in class org.h2.mvstore.db.MVTempResult
Whether this result is closed.
closed - Variable in class org.h2.mvstore.MVMap
Whether the map is closed.
closed - Variable in class org.h2.result.LazyResult
 
closed - Variable in class org.h2.result.LocalResult
 
closed - Variable in class org.h2.store.fs.mem.FileMem
 
closed - Variable in class org.h2.store.fs.niomem.FileNioMem
 
CLOSED - org.h2.engine.SessionLocal.State
 
CLOSED - org.h2.jdbc.JdbcLob.State
Object is closed.
closeDelay - Variable in class org.h2.engine.Database
 
closedHandle() - Method in class org.h2.jdbcx.JdbcXAConnection
INTERNAL
closeFile() - Method in class org.h2.store.FileStore
Close the file.
closeFiles() - Method in class org.h2.engine.Database
 
closeFileSilently() - Method in class org.h2.store.FileStore
Just close the file, without setting the reference to null.
closeIfCloseOnCompletion() - Method in class org.h2.jdbc.JdbcStatement
 
closeImmediately() - Method in class org.h2.mvstore.db.Store
Close the store, without persisting changes.
closeImmediately() - Method in class org.h2.mvstore.MVStore
Close the file and the store, without writing anything.
closeImpl(boolean) - Method in class org.h2.engine.Database
 
CloseImpl(MVStore, String) - Constructor for class org.h2.mvstore.db.MVTempResult.CloseImpl
 
closeInternal() - Method in class org.h2.jdbc.JdbcStatement
 
closeInternal(boolean) - Method in class org.h2.jdbc.JdbcResultSet
Close the result set.
closeIO() - Method in class org.h2.command.dml.ScriptBase
Close input and output streams.
closeIt() - Method in class org.h2.mvstore.tx.Transaction
Transition this transaction into a closed state.
closeLastResult() - Method in class org.h2.command.query.Query
 
closeOld() - Method in class org.h2.jdbc.JdbcConnection
 
closeOldResultSet() - Method in class org.h2.jdbc.JdbcStatement
INTERNAL.
closeOnCompletion - Variable in class org.h2.jdbc.JdbcStatement
 
closeOnCompletion() - Method in class org.h2.jdbc.JdbcStatement
Specifies that this statement will be closed when its dependent result set is closed.
closeOpenFilesAndUnlock() - Method in class org.h2.engine.Database
Close all open files and unlock the database.
closePreparedCommands() - Method in class org.h2.jdbc.JdbcConnection
 
closeResult() - Method in class org.h2.server.pg.PgServerThread.Prepared
Closes the result, if any.
closeSession() - Method in class org.h2.server.TcpServerThread
 
closeSilently() - Method in class org.h2.store.FileStore
Close the file without throwing any exceptions.
closeSilently(AutoCloseable) - Static method in class org.h2.util.IOUtils
Close an AutoCloseable without throwing an exception.
closeSilently(ServerSocket) - Static method in class org.h2.util.NetUtils
Close a server socket and ignore any exceptions.
closeSilently(Connection) - Static method in class org.h2.util.JdbcUtils
Close a connection without throwing an exception.
closeSilently(ResultSet) - Static method in class org.h2.util.JdbcUtils
Close a result set without throwing an exception.
closeSilently(Statement) - Static method in class org.h2.util.JdbcUtils
Close a statement without throwing an exception.
closeStore(boolean, int) - Method in class org.h2.mvstore.MVStore
 
CloseWatcher - Class in org.h2.util
A phantom reference to watch for unclosed objects.
CloseWatcher(Object, ReferenceQueue<Object>, AutoCloseable) - Constructor for class org.h2.util.CloseWatcher
 
closeWriter() - Method in class org.h2.message.TraceSystem
 
closing - Variable in class org.h2.engine.Database
 
closingDatabase() - Method in interface org.h2.api.DatabaseEventListener
This method is called before the database is closed normally.
cluster - Variable in class org.h2.engine.Database
 
cluster - Variable in class org.h2.engine.SessionRemote
 
CLUSTER - Static variable in class org.h2.command.dml.SetTypes
The type of a SET CLUSTER statement.
CLUSTER_ERROR_DATABASE_RUNS_ALONE - Static variable in class org.h2.api.ErrorCode
The error with code 90093 is thrown when trying to connect to a clustered database that runs in standalone mode.
CLUSTER_ERROR_DATABASE_RUNS_CLUSTERED_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90094 is thrown when trying to connect to a clustered database that runs together with a different cluster node setting than what is used when trying to connect.
CLUSTERING_DISABLED - Static variable in class org.h2.engine.Constants
The value of the cluster setting if clustering is disabled.
CLUSTERING_ENABLED - Static variable in class org.h2.engine.Constants
The value of the cluster setting if clustering is enabled (the actual value is checked later).
cmdType - Variable in class org.h2.command.CommandRemote
 
COALESCE - Static variable in class org.h2.expression.function.CoalesceFunction
COALESCE().
CoalesceFunction - Class in org.h2.expression.function
A COALESCE, GREATEST, or LEAST function.
CoalesceFunction(int) - Constructor for class org.h2.expression.function.CoalesceFunction
 
CoalesceFunction(int, Expression...) - Constructor for class org.h2.expression.function.CoalesceFunction
 
COLLATION - Static variable in class org.h2.command.dml.SetTypes
The type of a SET COLLATION statement.
COLLATION_CHANGE_WITH_DATA_TABLE_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90089 is thrown when trying to change the collation while there was already data in the database.
collationKeys - Variable in class org.h2.value.CompareModeDefault
 
collations(SessionLocal, ArrayList<Row>, String) - Method in class org.h2.table.InformationSchemaTable
 
collations(SessionLocal, ArrayList<Row>, String, String, String, String) - Method in class org.h2.table.InformationSchemaTable
 
COLLATIONS - Static variable in class org.h2.table.InformationSchemaTable
 
COLLATIONS - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
collator - Variable in class org.h2.value.CompareModeDefault
 
collator - Variable in class org.h2.value.CompareModeIcu4J
 
COLLATOR_CACHE_SIZE - Static variable in class org.h2.engine.SysProperties
System property h2.collatorCacheSize (default: 3 2000).
collect(SessionLocal, AggregateDataCollecting, AggregateData) - Static method in class org.h2.expression.aggregate.Aggregate
 
collectChangedMapRoots(long) - Method in class org.h2.mvstore.MVStore
 
collectDependencies(HashSet<DbObject>) - Method in class org.h2.command.dml.Delete
 
collectDependencies(HashSet<DbObject>) - Method in class org.h2.command.dml.Explain
 
collectDependencies(HashSet<DbObject>) - Method in class org.h2.command.dml.Insert
 
collectDependencies(HashSet<DbObject>) - Method in class org.h2.command.dml.Merge
 
collectDependencies(HashSet<DbObject>) - Method in class org.h2.command.dml.MergeUsing
 
collectDependencies(HashSet<DbObject>) - Method in class org.h2.command.dml.Update
 
collectDependencies(HashSet<DbObject>) - Method in class org.h2.command.Prepared
Find and collect all DbObjects, this Prepared depends on.
collectDependencies(HashSet<DbObject>) - Method in class org.h2.command.query.Query
 
collectDependencies(ExpressionVisitor) - Method in class org.h2.command.dml.MergeUsing.When
Find and collect all DbObjects, this When object depends on.
collectDependencies(ExpressionVisitor) - Method in class org.h2.command.dml.MergeUsing.WhenMatchedThenUpdate
 
collectDependencies(ExpressionVisitor) - Method in class org.h2.command.dml.MergeUsing.WhenNotMatched
 
collectGarbage() - Static method in class org.h2.util.Utils
Run Java memory garbage collection.
collectInsertedFinalRow(SessionLocal, Table, ResultTarget, DataChangeDeltaTable.ResultOption, Row) - Static method in class org.h2.table.DataChangeDeltaTable
Collects final row for INSERT operations.
collectPriority - Variable in class org.h2.mvstore.Chunk
The garbage collection priority.
collectUndoLogRootReferences() - Method in class org.h2.mvstore.tx.TransactionStore
Get the root references (snapshots) for undo-log maps.
COLON - Static variable in class org.h2.command.Token
The token ":".
COLON_COLON - Static variable in class org.h2.command.Token
The token "::".
COLON_EQ - Static variable in class org.h2.command.Token
The token ":=".
column - Variable in class org.h2.command.ddl.AlterSequence
 
column - Variable in class org.h2.command.ddl.SetComment
 
column - Variable in class org.h2.constraint.DomainColumnResolver
 
column - Variable in class org.h2.expression.ExpressionColumn
 
column - Variable in class org.h2.expression.Parameter
 
column - Variable in class org.h2.index.IndexCondition
 
column - Variable in class org.h2.mode.OnDuplicateKeyValues
 
column - Variable in class org.h2.table.IndexColumn
The column, or null if not set.
column(String) - Method in class org.h2.table.MetaTable
Creates a column with the specified name and character string data type.
column(String, TypeInfo) - Method in class org.h2.table.MetaTable
Creates a column with the specified name and data type.
Column - Class in org.h2.table
This class represents a column in a table.
Column(String, String, TypeInfo) - Constructor for class org.h2.result.SimpleResult.Column
 
Column(String, TypeInfo) - Constructor for class org.h2.table.Column
 
Column(String, TypeInfo, Table, int) - Constructor for class org.h2.table.Column
 
COLUMN - Static variable in class org.h2.bnf.context.DbContextRule
 
COLUMN_ALIAS - Static variable in class org.h2.bnf.context.DbContextRule
 
COLUMN_ALIAS_IS_NOT_SPECIFIED_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90156 is thrown when trying to create a view or a table from a select and some expression doesn't have a column name or alias when it is required by a compatibility mode.
COLUMN_CONTAINS_NULL_VALUES_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90081 is thrown when trying to alter a column to not allow NULL, if there is already data in the table where this column is NULL.
COLUMN_COUNT_DOES_NOT_MATCH - Static variable in class org.h2.api.ErrorCode
The error with code 21002 is thrown when the number of columns does not match.
COLUMN_IS_PART_OF_INDEX_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90075 is thrown when trying to alter a table and allow null for a column that is part of a primary key or hash index.
COLUMN_IS_REFERENCED_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90083 is thrown when trying to drop a column that is part of a constraint.
COLUMN_MUST_NOT_BE_NULLABLE_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90023 is thrown when trying to set a primary key on a nullable column or when trying to drop NOT NULL constraint on primary key or identity column.
COLUMN_NAMES - Static variable in class org.h2.engine.GeneratedKeysMode
Use specified column names to return generated keys from.
COLUMN_NO_NULLS - Static variable in class org.h2.jdbc.meta.DatabaseMetaLocal
 
COLUMN_NO_NULLS_SMALL - Static variable in class org.h2.jdbc.meta.DatabaseMetaLocal
 
COLUMN_NOT_FOUND_1 - Static variable in class org.h2.api.ErrorCode
The error with code 42122 is thrown when referencing an non-existing column.
COLUMN_NULLABLE - Static variable in class org.h2.jdbc.meta.DatabaseMetaLocal
 
COLUMN_NULLABLE_UNKNOWN_SMALL - Static variable in class org.h2.jdbc.meta.DatabaseMetaLocal
 
COLUMN_NUMBERS - Static variable in class org.h2.engine.GeneratedKeysMode
Use specified column indices to return generated keys from.
COLUMN_PRIVILEGES - Static variable in class org.h2.table.InformationSchemaTable
 
COLUMN_PRIVILEGES - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
columnCount - Variable in class org.h2.command.query.Select.LazyResultSelect
 
columnCount - Variable in class org.h2.command.query.SelectUnion.LazyResultUnion
 
columnCount - Variable in class org.h2.expression.condition.UniquePredicate.Target
 
columnCount - Variable in class org.h2.jdbc.JdbcResultSet
 
columnCount - Variable in class org.h2.jdbc.JdbcResultSetMetaData
 
columnCount - Variable in class org.h2.mvstore.db.RowDataType
 
columnCount - Variable in class org.h2.result.RowFactory.DefaultRowFactory
 
columnCount - Variable in class org.h2.result.Sparse
 
columnCount - Variable in class org.h2.result.UpdatableRow
 
columnId - Variable in class org.h2.mvstore.db.MVSpatialIndex.FindBoundsCursor
 
columnId - Variable in class org.h2.table.Column
 
columnIds - Variable in class org.h2.index.Index
Identities of table columns.
columnIfTableExists(Schema, String, String, boolean, boolean) - Method in class org.h2.command.Parser
 
columnIndexExpr - Variable in class org.h2.command.query.QueryOrderBy
The column index expression.
columnLabelMap - Variable in class org.h2.jdbc.JdbcResultSet
 
columnMap - Variable in class org.h2.table.GeneratedColumnResolver
 
columnMap - Variable in class org.h2.table.Table
 
columnName - Variable in class org.h2.command.ddl.SetComment
 
columnName - Variable in class org.h2.expression.ExpressionColumn
 
columnName - Variable in class org.h2.result.ResultColumn
The column name or null.
columnName - Variable in class org.h2.result.SimpleResult.Column
Column name.
columnName - Variable in class org.h2.table.IndexColumn
The column name.
columnNames - Variable in class org.h2.command.ddl.CreateView
 
columnNames - Variable in class org.h2.tools.Csv
 
columnPrivileges(SessionLocal, Value, Value, ArrayList<Row>, String) - Method in class org.h2.table.InformationSchemaTable
 
columnResolver - Variable in class org.h2.command.query.TableValueConstructor
 
columnResolver - Variable in class org.h2.expression.DomainValueExpression
 
columnResolver - Variable in class org.h2.expression.ExpressionColumn
 
ColumnResolver - Interface in org.h2.table
A column resolver is list of column (for example, a table) that can map a column name to an actual column.
columns - Variable in class org.h2.bnf.context.DbTableOrView
The column list.
columns - Variable in class org.h2.command.ddl.CreateTableData
The column list.
columns - Variable in class org.h2.command.dml.Insert
 
columns - Variable in class org.h2.command.dml.Merge
 
columns - Variable in class org.h2.command.dml.MergeUsing.WhenNotMatched
 
columns - Variable in class org.h2.command.dml.SetClauseList.RowExpression
 
columns - Variable in class org.h2.command.query.SelectListColumnResolver
 
columns - Variable in class org.h2.constraint.ConstraintReferential
 
columns - Variable in class org.h2.constraint.ConstraintUnique
 
columns - Variable in class org.h2.expression.function.table.ArrayTableFunction
 
columns - Variable in class org.h2.fulltext.FullTextLucene.FullTextTrigger
 
columns - Variable in class org.h2.fulltext.IndexInfo
The column names.
columns - Variable in class org.h2.index.Index
Table columns used in this index.
columns - Variable in class org.h2.result.MergedResult
 
columns - Variable in class org.h2.result.ResultRemote
 
columns - Variable in class org.h2.result.SimpleResult
 
columns - Variable in class org.h2.server.web.WebApp.IndexInfo
The indexed columns.
columns - Variable in class org.h2.table.GeneratedColumnResolver
 
columns - Variable in class org.h2.table.Table
The columns of this table.
columns - Variable in class org.h2.tools.SimpleResultSet
 
columns(SessionLocal, ArrayList<Row>, String, String, String, Table, String) - Method in class org.h2.table.InformationSchemaTable
 
columns(SessionLocal, ArrayList<Row>, String, String, String, Table, String, Column, int) - Method in class org.h2.table.InformationSchemaTable
 
columns(SessionLocal, Value, Value, ArrayList<Row>, String) - Method in class org.h2.table.InformationSchemaTable
 
COLUMNS - Static variable in class org.h2.table.InformationSchemaTable
 
COLUMNS - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
COLUMNS_QUERY_H2_197 - Static variable in class org.h2.bnf.context.DbSchema
 
COLUMNS_QUERY_H2_202 - Static variable in class org.h2.bnf.context.DbSchema
 
columns1 - Variable in class org.h2.expression.ExpressionVisitor
 
columnsToAdd - Variable in class org.h2.command.ddl.AlterTableAlterColumn
 
columnsToRemove - Variable in class org.h2.command.ddl.AlterTableAlterColumn
 
ColumnTemplate - Interface in org.h2.table
Column or domain.
columnTemplates - Variable in class org.h2.table.TableView
 
columnType - Variable in class org.h2.bnf.context.DbContextRule
 
columnType - Variable in class org.h2.result.ResultColumn
The column type.
columnType - Variable in class org.h2.result.SimpleResult.Column
Column type.
columnTypeMap - Variable in class org.h2.tools.Recover
 
columnTypes - Variable in class org.h2.fulltext.FullText.FullTextTrigger
 
columnTypes - Variable in class org.h2.fulltext.FullTextLucene.FullTextTrigger
 
columnTypes - Variable in class org.h2.result.RowFactory.DefaultRowFactory
 
combineBlob(Connection, int) - Static method in class org.h2.command.dml.ScriptCommand
Combine a BLOB.
combineClob(Connection, int) - Static method in class org.h2.command.dml.ScriptCommand
Combine a CLOB.
combineEntries(ArrayList<long[]>, int) - Method in class org.h2.tools.MultiDimension
Combine entries if the size of the list is too large.
combineTypes(TypeInfo, Expression) - Static method in class org.h2.expression.SimpleCase
 
comma - Variable in class org.h2.bnf.RuleRepeat
 
COMMA - Static variable in class org.h2.command.Token
The token ",".
command - Variable in class org.h2.command.CommandList
 
command - Variable in class org.h2.command.dml.Explain
 
command - Variable in class org.h2.command.Prepared
 
command - Variable in class org.h2.jdbc.JdbcPreparedStatement
 
command - Variable in class org.h2.jdbc.JdbcResultSet
 
Command - Class in org.h2.command
Represents a SQL statement.
Command(SessionLocal, String) - Constructor for class org.h2.command.Command
 
COMMAND - Static variable in class org.h2.message.Trace
The trace module id for commands.
COMMAND_CLOSE - Static variable in class org.h2.engine.SessionRemote
 
COMMAND_COMMIT - Static variable in class org.h2.engine.SessionRemote
 
COMMAND_EXECUTE_QUERY - Static variable in class org.h2.engine.SessionRemote
 
COMMAND_EXECUTE_UPDATE - Static variable in class org.h2.engine.SessionRemote
 
COMMAND_GET_META_DATA - Static variable in class org.h2.engine.SessionRemote
 
COMMAND_HISTORY - Static variable in class org.h2.server.web.WebServer
 
CommandContainer - Class in org.h2.command
Represents a single SQL statements.
CommandContainer(SessionLocal, String, Prepared) - Constructor for class org.h2.command.CommandContainer
 
CommandContainer.GeneratedKeysCollector - Class in org.h2.command
Collector of generated keys.
commandHistory - Variable in class org.h2.server.web.WebSession
 
commandHistoryString - Variable in class org.h2.server.web.WebServer
 
commandIfTableExists(Schema, String, boolean, Prepared) - Method in class org.h2.command.Parser
 
CommandInterface - Interface in org.h2.command
Represents a SQL statement.
CommandList - Class in org.h2.command
Represents a list of SQL statements.
CommandList(SessionLocal, String, CommandContainer, ArrayList<Prepared>, ArrayList<Parameter>, String) - Constructor for class org.h2.command.CommandList
 
CommandRemote - Class in org.h2.command
Represents the client-side part of a SQL statement.
CommandRemote(SessionRemote, ArrayList<Transfer>, String, int) - Constructor for class org.h2.command.CommandRemote
 
commands - Variable in class org.h2.command.CommandList
 
commandStartOrEnd - Variable in class org.h2.engine.SessionLocal
 
CommandWithColumns - Class in org.h2.command.ddl
 
CommandWithColumns(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.CommandWithColumns
 
CommandWithValues - Class in org.h2.command.dml
Command that supports VALUES clause.
CommandWithValues(SessionLocal) - Constructor for class org.h2.command.dml.CommandWithValues
Creates new instance of command with VALUES clause.
comment - Variable in class org.h2.command.ddl.AlterDomainAddConstraint
 
comment - Variable in class org.h2.command.ddl.AlterTableAddConstraint
 
comment - Variable in class org.h2.command.ddl.CreateDomain
 
comment - Variable in class org.h2.command.ddl.CreateIndex
 
comment - Variable in class org.h2.command.ddl.CreateLinkedTable
 
comment - Variable in class org.h2.command.ddl.CreateSynonym
 
comment - Variable in class org.h2.command.ddl.CreateTable
 
comment - Variable in class org.h2.command.ddl.CreateUser
 
comment - Variable in class org.h2.command.ddl.CreateView
 
comment - Variable in class org.h2.engine.DbObject
The comment (if set).
comment - Variable in class org.h2.table.Column
 
Comment - Class in org.h2.engine
Represents a database object comment.
Comment(Database, int, DbObject) - Constructor for class org.h2.engine.Comment
 
COMMENT - Static variable in interface org.h2.command.CommandInterface
The type of a COMMENT statement.
COMMENT - Static variable in class org.h2.engine.DbObject
This object is a comment.
comments - Variable in class org.h2.engine.Database
 
commentText - Variable in class org.h2.engine.Comment
 
commit - Variable in class org.h2.jdbc.JdbcConnection
 
commit - Variable in class org.h2.server.TcpServerThread
 
commit() - Method in class org.h2.fulltext.FullTextLucene.IndexAccess
Commit the changes.
commit() - Method in class org.h2.jdbc.JdbcConnection
Commits the current transaction.
commit() - Method in class org.h2.mvstore.db.MVTable
Mark the transaction as committed, so that the modification counter of the database is incremented.
commit() - Method in class org.h2.mvstore.MVStore
Commit the changes.
commit() - Method in class org.h2.mvstore.tx.Transaction
Commit the transaction.
commit(boolean) - Method in class org.h2.engine.SessionLocal
Commit the current transaction.
commit(Predicate<MVStore>) - Method in class org.h2.mvstore.MVStore
 
commit(Xid, boolean) - Method in class org.h2.jdbcx.JdbcXAConnection
Commit a transaction.
commit(Transaction, boolean) - Method in class org.h2.mvstore.tx.TransactionStore
Commit a transaction.
COMMIT - Static variable in interface org.h2.command.CommandInterface
The type of a COMMIT statement.
COMMIT - Static variable in interface org.h2.store.InDoubtTransaction
The transaction state meaning this transaction is committed.
COMMIT_MARKER - Static variable in class org.h2.mvstore.tx.Record
 
COMMIT_ROLLBACK_NOT_ALLOWED - Static variable in class org.h2.api.ErrorCode
The error with code 90058 is thrown when trying to call commit or rollback inside a trigger, or when trying to call a method inside a trigger that implicitly commits the current transaction, if an object is locked.
COMMIT_TRANSACTION - Static variable in interface org.h2.command.CommandInterface
The type of a COMMIT TRANSACTION statement.
CommitDecisionMaker<V> - Class in org.h2.mvstore.tx
Class CommitDecisionMaker makes a decision during post-commit processing about how to transform uncommitted map entry into committed one, based on undo log information.
CommitDecisionMaker() - Constructor for class org.h2.mvstore.tx.CommitDecisionMaker
 
commitIfNonTransactional() - Method in class org.h2.command.Command
 
commitIndex() - Method in class org.h2.fulltext.FullTextLucene.FullTextTrigger
Commit all changes to the Lucene index.
commitOrRollbackDisabled - Variable in class org.h2.engine.SessionLocal
 
CommittedIterator(TransactionMap<K, V>, K, K, boolean, boolean) - Constructor for class org.h2.mvstore.tx.TransactionMap.CommittedIterator
 
committedValue - Variable in class org.h2.mvstore.tx.VersionedValueUncommitted
 
committingTransactions - Variable in class org.h2.mvstore.tx.Snapshot
The committing transactions (see also TransactionStore.committingTransactions).
committingTransactions - Variable in class org.h2.mvstore.tx.TransactionMap.TMIterator
 
committingTransactions - Variable in class org.h2.mvstore.tx.TransactionStore
This is intended to be the source of ultimate truth about transaction being committed.
COMMON_CLASSES - Static variable in class org.h2.mvstore.type.ObjectDataType
 
COMMON_CLASSES_MAP - Static variable in class org.h2.mvstore.type.ObjectDataType.Holder
 
commonJoinColumns - Variable in class org.h2.table.TableFilter
Map of common join columns, used for NATURAL joins and USING clause of other joins.
commonJoinColumnsFilter - Variable in class org.h2.table.TableFilter
 
commonJoinColumnsToExclude - Variable in class org.h2.table.TableFilter
 
commonType - Variable in class org.h2.expression.function.MathFunction
 
compact(int, int) - Method in class org.h2.mvstore.MVStore
Try to increase the fill rate by re-writing partially full chunks.
compact(String, boolean) - Static method in class org.h2.mvstore.MVStoreTool
Compress the store by creating a new file and copying the live pages there.
compact(String, String, boolean) - Static method in class org.h2.mvstore.MVStoreTool
Copy all live pages from the source store to the target store.
compact(MVStore, MVStore) - Static method in class org.h2.mvstore.MVStoreTool
Copy all live pages from the source store to the target store.
compactCleanUp(String) - Static method in class org.h2.mvstore.MVStoreTool
Clean up if needed, in a case a compact operation was interrupted due to killing the process or a power failure.
compactFile(int) - Method in class org.h2.mvstore.db.Store
Compact the database file, that is, compact blocks that have a low fill rate, and move chunks next to each other.
compactFile(int) - Method in class org.h2.mvstore.MVStore
Compact store file, that is, compact blocks that have a low fill rate, and move chunks next to each other.
compactMode - Variable in class org.h2.engine.Database
 
compactMoveChunks() - Method in class org.h2.mvstore.MVStore
Compact by moving all chunks next to each other.
compactMoveChunks(int, long) - Method in class org.h2.mvstore.MVStore
Compact the store by moving all chunks next to each other, if there is free space between chunks.
compactMoveChunks(long) - Method in class org.h2.mvstore.MVStore
 
compactMoveChunks(Iterable<Chunk>) - Method in class org.h2.mvstore.MVStore
 
compactRewrite(Set<Integer>) - Method in class org.h2.mvstore.MVStore
 
Comparator(DataType<SearchRow>) - Constructor for class org.h2.mvstore.db.MVSecondaryIndex.Source.Comparator
 
COMPARATOR - Static variable in class org.h2.value.CharsetCollator
The comparator used to compare byte arrays.
compare(char[], String, int, int) - Method in class org.h2.expression.condition.CompareLike
 
compare(long[], long[]) - Method in class org.h2.tools.MultiDimension
 
compare(Boolean, Boolean) - Method in class org.h2.mvstore.type.ObjectDataType.BooleanType
 
compare(Byte, Byte) - Method in class org.h2.mvstore.type.ObjectDataType.ByteType
 
compare(Character, Character) - Method in class org.h2.mvstore.type.ObjectDataType.CharacterType
 
compare(Double, Double) - Method in class org.h2.mvstore.type.ObjectDataType.DoubleType
 
compare(Float, Float) - Method in class org.h2.mvstore.type.ObjectDataType.FloatType
 
compare(Integer, Integer) - Method in class org.h2.mvstore.type.ObjectDataType.IntegerType
 
compare(Long, Long) - Method in class org.h2.mvstore.type.LongDataType
 
compare(Long, Long) - Method in class org.h2.mvstore.type.ObjectDataType.LongType
 
compare(Object, Object) - Method in class org.h2.mvstore.type.ObjectDataType
 
compare(Object, Object) - Method in class org.h2.mvstore.type.ObjectDataType.NullType
 
compare(Object, Object) - Method in class org.h2.mvstore.type.ObjectDataType.ObjectArrayType
 
compare(Object, Object) - Method in class org.h2.mvstore.type.ObjectDataType.SerializedObjectType
 
compare(Short, Short) - Method in class org.h2.mvstore.type.ObjectDataType.ShortType
 
compare(String, String) - Method in class org.h2.mvstore.type.ObjectDataType.StringType
 
compare(String, String) - Method in class org.h2.mvstore.type.StringDataType
 
compare(String, String) - Method in class org.h2.value.CharsetCollator
 
compare(BigDecimal, BigDecimal) - Method in class org.h2.mvstore.type.ObjectDataType.BigDecimalType
 
compare(BigInteger, BigInteger) - Method in class org.h2.mvstore.type.ObjectDataType.BigIntegerType
 
compare(Date, Date) - Method in class org.h2.mvstore.type.ObjectDataType.DateType
 
compare(UUID, UUID) - Method in class org.h2.mvstore.type.ObjectDataType.UUIDType
 
compare(K, K) - Method in class org.h2.mvstore.MVMap
Compare two keys.
compare(SessionLocal, Value, Value, int) - Static method in class org.h2.expression.condition.Comparison
Compare two values.
compare(Chunk, Chunk) - Method in class org.h2.mvstore.Chunk.PositionComparator
 
compare(LobStorageMap.BlobReference, LobStorageMap.BlobReference) - Method in class org.h2.mvstore.db.LobStorageMap.BlobReference.Type
 
compare(MVSecondaryIndex.Source, MVSecondaryIndex.Source) - Method in class org.h2.mvstore.db.MVSecondaryIndex.Source.Comparator
 
compare(Spatial, Spatial) - Method in class org.h2.mvstore.rtree.SpatialDataType
 
compare(Record<K, V>, Record<K, V>) - Method in class org.h2.mvstore.tx.Record.Type
 
compare(DataType<?>, DataType<?>) - Method in class org.h2.mvstore.type.MetaType
 
compare(SearchRow, SearchRow) - Method in class org.h2.mvstore.db.RowDataType
 
compare(SearchRow, SearchRow) - Method in class org.h2.mvstore.db.ValueDataType
 
compare(Value[], Value[]) - Method in class org.h2.result.SortOrder
Compare two expression lists.
compare(ValueBlob, ValueBlob) - Static method in class org.h2.value.ValueBlob
Compares two BLOB values directly.
compare(ValueClob, ValueClob) - Static method in class org.h2.value.ValueClob
Compares two CLOB values directly.
compare(Value, Value) - Method in class org.h2.engine.SessionLocal
Compare two values with the current comparison mode.
compare(Value, Value) - Method in class org.h2.mvstore.db.NullValueDataType
 
compare(Value, Value) - Method in class org.h2.mvstore.db.ValueDataType
 
compare(Value, Value) - Method in class org.h2.value.CompareMode
 
compare(VersionedValue<T>, VersionedValue<T>) - Method in class org.h2.mvstore.tx.VersionedValueType
 
compare(T, T) - Method in class org.h2.mvstore.type.BasicDataType
 
compare(T, T) - Method in interface org.h2.mvstore.type.DataType
Compare two keys.
COMPARE_BY_COST - Static variable in class org.h2.expression.condition.ConditionAndOrN
 
COMPARE_TYPES - Static variable in class org.h2.expression.condition.Comparison
 
compareAndSetRoot(RootReference<K, V>, RootReference<K, V>) - Method in class org.h2.mvstore.MVMap
Compare and set the root reference.
compareAt(String, int, int, int, char[], int[]) - Method in class org.h2.expression.condition.CompareLike
 
CompareLike - Class in org.h2.expression.condition
Pattern matching comparison expression: WHERE NAME LIKE ?
CompareLike(Database, Expression, boolean, boolean, Expression, Expression, CompareLike.LikeType) - Constructor for class org.h2.expression.condition.CompareLike
 
CompareLike(CompareMode, String, Expression, boolean, boolean, Expression, Expression, CompareLike.LikeType) - Constructor for class org.h2.expression.condition.CompareLike
 
CompareLike.LikeType - Enum in org.h2.expression.condition
The type of comparison.
compareLocaleNames(Locale, String) - Static method in class org.h2.value.CompareMode
Compare name of the locale with the given name.
compareMode - Variable in class org.h2.engine.Database
 
compareMode - Variable in class org.h2.engine.SessionRemote
 
compareMode - Variable in class org.h2.expression.condition.CompareLike
 
compareMode - Variable in class org.h2.mvstore.db.ValueDataType
 
compareMode - Variable in class org.h2.table.Table
The compare mode used for this table.
CompareMode - Class in org.h2.value
Instances of this class can compare strings.
CompareMode(String, int) - Constructor for class org.h2.value.CompareMode
 
CompareModeDefault - Class in org.h2.value
The default implementation of CompareMode.
CompareModeDefault(String, int) - Constructor for class org.h2.value.CompareModeDefault
 
CompareModeIcu4J - Class in org.h2.value
An implementation of CompareMode that uses the ICU4J Collator.
CompareModeIcu4J(String, int) - Constructor for class org.h2.value.CompareModeIcu4J
 
compareNotNull(byte[], byte[]) - Static method in class org.h2.mvstore.type.ObjectDataType
Compare the contents of two byte arrays.
compareNotNull(char[], char[]) - Static method in class org.h2.util.Bits
Compare the contents of two char arrays.
compareNotNullSigned(byte[], byte[]) - Static method in class org.h2.util.Bits
Compare the contents of two byte arrays.
compareNotNullUnsigned(byte[], byte[]) - Static method in class org.h2.util.Bits
Compare the contents of two byte arrays.
compareNull(boolean, int) - Method in enum org.h2.mode.DefaultNullOrdering
Compare two expressions where one of them is NULL.
compareRows(SearchRow, SearchRow) - Method in class org.h2.index.Index
Compare two rows.
compareSearchRows(SearchRow, SearchRow) - Method in class org.h2.mvstore.db.RowDataType
 
compareSecure(byte[], byte[]) - Static method in class org.h2.util.Utils
Compare two byte arrays.
compareString(String, String, boolean) - Method in class org.h2.value.CompareMode
Compare two strings.
compareString(String, String, boolean) - Method in class org.h2.value.CompareModeDefault
 
compareString(String, String, boolean) - Method in class org.h2.value.CompareModeIcu4J
 
compareTo(CollationKey) - Method in class org.h2.value.CharsetCollator.CharsetCollationKey
 
compareTo(Constraint) - Method in class org.h2.constraint.Constraint
 
compareTo(MetaRecord) - Method in class org.h2.engine.MetaRecord
Sort the list of meta records by 'create order'.
compareTo(LobStorageMap.BlobReference) - Method in class org.h2.mvstore.db.LobStorageMap.BlobReference
 
compareTo(MVStore.RemovedPageInfo) - Method in class org.h2.mvstore.MVStore.RemovedPageInfo
 
compareTo(FunctionAlias.JavaMethod) - Method in class org.h2.schema.FunctionAlias.JavaMethod
 
compareTo(ConnectionInfo) - Method in class org.h2.server.web.ConnectionInfo
 
compareTo(ConvertTraceFile.Stat) - Method in class org.h2.tools.ConvertTraceFile.Stat
 
compareTo(CacheObject) - Method in class org.h2.util.CacheObject
 
compareTo(Value, CastDataProvider, CompareMode) - Method in class org.h2.value.Value
Compare this value against another value using the specified compare mode.
compareToNotNullable(Value, CastDataProvider, CompareMode) - Method in class org.h2.value.Value
 
compareType - Variable in class org.h2.expression.condition.Comparison
 
compareType - Variable in class org.h2.expression.condition.ConditionInQuery
 
compareType - Variable in class org.h2.index.IndexCondition
see constants in Comparison
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.mvstore.db.SpatialKey
 
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.result.SearchRow
 
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.value.Value
Compare this value against another value given that the values are of the same data type.
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.value.ValueArray
 
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.value.ValueBigint
 
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.value.ValueBlob
 
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.value.ValueBoolean
 
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.value.ValueBytesBase
 
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.value.ValueChar
 
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.value.ValueClob
 
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.value.ValueDate
 
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.value.ValueDecfloat
 
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.value.ValueDouble
 
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.value.ValueEnumBase
 
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.value.ValueInteger
 
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.value.ValueInterval
 
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.value.ValueNull
 
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.value.ValueNumeric
 
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.value.ValueReal
 
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.value.ValueRow
 
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.value.ValueSmallint
 
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.value.ValueStringBase
 
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.value.ValueTime
 
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.value.ValueTimestamp
 
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.value.ValueTimestampTimeZone
 
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.value.ValueTimeTimeZone
 
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.value.ValueTinyint
 
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.value.ValueUuid
 
compareTypeSafe(Value, CompareMode, CastDataProvider) - Method in class org.h2.value.ValueVarcharIgnoreCase
 
compareTypeSafe(Value, Value) - Method in class org.h2.engine.SessionLocal
Compare two values with the current comparison mode.
compareTypeToString(StringBuilder, int) - Static method in class org.h2.index.IndexCondition
 
compareValues(CastDataProvider, Value, Value) - Method in class org.h2.table.Table
Compare two values with the current comparison mode.
compareValues(Value, Value, int) - Method in class org.h2.index.Index
 
compareValues(Value, Value, int) - Method in class org.h2.mvstore.db.ValueDataType
Compares the specified values.
compareWithNull(Value, boolean, CastDataProvider, CompareMode) - Method in class org.h2.value.Value
Compare this value against another value using the specified compare mode.
compareWithNull(Value, boolean, CastDataProvider, CompareMode) - Method in class org.h2.value.ValueCollectionBase
 
compareWithNull(Value, Value, boolean) - Method in class org.h2.engine.SessionLocal
Compare two values with the current comparison mode.
Comparison - Class in org.h2.expression.condition
Example comparison expressions are ID=1, NAME=NAME, NAME IS NULL.
Comparison(int, Expression, Expression, boolean) - Constructor for class org.h2.expression.condition.Comparison
 
compatibility - Variable in class org.h2.bnf.RuleExtension
 
CompatibilityDatePlusTimeOperation - Class in org.h2.expression
A compatibility mathematical operation with datetime values.
CompatibilityDatePlusTimeOperation(Expression, Expression) - Constructor for class org.h2.expression.CompatibilityDatePlusTimeOperation
 
CompatibilitySequenceValueFunction - Class in org.h2.expression.function
NEXTVAL() and CURRVAL() compatibility functions.
CompatibilitySequenceValueFunction(Expression, Expression, boolean) - Constructor for class org.h2.expression.function.CompatibilitySequenceValueFunction
 
COMPILE_DIR - Static variable in class org.h2.util.SourceCompiler
 
compiled - Variable in class org.h2.util.SourceCompiler
The class name to byte code map.
compiledScripts - Variable in class org.h2.util.SourceCompiler
The class name to compiled scripts map.
compiler - Variable in class org.h2.engine.Database
 
compileViewQuery(SessionLocal, String, boolean) - Method in class org.h2.table.TableView
 
complete - Variable in class org.h2.mvstore.Page.IncompleteNonLeaf
 
complete(Future<T>) - Static method in class org.h2.store.fs.async.FileAsync
 
completeWrite(Value) - Method in class org.h2.jdbc.JdbcLob
Change the state LOB state (LOB value is set completely and available to read).
complexIterator(ArrayList<Value[]>, SortOrder, int, int, int, boolean) - Method in class org.h2.expression.analysis.WindowFrame
 
componentType - Variable in class org.h2.expression.ArrayConstructorByQuery
 
componentType - Variable in class org.h2.value.ValueArray
 
composeState(int, long, boolean) - Static method in class org.h2.mvstore.tx.Transaction
 
compress - Variable in class org.h2.compress.LZFOutputStream
 
compress - Variable in class org.h2.store.FileStoreInputStream
 
compress - Variable in class org.h2.store.FileStoreOutputStream
 
compress - Variable in class org.h2.store.fs.mem.FileMemData
 
compress - Variable in class org.h2.store.fs.niomem.FileNioMemData
 
compress() - Method in class org.h2.mvstore.MVStore.Builder
Compress data before writing using the LZF algorithm.
compress(byte[], int, int, byte[], int) - Method in class org.h2.compress.CompressDeflate
 
compress(byte[], int, int, byte[], int) - Method in class org.h2.compress.CompressLZF
 
compress(byte[], int, int, byte[], int) - Method in class org.h2.compress.CompressNo
 
compress(byte[], int, int, byte[], int) - Method in interface org.h2.compress.Compressor
Compress a number of bytes.
compress(byte[], int, Compressor, byte[]) - Static method in class org.h2.tools.CompressTool
 
compress(byte[], String) - Method in class org.h2.tools.CompressTool
Compressed the data using the specified algorithm.
compress(int) - Method in class org.h2.store.fs.mem.FileMemData
Compress the data in a byte array.
compress(ByteBuffer, int, byte[], int) - Method in class org.h2.compress.CompressLZF
Compress a number of bytes.
COMPRESS - Static variable in class org.h2.expression.function.CompressFunction
COMPRESS() (non-standard).
COMPRESS_LATER - Static variable in class org.h2.store.fs.mem.FileMemData
 
COMPRESS_OUT_BUF_THREAD_LOCAL - Static variable in class org.h2.store.fs.niomem.FileNioMemData
the output buffer when compressing
compressAndWrite(byte[], int) - Method in class org.h2.compress.LZFOutputStream
 
compressData - Variable in class org.h2.engine.DbSettings
Database setting COMPRESS (default: false).
CompressDeflate - Class in org.h2.compress
This is a wrapper class for the Deflater class.
CompressDeflate() - Constructor for class org.h2.compress.CompressDeflate
 
compressed() - Method in class org.h2.store.fs.mem.FilePathMem
Whether the file should be compressed.
compressed() - Method in class org.h2.store.fs.mem.FilePathMemLZF
 
compressed() - Method in class org.h2.store.fs.niomem.FilePathNioMem
Whether the file should be compressed.
compressed() - Method in class org.h2.store.fs.niomem.FilePathNioMemLZF
 
COMPRESSED_EMPTY_BLOCK - Static variable in class org.h2.store.fs.mem.FileMemData
 
COMPRESSED_EMPTY_BLOCK - Static variable in class org.h2.store.fs.niomem.FileNioMemData
 
COMPRESSED_VAR_INT_MAX - Static variable in class org.h2.mvstore.DataUtils
The maximum integer that needs less space when using variable size encoding (only 3 bytes instead of 4).
COMPRESSED_VAR_LONG_MAX - Static variable in class org.h2.mvstore.DataUtils
The maximum long that needs less space when using variable size encoding (only 7 bytes instead of 8).
CompressFunction - Class in org.h2.expression.function
A COMPRESS or EXPAND function.
CompressFunction(Expression, Expression, int) - Constructor for class org.h2.expression.function.CompressFunction
 
compressHigh() - Method in class org.h2.mvstore.MVStore.Builder
Compress data before writing using the Deflate algorithm.
COMPRESSION_ERROR - Static variable in class org.h2.api.ErrorCode
The error with code 90104 is thrown when the data can not be de-compressed.
compressionAlgorithm - Variable in class org.h2.command.dml.ScriptBase
 
compressionAlgorithm - Variable in class org.h2.store.FileStoreOutputStream
 
compressionLevel - Variable in class org.h2.mvstore.MVStore
The compression level for new pages (0 for disabled, 1 for fast, 2 for high).
CompressItem() - Constructor for class org.h2.store.fs.mem.FileMemData.CompressItem
 
CompressItem(FileNioMemData, int) - Constructor for class org.h2.store.fs.niomem.FileNioMemData.CompressItem
 
compressLater(int) - Method in class org.h2.store.fs.mem.FileMemData
 
compressLaterCache - Variable in class org.h2.store.fs.niomem.FileNioMemData
 
CompressLaterCache(int) - Constructor for class org.h2.store.fs.niomem.FileNioMemData.CompressLaterCache
 
compressLaterCachePercent - Variable in class org.h2.store.fs.niomem.FileNioMemData
 
compressLaterCachePercent - Variable in class org.h2.store.fs.niomem.FilePathNioMem
The percentage of uncompressed (cached) entries.
CompressLZF - Class in org.h2.compress
This class implements the LZF lossless data compression algorithm.
CompressLZF() - Constructor for class org.h2.compress.CompressLZF
 
CompressNo - Class in org.h2.compress
This class implements a data compression algorithm that does in fact not compress.
CompressNo() - Constructor for class org.h2.compress.CompressNo
 
Compressor - Interface in org.h2.compress
Each data compression algorithm must implement this interface.
compressorFast - Variable in class org.h2.mvstore.MVStore
 
compressorHigh - Variable in class org.h2.mvstore.MVStore
 
compressPage(int) - Method in class org.h2.store.fs.niomem.FileNioMemData
Compress the data in a byte array.
CompressTool - Class in org.h2.tools
A tool to losslessly compress data, and expand the compressed data again.
CompressTool() - Constructor for class org.h2.tools.CompressTool
 
CONCAT - Static variable in class org.h2.bnf.RuleFixed
 
CONCAT - Static variable in class org.h2.expression.function.ConcatFunction
CONCAT() (non-standard).
CONCAT_WS - Static variable in class org.h2.expression.function.ConcatFunction
CONCAT_WS() (non-standard).
CONCATENATION - Static variable in class org.h2.command.Token
The token "||".
ConcatenationOperation - Class in org.h2.expression
Character string concatenation as in 'Hello' || 'World', binary string concatenation as in X'01' || X'AB' or an array concatenation as in ARRAY[1, 2] || 3.
ConcatenationOperation() - Constructor for class org.h2.expression.ConcatenationOperation
 
ConcatenationOperation(Expression, Expression) - Constructor for class org.h2.expression.ConcatenationOperation
 
ConcatFunction - Class in org.h2.expression.function
A CONCAT or CONCAT_WS function.
ConcatFunction(int) - Constructor for class org.h2.expression.function.ConcatFunction
 
ConcatFunction(int, Expression...) - Constructor for class org.h2.expression.function.ConcatFunction
 
CONCURRENT_UPDATE_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90131 is thrown when using multi version concurrency control, and trying to update the same row from within two connections at the same time, or trying to insert two rows with the same key from two connections.
condition - Variable in class org.h2.command.dml.FilteredDataChangeStatement
The WHERE criteria.
condition - Variable in class org.h2.command.query.Optimizer
 
condition - Variable in class org.h2.command.query.Select
WHERE condition.
condition - Variable in class org.h2.expression.condition.ConditionNot
 
Condition - Class in org.h2.expression.condition
Represents a condition returning a boolean value, or NULL.
Condition() - Constructor for class org.h2.expression.condition.Condition
 
ConditionAndOr - Class in org.h2.expression.condition
An 'and' or 'or' condition as in WHERE ID=1 AND NAME=?
ConditionAndOr(int, Expression, Expression) - Constructor for class org.h2.expression.condition.ConditionAndOr
 
ConditionAndOrN - Class in org.h2.expression.condition
An 'and' or 'or' condition as in WHERE ID=1 AND NAME=? with N operands.
ConditionAndOrN(int, List<Expression>) - Constructor for class org.h2.expression.condition.ConditionAndOrN
 
ConditionAndOrN(int, Expression, Expression, Expression) - Constructor for class org.h2.expression.condition.ConditionAndOrN
 
ConditionIn - Class in org.h2.expression.condition
An 'in' condition with a list of values, as in WHERE NAME IN(...)
ConditionIn(Expression, boolean, boolean, ArrayList<Expression>) - Constructor for class org.h2.expression.condition.ConditionIn
Create a new IN(..) condition.
ConditionInConstantSet - Class in org.h2.expression.condition
Used for optimised IN(...) queries where the contents of the IN list are all constant and of the same type.
ConditionInConstantSet(SessionLocal, Expression, boolean, boolean, ArrayList<Expression>) - Constructor for class org.h2.expression.condition.ConditionInConstantSet
Create a new IN(..) condition.
ConditionInParameter - Class in org.h2.expression.condition
A condition with parameter as = ANY(?).
ConditionInParameter(Expression, boolean, boolean, Parameter) - Constructor for class org.h2.expression.condition.ConditionInParameter
Create a new = ANY(?) condition.
ConditionInParameter.ParameterList - Class in org.h2.expression.condition
 
ConditionInQuery - Class in org.h2.expression.condition
An IN() condition with a subquery, as in WHERE ID IN(SELECT ...)
ConditionInQuery(Expression, boolean, boolean, Query, boolean, int) - Constructor for class org.h2.expression.condition.ConditionInQuery
 
ConditionLocalAndGlobal - Class in org.h2.expression.condition
A global condition or combination of local and global conditions.
ConditionLocalAndGlobal(Expression, Expression) - Constructor for class org.h2.expression.condition.ConditionLocalAndGlobal
 
ConditionNot - Class in org.h2.expression.condition
A NOT condition.
ConditionNot(Expression) - Constructor for class org.h2.expression.condition.ConditionNot
 
conditions - Variable in class org.h2.command.dml.Help
 
config - Variable in class org.h2.mvstore.MVStore.Builder
 
Config() - Constructor for class org.h2.mvstore.cache.CacheLongKeyLIRS.Config
 
ConfigParam(String) - Constructor for enum org.h2.mode.ToDateParser.ConfigParam
 
ConfigProperties - Class in org.h2.security.auth
wrapper for configuration properties
ConfigProperties() - Constructor for class org.h2.security.auth.ConfigProperties
 
ConfigProperties(Collection<PropertyConfig>) - Constructor for class org.h2.security.auth.ConfigProperties
 
ConfigProperties(PropertyConfig...) - Constructor for class org.h2.security.auth.ConfigProperties
 
Configurable - Interface in org.h2.security.auth
describe how to perform objects runtime configuration
configure(ConfigProperties) - Method in interface org.h2.security.auth.Configurable
configure the component
configure(ConfigProperties) - Method in class org.h2.security.auth.impl.AssignRealmNameRole
 
configure(ConfigProperties) - Method in class org.h2.security.auth.impl.JaasCredentialsValidator
 
configure(ConfigProperties) - Method in class org.h2.security.auth.impl.LdapCredentialsValidator
 
configure(ConfigProperties) - Method in class org.h2.security.auth.impl.StaticRolesMapper
 
configure(ConfigProperties) - Method in class org.h2.security.auth.impl.StaticUserCredentialsValidator
 
configureFrom(H2AuthConfig) - Method in class org.h2.security.auth.DefaultAuthenticator
 
configureFromUrl(URL) - Method in class org.h2.security.auth.DefaultAuthenticator
Configure the authenticator from a configuration file
conn - Variable in class org.h2.jdbc.JdbcArray
 
conn - Variable in class org.h2.jdbc.JdbcDatabaseMetaData
 
conn - Variable in class org.h2.jdbc.JdbcLob
JDBC connection.
conn - Variable in class org.h2.jdbc.JdbcResultSet
 
conn - Variable in class org.h2.jdbc.JdbcSavepoint
 
conn - Variable in class org.h2.jdbc.JdbcStatement
 
conn - Variable in class org.h2.result.UpdatableRow
 
conn - Variable in class org.h2.server.web.DbStarter
 
conn - Variable in class org.h2.server.web.JakartaDbStarter
 
conn - Variable in class org.h2.server.web.WebSession
 
conn - Variable in class org.h2.table.TableLink
 
conn - Variable in class org.h2.table.TableLinkConnection
The database connection.
conn - Variable in class org.h2.tools.Shell
 
CONN_URL_COLUMNLIST - Static variable in class org.h2.engine.Constants
The database URL used when calling a function if only the column list should be returned.
CONN_URL_INTERNAL - Static variable in class org.h2.engine.Constants
The database URL used when calling a function if the data should be returned.
connect() - Method in class org.h2.table.TableLink
 
connect() - Method in class org.h2.tools.Shell
 
connect(String, Properties) - Method in class org.h2.Driver
Open a database connection.
connectEmbeddedOrServer(boolean) - Method in class org.h2.engine.SessionRemote
Open a new (remote or embedded) session.
connectException - Variable in class org.h2.table.TableLink
 
connectH2(String, String, String) - Method in class org.h2.tools.Shell
 
CONNECTION - Static variable in class org.h2.message.TraceObject
The trace type id for connections.
CONNECTION_BROKEN_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90067 is thrown when the client could not connect to the database, or if the connection was lost.
connectionClosed(ConnectionEvent) - Method in class org.h2.jdbcx.JdbcConnectionPool
INTERNAL
connectionErrorOccurred(ConnectionEvent) - Method in class org.h2.jdbcx.JdbcConnectionPool
INTERNAL
connectionInfo - Variable in class org.h2.engine.SessionRemote
 
connectionInfo - Variable in class org.h2.security.auth.AuthenticationInfo
 
ConnectionInfo - Class in org.h2.engine
Encapsulates the connection settings, including user name and password.
ConnectionInfo - Class in org.h2.server.web
The connection info object is a wrapper for database connection information such as the database URL, user name and password.
ConnectionInfo() - Constructor for class org.h2.server.web.ConnectionInfo
 
ConnectionInfo(String) - Constructor for class org.h2.engine.ConnectionInfo
Create a connection info object.
ConnectionInfo(String) - Constructor for class org.h2.server.web.ConnectionInfo
 
ConnectionInfo(String, Properties, String, Object) - Constructor for class org.h2.engine.ConnectionInfo
Create a connection info object.
connectServer(ConnectionInfo) - Method in class org.h2.engine.SessionRemote
 
connInfoMap - Variable in class org.h2.server.web.WebServer
 
Console - Class in org.h2.tools
Starts the H2 Console (web-) server, as well as the TCP and PG server.
Console() - Constructor for class org.h2.tools.Console
 
CONSOLE_MAX_PROCEDURES_LIST_COLUMNS - Static variable in class org.h2.engine.SysProperties
System property h2.consoleProcedureColumns (default: 500).
CONSOLE_MAX_TABLES_LIST_COLUMNS - Static variable in class org.h2.engine.SysProperties
System property h2.consoleTableColumns (default: 500).
CONSOLE_MAX_TABLES_LIST_INDEXES - Static variable in class org.h2.engine.SysProperties
System property h2.consoleTableIndexes (default: 100).
CONSOLE_STREAM - Static variable in class org.h2.engine.SysProperties
System property h2.consoleStream (default: true).
CONSOLE_TIMEOUT - Static variable in class org.h2.engine.SysProperties
System property h2.consoleTimeout (default: 1800000).
Constant - Class in org.h2.schema
A user-defined constant as created by the SQL statement CREATE CONSTANT
Constant(Schema, int, String) - Constructor for class org.h2.schema.Constant
 
CONSTANT - Static variable in class org.h2.engine.DbObject
This object is a constant.
CONSTANT_ALREADY_EXISTS_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90114 is thrown when trying to create a constant if a constant with this name already exists.
CONSTANT_NOT_FOUND_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90115 is thrown when trying to drop a constant that does not exists.
constantName - Variable in class org.h2.command.ddl.CreateConstant
 
constantName - Variable in class org.h2.command.ddl.DropConstant
 
constants - Variable in class org.h2.schema.Schema
 
constants(SessionLocal, ArrayList<Row>, String, String, String, Constant, String) - Method in class org.h2.table.InformationSchemaTable
 
constants(SessionLocal, Value, Value, ArrayList<Row>, String) - Method in class org.h2.table.InformationSchemaTable
 
Constants - Class in org.h2.engine
Constants are fixed values that are used in the whole database code.
Constants() - Constructor for class org.h2.engine.Constants
 
CONSTANTS - Static variable in class org.h2.table.InformationSchemaTable
 
CONSTANTS - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
Constraint - Class in org.h2.constraint
The base class for constraint checking.
Constraint(Schema, int, String, Table) - Constructor for class org.h2.constraint.Constraint
 
CONSTRAINT - Static variable in class org.h2.engine.DbObject
This object is a constraint (check constraint, unique constraint, or referential constraint).
CONSTRAINT - Static variable in class org.h2.message.Trace
The trace module id for constraints.
CONSTRAINT - Static variable in class org.h2.util.ParserUtil
The token "CONSTRAINT".
CONSTRAINT_ALREADY_EXISTS_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90045 is thrown when trying to create a constraint if an object with this name already exists.
CONSTRAINT_COLUMN_USAGE - Static variable in class org.h2.table.InformationSchemaTable
 
CONSTRAINT_COLUMN_USAGE - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
CONSTRAINT_IS_USED_BY_CONSTRAINT_2 - Static variable in class org.h2.api.ErrorCode
The error with code 90152 is thrown when trying to manually drop a unique or primary key constraint that is referenced by a foreign key constraint without a CASCADE clause.
CONSTRAINT_NOT_FOUND_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90057 is thrown when trying to drop a constraint that does not exist.
Constraint.Type - Enum in org.h2.constraint
 
ConstraintActionType - Enum in org.h2.constraint
 
ConstraintActionType() - Constructor for enum org.h2.constraint.ConstraintActionType
 
ConstraintCheck - Class in org.h2.constraint
A check constraint.
ConstraintCheck(Schema, int, String, Table) - Constructor for class org.h2.constraint.ConstraintCheck
 
constraintColumnUsage(SessionLocal, Value, Value, ArrayList<Row>, String) - Method in class org.h2.table.InformationSchemaTable
 
constraintColumnUsage(SessionLocal, Value, Value, ArrayList<Row>, String, Constraint) - Method in class org.h2.table.InformationSchemaTable
 
constraintCommands - Variable in class org.h2.command.ddl.CommandWithColumns
 
constraintCommands - Variable in class org.h2.command.ddl.CreateDomain
 
ConstraintDomain - Class in org.h2.constraint
A domain constraint.
ConstraintDomain(Schema, int, String, Domain) - Constructor for class org.h2.constraint.ConstraintDomain
 
ConstraintDomain.CheckExistingData - Class in org.h2.constraint
 
constraintName - Variable in class org.h2.command.ddl.AlterDomainAddConstraint
 
constraintName - Variable in class org.h2.command.ddl.AlterDomainDropConstraint
 
constraintName - Variable in class org.h2.command.ddl.AlterDomainRenameConstraint
 
constraintName - Variable in class org.h2.command.ddl.AlterTableAddConstraint
 
constraintName - Variable in class org.h2.command.ddl.AlterTableDropConstraint
 
constraintName - Variable in class org.h2.command.ddl.AlterTableRenameConstraint
 
ConstraintReferential - Class in org.h2.constraint
A referential constraint.
ConstraintReferential(Schema, int, String, Table) - Constructor for class org.h2.constraint.ConstraintReferential
 
constraints - Variable in class org.h2.schema.Domain
 
constraints - Variable in class org.h2.schema.Schema
 
constraints - Variable in class org.h2.table.Table
 
CONSTRAINTS - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
CONSTRAINTS_COMPARATOR - Static variable in class org.h2.engine.MetaRecord
Comparator for prepared constraints, sorts unique and primary key constraints first.
ConstraintUnique - Class in org.h2.constraint
A unique constraint.
ConstraintUnique(Schema, int, String, Table, boolean) - Constructor for class org.h2.constraint.ConstraintUnique
 
constructEmptyPageRefs(int) - Static method in class org.h2.mvstore.Page.IncompleteNonLeaf
 
constructGroupResultRow(Value[], int) - Method in class org.h2.command.query.Select
 
constructStatsData(long, long, int, int) - Static method in class org.h2.util.MemoryEstimator
 
contains(Object, Object) - Method in class org.h2.mvstore.rtree.SpatialDataType
Check whether a contains b.
contains(Page<Spatial, V>, int, Object) - Method in class org.h2.mvstore.rtree.MVRTreeMap
 
contains(Value[]) - Method in class org.h2.mvstore.db.MVPlainTempResult
 
contains(Value[]) - Method in class org.h2.mvstore.db.MVSortedTempResult
 
contains(Value[]) - Method in interface org.h2.result.ResultExternal
Check if the given row exists in this object.
containsAggregate(Expression) - Static method in class org.h2.command.query.Select
 
containsAt(String, int, String...) - Static method in class org.h2.expression.function.ToCharFunction
Returns a capitalization strategy if the specified string contains any of the specified substrings at the specified index.
containsDistinct(Value[]) - Method in class org.h2.result.LocalResult
Check if this result set contains the given row.
containsIgnoreCase(String, String) - Static method in class org.h2.expression.condition.CompareLike
 
containsKey(long) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Check whether there is a resident entry for the given key.
containsKey(Object) - Method in class org.h2.mvstore.MVMap
 
containsKey(Object) - Method in class org.h2.mvstore.tx.TransactionMap
Whether the map contains the key.
containsKey(Object) - Method in class org.h2.value.CaseInsensitiveConcurrentMap
 
containsKey(Object) - Method in class org.h2.value.CaseInsensitiveMap
 
containsKey(String) - Method in class org.h2.engine.SettingsBase
Check if the settings contains the given key.
containsLargeObject - Variable in class org.h2.mvstore.db.MVTable
Whether the table contains a CLOB or BLOB.
containsLobs - Variable in class org.h2.result.LocalResult
 
containsNull - Variable in class org.h2.result.LocalResult
 
containsNull() - Method in class org.h2.result.LocalResult
Check if this result set contains a NULL value.
containsNull() - Method in class org.h2.value.Value
Returns true if this value is NULL or contains NULL value.
containsNull() - Method in class org.h2.value.ValueCollectionBase
 
containsNull() - Method in class org.h2.value.ValueNull
 
ContainsRTreeCursor(Page<Spatial, V>, Spatial, SpatialDataType) - Constructor for class org.h2.mvstore.rtree.MVRTreeMap.ContainsRTreeCursor
 
containsUncommitted() - Method in class org.h2.engine.SessionLocal
Whether the session contains any uncommitted changes.
containsValue(V) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Check whether the given value is stored.
contents - Variable in class org.h2.bnf.context.DbContextRule
 
contents - Variable in class org.h2.bnf.context.DbSchema
The database content container.
contents - Variable in class org.h2.server.web.WebSession
 
CONTEXT - Static variable in class org.h2.bnf.Sentence
This token type means the possible choices of the item depend on the context.
contextDestroyed(ServletContextEvent) - Method in class org.h2.server.web.JakartaDbStarter
 
contextDestroyed(ServletContextEvent) - Method in class org.h2.server.web.DbStarter
 
contextInitialized(ServletContextEvent) - Method in class org.h2.server.web.JakartaDbStarter
 
contextInitialized(ServletContextEvent) - Method in class org.h2.server.web.DbStarter
 
convert(Throwable) - Static method in exception org.h2.message.DbException
Convert a throwable to an SQL exception using the default mapping.
convert(CastDataProvider, Value) - Method in class org.h2.table.Column
Convert a value to this column's type without precision and scale checks.
convert(Value[], int) - Method in class org.h2.command.query.SelectUnion
 
CONVERT_TO - Static variable in class org.h2.value.Value
Convert a value to the specified type without taking scale and precision into account.
convertBytesToHex(byte[]) - Static method in class org.h2.util.StringUtils
Convert a byte array to a hex encoded string.
convertBytesToHex(byte[], int) - Static method in class org.h2.util.StringUtils
Convert a byte array to a hex encoded string.
convertBytesToHex(StringBuilder, byte[]) - Static method in class org.h2.util.StringUtils
Convert a byte array to a hex encoded string and appends it to a specified string builder.
convertBytesToHex(StringBuilder, byte[], int) - Static method in class org.h2.util.StringUtils
Convert a byte array to a hex encoded string and appends it to a specified string builder.
convertCase(String) - Method in class org.h2.command.Tokenizer
 
convertColumnName(String) - Method in class org.h2.table.TableLink
 
convertException(Exception) - Static method in class org.h2.fulltext.FullTextLucene
Convert an exception to a fulltext exception.
convertException(String, Exception) - Static method in class org.h2.tools.Csv
 
convertException(SQLException) - Static method in class org.h2.jdbcx.JdbcXAConnection
 
convertException(MVStoreException) - Method in class org.h2.mvstore.db.MVTable
Convert the MVStoreException to a database exception.
convertFile(String, String, String) - Method in class org.h2.tools.ConvertTraceFile
Converts a trace file to a Java class file and a script file.
convertForAssignTo(TypeInfo, CastDataProvider, Object) - Method in class org.h2.value.Value
Cast a value to the specified type for assignment.
convertHexToBytes(String) - Static method in class org.h2.util.StringUtils
Convert a hex encoded string to a byte array.
convertHexWithSpacesToBytes(ByteArrayOutputStream, String, int, int) - Static method in class org.h2.util.StringUtils
Parses a hex encoded string with possible space separators and appends the decoded binary string to the specified output stream.
convertIdentityColumn(Table, Column) - Method in class org.h2.command.ddl.AlterTableAlterColumn
 
convertInsertRow(SessionLocal, Row, Boolean) - Method in class org.h2.table.Table
Prepares the specified row for INSERT operation.
convertInsertRow(SessionLocal, Row, Boolean) - Method in class org.h2.table.TableLink
 
convertIntToShort(int) - Static method in class org.h2.util.MathUtils
Convert an int value to a short value.
convertInvocation(InvocationTargetException, String) - Static method in exception org.h2.message.DbException
Convert an InvocationTarget exception to a database exception.
convertIOException(IOException, String) - Static method in exception org.h2.message.DbException
Convert an IO exception to a database exception.
convertLongToInt(long) - Static method in class org.h2.util.MathUtils
Convert a long value to an int value.
convertMVStoreException(MVStoreException) - Method in class org.h2.mvstore.db.Store
Convert a MVStoreException to the similar exception used for the table/sql layers.
convertOldestHotToCold() - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
 
convertOnlyToSmallerScale - Variable in class org.h2.engine.Mode
When converting the scale of decimal data, the number is only converted if the new scale is smaller than the current scale.
convertPasswords() - Method in class org.h2.engine.ConnectionInfo
Split the password property into file password and user password if necessary, and convert them to the internal hash format.
convertPrecision(int, long) - Static method in class org.h2.table.TableLink
 
convertPrecision(long) - Method in class org.h2.value.ValueBlob
Convert the precision to the requested value.
convertPrecision(long) - Method in class org.h2.value.ValueClob
Convert the precision to the requested value.
convertRight - Variable in class org.h2.expression.BinaryOperation
 
convertRow(SessionLocal, Row) - Method in class org.h2.table.TableLink
 
convertSavepoint(Savepoint) - Static method in class org.h2.jdbc.JdbcConnection
 
convertScale(int, int) - Static method in class org.h2.table.TableLink
 
convertScale(long, int, long) - Static method in class org.h2.util.DateTimeUtils
Converts scale of nanoseconds.
convertSQLTypeToValueType(int) - Static method in class org.h2.value.DataType
Convert a SQL type to a value type.
convertSQLTypeToValueType(int, String) - Static method in class org.h2.value.DataType
Convert a SQL type to a value type using SQL type name, in order to manage SQL type extension mechanism.
convertSQLTypeToValueType(SQLType) - Static method in class org.h2.value.DataType
Convert a SQL type to a value type.
convertTimeZone(String, String) - Static method in class org.h2.server.pg.PgServerThread
 
convertTo(int) - Method in class org.h2.value.Value
Convert a value to the specified type without taking scale and precision into account.
convertTo(int, CastDataProvider) - Method in class org.h2.value.Value
Convert a value to the specified type without taking scale and precision into account.
convertTo(TypeInfo) - Method in class org.h2.value.Value
Convert a value to the specified type without taking scale and precision into account.
convertTo(TypeInfo, CastDataProvider) - Method in class org.h2.value.Value
Convert a value to the specified type without taking scale and precision into account.
convertTo(TypeInfo, CastDataProvider, int, Object) - Method in class org.h2.value.Value
Convert a value to the specified type.
convertTo(TypeInfo, CastDataProvider, Object) - Method in class org.h2.value.Value
Convert a value to the specified type without taking scale and precision into account.
convertToAnyArray(CastDataProvider) - Method in class org.h2.value.Value
Convert this value to any ARRAY data type.
convertToAnyRow() - Method in class org.h2.value.Value
Convert this value to any ROW data type.
convertToArray(TypeInfo, CastDataProvider, int, Object) - Method in class org.h2.value.Value
 
convertToBigint(Object) - Method in class org.h2.value.Value
Converts this value to a BIGINT value.
convertToBinary(TypeInfo, int, Object) - Method in class org.h2.value.Value
 
convertToBlob(TypeInfo, int, Object) - Method in class org.h2.value.Value
 
convertToBoolean() - Method in class org.h2.value.Value
Converts this value to a BOOLEAN value.
convertToByte(long, Object) - Static method in class org.h2.value.Value
 
convertToChar() - Method in class org.h2.value.Value
Converts this value to a CHAR value.
convertToChar(TypeInfo, CastDataProvider, int, Object) - Method in class org.h2.value.Value
 
convertToClientInfoException(SQLException) - Static method in class org.h2.jdbc.JdbcConnection
 
convertToClob(TypeInfo, int, Object) - Method in class org.h2.value.Value
 
convertToDate(CastDataProvider) - Method in class org.h2.value.Value
Converts this value to a DATE value.
convertToDecfloat(TypeInfo, int) - Method in class org.h2.value.Value
 
convertToDistinct(ResultInterface) - Method in class org.h2.command.query.Query
Convert a result into a distinct result, using the current columns.
convertToDouble() - Method in class org.h2.value.Value
Converts this value to a DOUBLE value.
convertToEnum(ExtTypeInfoEnum, CastDataProvider) - Method in class org.h2.value.Value
Converts this value to an ENUM value.
convertToGeometry(ExtTypeInfoGeometry) - Method in class org.h2.value.Value
Converts this value to a GEOMETRY value.
convertToInt(long, Object) - Static method in class org.h2.value.Value
Convert to integer, throwing exception if out of range.
convertToInt(Object) - Method in class org.h2.value.Value
Converts this value to a INT value.
convertToIntervalDayTime(int, Object) - Method in class org.h2.value.Value
 
convertToIntervalDayTime(BigDecimal, int) - Method in class org.h2.value.Value
 
convertToIntervalDayTime(TypeInfo, int, Object) - Method in class org.h2.value.Value
 
convertToIntervalYearMonth(int, Object) - Method in class org.h2.value.Value
 
convertToIntervalYearMonth(TypeInfo, int, Object) - Method in class org.h2.value.Value
 
convertToIOException(Throwable) - Static method in class org.h2.mvstore.DataUtils
Convert an exception to an IO exception.
convertToJavaObject(TypeInfo, int, Object) - Method in class org.h2.value.Value
Converts this value to a JAVA_OBJECT value.
convertToJson(TypeInfo, int, Object) - Method in class org.h2.value.Value
 
convertToKey(SearchRow, Boolean) - Method in class org.h2.mvstore.db.MVSecondaryIndex
 
convertToLong(double, Object) - Static method in class org.h2.value.Value
 
convertToLong(BigDecimal, Object) - Static method in class org.h2.value.Value
 
convertToNumeric(TypeInfo, CastDataProvider, int, Object) - Method in class org.h2.value.Value
 
convertToObjectList(Row, JdbcConnection) - Static method in class org.h2.schema.TriggerObject
 
convertToReal() - Method in class org.h2.value.Value
Converts this value to a REAL value.
convertToRow(TypeInfo, CastDataProvider, int, Object) - Method in class org.h2.value.Value
 
convertToShort(long, Object) - Static method in class org.h2.value.Value
 
convertToSimpleDateFormat(String) - Static method in class org.h2.mode.FunctionsMySQL
 
convertToSmallint(Object) - Method in class org.h2.value.Value
Converts this value to a SMALLINT value.
convertToString(char[]) - Static method in class org.h2.jdbcx.JdbcDataSource
 
convertToTime(TypeInfo, CastDataProvider, int) - Method in class org.h2.value.Value
 
convertToTimestamp(TypeInfo, CastDataProvider, int) - Method in class org.h2.value.Value
 
convertToTimestampTimeZone(TypeInfo, CastDataProvider, int) - Method in class org.h2.value.Value
 
convertToTimeTimeZone(TypeInfo, CastDataProvider, int) - Method in class org.h2.value.Value
 
convertToTinyint(Object) - Method in class org.h2.value.Value
Converts this value to a TINYINT value.
convertToUnknownValue(Object) - Method in class org.h2.jdbc.JdbcResultSet
 
convertToUuid() - Method in class org.h2.value.Value
Converts this value to a UUID value.
convertToValue(Object, SQLType) - Method in class org.h2.jdbc.JdbcResultSet
 
convertToVarbinary(TypeInfo, int, Object) - Method in class org.h2.value.Value
 
convertToVarchar(TypeInfo, CastDataProvider, int, Object) - Method in class org.h2.value.Value
 
convertToVarcharIgnoreCase(TypeInfo, int, Object) - Method in class org.h2.value.Value
 
ConvertTraceFile - Class in org.h2.tools
Converts a .trace.db file to a SQL script and Java source code.
ConvertTraceFile() - Constructor for class org.h2.tools.ConvertTraceFile
 
ConvertTraceFile.Stat - Class in org.h2.tools
This class holds statistics about a SQL statement.
convertType(TypeInfo) - Static method in class org.h2.server.pg.PgServer
Convert the SQL type to a PostgreSQL type
convertTypeToSQLType(TypeInfo) - Static method in class org.h2.value.DataType
Convert a value type to a SQL type.
convertUnicode(int) - Method in class org.h2.command.Token.CharacterStringToken
 
convertUnicode(int) - Method in class org.h2.command.Token
 
convertUnicode(int) - Method in class org.h2.command.Token.IdentifierToken
 
convertUpdateRow(SessionLocal, Row, boolean) - Method in class org.h2.table.Table
Prepares the specified row for UPDATE operation.
convertUpdateRow(SessionLocal, Row, boolean) - Method in class org.h2.table.TableLink
 
convertWord(String) - Method in class org.h2.fulltext.FullTextSettings
Convert a word to uppercase.
coordinates - Variable in class org.h2.util.geometry.JTSUtils.GeometryTarget
 
copy() - Method in class org.h2.mvstore.Page
Create a copy of this page.
copy(byte[], byte[]) - Static method in class org.h2.util.Utils
Copy the contents of the source array to the target array.
copy(InputStream, OutputStream) - Static method in class org.h2.util.IOUtils
Copy all data from the input stream to the output stream.
copy(InputStream, OutputStream, long) - Static method in class org.h2.util.IOUtils
Copy all data from the input stream to the output stream.
copy(MVMap<K, V>, boolean) - Method in class org.h2.mvstore.Page
Create a copy of this page with potentially different owning map.
copy(MVMap<K, V>, boolean) - Method in class org.h2.mvstore.Page.Leaf
 
copy(MVMap<K, V>, boolean) - Method in class org.h2.mvstore.Page.NonLeaf
 
copy(Page<K, V>, Page<K, V>, int) - Method in class org.h2.mvstore.MVMap
 
copy(DataHandler, int) - Method in class org.h2.value.ValueBlob
 
copy(DataHandler, int) - Method in class org.h2.value.ValueClob
 
copy(DataHandler, int) - Method in class org.h2.value.ValueLob
Copy a large value, to be used in the given table.
copy(Column) - Method in class org.h2.table.Column
Copy the data of the source column into the current column.
copyAndClose(InputStream, OutputStream) - Static method in class org.h2.util.IOUtils
Copy all data from the input stream to the output stream and close both streams.
copyAndCloseInput(InputStream, OutputStream) - Static method in class org.h2.util.IOUtils
Copy all data from the input stream to the output stream and close the input stream.
copyAndCloseInput(Reader, Writer, long) - Static method in class org.h2.util.IOUtils
Copy all data from the reader to the writer and close the reader.
copyBytes(byte[], int) - Static method in class org.h2.util.Utils
Creates a copy of array of bytes with the new size.
copyColumn(Domain, Column) - Method in class org.h2.command.ddl.AlterDomainExpressions
 
copyColumn(Domain, Column) - Method in class org.h2.command.ddl.DropDomain
 
copyData(Table, ArrayList<Sequence>, boolean) - Method in class org.h2.command.ddl.AlterTableAlterColumn
 
copyDomain(Domain, Domain) - Method in class org.h2.command.ddl.AlterDomainExpressions
 
copyDomain(Domain, Domain) - Method in class org.h2.command.ddl.DropDomain
 
copyExcept(Object, Object, int, int) - Static method in class org.h2.mvstore.DataUtils
Copy the elements of an array, and remove one element.
copyExpressions(SessionLocal, Domain, ColumnTemplate) - Method in class org.h2.command.ddl.AlterDomainExpressions
 
copyExpressions(SessionLocal, Domain, ColumnTemplate) - Static method in class org.h2.command.ddl.DropDomain
 
copyFiles(String, String) - Static method in class org.h2.util.IOUtils
Copy a file from one directory to another, or to another file.
copyFrom(MVMap<K, V>) - Method in class org.h2.mvstore.MVMap
Copy a map.
copyFrom(SearchRow) - Method in class org.h2.result.DefaultRow
 
copyFrom(SearchRow) - Method in class org.h2.result.SearchRow
Copy all relevant values from the source to this row.
copyFrom(SearchRow) - Method in class org.h2.result.SimpleRowValue
 
copyFrom(SearchRow) - Method in class org.h2.result.Sparse
 
copyFromOldSequence() - Method in class org.h2.command.ddl.SequenceOptions
 
copyInThread(InputStream, OutputStream) - Static method in class org.h2.util.Profiler
 
copyInThread(InputStream, OutputStream) - Static method in class org.h2.util.SourceCompiler
 
copyLob(ValueLob, int) - Method in class org.h2.mvstore.db.LobStorageMap
 
copyLob(ValueLob, int) - Method in class org.h2.store.LobStorageFrontend
 
copyLob(ValueLob, int) - Method in interface org.h2.store.LobStorageInterface
Copy a lob.
copyMvStore(String, boolean, char[]) - Method in class org.h2.tools.ChangeFileEncryption
 
copyProperty(ConnectionInfo, StringBuilder, String) - Static method in class org.h2.tools.Upgrade
 
copyString(Reader, OutputStream) - Static method in class org.h2.store.Data
Copy a String from a reader to an output stream.
copyToResult() - Method in class org.h2.value.ValueLob
Create an independent copy of this value, that will be bound to a result.
copyWithGap(Object, Object, int, int) - Static method in class org.h2.mvstore.DataUtils
Copy the elements of an array, with a gap.
CORR - org.h2.expression.aggregate.AggregateType
The aggregate type for CORR binary set function.
correctFileName(String) - Static method in class org.h2.command.dml.BackupCommand
Fix the file name, replacing backslash with slash.
COS - Static variable in class org.h2.expression.function.MathFunction1
COS().
COSH - Static variable in class org.h2.expression.function.MathFunction1
COSH().
cost - Variable in class org.h2.command.query.Optimizer
 
cost - Variable in class org.h2.command.query.Select
 
cost - Variable in class org.h2.command.query.TableValueConstructor
 
cost - Variable in class org.h2.table.PlanItem
The cost.
COST_ROW_OFFSET - Static variable in class org.h2.engine.Constants
The cost is calculated on rowcount + this offset, to avoid using the wrong or no index if the table contains no rows _currently_ (when preparing the statement)
COT - Static variable in class org.h2.expression.function.MathFunction1
COT() (non-standard).
count - Variable in class org.h2.engine.QueryStatisticsData.QueryEntry
The number of times the statement was executed.
count - Variable in class org.h2.expression.aggregate.AggregateDataAvg
 
count - Variable in class org.h2.expression.aggregate.AggregateDataCorr
 
count - Variable in class org.h2.expression.aggregate.AggregateDataCount
 
count - Variable in class org.h2.expression.aggregate.AggregateDataCovar
 
count - Variable in class org.h2.expression.aggregate.AggregateDataStdVar
 
count - Variable in class org.h2.expression.aggregate.LongDataCounter
The value.
count - Variable in class org.h2.mvstore.Page.PageReference
The descendant count for this child page.
COUNT - org.h2.expression.aggregate.AggregateType
The aggregate type for COUNT(expression).
COUNT - Static variable in class org.h2.command.dml.SetTypes
 
COUNT_ALL - org.h2.expression.aggregate.AggregateType
The aggregate type for COUNT(*).
counter - Variable in class org.h2.mvstore.db.MVPlainTempResult
Counter for the identities of rows.
counter - Variable in class org.h2.mvstore.MVStore.TxCounter
Counter of outstanding operation on this version of a store
counter - Static variable in class org.h2.util.Task
 
COUNTER_MASK - Static variable in class org.h2.util.MemoryEstimator
 
counterUpdater - Static variable in class org.h2.mvstore.MVStore.TxCounter
 
CountingReaderInputStream - Class in org.h2.store
An input stream that reads the data from a reader and limits the number of bytes that can be read.
CountingReaderInputStream(Reader, long) - Constructor for class org.h2.store.CountingReaderInputStream
 
counts - Variable in class org.h2.util.Profiler
 
COVAR_POP - org.h2.expression.aggregate.AggregateType
The aggregate type for COVAR_POP binary set function.
COVAR_SAMP - org.h2.expression.aggregate.AggregateType
The aggregate type for COVAR_SAMP binary set function.
create - Variable in class org.h2.command.Prepared
Whether to create a new object (for indexes).
create(int) - Static method in class org.h2.store.Data
Create a new buffer.
create(long, float...) - Method in class org.h2.mvstore.rtree.SpatialDataType
Creates spatial object with specified parameters.
create(String, String, String) - Static method in class org.h2.jdbcx.JdbcConnectionPool
Constructs a new connection pool for H2 databases.
create(String, FilePath) - Method in class org.h2.store.fs.FilePathWrapper
 
create(ByteBuffer, MetaType<D>, D) - Method in class org.h2.mvstore.tx.VersionedValueType.Factory
 
create(ByteBuffer, MetaType<D>, D) - Method in interface org.h2.mvstore.type.StatefulDataType.Factory
Reads the data type.
create(ByteBuffer, MetaType<Database>, Database) - Method in class org.h2.mvstore.db.RowDataType.Factory
 
create(ByteBuffer, MetaType<Database>, Database) - Method in class org.h2.mvstore.db.ValueDataType.Factory
 
create(Map<String, Object>) - Method in class org.h2.mvstore.MVMap.BasicBuilder
Create map from config.
create(Map<String, Object>) - Method in class org.h2.mvstore.MVMap.Builder
 
create(Map<String, Object>) - Method in class org.h2.mvstore.rtree.MVRTreeMap.Builder
 
create(Map<String, Object>) - Method in class org.h2.mvstore.tx.TransactionStore.TxMapBuilder
 
create(ConnectionPoolDataSource) - Static method in class org.h2.jdbcx.JdbcConnectionPool
Constructs a new connection pool.
create(MVStore, Map<String, Object>) - Method in class org.h2.mvstore.MVMap.BasicBuilder
 
create(MVStore, Map<String, Object>) - Method in interface org.h2.mvstore.MVMap.MapBuilder
Create a new map of the given type.
create(MVStore, Map<String, Object>) - Method in class org.h2.mvstore.tx.TransactionStore.TxMapBuilder
 
create(T[], T[]) - Static method in class org.h2.util.Permutations
Create a new permutations object.
create(T[], T[], int) - Static method in class org.h2.util.Permutations
Create a new permutations object.
CREATE_AGGREGATE - Static variable in interface org.h2.command.CommandInterface
The type of a CREATE AGGREGATE statement.
CREATE_ALIAS - Static variable in interface org.h2.command.CommandInterface
The type of a CREATE ALIAS statement.
CREATE_BUILD - Static variable in class org.h2.command.dml.SetTypes
The type of a SET CREATE_BUILD statement.
CREATE_CONSTANT - Static variable in interface org.h2.command.CommandInterface
The type of a CREATE CONSTANT statement.
CREATE_DOMAIN - Static variable in interface org.h2.command.CommandInterface
The type of a CREATE DOMAIN statement.
CREATE_INDEX - Static variable in interface org.h2.command.CommandInterface
The type of a CREATE INDEX statement.
CREATE_LINKED_TABLE - Static variable in interface org.h2.command.CommandInterface
The type of a CREATE LINKED TABLE statement.
CREATE_NEW_FILE - Static variable in interface org.h2.store.fs.Recorder
Create a new file.
CREATE_ROLE - Static variable in interface org.h2.command.CommandInterface
The type of a CREATE ROLE statement.
CREATE_SCHEMA - Static variable in interface org.h2.command.CommandInterface
The type of a CREATE SCHEMA statement.
CREATE_SEQUENCE - Static variable in interface org.h2.command.CommandInterface
The type of a CREATE SEQUENCE statement.
CREATE_SYNONYM - Static variable in interface org.h2.command.CommandInterface
The type of a CREATE SYNONYM statement.
CREATE_TABLE - Static variable in interface org.h2.command.CommandInterface
The type of a CREATE TABLE statement.
CREATE_TEMP_FILE - Static variable in interface org.h2.store.fs.Recorder
Create a temporary file.
CREATE_TRIGGER - Static variable in interface org.h2.command.CommandInterface
The type of a CREATE TRIGGER statement.
CREATE_USER - Static variable in interface org.h2.command.CommandInterface
The type of a CREATE USER statement.
CREATE_VIEW - Static variable in interface org.h2.command.CommandInterface
The type of a CREATE VIEW statement.
CreateAggregate - Class in org.h2.command.ddl
This class represents the statement CREATE AGGREGATE
CreateAggregate(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.CreateAggregate
 
createAggregateData() - Method in class org.h2.expression.aggregate.Aggregate
 
createAggregateData() - Method in class org.h2.expression.aggregate.JavaAggregate
 
createAggregateData() - Method in class org.h2.expression.analysis.DataAnalysisOperation
Create aggregate data object specific to the subclass.
createAggregateData() - Method in class org.h2.expression.analysis.WindowFunction
 
createArrayOf(String, Object[]) - Method in class org.h2.jdbc.JdbcConnection
Create a new Array object.
createAuthenticator() - Static method in class org.h2.security.auth.AuthenticatorFactory
Factory method.
createBinary(boolean) - Static method in class org.h2.value.DataType
 
createBlob() - Method in class org.h2.jdbc.JdbcConnection
Create a new empty Blob object.
createBlob(InputStream) - Method in class org.h2.mvstore.db.LobStorageMap
 
createBlob(InputStream, long) - Method in class org.h2.jdbc.JdbcConnection
Create a Blob value from this input stream.
createBlob(InputStream, long) - Method in class org.h2.mvstore.db.LobStorageMap
 
createBlob(InputStream, long) - Method in class org.h2.store.LobStorageFrontend
 
createBlob(InputStream, long) - Method in interface org.h2.store.LobStorageInterface
Create a BLOB object.
createBoundingBox(Object) - Method in class org.h2.mvstore.rtree.SpatialDataType
Create a bounding box starting with the given object.
createButton - Variable in class org.h2.tools.GUIConsole
 
createChunk(long, long) - Method in class org.h2.mvstore.MVStore
 
createClob() - Method in class org.h2.jdbc.JdbcConnection
Create a new empty Clob object.
createClob(Reader, long) - Method in class org.h2.jdbc.JdbcConnection
Create a Clob value from this reader.
createClob(Reader, long) - Method in class org.h2.mvstore.db.LobStorageMap
 
createClob(Reader, long) - Method in class org.h2.store.LobStorageFrontend
Create a CLOB object.
createClob(Reader, long) - Method in interface org.h2.store.LobStorageInterface
Create a CLOB object.
CreateCluster - Class in org.h2.tools
Creates a cluster from a stand-alone database.
CreateCluster() - Constructor for class org.h2.tools.CreateCluster
 
createColumns() - Method in class org.h2.table.GeneratedColumnResolver
 
createConnection(boolean) - Method in class org.h2.engine.SessionLocal
Create an internal connection.
createConnectionPoolDataSource(Properties) - Method in class org.h2.util.OsgiDataSourceFactory
Creates a pooled data source.
CreateConstant - Class in org.h2.command.ddl
This class represents the statement CREATE CONSTANT
CreateConstant(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.CreateConstant
 
createConstraints() - Method in class org.h2.command.ddl.CommandWithColumns
Create the constraints.
createCoordinates(int) - Method in class org.h2.util.geometry.JTSUtils.GeometryTarget
 
createCTEView(String, String, List<Column>, boolean, boolean, boolean) - Method in class org.h2.command.Parser
 
created - Variable in class org.h2.command.CommandRemote
 
created - Variable in class org.h2.engine.SessionLocal.TimeoutValue
The time when this object was created.
createDatabase() - Method in class org.h2.tools.GUIConsole
 
createDataSource(Properties) - Method in class org.h2.util.OsgiDataSourceFactory
Creates a basic data source.
createDate(int, int, String, boolean, int, int) - Static method in class org.h2.value.DataType
Create a date-time data type.
createdIndexes - Variable in class org.h2.command.ddl.AlterTableAddConstraint
 
createDirectories(String) - Static method in class org.h2.store.fs.FileUtils
Create the directory and all required parent directories.
createDirectory() - Method in class org.h2.store.fs.disk.FilePathDisk
 
createDirectory() - Method in class org.h2.store.fs.FilePath
Create a directory (all required parent directories already exist).
createDirectory() - Method in class org.h2.store.fs.FilePathWrapper
 
createDirectory() - Method in class org.h2.store.fs.mem.FilePathMem
 
createDirectory() - Method in class org.h2.store.fs.niomem.FilePathNioMem
 
createDirectory() - Method in class org.h2.store.fs.zip.FilePathZip
 
createDirectory(String) - Static method in class org.h2.store.fs.FileUtils
Create a directory (all required parent directories must already exist).
CreateDomain - Class in org.h2.command.ddl
This class represents the statement CREATE DOMAIN
CreateDomain(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.CreateDomain
 
createDriver(Properties) - Method in class org.h2.util.OsgiDataSourceFactory
Returns a driver.
createdUniqueConstraint - Variable in class org.h2.command.ddl.AlterTableAddConstraint
 
createEmptyLeaf() - Method in class org.h2.mvstore.MVMap
Create empty leaf node page.
createEmptyLeaf(MVMap<K, V>) - Static method in class org.h2.mvstore.Page
Create a new, empty leaf page.
createEmptyNode() - Method in class org.h2.mvstore.MVMap
Create empty internal node page.
createEmptyNode(MVMap<K, V>) - Static method in class org.h2.mvstore.Page
Create a new, empty internal node page.
createException - Variable in class org.h2.table.TableView
 
createExternalResult() - Method in class org.h2.result.LocalResult
 
createFile() - Method in class org.h2.store.fs.disk.FilePathDisk
 
createFile() - Method in class org.h2.store.fs.FilePath
Create a new file.
createFile() - Method in class org.h2.store.fs.FilePathWrapper
 
createFile() - Method in class org.h2.store.fs.mem.FilePathMem
 
createFile() - Method in class org.h2.store.fs.niomem.FilePathNioMem
 
createFile() - Method in class org.h2.store.fs.rec.FilePathRec
 
createFile() - Method in class org.h2.store.fs.zip.FilePathZip
 
createFile(String) - Static method in class org.h2.store.fs.FileUtils
Create a new file.
createFrame - Variable in class org.h2.tools.GUIConsole
 
CreateFunctionAlias - Class in org.h2.command.ddl
This class represents the statement CREATE ALIAS
CreateFunctionAlias(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.CreateFunctionAlias
 
createGeometry() - Static method in class org.h2.value.DataType
 
createGroupSortedRow(Value[], int) - Method in class org.h2.command.query.Select
Create a row with the current values, for queries with group-sort.
createIdSet(Iterable<Chunk>) - Static method in class org.h2.mvstore.MVStore
 
createIndex(Connection, String, String, String) - Static method in class org.h2.fulltext.FullText
Create a new full text index for a table and column list.
createIndex(Connection, String, String, String) - Static method in class org.h2.fulltext.FullTextLucene
Create a new full text index for a table and column list.
createIndex(Table, IndexColumn[], boolean) - Method in class org.h2.command.ddl.AlterTableAddConstraint
 
CreateIndex - Class in org.h2.command.ddl
This class represents the statement CREATE INDEX
CreateIndex(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.CreateIndex
 
createIndexConditions() - Method in class org.h2.table.TableFilter
Create the index conditions for this filter if needed.
createIndexConditions(SessionLocal, TableFilter) - Method in class org.h2.expression.condition.BetweenPredicate
 
createIndexConditions(SessionLocal, TableFilter) - Method in class org.h2.expression.condition.BooleanTest
 
createIndexConditions(SessionLocal, TableFilter) - Method in class org.h2.expression.condition.CompareLike
 
createIndexConditions(SessionLocal, TableFilter) - Method in class org.h2.expression.condition.Comparison
 
createIndexConditions(SessionLocal, TableFilter) - Method in class org.h2.expression.condition.ConditionAndOr
 
createIndexConditions(SessionLocal, TableFilter) - Method in class org.h2.expression.condition.ConditionAndOrN
 
createIndexConditions(SessionLocal, TableFilter) - Method in class org.h2.expression.condition.ConditionIn
 
createIndexConditions(SessionLocal, TableFilter) - Method in class org.h2.expression.condition.ConditionInConstantSet
 
createIndexConditions(SessionLocal, TableFilter) - Method in class org.h2.expression.condition.ConditionInParameter
 
createIndexConditions(SessionLocal, TableFilter) - Method in class org.h2.expression.condition.ConditionInQuery
 
createIndexConditions(SessionLocal, TableFilter) - Method in class org.h2.expression.condition.ConditionLocalAndGlobal
 
createIndexConditions(SessionLocal, TableFilter) - Method in class org.h2.expression.condition.NullPredicate
 
createIndexConditions(SessionLocal, TableFilter) - Method in class org.h2.expression.Expression
Create index conditions if possible and attach them to the table filter.
createIndexConditions(SessionLocal, TableFilter) - Method in class org.h2.expression.ExpressionColumn
 
createIndexConditions(SessionLocal, TableFilter) - Method in class org.h2.expression.ValueExpression
 
createIndexConditions(TableFilter, Expression, Expression, int) - Static method in class org.h2.expression.condition.Comparison
 
createKeyStorage(int) - Method in class org.h2.mvstore.Page
Create array for keys storage.
createLeaf(MVMap<K, V>, K[], V[], int) - Static method in class org.h2.mvstore.Page
Create a new leaf page.
CreateLinkedTable - Class in org.h2.command.ddl
This class represents the statement CREATE LINKED TABLE
CreateLinkedTable(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.CreateLinkedTable
 
createLob(boolean) - Static method in class org.h2.value.DataType
 
createLocalResult(int) - Method in class org.h2.command.query.SelectUnion
 
createLocalResult(LocalResult) - Method in class org.h2.command.query.Select
 
createLoopbackSocket(int, boolean) - Static method in class org.h2.util.NetUtils
Create a loopback socket (a socket that is connected to localhost) on this port.
createMissingRoles - Variable in class org.h2.security.auth.DefaultAuthenticator
 
createMissingRoles - Variable in class org.h2.security.auth.H2AuthConfig
 
createNClob() - Method in class org.h2.jdbc.JdbcConnection
Create a new empty NClob object.
createNewSession(String) - Method in class org.h2.server.web.WebServer
Create a new web session id and object.
createNode(MVMap<K, V>, K[], Page.PageReference<K, V>[], long, int) - Static method in class org.h2.mvstore.Page
Create a new non-leaf page.
createNonUnique(boolean) - Static method in class org.h2.index.IndexType
Create a non-unique index.
createNonUnique(boolean, boolean, boolean) - Static method in class org.h2.index.IndexType
Create a non-unique index.
createNullIndexCondition(TableFilter, ExpressionColumn) - Static method in class org.h2.expression.condition.NullPredicate
 
createNumeric(int, int) - Static method in class org.h2.value.DataType
Create a numeric data type without parameters.
createOrder(SessionLocal, ArrayList<QueryOrderBy>, int) - Static method in class org.h2.expression.analysis.DataAnalysisOperation
Create sort order.
createOrDropTrigger(Connection, String, String, boolean) - Static method in class org.h2.fulltext.FullText
 
createOrDropTrigger(Connection, String, String, boolean) - Static method in class org.h2.fulltext.FullTextLucene
 
createPgServer(String...) - Static method in class org.h2.tools.Server
Create a new PG server, but does not start it yet.
createPrimaryKey(boolean, boolean) - Static method in class org.h2.index.IndexType
Create a primary key index.
createQueryColumnTemplateList(String[], Query, String[]) - Static method in class org.h2.table.TableView
Creates a list of column templates from a query (usually from WITH query, but could be any query)
createRefStorage(int) - Static method in class org.h2.mvstore.Page
Create an array of page references.
createRemovedPageInfo(long, boolean, int) - Static method in class org.h2.mvstore.MVStore.RemovedPageInfo
Transforms saved page position into removed page info by replacing "page offset" with "page sequential number" and "page type" bit with "pinned page" flag.
createResult() - Method in class org.h2.command.dml.ScriptCommand
 
createResultSet(boolean) - Static method in class org.h2.fulltext.FullText
Create an empty search result and initialize the columns.
createResultSet(JdbcConnection, Table, Row, boolean) - Static method in class org.h2.schema.TriggerObject
 
CreateRole - Class in org.h2.command.ddl
This class represents the statement CREATE ROLE
CreateRole(SessionLocal) - Constructor for class org.h2.command.ddl.CreateRole
 
createRow() - Method in class org.h2.command.query.SelectGroups
Creates new object arrays to holds group-by data.
createRow() - Method in class org.h2.result.RowFactory
Create new row.
createRow() - Method in class org.h2.result.RowFactory.DefaultRowFactory
 
createRow(Value[], int) - Method in class org.h2.result.RowFactory
Create a new row.
createRow(Value[], int) - Method in class org.h2.result.RowFactory.DefaultRowFactory
 
createRow(Value[], int) - Method in class org.h2.table.Table
Create a new row for this table.
createRowFactory(CastDataProvider, CompareMode, DataHandler, int[], int[], TypeInfo[], int, boolean) - Method in class org.h2.result.RowFactory.DefaultRowFactory
Create a new row factory.
createRowFactory(CastDataProvider, CompareMode, DataHandler, Typed[], IndexColumn[], boolean) - Method in class org.h2.result.RowFactory
Create a new row factory.
createRowFactory(CastDataProvider, CompareMode, DataHandler, Typed[], IndexColumn[], boolean) - Method in class org.h2.result.RowFactory.DefaultRowFactory
 
createScan(boolean) - Static method in class org.h2.index.IndexType
Create a scan pseudo-index.
CreateSchema - Class in org.h2.command.ddl
This class represents the statement CREATE SCHEMA
CreateSchema(SessionLocal) - Constructor for class org.h2.command.ddl.CreateSchema
 
CreateSequence - Class in org.h2.command.ddl
This class represents the statement CREATE SEQUENCE.
CreateSequence(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.CreateSequence
 
createServerSocket(int, boolean) - Static method in class org.h2.util.NetUtils
Create a server socket.
createServerSocket(int, InetAddress) - Static method in class org.h2.security.CipherFactory
Create a secure server socket.
createServerSocketTry(int, boolean) - Static method in class org.h2.util.NetUtils
 
createSession - Variable in class org.h2.index.ViewIndex
 
createSession(ConnectionInfo) - Static method in class org.h2.engine.Engine
Open a database connection with the given connection information.
createSession(User) - Method in class org.h2.engine.Database
 
createSession(User, NetworkConnectionInfo) - Method in class org.h2.engine.Database
Create a session for the given user.
createShadowTableForRecursiveTableExpression(boolean, SessionLocal, String, Schema, List<Column>, Database) - Static method in class org.h2.table.TableView
Create a table for a recursive query.
createShallowCopy() - Method in class org.h2.mvstore.db.MVPlainTempResult
 
createShallowCopy() - Method in class org.h2.mvstore.db.MVSortedTempResult
 
createShallowCopy() - Method in interface org.h2.result.ResultExternal
Create a shallow copy of this object if possible.
createShallowCopy(Session) - Method in class org.h2.result.FetchedResult
 
createShallowCopy(Session) - Method in class org.h2.result.LocalResult
Create a shallow copy of the result set.
createShallowCopy(Session) - Method in interface org.h2.result.ResultInterface
Create a shallow copy of the result set.
createShallowCopy(Session) - Method in class org.h2.result.ResultWithPaddedStrings
 
createShallowCopy(Session) - Method in class org.h2.result.SimpleResult
 
createSingleThreadExecutor(String) - Static method in class org.h2.mvstore.MVStore
 
createSmall(byte[]) - Static method in class org.h2.value.ValueBlob
Creates a small BLOB value that can be stored in the row directly.
createSmall(byte[]) - Static method in class org.h2.value.ValueClob
Creates a small CLOB value that can be stored in the row directly.
createSmall(byte[], long) - Static method in class org.h2.value.ValueClob
Creates a small CLOB value that can be stored in the row directly.
createSmall(String) - Static method in class org.h2.value.ValueClob
Creates a small CLOB value that can be stored in the row directly.
createSnapshot() - Method in class org.h2.mvstore.tx.TransactionMap
Create a new snapshot for this map.
createSocket(String, int, boolean) - Static method in class org.h2.util.NetUtils
Create a client socket that is connected to the given address and port.
createSocket(String, int, boolean, int) - Static method in class org.h2.util.NetUtils
Create a client socket that is connected to the given address and port.
createSocket(InetAddress, int) - Static method in class org.h2.security.CipherFactory
Create a secure client socket that is connected to the given address and port.
createSocket(InetAddress, int, boolean) - Static method in class org.h2.util.NetUtils
Create a client socket that is connected to the given address and port.
createSocket(InetAddress, int, boolean, int) - Static method in class org.h2.util.NetUtils
Create a client socket that is connected to the given address and port.
createSQLXML() - Method in class org.h2.jdbc.JdbcConnection
Create a new SQLXML object with no data.
createStatement() - Method in class org.h2.jdbc.JdbcConnection
Creates a new statement.
createStatement(int, int) - Method in class org.h2.jdbc.JdbcConnection
Creates a statement with the specified result set type and concurrency.
createStatement(int, int, int) - Method in class org.h2.jdbc.JdbcConnection
Creates a statement with the specified result set type, concurrency, and holdability.
createStorage(int) - Method in class org.h2.mvstore.db.LobStorageMap.BlobMeta.Type
 
createStorage(int) - Method in class org.h2.mvstore.db.LobStorageMap.BlobReference.Type
 
createStorage(int) - Method in class org.h2.mvstore.db.NullValueDataType
 
createStorage(int) - Method in class org.h2.mvstore.db.RowDataType
 
createStorage(int) - Method in class org.h2.mvstore.db.ValueDataType
 
createStorage(int) - Method in class org.h2.mvstore.MVStoreTool.GenericDataType
 
createStorage(int) - Method in class org.h2.mvstore.rtree.SpatialDataType
 
createStorage(int) - Method in class org.h2.mvstore.tx.Record.Type
 
createStorage(int) - Method in class org.h2.mvstore.tx.VersionedValueType
 
createStorage(int) - Method in class org.h2.mvstore.type.ByteArrayDataType
 
createStorage(int) - Method in interface org.h2.mvstore.type.DataType
Create storage object of array type to hold values
createStorage(int) - Method in class org.h2.mvstore.type.LongDataType
 
createStorage(int) - Method in class org.h2.mvstore.type.MetaType
 
createStorage(int) - Method in class org.h2.mvstore.type.ObjectDataType.BigDecimalType
 
createStorage(int) - Method in class org.h2.mvstore.type.ObjectDataType.BigIntegerType
 
createStorage(int) - Method in class org.h2.mvstore.type.ObjectDataType.BooleanType
 
createStorage(int) - Method in class org.h2.mvstore.type.ObjectDataType.ByteType
 
createStorage(int) - Method in class org.h2.mvstore.type.ObjectDataType.CharacterType
 
createStorage(int) - Method in class org.h2.mvstore.type.ObjectDataType
 
createStorage(int) - Method in class org.h2.mvstore.type.ObjectDataType.DateType
 
createStorage(int) - Method in class org.h2.mvstore.type.ObjectDataType.DoubleType
 
createStorage(int) - Method in class org.h2.mvstore.type.ObjectDataType.FloatType
 
createStorage(int) - Method in class org.h2.mvstore.type.ObjectDataType.IntegerType
 
createStorage(int) - Method in class org.h2.mvstore.type.ObjectDataType.LongType
 
createStorage(int) - Method in class org.h2.mvstore.type.ObjectDataType.NullType
 
createStorage(int) - Method in class org.h2.mvstore.type.ObjectDataType.ObjectArrayType
 
createStorage(int) - Method in class org.h2.mvstore.type.ObjectDataType.SerializedObjectType
 
createStorage(int) - Method in class org.h2.mvstore.type.ObjectDataType.ShortType
 
createStorage(int) - Method in class org.h2.mvstore.type.ObjectDataType.StringType
 
createStorage(int) - Method in class org.h2.mvstore.type.ObjectDataType.UUIDType
 
createStorage(int) - Method in class org.h2.mvstore.type.StringDataType
 
createString(boolean, boolean) - Static method in class org.h2.value.DataType
 
createString(boolean, boolean, String, String) - Static method in class org.h2.value.DataType
 
createStruct(String, Object[]) - Method in class org.h2.jdbc.JdbcConnection
[Not supported] Create a new empty Struct object.
createSynonym(CreateSynonymData) - Method in class org.h2.schema.Schema
Add a table synonym to the schema.
CreateSynonym - Class in org.h2.command.ddl
This class represents the statement CREATE SYNONYM
CreateSynonym(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.CreateSynonym
 
CreateSynonymData - Class in org.h2.command.ddl
The data required to create a synonym.
CreateSynonymData() - Constructor for class org.h2.command.ddl.CreateSynonymData
 
createSysTableData() - Method in class org.h2.engine.Database
 
createTable() - Method in class org.h2.command.query.TableValueConstructor
 
createTable(CreateTableData) - Method in interface org.h2.api.TableEngine
Create new table.
createTable(CreateTableData) - Method in class org.h2.mvstore.db.Store
Create a table.
createTable(CreateTableData) - Method in class org.h2.schema.Schema
Add a table to the schema.
CreateTable - Class in org.h2.command.ddl
This class represents the statement CREATE TABLE
CreateTable(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.CreateTable
 
CreateTableData - Class in org.h2.command.ddl
The data required to create a table.
CreateTableData() - Constructor for class org.h2.command.ddl.CreateTableData
 
createTableLink(int, String, String, String, String, String, String, String, boolean, boolean) - Method in class org.h2.schema.Schema
Add a linked table to the schema.
createTableSynonym(Database) - Method in class org.h2.command.ddl.CreateSynonym
 
createTableViewMaybeRecursive(Schema, int, String, String, ArrayList<Parameter>, Column[], SessionLocal, boolean, boolean, boolean, Database) - Static method in class org.h2.table.TableView
Create a view.
createTcpServer(String...) - Static method in class org.h2.tools.Server
Create a new TCP server, but does not start it yet.
createTempBlob(InputStream, long, DataHandler) - Static method in class org.h2.value.ValueBlob
Create a temporary BLOB value from a stream.
createTempClob(Reader, long, DataHandler) - Static method in class org.h2.value.ValueClob
Create a temporary CLOB value from a stream.
createTempFile(String, boolean) - Method in class org.h2.store.fs.disk.FilePathDisk
 
createTempFile(String, boolean) - Method in class org.h2.store.fs.FilePath
Create a new temporary file.
createTempFile(String, boolean) - Method in class org.h2.store.fs.FilePathWrapper
 
createTempFile(String, boolean) - Method in class org.h2.store.fs.rec.FilePathRec
 
createTempFile(String, boolean) - Method in class org.h2.store.fs.zip.FilePathZip
 
createTempFile(String, String, boolean) - Static method in class org.h2.store.fs.FileUtils
Create a new temporary file.
createTempLobFileName(DataHandler) - Static method in class org.h2.value.ValueLob
Create file name for temporary LOB storage
createTemporary(DataHandler, byte[], int, InputStream, long) - Static method in class org.h2.value.ValueBlob
Create a BLOB in a temporary file.
createTemporary(DataHandler, Reader, long) - Static method in class org.h2.value.ValueClob
Create a CLOB in a temporary file.
createTemporaryTable(PrintWriter) - Method in class org.h2.tools.Recover
 
createTempView(SessionLocal, User, String, Column[], Query, Query) - Static method in class org.h2.table.TableView
Create a temporary view out of the given query.
createTrayIcon() - Method in class org.h2.tools.GUIConsole
 
createTrigger(Connection, String, String) - Static method in class org.h2.fulltext.FullText
Create the trigger.
createTrigger(Connection, String, String) - Static method in class org.h2.fulltext.FullTextLucene
Create the trigger.
CreateTrigger - Class in org.h2.command.ddl
This class represents the statement CREATE TRIGGER
CreateTrigger(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.CreateTrigger
 
createUndoLogBuilder() - Method in class org.h2.mvstore.tx.TransactionStore
 
createUnique(boolean, boolean) - Static method in class org.h2.index.IndexType
Create a unique index.
createUniqueConstraint(Table, Index, IndexColumn[], boolean) - Method in class org.h2.command.ddl.AlterTableAddConstraint
 
createUniqueConstraintForReferencedColumns - Variable in class org.h2.engine.Mode
If true, referential constraints will create a unique constraint on referenced columns if it doesn't exist instead of throwing an exception.
createUseIndexHints(LinkedHashSet<String>) - Static method in class org.h2.table.IndexHints
Create an index hint object.
CreateUser - Class in org.h2.command.ddl
This class represents the statement CREATE USER
CreateUser(SessionLocal) - Constructor for class org.h2.command.ddl.CreateUser
 
createValueStorage(int) - Method in class org.h2.mvstore.Page
Create array for values storage.
createVersion - Variable in class org.h2.mvstore.MVMap
 
createView - Variable in class org.h2.command.Parser
 
CreateView - Class in org.h2.command.ddl
This class represents the statement CREATE VIEW
CreateView(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.CreateView
 
createViewLevel - Variable in class org.h2.engine.SessionLocal
 
createWebServer(String...) - Static method in class org.h2.tools.Server
Create a new web server, but does not start it yet.
createWebServer(String[], String, boolean) - Static method in class org.h2.tools.Server
Create a new web server, but does not start it yet.
createXADataSource(Properties) - Method in class org.h2.util.OsgiDataSourceFactory
Creates a pooled XA data source.
createXTS() - Method in class org.h2.store.fs.encrypt.FileEncrypt
 
creationTime - Variable in class org.h2.mvstore.MVStore
The time the store was created, in milliseconds since 1970.
CredentialsValidator - Interface in org.h2.api
A class that implement this interface can be used to validate credentials provided by client.
CROSS - Static variable in class org.h2.util.ParserUtil
The token "CROSS".
CROSS_REFERENCES - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
CryptFunction - Class in org.h2.expression.function
An ENCRYPT or DECRYPT function.
CryptFunction(Expression, Expression, Expression, int) - Constructor for class org.h2.expression.function.CryptFunction
 
Csv - Class in org.h2.tools
A facility to read from and write to CSV (comma separated values) files.
Csv() - Constructor for class org.h2.tools.Csv
 
CSVReadFunction - Class in org.h2.expression.function.table
A CSVREAD function.
CSVReadFunction() - Constructor for class org.h2.expression.function.table.CSVReadFunction
 
CSVWriteFunction - Class in org.h2.expression.function
A CSVWRITE function.
CSVWriteFunction() - Constructor for class org.h2.expression.function.CSVWriteFunction
 
cteCleanups - Variable in class org.h2.command.Parser
 
cteCleanups - Variable in class org.h2.command.Prepared
Common table expressions (CTE) in queries require us to create temporary views, which need to be cleaned up once a command is done executing.
CUME_DIST - org.h2.expression.aggregate.AggregateType
The type for CUME_DIST() hypothetical set function.
CUME_DIST - org.h2.expression.analysis.WindowFunctionType
The type for CUME_DIST() window function.
current - Variable in class org.h2.expression.function.CompatibilitySequenceValueFunction
 
current - Variable in class org.h2.expression.SequenceValue
 
current - Variable in class org.h2.index.LinkedCursor
 
current - Variable in class org.h2.index.MetaCursor
 
current - Variable in class org.h2.index.RangeCursor
 
current - Variable in class org.h2.index.ViewCursor
 
current - Variable in class org.h2.mvstore.Cursor
 
current - Variable in class org.h2.mvstore.db.MVPrimaryIndex.MVStoreCursor
 
current - Variable in class org.h2.mvstore.db.MVSecondaryIndex.MVStoreCursor
 
current - Variable in class org.h2.mvstore.db.MVSortedTempResult
Current value for the MVSortedTempResult.next() method.
current - Variable in class org.h2.mvstore.db.MVSpatialIndex.MVStoreCursor
 
current - Variable in class org.h2.mvstore.db.MVSpatialIndex.SpatialKeyIterator
 
current - Variable in class org.h2.mvstore.rtree.MVRTreeMap.RTreeCursor
 
current - Variable in class org.h2.mvstore.tx.TransactionMap.TMIterator
 
current - Variable in class org.h2.table.GeneratedColumnResolver
 
current - Variable in class org.h2.table.TableFilter
 
CURRENT_CATALOG - Static variable in class org.h2.expression.function.CurrentGeneralValueSpecification
The "CURRENT_CATALOG" general value specification.
CURRENT_CATALOG - Static variable in class org.h2.util.ParserUtil
The token "CURRENT_CATALOG".
CURRENT_DATABASE - Static variable in class org.h2.mode.FunctionsPostgreSQL
 
CURRENT_DATE - Static variable in class org.h2.expression.function.CurrentDateTimeValueFunction
The function "CURRENT_DATE"
CURRENT_DATE - Static variable in class org.h2.util.ParserUtil
The token "CURRENT_DATE".
CURRENT_PATH - Static variable in class org.h2.expression.function.CurrentGeneralValueSpecification
The "CURRENT_PATH" general value specification.
CURRENT_PATH - Static variable in class org.h2.util.ParserUtil
The token "CURRENT_PATH".
CURRENT_ROLE - Static variable in class org.h2.expression.function.CurrentGeneralValueSpecification
The function "CURRENT_ROLE" general value specification.
CURRENT_ROLE - Static variable in class org.h2.util.ParserUtil
The token "CURRENT_ROLE".
CURRENT_ROW - org.h2.expression.analysis.WindowFrameBoundType
CURRENT_ROW clause.
CURRENT_SCHEMA - Static variable in class org.h2.expression.function.CurrentGeneralValueSpecification
The function "CURRENT_SCHEMA" general value specification.
CURRENT_SCHEMA - Static variable in class org.h2.util.ParserUtil
The token "CURRENT_SCHEMA".
CURRENT_SEQUENCE_VALUE_IS_NOT_DEFINED_IN_SESSION_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90148 is thrown when trying to access the current value of a sequence before execution of NEXT VALUE FOR sequenceName in the current session.
CURRENT_TIME - Static variable in class org.h2.expression.function.CurrentDateTimeValueFunction
The function "CURRENT_TIME"
CURRENT_TIME - Static variable in class org.h2.util.ParserUtil
The token "CURRENT_TIME".
CURRENT_TIMESTAMP - Static variable in class org.h2.expression.function.CurrentDateTimeValueFunction
The function "CURRENT_TIMESTAMP"
CURRENT_TIMESTAMP - Static variable in class org.h2.util.ParserUtil
The token "CURRENT_TIMESTAMP".
CURRENT_USER - Static variable in class org.h2.expression.function.CurrentGeneralValueSpecification
The function "CURRENT_USER" general value specification.
CURRENT_USER - Static variable in class org.h2.util.ParserUtil
The token "CURRENT_USER".
currentCommand - Variable in class org.h2.engine.SessionLocal
 
CurrentDateTimeValueFunction - Class in org.h2.expression.function
Current datetime value function.
CurrentDateTimeValueFunction(int, int) - Constructor for class org.h2.expression.function.CurrentDateTimeValueFunction
 
CurrentGeneralValueSpecification - Class in org.h2.expression.function
Simple general value specifications.
CurrentGeneralValueSpecification(int) - Constructor for class org.h2.expression.function.CurrentGeneralValueSpecification
 
currentGroupByExprData - Variable in class org.h2.command.query.SelectGroups
The array of current group-by expression data e.g.
currentGroupRowId - Variable in class org.h2.command.query.SelectGroups
The id of the current group.
currentGroupsKey - Variable in class org.h2.command.query.SelectGroups.Grouped
Key into groupByData that produces currentGroupByExprData.
currentMonth - Variable in class org.h2.mode.ToDateParser
 
currentNanoTime() - Static method in class org.h2.util.Utils
Returns the current value of the high-resolution time source.
currentNanoTimePlusMillis(int) - Static method in class org.h2.util.Utils
Returns the current value of the high-resolution time source plus the specified offset.
currentPrepared - Variable in class org.h2.command.Parser
 
currentRow - Variable in class org.h2.command.query.TableValueConstructor.TableValueColumnResolver
 
currentRow - Variable in class org.h2.index.DualCursor
 
currentRow - Variable in class org.h2.index.RangeCursor
 
currentRow - Variable in class org.h2.result.FetchedResult
 
currentRow - Variable in class org.h2.result.LocalResult
 
currentRow - Variable in class org.h2.tools.SimpleResultSet
 
currentRow() - Method in class org.h2.result.FetchedResult
 
currentRow() - Method in class org.h2.result.LocalResult
 
currentRow() - Method in interface org.h2.result.ResultInterface
Get the current row.
currentRow() - Method in class org.h2.result.ResultWithPaddedStrings
 
currentRow() - Method in class org.h2.result.SimpleResult
 
currentRowData - Variable in class org.h2.mvstore.db.MVSecondaryIndex.Source
 
currentRowForTable() - Method in class org.h2.result.LocalResult
Retrieve the current row
currentRowNumber - Variable in class org.h2.command.Prepared
 
currentSchemaName - Variable in class org.h2.engine.SessionLocal
 
currentSchemaName - Variable in class org.h2.engine.SessionRemote
 
currentSearchRow - Variable in class org.h2.table.TableFilter
 
currentSelect - Variable in class org.h2.command.Parser
 
currentSize() - Method in class org.h2.command.ddl.Analyze.SelectivityData
 
currentStoreVersion - Variable in class org.h2.mvstore.MVStore
The version of the current store operation (if any).
currentTimestamp - Variable in class org.h2.engine.SessionLocal
 
currentTimestamp() - Method in interface org.h2.engine.CastDataProvider
Returns the current timestamp with maximum resolution.
currentTimestamp() - Method in class org.h2.engine.Database
 
currentTimestamp() - Method in class org.h2.engine.SessionLocal
 
currentTimestamp() - Method in class org.h2.engine.SessionRemote
 
currentTimestamp() - Method in class org.h2.jdbc.JdbcConnection
 
currentTimestamp(TimeZoneProvider) - Static method in class org.h2.util.DateTimeUtils
Returns current timestamp.
currentTimestamp(TimeZoneProvider, Instant) - Static method in class org.h2.util.DateTimeUtils
Returns current timestamp using the specified instant for its value.
currentTimeZone() - Method in interface org.h2.engine.CastDataProvider
Returns the current time zone.
currentTimeZone() - Method in class org.h2.engine.Database
 
currentTimeZone() - Method in class org.h2.engine.SessionLocal
 
currentTimeZone() - Method in class org.h2.engine.SessionRemote
 
currentTimeZone() - Method in class org.h2.jdbc.JdbcConnection
 
currentToken - Variable in class org.h2.bnf.Bnf
 
currentToken - Variable in class org.h2.command.Parser
 
currentTokenType - Variable in class org.h2.command.Parser
 
currentTopic - Variable in class org.h2.bnf.Bnf
 
currentTransaction - Variable in class org.h2.jdbcx.JdbcXAConnection
 
currentTransactionName - Variable in class org.h2.engine.SessionLocal
 
currentTxCounter - Variable in class org.h2.mvstore.MVStore
Counter of open transactions for the latest (current) store version
currentValueFor - Variable in class org.h2.engine.SessionLocal
 
currentVersion - Variable in class org.h2.mvstore.MVStore
 
currentYear - Variable in class org.h2.mode.ToDateParser
 
CURRTID2 - Static variable in class org.h2.mode.FunctionsPostgreSQL
 
cursor - Variable in class org.h2.command.query.SelectGroups.Grouped
Cursor for SelectGroups.Grouped.next() method.
cursor - Variable in class org.h2.command.query.SelectGroups.Plain
Cursor for SelectGroups.Plain.next() method.
cursor - Variable in class org.h2.expression.analysis.WindowFrame.Itr
 
cursor - Variable in class org.h2.index.IndexCursor
 
cursor - Variable in class org.h2.mvstore.db.MVPlainTempResult
Cursor for the MVPlainTempResult.next() method.
cursor - Variable in class org.h2.mvstore.db.MVSortedTempResult
Cursor for the MVSortedTempResult.next() method.
cursor - Variable in class org.h2.mvstore.tx.TransactionMap.TMIterator
 
cursor - Variable in class org.h2.table.TableFilter
The filter used to walk through the index.
cursor(K) - Method in class org.h2.mvstore.MVMap
Get a cursor to iterate over a number of keys and values in the latest version of this map.
cursor(K, K, boolean) - Method in class org.h2.mvstore.MVMap
Get a cursor to iterate over a number of keys and values in the latest version of this map.
cursor(RootReference<K, V>, K, K, boolean) - Method in class org.h2.mvstore.MVMap
Get a cursor to iterate over a number of keys and values.
Cursor<K,​V> - Class in org.h2.mvstore
A cursor to iterate over elements in ascending or descending order.
Cursor - Interface in org.h2.index
A cursor is a helper object to iterate through an index.
Cursor(RootReference<K, V>, K, K) - Constructor for class org.h2.mvstore.Cursor
 
Cursor(RootReference<K, V>, K, K, boolean) - Constructor for class org.h2.mvstore.Cursor
 
cursorPos - Variable in class org.h2.mvstore.Cursor
 
CursorPos<K,​V> - Class in org.h2.mvstore
A position in a cursor.
CursorPos(Page<K, V>, int, CursorPos<K, V>) - Constructor for class org.h2.mvstore.CursorPos
 
cycle - Variable in class org.h2.command.ddl.SequenceOptions
 
cycle - Variable in class org.h2.schema.Sequence
 
Cycle() - Constructor for enum org.h2.schema.Sequence.Cycle
 
CYCLE - org.h2.schema.Sequence.Cycle
Sequence is cycled.

D

D - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
data - Variable in class org.h2.command.ddl.CreateSynonym
 
data - Variable in class org.h2.command.ddl.CreateTable
 
data - Variable in class org.h2.command.dml.ScriptCommand
 
data - Variable in class org.h2.expression.analysis.PartitionData
Aggregate data.
data - Variable in class org.h2.result.DefaultRow
The values of the row (one entry per column).
data - Variable in class org.h2.result.MergedResult
 
data - Variable in class org.h2.result.SimpleRowValue
 
data - Variable in class org.h2.store.Data
The data itself.
data - Variable in class org.h2.store.fs.mem.FileMem
The file data.
data - Variable in class org.h2.store.fs.mem.FileMemData
 
data - Variable in class org.h2.store.fs.niomem.FileNioMem
The file data.
data - Variable in class org.h2.store.fs.niomem.FileNioMemData.CompressItem
The file data.
data - Variable in class org.h2.table.TableSynonym
 
data - Variable in class org.h2.util.IntArray
 
Data - Class in org.h2.store
This class represents a byte buffer that contains persistent data of a page.
Data(byte[]) - Constructor for class org.h2.store.Data
 
DATA_CONVERSION_ERROR_1 - Static variable in class org.h2.api.ErrorCode
The error with code 22018 is thrown when trying to convert a value to a data type where the conversion is undefined, or when an error occurred trying to convert.
DATA_SOURCE - Static variable in class org.h2.message.TraceObject
The trace type id for data sources.
DataAnalysisOperation - Class in org.h2.expression.analysis
A base class for data analysis operations such as aggregates and window functions.
DataAnalysisOperation(Select) - Constructor for class org.h2.expression.analysis.DataAnalysisOperation
 
database - Variable in class org.h2.command.Parser
 
database - Variable in class org.h2.engine.DbObject
The database.
database - Variable in class org.h2.engine.Engine.DatabaseHolder
 
database - Variable in class org.h2.engine.SessionLocal
 
database - Variable in class org.h2.expression.ExpressionColumn
 
database - Variable in class org.h2.jmx.DatabaseInfo
Database.
database - Variable in class org.h2.mvstore.db.LobStorageMap
 
database - Variable in class org.h2.mvstore.db.MVTempResult
 
database - Variable in class org.h2.mvstore.type.MetaType
 
Database - Class in org.h2.engine
There is one database object per open database.
Database(ConnectionInfo, String) - Constructor for class org.h2.engine.Database
 
DATABASE - Static variable in class org.h2.message.Trace
The trace module id for databases.
DATABASE_ALREADY_OPEN_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90020 is thrown when trying to open a database in embedded mode if this database is already in use in another process (or in a different class loader).
DATABASE_CALLED_AT_SHUTDOWN - Static variable in class org.h2.api.ErrorCode
The error with code 90121 is thrown when a database operation is started while the virtual machine exits (for example in a shutdown hook), or when the session is closed.
DATABASE_EVENT_LISTENER - Static variable in class org.h2.command.dml.SetTypes
The type of a SET DATABASE_EVENT_LISTENER statement.
DATABASE_IS_CLOSED - Static variable in class org.h2.api.ErrorCode
The error with code 90098 is thrown when the database has been closed, for example because the system ran out of memory or because the self-destruction counter has reached zero.
DATABASE_IS_IN_EXCLUSIVE_MODE - Static variable in class org.h2.api.ErrorCode
The error with code 90135 is thrown when trying to open a connection to a database that is currently open in exclusive mode.
DATABASE_IS_NOT_PERSISTENT - Static variable in class org.h2.api.ErrorCode
The error with code 90126 is thrown when trying to call the BACKUP statement for an in-memory database.
DATABASE_IS_READ_ONLY - Static variable in class org.h2.api.ErrorCode
The error with code 90097 is thrown when trying to delete or update a database if it is open in read-only mode.
DATABASE_META_DATA - Static variable in class org.h2.message.TraceObject
The trace type id for database meta data objects.
DATABASE_NOT_FOUND_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90013 is thrown when when trying to access a database object with a catalog name that does not match the database name.
DATABASE_NOT_FOUND_WITH_IF_EXISTS_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90146 is thrown when trying to open a database that does not exist using the flag IFEXISTS=TRUE
DATABASE_PATH - Static variable in class org.h2.expression.function.SysInfoFunction
DATABASE_PATH().
DatabaseEventListener - Interface in org.h2.api
A class that implements this interface can get notified about exceptions and other events.
DatabaseHolder() - Constructor for class org.h2.engine.Engine.DatabaseHolder
 
DatabaseInfo - Class in org.h2.jmx
The MBean implementation.
DatabaseInfo(Database) - Constructor for class org.h2.jmx.DatabaseInfo
 
DatabaseInfoMBean - Interface in org.h2.jmx
Information and management operations for the given database.
DatabaseMeta - Class in org.h2.jdbc.meta
Database meta information.
DatabaseMeta() - Constructor for class org.h2.jdbc.meta.DatabaseMeta
 
DatabaseMetaLegacy - Class in org.h2.jdbc.meta
Legacy implementation of database meta information.
DatabaseMetaLegacy(Session) - Constructor for class org.h2.jdbc.meta.DatabaseMetaLegacy
 
DatabaseMetaLocal - Class in org.h2.jdbc.meta
Local implementation of database meta information.
DatabaseMetaLocal(SessionLocal) - Constructor for class org.h2.jdbc.meta.DatabaseMetaLocal
 
DatabaseMetaLocalBase - Class in org.h2.jdbc.meta
Base implementation of database meta information.
DatabaseMetaLocalBase() - Constructor for class org.h2.jdbc.meta.DatabaseMetaLocalBase
 
DatabaseMetaRemote - Class in org.h2.jdbc.meta
Remote implementation of database meta information.
DatabaseMetaRemote(SessionRemote, ArrayList<Transfer>) - Constructor for class org.h2.jdbc.meta.DatabaseMetaRemote
 
DatabaseMetaServer - Class in org.h2.jdbc.meta
Server side support of database meta information.
DatabaseMetaServer() - Constructor for class org.h2.jdbc.meta.DatabaseMetaServer
 
databaseName - Variable in class org.h2.engine.Database
 
databaseName - Variable in class org.h2.engine.SessionRemote
 
databaseName - Variable in class org.h2.server.pg.PgServerThread
 
databaseName - Variable in class org.h2.tools.Recover
 
databaseRef - Variable in class org.h2.engine.DelayedDatabaseCloser
 
DATABASES - Static variable in class org.h2.engine.Engine
 
DATABASES - Static variable in class org.h2.engine.OnExitDatabaseCloser
 
databaseShortName - Variable in class org.h2.engine.Database
 
databaseToLower - Variable in class org.h2.bnf.context.DbContents
 
databaseToLower - Variable in class org.h2.engine.DbSettings
Database setting DATABASE_TO_LOWER (default: false).
databaseToLower - Variable in class org.h2.engine.Session.StaticSettings
Whether unquoted identifiers are converted to lower case.
databaseToUpper - Variable in class org.h2.bnf.context.DbContents
 
databaseToUpper - Variable in class org.h2.engine.DbSettings
Database setting DATABASE_TO_UPPER (default: true).
databaseToUpper - Variable in class org.h2.engine.Session.StaticSettings
Whether unquoted identifiers are converted to upper case.
databaseURL - Variable in class org.h2.engine.Database
 
DataChangeDeltaTable - Class in org.h2.table
A data change delta table.
DataChangeDeltaTable(Schema, SessionLocal, DataChangeStatement, DataChangeDeltaTable.ResultOption) - Constructor for class org.h2.table.DataChangeDeltaTable
 
DataChangeDeltaTable.ResultOption - Enum in org.h2.table
Result option.
DataChangeStatement - Class in org.h2.command.dml
Data change statement.
DataChangeStatement(SessionLocal) - Constructor for class org.h2.command.dml.DataChangeStatement
Creates new instance of DataChangeStatement.
dataDefinitionCausesTransactionCommit() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether CREATE/DROP commit an open transaction.
dataDefinitionIgnoredInTransactions() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether CREATE/DROP do not affect transactions.
DataHandler - Interface in org.h2.store
A data handler contains a number of callback methods, mostly related to CLOB and BLOB handling.
dataIn - Variable in class org.h2.server.pg.PgServerThread
 
dataInRaw - Variable in class org.h2.server.pg.PgServerThread
 
dataLength - Variable in class org.h2.server.web.WebThread
 
dataMap - Variable in class org.h2.mvstore.db.MVPrimaryIndex
 
dataMap - Variable in class org.h2.mvstore.db.MVSecondaryIndex
 
dataMap - Variable in class org.h2.mvstore.db.MVSpatialIndex
 
dataOut - Variable in class org.h2.server.pg.PgServerThread
 
DataReader - Class in org.h2.store
This class is backed by an input stream and supports reading values and variable size data.
DataReader(InputStream) - Constructor for class org.h2.store.DataReader
Create a new data reader.
DataReader.FastEOFException - Exception in org.h2.store
Constructing such an EOF exception is fast, because the stack trace is not filled in.
dataSource - Variable in class org.h2.jdbcx.JdbcConnectionPool
 
DATASOURCE_FACTORY_CLASS - Static variable in class org.h2.util.DbDriverActivator
 
DATASOURCE_TRACE_LEVEL - Static variable in class org.h2.engine.SysProperties
System property h2.dataSourceTraceLevel (default: 1).
dataType - Variable in class org.h2.bnf.context.DbColumn
 
dataType - Variable in class org.h2.command.ddl.CreateDomain
 
dataType - Variable in class org.h2.command.ddl.SequenceOptions
 
dataType - Variable in class org.h2.expression.aggregate.AggregateDataAvg
 
dataType - Variable in class org.h2.expression.aggregate.AggregateDataDefault
 
dataType - Variable in class org.h2.expression.aggregate.JavaAggregate
 
dataType - Variable in class org.h2.mvstore.MVMap.EqualsDecisionMaker
 
dataType - Variable in class org.h2.mvstore.tx.TransactionStore
 
dataType - Variable in class org.h2.result.RowFactory.DefaultRowFactory
 
dataType - Variable in class org.h2.schema.FunctionAlias.JavaMethod
 
dataType - Variable in class org.h2.schema.Sequence
 
dataType - Variable in class org.h2.table.InformationSchemaTable.DataTypeInformation
DATA_TYPE.
DataType - Class in org.h2.value
This class contains meta data information about data types, and can convert between Java objects and Values.
DataType<T> - Interface in org.h2.mvstore.type
A data type.
DataType() - Constructor for class org.h2.value.DataType
 
DataTypeInformation(String, Value, Value, Value, Value, Value, Value, Value, Value, boolean, String, Value, Value, String, Value) - Constructor for class org.h2.table.InformationSchemaTable.DataTypeInformation
 
DataTypeSQLFunction - Class in org.h2.expression.function
DATA_TYPE_SQL() function.
DataTypeSQLFunction(Expression, Expression, Expression, Expression) - Constructor for class org.h2.expression.function.DataTypeSQLFunction
 
DataUtils - Class in org.h2.mvstore
Utility methods
DataUtils() - Constructor for class org.h2.mvstore.DataUtils
 
DATE - Static variable in class org.h2.api.H2Type
The DATE data type.
DATE - Static variable in class org.h2.mode.FunctionsMySQL
 
DATE - Static variable in class org.h2.mvstore.db.ValueDataType
 
DATE - Static variable in class org.h2.value.Transfer
 
DATE - Static variable in class org.h2.value.Value
The value type for DATE values.
DATE_TIME_FORMAT - Static variable in class org.h2.mode.FunctionsMySQL
The date format of a MySQL formatted date/time.
DATE_TRUNC - Static variable in class org.h2.expression.function.DateTimeFunction
DATE_TRUNC() (non-standard).
dateadd(SessionLocal, int, long, Value) - Static method in class org.h2.expression.function.DateTimeFunction
DATEADD function.
DATEADD - Static variable in class org.h2.expression.function.DateTimeFunction
DATEADD() (non-standard).
dateAndTimeFromValue(Value, CastDataProvider) - Static method in class org.h2.util.DateTimeUtils
Extracts date value and nanos of day from the specified value.
datediff(SessionLocal, int, Value, Value) - Static method in class org.h2.expression.function.DateTimeFunction
Calculate the number of crossed unit boundaries between two timestamps.
DATEDIFF - Static variable in class org.h2.expression.function.DateTimeFunction
DATEDIFF() (non-standard).
dateFormat - Variable in class org.h2.message.TraceSystem
 
dateStyle - Variable in class org.h2.server.pg.PgServerThread
 
DATETIME_MINUS_DATETIME - org.h2.expression.IntervalOperation.IntervalOpType
Date-time minus date-time.
DATETIME_MINUS_INTERVAL - org.h2.expression.IntervalOperation.IntervalOpType
Date-time minus interval.
DATETIME_PLUS_INTERVAL - org.h2.expression.IntervalOperation.IntervalOpType
Date-time plus interval.
DateTimeFormatFunction - Class in org.h2.expression.function
A date-time format function.
DateTimeFormatFunction(int) - Constructor for class org.h2.expression.function.DateTimeFormatFunction
 
DateTimeFormatFunction.CacheKey - Class in org.h2.expression.function
 
DateTimeFormatFunction.CacheValue - Class in org.h2.expression.function
 
DateTimeFunction - Class in org.h2.expression.function
A date-time function.
DateTimeFunction(int, int, Expression, Expression) - Constructor for class org.h2.expression.function.DateTimeFunction
 
datetimePrecision - Variable in class org.h2.table.InformationSchemaTable.DataTypeInformation
DATETIME_PRECISION.
dateTimeToValue(Value, long, long) - Static method in class org.h2.util.DateTimeUtils
Creates a new date-time value with the same type as original value.
DateTimeUtils - Class in org.h2.util
This utility class contains time conversion functions.
DateTimeUtils() - Constructor for class org.h2.util.DateTimeUtils
 
dateTimeValueWithinTransaction - Variable in class org.h2.engine.Mode
If true, datetime value function return the same value within a transaction, if false datetime value functions return the same value within a command.
DateType() - Constructor for class org.h2.mvstore.type.ObjectDataType.DateType
 
dateValue - Variable in class org.h2.value.ValueDate
 
dateValue - Variable in class org.h2.value.ValueTimestamp
A bit field with bits for the year, month, and day (see DateTimeUtils for encoding)
dateValue - Variable in class org.h2.value.ValueTimestampTimeZone
A bit field with bits for the year, month, and day (see DateTimeUtils for encoding)
dateValue(long, int, int) - Static method in class org.h2.util.DateTimeUtils
Get the date value from a given date.
dateValueFromAbsoluteDay(long) - Static method in class org.h2.util.DateTimeUtils
Calculate the encoded date value from an absolute day.
dateValueFromDenormalizedDate(long, long, int) - Static method in class org.h2.util.DateTimeUtils
Get the date value from a given denormalized date with possible out of range values of month and/or day.
dateValueFromLocalMillis(long) - Static method in class org.h2.util.LegacyDateTimeUtils
Convert a local datetime in millis to an encoded date.
dateValueFromLocalSeconds(long) - Static method in class org.h2.util.DateTimeUtils
Convert a local seconds to an encoded date.
day - Variable in class org.h2.mode.ToDateParser
 
DAY - org.h2.api.IntervalQualifier
DAY
DAY - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
DAY - Static variable in class org.h2.expression.function.DateTimeFunction
Day of month.
DAY - Static variable in class org.h2.util.ParserUtil
The token "DAY".
DAY_OF_WEEK - Static variable in class org.h2.expression.function.DateTimeFunction
Day of week (locale-specific).
DAY_OF_YEAR - Static variable in class org.h2.expression.function.DateTimeFunction
Day of year.
DAY_TO_HOUR - org.h2.api.IntervalQualifier
DAY TO HOUR
DAY_TO_MINUTE - org.h2.api.IntervalQualifier
DAY TO MINUTE
DAY_TO_SECOND - org.h2.api.IntervalQualifier
DAY TO SECOND
dayFromDateValue(long) - Static method in class org.h2.util.DateTimeUtils
Get the day of month from a date value.
DayMonthNameFunction - Class in org.h2.expression.function
A DAYNAME() or MONTHNAME() function.
DayMonthNameFunction(Expression, int) - Constructor for class org.h2.expression.function.DayMonthNameFunction
 
DAYNAME - Static variable in class org.h2.expression.function.DayMonthNameFunction
DAYNAME() (non-standard).
dayOfYear - Variable in class org.h2.mode.ToDateParser
 
DayParslet() - Constructor for class org.h2.mode.ToDateTokenizer.DayParslet
 
daysFromInterval(IntervalQualifier, boolean, long, long) - Static method in class org.h2.util.IntervalUtils
Returns days value of interval, if any.
DB_CLOSE_DELAY - Static variable in class org.h2.command.dml.SetTypes
The type of a SET DB_CLOSE_DELAY statement.
DB_OBJECT_ID - Static variable in class org.h2.expression.function.DBObjectFunction
DB_OBJECT_ID() (non-standard).
DB_OBJECT_SQL - Static variable in class org.h2.expression.function.DBObjectFunction
DB_OBJECT_SQL() (non-standard).
DB2 - org.h2.engine.Mode.ModeEnum
 
dbCloseOnExit - Variable in class org.h2.engine.DbSettings
Database setting DB_CLOSE_ON_EXIT (default: true).
DbColumn - Class in org.h2.bnf.context
Keeps the meta data information of a column.
DbColumn(DbContents, ResultSet, boolean) - Constructor for class org.h2.bnf.context.DbColumn
 
DbContents - Class in org.h2.bnf.context
Keeps meta data information about a database.
DbContents() - Constructor for class org.h2.bnf.context.DbContents
 
DbContextRule - Class in org.h2.bnf.context
A BNF terminal rule that is linked to the database context information.
DbContextRule(DbContents, int) - Constructor for class org.h2.bnf.context.DbContextRule
BNF terminal rule Constructor
DbDriverActivator - Class in org.h2.util
The driver activator loads the H2 driver when starting the bundle.
DbDriverActivator() - Constructor for class org.h2.util.DbDriverActivator
 
DbException - Exception in org.h2.message
This exception wraps a checked exception.
DbException(SQLException) - Constructor for exception org.h2.message.DbException
 
DbObject - Class in org.h2.engine
A database object such as a table, an index, or a user.
DbObject(Database, int, String, int) - Constructor for class org.h2.engine.DbObject
Initialize some attributes of this object.
DBObjectFunction - Class in org.h2.expression.function
DB_OBJECT_ID() and DB_OBJECT_SQL() functions.
DBObjectFunction(Expression, Expression, Expression, int) - Constructor for class org.h2.expression.function.DBObjectFunction
 
DbProcedure - Class in org.h2.bnf.context
Contains meta data information about a procedure.
DbProcedure(DbSchema, ResultSet) - Constructor for class org.h2.bnf.context.DbProcedure
 
DbSchema - Class in org.h2.bnf.context
Contains meta data information about a database schema.
DbSchema(DbContents, String, boolean) - Constructor for class org.h2.bnf.context.DbSchema
 
dbSettings - Variable in class org.h2.engine.Database
 
DbSettings - Class in org.h2.engine
This class contains various database-level settings.
DbSettings(HashMap<String, String>) - Constructor for class org.h2.engine.DbSettings
 
DbStarter - Class in org.h2.server.web
This class can be used to start the H2 TCP server (or other H2 servers, for example the PG server) inside a web application container such as Tomcat or Jetty.
DbStarter() - Constructor for class org.h2.server.web.DbStarter
 
DbTableOrView - Class in org.h2.bnf.context
Contains meta data information about a table or a view.
DbTableOrView(DbSchema, ResultSet) - Constructor for class org.h2.bnf.context.DbTableOrView
 
DD - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
DDD - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
deadChunks - Variable in class org.h2.mvstore.MVStore
 
DEADLOCK_1 - Static variable in class org.h2.api.ErrorCode
The error with code 40001 is thrown when the database engine has detected a deadlock.
DEADLOCK_CHECK - Static variable in class org.h2.engine.Constants
The number of milliseconds after which to check for a deadlock if locking is not successful.
DEALLOCATE - Static variable in interface org.h2.command.CommandInterface
The type of a DEALLOCATE statement.
DeallocateProcedure - Class in org.h2.command.ddl
This class represents the statement DEALLOCATE
DeallocateProcedure(SessionLocal) - Constructor for class org.h2.command.ddl.DeallocateProcedure
 
debug(String) - Method in class org.h2.message.Trace
Write a message with trace level DEBUG to the trace system.
debug(String, Object...) - Method in class org.h2.message.Trace
Write a message with trace level DEBUG to the trace system.
debug(Throwable, String) - Method in class org.h2.message.Trace
Write a message with trace level DEBUG to the trace system.
DEBUG - Static variable in class org.h2.message.TraceSystem
This trace level means all type of messages should be written.
debugCode(String) - Method in class org.h2.message.Trace
Write Java source code with trace level DEBUG to the trace system.
debugCode(String) - Method in class org.h2.message.TraceObject
Write trace information in the form objectName.text.
debugCodeAssign(String, int, int, String) - Method in class org.h2.message.TraceObject
Write trace information as an assignment in the form className prefixId = objectName.value.
debugCodeCall(String) - Method in class org.h2.message.TraceObject
Write trace information as a method call in the form objectName.methodName().
debugCodeCall(String, long) - Method in class org.h2.message.TraceObject
Write trace information as a method call in the form objectName.methodName(param) where the parameter is formatted as a long value.
debugCodeCall(String, String) - Method in class org.h2.message.TraceObject
Write trace information as a method call in the form objectName.methodName(param) where the parameter is formatted as a Java string.
DebuggingThreadLocal<T> - Class in org.h2.util
Similar to ThreadLocal, except that it allows its data to be read from other threads - useful for debugging info.
DebuggingThreadLocal() - Constructor for class org.h2.util.DebuggingThreadLocal
 
decade(int) - Static method in class org.h2.expression.function.DateTimeFunction
 
DECADE - Static variable in class org.h2.expression.function.DateTimeFunction
Decade.
DECFLOAT - Static variable in class org.h2.api.H2Type
The DECFLOAT data type.
DECFLOAT - Static variable in class org.h2.mvstore.db.ValueDataType
 
DECFLOAT - Static variable in class org.h2.value.Transfer
 
DECFLOAT - Static variable in class org.h2.value.Value
The value type for DECFLOAT values.
decide(Record, Record) - Method in class org.h2.mvstore.tx.RollbackDecisionMaker
 
decide(VersionedValue<V>, VersionedValue<V>) - Method in class org.h2.mvstore.tx.CommitDecisionMaker
 
decide(VersionedValue<V>, VersionedValue<V>) - Method in class org.h2.mvstore.tx.TxDecisionMaker
 
decide(VersionedValue<V>, VersionedValue<V>) - Method in class org.h2.mvstore.tx.TxDecisionMaker.LockDecisionMaker
 
decide(VersionedValue<V>, VersionedValue<V>) - Method in class org.h2.mvstore.tx.TxDecisionMaker.PutIfAbsentDecisionMaker
 
decide(V, V) - Method in class org.h2.mvstore.MVMap.DecisionMaker
Makes a decision about how to proceed with the update.
decide(V, V) - Method in class org.h2.mvstore.MVMap.EqualsDecisionMaker
 
decide(V, V) - Method in class org.h2.mvstore.MVMap.RewriteDecisionMaker
 
decide(V, V, CursorPos<?, ?>) - Method in class org.h2.mvstore.MVMap.DecisionMaker
Makes a decision about how to proceed with the update.
decide(V, V, CursorPos<?, ?>) - Method in class org.h2.mvstore.MVMap.RewriteDecisionMaker
 
decideToAbort(V) - Method in class org.h2.mvstore.tx.TxDecisionMaker
 
DECIMAL - Static variable in class org.h2.value.ExtTypeInfoNumeric
DECIMAL data type.
DECIMAL_PRECISION - Static variable in class org.h2.value.ValueBigint
The approximate precision in decimal digits.
DECIMAL_PRECISION - Static variable in class org.h2.value.ValueDouble
The approximate precision in decimal digits.
DECIMAL_PRECISION - Static variable in class org.h2.value.ValueInteger
The approximate precision in decimal digits.
DECIMAL_PRECISION - Static variable in class org.h2.value.ValueReal
The approximate precision in decimal digits.
DECIMAL_PRECISION - Static variable in class org.h2.value.ValueSmallint
The approximate precision in decimal digits.
DECIMAL_PRECISION - Static variable in class org.h2.value.ValueTinyint
The approximate precision in decimal digits.
decimalSequences - Variable in class org.h2.engine.Mode
If true NEXT VALUE FOR SEQUENCE, CURRENT VALUE FOR SEQUENCE, SEQUENCE.NEXTVAL, and SEQUENCE.CURRVAL return values with DECIMAL/NUMERIC data type instead of BIGINT.
decimalValue - Variable in class org.h2.expression.aggregate.AggregateDataAvg
 
decision - Variable in class org.h2.mvstore.MVMap.EqualsDecisionMaker
 
decision - Variable in class org.h2.mvstore.MVMap.RewriteDecisionMaker
 
decision - Variable in class org.h2.mvstore.tx.CommitDecisionMaker
 
decision - Variable in class org.h2.mvstore.tx.RollbackDecisionMaker
 
decision - Variable in class org.h2.mvstore.tx.TxDecisionMaker
 
Decision() - Constructor for enum org.h2.mvstore.MVMap.Decision
 
DecisionMaker() - Constructor for class org.h2.mvstore.MVMap.DecisionMaker
 
decKey - Variable in class org.h2.security.AES
 
declaredDataType - Variable in class org.h2.table.InformationSchemaTable.DataTypeInformation
DECLARED_DATA_TYPE.
declaredNumericPrecision - Variable in class org.h2.table.InformationSchemaTable.DataTypeInformation
DECLARED_NUMERIC_PRECISION.
declaredNumericScale - Variable in class org.h2.table.InformationSchemaTable.DataTypeInformation
DECLARED_NUMERIC_SCALE.
decodePageLength(int) - Static method in class org.h2.mvstore.DataUtils
Get the maximum length for the given code.
decodePassword(byte[]) - Static method in class org.h2.mvstore.db.Store
Convert password from byte[] to char[].
decodeToWhen(Expression, boolean, Expression, Expression) - Method in class org.h2.command.Parser
 
decodeUnicodeStringSQL(String, int) - Static method in class org.h2.util.StringUtils
Decodes a Unicode SQL string.
decompress - Variable in class org.h2.compress.LZFInputStream
 
decrement(long, long) - Method in class org.h2.schema.Sequence
 
DECREMENT_QUERY_LEVEL - Static variable in class org.h2.expression.ExpressionVisitor
Decrement query level of all expression columns.
decrementAndGet() - Method in class org.h2.mvstore.MVStore.TxCounter
Decrement and get the counter values.
decrementDateValue(long) - Static method in class org.h2.util.DateTimeUtils
Return the previous date value.
decrypt(byte[], int, int) - Method in class org.h2.security.AES
 
decrypt(byte[], int, int) - Method in interface org.h2.security.BlockCipher
Decrypt a number of bytes.
decrypt(byte[], int, int) - Method in class org.h2.security.Fog
 
decrypt(byte[], int, int) - Method in class org.h2.security.XTEA
 
decrypt(long, int, byte[], int) - Method in class org.h2.store.fs.encrypt.XTS
Decrypt the data.
DECRYPT - Static variable in class org.h2.expression.function.CryptFunction
DECRYPT() (non-standard).
decryptBlock(byte[], byte[], int) - Method in class org.h2.security.AES
 
decryptBlock(byte[], byte[], int) - Method in class org.h2.security.Fog
 
decryptBlock(byte[], byte[], int) - Method in class org.h2.security.XTEA
 
decryptKey - Variable in class org.h2.tools.ChangeFileEncryption
 
DEFAULT - Static variable in class org.h2.engine.DbSettings
INTERNAL.
DEFAULT - Static variable in class org.h2.expression.ValueExpression
This special expression represents the default value.
DEFAULT - Static variable in class org.h2.mvstore.MVMap.DecisionMaker
Decision maker for transaction rollback.
DEFAULT - Static variable in class org.h2.util.ParserUtil
The token "DEFAULT".
DEFAULT - Static variable in class org.h2.value.CompareMode
This constant means the default collator should be used, even if ICU4J is in the classpath.
DEFAULT_APPNAME - Static variable in class org.h2.security.auth.impl.JaasCredentialsValidator
 
DEFAULT_CACHE_SIZE - Static variable in class org.h2.schema.Sequence
The default cache size for sequences.
DEFAULT_CONNECTION - Static variable in class org.h2.Driver
 
DEFAULT_HTTP_PORT - Static variable in class org.h2.engine.Constants
The default port number of the HTTP server (for the H2 Console).
DEFAULT_LANGUAGE - Static variable in class org.h2.server.web.WebServer
 
DEFAULT_LEGACY_ALGORITHMS - Static variable in class org.h2.security.CipherFactory
The value of "jdk.tls.legacyAlgorithms" security property at the time of class initialization.
DEFAULT_LOCK_MODE - Static variable in class org.h2.engine.Constants
The default value for the LOCK_MODE setting.
DEFAULT_LOCK_TIMEOUT - Static variable in class org.h2.command.dml.SetTypes
The type of a SET DEFAULT_LOCK_TIMEOUT statement.
DEFAULT_MAX_CONNECTIONS - Static variable in class org.h2.jdbcx.JdbcConnectionPool
 
DEFAULT_MAX_FILE_SIZE - Static variable in class org.h2.message.TraceSystem
The default maximum trace file size.
DEFAULT_MAX_LENGTH_INPLACE_LOB - Static variable in class org.h2.engine.Constants
The default maximum length of an LOB that is stored with the record itself, and not in a separate place.
DEFAULT_MAX_OPERATION_MEMORY - Static variable in class org.h2.engine.Constants
The default for the setting MAX_OPERATION_MEMORY.
DEFAULT_NULL_ORDERING - Static variable in class org.h2.command.dml.SetTypes
The type of a SET DEFAULT_NULL_ORDERING statement.
DEFAULT_NULL_ORDERING - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
DEFAULT_PAGE_SIZE - Static variable in class org.h2.engine.Constants
The default page size to use for new databases.
DEFAULT_PORT - Static variable in class org.h2.server.pg.PgServer
The default port to use for the PG server.
DEFAULT_PRECISION - Static variable in class org.h2.value.ValueInterval
The default leading field precision for intervals.
DEFAULT_PRECISION - Static variable in class org.h2.value.ValueTime
The default precision and display size of the textual representation of a time.
DEFAULT_PRECISION - Static variable in class org.h2.value.ValueTimestamp
The default precision and display size of the textual representation of a timestamp.
DEFAULT_PRECISION - Static variable in class org.h2.value.ValueTimestampTimeZone
The default precision and display size of the textual representation of a timestamp.
DEFAULT_PRECISION - Static variable in class org.h2.value.ValueTimeTimeZone
The default precision and display size of the textual representation of a time.
DEFAULT_QUEUE_SIZE - Static variable in class org.h2.schema.TriggerObject
The default queue size.
DEFAULT_REALMNAME - Static variable in class org.h2.security.auth.DefaultAuthenticator
 
DEFAULT_RESULT_SET_CONCURRENCY - Static variable in class org.h2.engine.Constants
The default result set concurrency for statements created with Connection.createStatement() or prepareStatement(String sql).
DEFAULT_SCALE - Static variable in class org.h2.value.ValueInterval
The default scale for intervals with seconds.
DEFAULT_SCALE - Static variable in class org.h2.value.ValueNumeric
The default scale for a NUMERIC value.
DEFAULT_SCALE - Static variable in class org.h2.value.ValueTime
The default scale for time.
DEFAULT_SCALE - Static variable in class org.h2.value.ValueTimestamp
The default scale for timestamps.
DEFAULT_SQL_FLAGS - Static variable in interface org.h2.util.HasSQL
Default flags.
DEFAULT_TABLE_TYPE - Static variable in class org.h2.command.dml.SetTypes
The type of a SET DEFAULT_TABLE_TYPE statement.
DEFAULT_TCP_PORT - Static variable in class org.h2.engine.Constants
The default port of the TCP server.
DEFAULT_TIMEOUT - Static variable in class org.h2.jdbcx.JdbcConnectionPool
 
DEFAULT_TRACE_LEVEL_FILE - Static variable in class org.h2.message.TraceSystem
The default level for file trace messages.
DEFAULT_TRACE_LEVEL_SYSTEM_OUT - Static variable in class org.h2.message.TraceSystem
The default level for system out trace messages.
DEFAULT_URL - Static variable in class org.h2.Driver
 
DEFAULT_WRITE_DELAY - Static variable in class org.h2.engine.Constants
The default delay in milliseconds before the transaction log is written.
defaultAscNulls - Variable in enum org.h2.mode.DefaultNullOrdering
 
DefaultAuthenticator - Class in org.h2.security.auth
Default authenticator implementation.
DefaultAuthenticator() - Constructor for class org.h2.security.auth.DefaultAuthenticator
Create the Authenticator with default configurations
DefaultAuthenticator(boolean) - Constructor for class org.h2.security.auth.DefaultAuthenticator
Create authenticator and optionally skip the default configuration.
defaultConfiguration() - Method in class org.h2.security.auth.DefaultAuthenticator
 
defaultConnection - Variable in class org.h2.engine.DbSettings
Database setting DEFAULT_CONNECTION (default: false).
defaultDataType - Variable in class org.h2.mvstore.tx.TransactionStore.TxMapBuilder
 
defaultDescNulls - Variable in enum org.h2.mode.DefaultNullOrdering
 
defaultEscape - Variable in class org.h2.engine.DbSettings
Database setting DEFAULT_ESCAPE (default: \).
defaultEscape - Variable in class org.h2.expression.condition.CompareLike
 
defaultExpression - Variable in class org.h2.command.ddl.AlterTableAlterColumn
Default or on update expression.
defaultExpression - Variable in class org.h2.command.ddl.CreateDomain
 
defaultExpression - Variable in class org.h2.schema.Domain
 
defaultExpression - Variable in class org.h2.table.Column
 
defaultFormatStr - Variable in enum org.h2.mode.ToDateParser.ConfigParam
 
defaultNullOrdering - Variable in class org.h2.engine.Database
 
defaultNullOrdering() - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
defaultNullOrdering() - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
defaultNullOrdering() - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
defaultNullOrdering() - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
DefaultNullOrdering - Enum in org.h2.mode
Default ordering of NULL values.
DefaultNullOrdering(int, int) - Constructor for enum org.h2.mode.DefaultNullOrdering
 
defaultOnNull - Variable in class org.h2.table.Column
 
defaultPrecision - Variable in class org.h2.value.DataType
The default precision.
defaultProvider - Static variable in class org.h2.store.fs.FilePath
 
DefaultRow - Class in org.h2.result
The default implementation of a row in a table.
DefaultRow(int) - Constructor for class org.h2.result.DefaultRow
 
DefaultRow(Value[]) - Constructor for class org.h2.result.DefaultRow
 
DefaultRow(Value[], int) - Constructor for class org.h2.result.DefaultRow
 
DefaultRowFactory() - Constructor for class org.h2.result.RowFactory.DefaultRowFactory
 
DefaultRowFactory(RowDataType, int, int[], TypeInfo[]) - Constructor for class org.h2.result.RowFactory.DefaultRowFactory
 
defaultScale - Variable in class org.h2.value.DataType
The default scale.
defaultSchema - Variable in class org.h2.bnf.context.DbContents
 
DefaultSpatial - Class in org.h2.mvstore.rtree
Class BasicSpatialImpl.
DefaultSpatial(long, float...) - Constructor for class org.h2.mvstore.rtree.DefaultSpatial
Create a new key.
DefaultSpatial(long, DefaultSpatial) - Constructor for class org.h2.mvstore.rtree.DefaultSpatial
 
defaultTableEngine - Variable in class org.h2.engine.DbSettings
Database setting DEFAULT_TABLE_ENGINE (default: null).
defaultTableType - Variable in class org.h2.engine.Database
 
DefineCommand - Class in org.h2.command.ddl
This class represents a non-transaction statement, for example a CREATE or DROP.
DefineCommand(SessionLocal) - Constructor for class org.h2.command.ddl.DefineCommand
Create a new command for the given session.
DEFLATE - Static variable in interface org.h2.compress.Compressor
The DEFLATE compression algorithm is used.
defragAlways - Variable in class org.h2.engine.DbSettings
Database setting DEFRAG_ALWAYS (default: false) Each time the database is closed normally, it is fully defragmented (the same as SHUTDOWN DEFRAG).
DEGREES - Static variable in class org.h2.expression.function.MathFunction1
DEGREES() (non-standard).
deinterleave(int, long, int) - Method in class org.h2.tools.MultiDimension
Gets one of the original multi-dimensional values from a scalar value.
DELAY_WRONG_PASSWORD_MAX - Static variable in class org.h2.engine.SysProperties
System property h2.delayWrongPasswordMax (default: 4000).
DELAY_WRONG_PASSWORD_MIN - Static variable in class org.h2.engine.SysProperties
System property h2.delayWrongPasswordMin (default: 250).
delayedCloser - Variable in class org.h2.engine.Database
 
DelayedDatabaseCloser - Class in org.h2.engine
This class is responsible to close a database after the specified delay.
DelayedDatabaseCloser(Database, int) - Constructor for class org.h2.engine.DelayedDatabaseCloser
 
delayInMillis - Variable in class org.h2.engine.DelayedDatabaseCloser
 
delete() - Method in class org.h2.mvstore.db.MVTempResult
 
delete() - Method in class org.h2.store.fs.disk.FilePathDisk
 
delete() - Method in class org.h2.store.fs.FilePath
Delete a file or directory if it exists.
delete() - Method in class org.h2.store.fs.FilePathWrapper
 
delete() - Method in class org.h2.store.fs.mem.FilePathMem
 
delete() - Method in class org.h2.store.fs.niomem.FilePathNioMem
 
delete() - Method in class org.h2.store.fs.rec.FilePathRec
 
delete() - Method in class org.h2.store.fs.split.FilePathSplit
 
delete() - Method in class org.h2.store.fs.zip.FilePathZip
 
delete(Object[], boolean) - Method in class org.h2.fulltext.FullTextLucene.FullTextTrigger
Delete a row from the index.
delete(String) - Static method in class org.h2.store.fs.FileUtils
Delete a file or directory if it exists.
delete(Connection, Object[]) - Method in class org.h2.fulltext.FullText.FullTextTrigger
Delete a row from the index.
Delete - Class in org.h2.command.dml
This class represents the statement DELETE
Delete(SessionLocal) - Constructor for class org.h2.command.dml.Delete
 
DELETE - Static variable in interface org.h2.api.Trigger
The trigger is called for DELETE statements.
DELETE - Static variable in interface org.h2.command.CommandInterface
The type of a DELETE statement.
DELETE - Static variable in class org.h2.engine.Right
The right bit mask that means: deleting rows from a table is allowed.
DELETE - Static variable in interface org.h2.store.fs.Recorder
Delete a file.
DELETE_MAP - Static variable in class org.h2.fulltext.FullText.FullTextTrigger
 
DELETE_ROW - Static variable in class org.h2.fulltext.FullText.FullTextTrigger
 
deleteAction - Variable in class org.h2.command.ddl.AlterTableAddConstraint
 
deleteAction - Variable in class org.h2.constraint.ConstraintReferential
 
deleteAll() - Method in class org.h2.util.TempFileDeleter
Delete all registered temp resources.
DeleteDbFiles - Class in org.h2.tools
Deletes all files belonging to a database.
DeleteDbFiles() - Constructor for class org.h2.tools.DeleteDbFiles
 
deleteFile(Reference<?>, Object) - Method in class org.h2.util.TempFileDeleter
Delete the given file or close the closeable now.
deleteFiles - Variable in class org.h2.command.ddl.DropDatabase
 
deleteFilesOnDisconnect - Variable in class org.h2.engine.Database
 
deleteOldTempFiles() - Method in class org.h2.engine.Database
 
deleteRecursive(String, boolean) - Static method in class org.h2.store.fs.FileUtils
Delete a directory or file and all subdirectories and files.
deleteRow() - Method in class org.h2.jdbc.JdbcResultSet
Deletes the current row.
deleteRow() - Method in class org.h2.tools.SimpleResultSet
INTERNAL
deleteRow(Value[]) - Method in class org.h2.result.UpdatableRow
Delete the given row in the database.
deletesAreDetected(int) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether deletes are detected.
deleteSQL - Variable in class org.h2.constraint.ConstraintReferential
 
deleteStore() - Method in class org.h2.command.dml.ScriptBase
Delete the target file.
deleteUnused() - Method in class org.h2.util.TempFileDeleter
Delete all unused resources now.
DELTA - Static variable in class org.h2.security.XTEA
 
deltaChangeCollectionMode - Variable in class org.h2.command.dml.Insert
 
deltaChangeCollector - Variable in class org.h2.command.dml.Insert
 
DENSE_RANK - org.h2.expression.aggregate.AggregateType
The type for DENSE_RANK() hypothetical set function.
DENSE_RANK - org.h2.expression.analysis.WindowFunctionType
The type for DENSE_RANK() window function.
dependentViews - Variable in class org.h2.table.Table
views that depend on this table
depth - Variable in class org.h2.util.Profiler
 
Derby - org.h2.engine.Mode.ModeEnum
 
deregisterMapRoot(int) - Method in class org.h2.mvstore.MVStore
Performs final stage of map removal - delete root location info from the layout table.
deregisterVersionUsage(MVStore.TxCounter) - Method in class org.h2.mvstore.MVStore
De-register (close) completed operation (transaction).
derivedColumnMap - Variable in class org.h2.table.TableFilter
Map of derived column names.
DESCENDING - Static variable in class org.h2.result.SortOrder
This bit mask means the values should be sorted in descending order.
description - Variable in class org.h2.jdbcx.JdbcDataSource
 
DESERIALIZATION_FAILED_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90027 is thrown when an object could not be de-serialized.
deserialize(byte[]) - Method in interface org.h2.api.JavaObjectSerializer
Deserialize object from byte array.
deserialize(byte[]) - Static method in class org.h2.mvstore.type.ObjectDataType
De-serialize the byte array to an object.
deserialize(byte[], JavaObjectSerializer) - Static method in class org.h2.util.JdbcUtils
De-serialize the byte array to an object, eventually using the serializer specified by the connection info.
deserializeUuid(byte[]) - Static method in class org.h2.util.JdbcUtils
De-serialize the byte array to a UUID object.
destroy() - Method in class org.h2.server.web.JakartaWebServlet
 
destroy() - Method in class org.h2.server.web.WebServlet
 
destroyShadowTableForRecursiveExpression(boolean, SessionLocal, Table) - Static method in class org.h2.table.TableView
Remove a table for a recursive query.
DETAILED_INFO - Static variable in class org.h2.mvstore.FreeSpaceBitSet
 
detector - Static variable in class org.h2.util.ThreadDeadlockDetector
 
determineType(SessionLocal) - Method in class org.h2.expression.ConcatenationOperation
 
deterministic - Variable in class org.h2.command.ddl.CreateFunctionAlias
 
deterministic - Variable in class org.h2.mode.FunctionInfo
If this function always returns the same value for the same parameters.
deterministic - Variable in class org.h2.schema.FunctionAlias
 
DETERMINISTIC - Static variable in class org.h2.expression.ExpressionVisitor
Does the expression return the same results for the same parameters?
DETERMINISTIC_VISITOR - Static variable in class org.h2.expression.ExpressionVisitor
The visitor singleton for the type DETERMINISTIC.
DIFFERENCE - Static variable in class org.h2.expression.function.SoundexFunction
DIFFERENCE() (non-standard).
digestLength - Variable in class org.h2.security.SHA3
 
DIGIT - Static variable in class org.h2.bnf.RuleFixed
 
DIMENSION_SYSTEM_XY - Static variable in class org.h2.util.geometry.GeometryUtils
Code of 2D (XY) dimension system.
DIMENSION_SYSTEM_XYM - Static variable in class org.h2.util.geometry.GeometryUtils
Code of M (XYM) dimension system.
DIMENSION_SYSTEM_XYZ - Static variable in class org.h2.util.geometry.GeometryUtils
Code of Z (XYZ) dimension system.
DIMENSION_SYSTEM_XYZM - Static variable in class org.h2.util.geometry.GeometryUtils
Code of ZM (XYZM) dimension system.
DIMENSION_SYSTEMS - Static variable in class org.h2.util.geometry.EWKTUtils
Names of dimension systems.
dimensions - Variable in class org.h2.mvstore.rtree.MVRTreeMap.Builder
 
dimensions - Variable in class org.h2.mvstore.rtree.SpatialDataType
 
dimensions(int) - Method in class org.h2.mvstore.rtree.MVRTreeMap.Builder
Set the dimensions.
dimensions(TypeInfo) - Static method in class org.h2.value.TypeInfo
 
dimensionSystem - Variable in class org.h2.util.geometry.EWKBUtils.EWKBTarget
 
dimensionSystem - Variable in class org.h2.util.geometry.EWKTUtils.EWKTTarget
 
dimensionSystem - Variable in class org.h2.util.geometry.GeoJsonUtils.GeoJsonTarget
 
dimensionSystem - Variable in class org.h2.util.geometry.JTSUtils.GeometryTarget
 
dimensionSystem(int) - Method in class org.h2.util.geometry.GeometryUtils.DimensionSystemTarget
 
dimensionSystem(int) - Method in class org.h2.util.geometry.GeometryUtils.Target
Invoked to add dimension system requirement.
DimensionSystemTarget() - Constructor for class org.h2.util.geometry.GeometryUtils.DimensionSystemTarget
Creates a new dimension system determination target.
directory - Variable in class org.h2.tools.ChangeFileEncryption
 
DIRECTORY - Static variable in class org.h2.store.fs.mem.FilePathMem
 
disableCache() - Method in class org.h2.command.query.Query
Disable caching of result sets.
disableLazyForJoinSubqueries(TableFilter) - Method in class org.h2.command.query.Select
 
disableSSL(String[]) - Static method in class org.h2.security.CipherFactory
 
disallowedTypes - Variable in class org.h2.engine.Mode
An optional Set of hidden/disallowed column types.
discardTableHint() - Method in class org.h2.command.Parser
 
discardWithTableHints - Variable in class org.h2.engine.Mode
Discard SQLServer table hints (e.g.
discardWithTableHints() - Method in class org.h2.command.Parser
 
discoverChunk(long) - Method in class org.h2.mvstore.MVStore
Discover a valid chunk, searching file backwards from the given block
DISK_SPACE_USED - Static variable in class org.h2.expression.function.TableInfoFunction
DISK_SPACE_USED() (non-standard).
diskSpaceUsed - Variable in class org.h2.mvstore.Page
Amount of used disk space by this page only in persistent case.
DISPLAY_SIZE - Static variable in class org.h2.value.ValueBigint
The maximum display size of a BIGINT.
DISPLAY_SIZE - Static variable in class org.h2.value.ValueBoolean
The maximum display size of a boolean.
DISPLAY_SIZE - Static variable in class org.h2.value.ValueDouble
The maximum display size of a DOUBLE.
DISPLAY_SIZE - Static variable in class org.h2.value.ValueInteger
The maximum display size of an INT.
DISPLAY_SIZE - Static variable in class org.h2.value.ValueNull
The display size of the textual representation of NULL.
DISPLAY_SIZE - Static variable in class org.h2.value.ValueReal
The maximum display size of a REAL.
DISPLAY_SIZE - Static variable in class org.h2.value.ValueSmallint
The maximum display size of a SMALLINT.
DISPLAY_SIZE - Static variable in class org.h2.value.ValueTinyint
The display size for a TINYINT.
DISPLAY_SIZE - Static variable in class org.h2.value.ValueUuid
The display size of the textual representation of a UUID.
dispose() - Method in class org.h2.jdbcx.JdbcConnectionPool
Closes all unused pooled connections.
distinct - Variable in class org.h2.command.query.Query
Whether the result must only contain distinct rows.
distinct - Variable in class org.h2.expression.aggregate.AbstractAggregate
is this a DISTINCT aggregate
distinct - Variable in class org.h2.expression.aggregate.AggregateDataCollecting
 
distinct - Variable in class org.h2.mvstore.db.MVSortedTempResult
Whether this result is a standard distinct result.
distinct - Variable in class org.h2.result.LocalResult
 
DISTINCT - Static variable in class org.h2.util.ParserUtil
The token "DISTINCT".
distinctCount - Variable in class org.h2.command.ddl.Analyze.SelectivityData
 
distinctExpressions - Variable in class org.h2.command.query.Select
DISTINCT ON(...) expressions.
distinctIndexes - Variable in class org.h2.command.query.Select
 
distinctIndexes - Variable in class org.h2.mvstore.db.MVSortedTempResult
Distinct indexes for DISTINCT ON results.
distinctIndexes - Variable in class org.h2.result.LocalResult
 
distinctRows - Variable in class org.h2.result.LocalResult
 
divide(BigDecimal, BigDecimal, TypeInfo) - Static method in class org.h2.value.ValueDecfloat
Divides to BigDecimal values and returns a DECFLOAT result of the specified data type.
divide(BigInteger[], int) - Static method in class org.h2.server.pg.PgServerThread
 
divide(Value, TypeInfo) - Method in class org.h2.value.Value
Divide by a value and return the result.
divide(Value, TypeInfo) - Method in class org.h2.value.ValueBigint
 
divide(Value, TypeInfo) - Method in class org.h2.value.ValueDecfloat
 
divide(Value, TypeInfo) - Method in class org.h2.value.ValueDouble
 
divide(Value, TypeInfo) - Method in class org.h2.value.ValueEnumBase
 
divide(Value, TypeInfo) - Method in class org.h2.value.ValueInteger
 
divide(Value, TypeInfo) - Method in class org.h2.value.ValueNumeric
 
divide(Value, TypeInfo) - Method in class org.h2.value.ValueReal
 
divide(Value, TypeInfo) - Method in class org.h2.value.ValueSmallint
 
divide(Value, TypeInfo) - Method in class org.h2.value.ValueTime
 
divide(Value, TypeInfo) - Method in class org.h2.value.ValueTinyint
 
DIVIDE - org.h2.expression.BinaryOperation.OpType
This operation represents a division as in 4 / 2.
DIVISION_BY_ZERO_1 - Static variable in class org.h2.api.ErrorCode
The error with code 22012 is thrown when trying to divide a value by zero.
DOC_ID_FIELD_TYPE - Variable in class org.h2.fulltext.FullTextLucene.FullTextTrigger
 
DocumentedMBean - Class in org.h2.jmx
An MBean that reads the documentation from a resource file.
DocumentedMBean(T, Class<T>) - Constructor for class org.h2.jmx.DocumentedMBean
 
doesColumnExist(String) - Method in class org.h2.table.Table
Does the column with the given name exist?
doesMaxRowSizeIncludeBlobs() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether the maximum row size includes blobs.
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.h2.server.web.JakartaWebServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.h2.server.web.WebServlet
 
doLock1(SessionLocal, int) - Method in class org.h2.mvstore.db.MVTable
 
doLock2(SessionLocal, int) - Method in class org.h2.mvstore.db.MVTable
 
domain - Variable in class org.h2.constraint.ConstraintDomain
 
domain - Variable in class org.h2.expression.function.CastSpecification
 
domain - Variable in class org.h2.schema.Domain
Parent domain.
domain - Variable in class org.h2.table.Column
 
Domain - Class in org.h2.schema
Represents a domain.
Domain(Schema, int, String) - Constructor for class org.h2.schema.Domain
 
DOMAIN - org.h2.constraint.Constraint.Type
The constraint type for domain constraints.
DOMAIN - Static variable in class org.h2.engine.DbObject
This object is a domain.
DOMAIN_ALREADY_EXISTS_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90119 is thrown when trying to create a domain if an object with this name already exists, or when trying to overload a built-in data type.
DOMAIN_CONSTRAINTS - Static variable in class org.h2.table.InformationSchemaTable
 
DOMAIN_CONSTRAINTS - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
DOMAIN_NOT_FOUND_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90120 is thrown when trying to drop a domain that doesn't exist.
DomainColumnResolver - Class in org.h2.constraint
The single column resolver resolves the VALUE column.
DomainColumnResolver(TypeInfo) - Constructor for class org.h2.constraint.DomainColumnResolver
 
domainConstraints(SessionLocal, ArrayList<Row>, String, ConstraintDomain, Domain, String) - Method in class org.h2.table.InformationSchemaTable
 
domainConstraints(SessionLocal, Value, Value, ArrayList<Row>, String) - Method in class org.h2.table.InformationSchemaTable
 
domainName - Variable in class org.h2.command.ddl.AlterDomain
 
domains - Variable in class org.h2.schema.Schema
 
domains(SessionLocal, ArrayList<Row>, String, String, String, Domain, String) - Method in class org.h2.table.InformationSchemaTable
 
domains(SessionLocal, Value, Value, ArrayList<Row>, String) - Method in class org.h2.table.InformationSchemaTable
 
DOMAINS - Static variable in class org.h2.table.InformationSchemaTable
 
DOMAINS - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
doMaintenance(int) - Method in class org.h2.mvstore.MVStore
 
DomainValueExpression - Class in org.h2.expression
An expression representing a value for domain constraint.
DomainValueExpression() - Constructor for class org.h2.expression.DomainValueExpression
 
domResult - Variable in class org.h2.jdbc.JdbcSQLXML
 
done() - Method in class org.h2.command.query.SelectGroups
Invoked after all source rows are evaluated.
done() - Method in class org.h2.command.query.SelectGroups.Grouped
 
done() - Method in class org.h2.command.query.SelectGroups.Plain
 
done() - Method in class org.h2.result.LocalResult
This method is called after all rows have been added.
done(Transfer) - Method in class org.h2.engine.SessionRemote
Called to flush the output after data has been sent to the server and just before receiving data.
doneWithParameters() - Method in interface org.h2.expression.ExpressionWithVariableParameters
This method must be called after all the parameters have been set.
doneWithParameters() - Method in class org.h2.expression.function.table.TableFunction
 
doneWithParameters() - Method in class org.h2.expression.OperationN
 
doneWithParameters() - Method in class org.h2.mode.ModeFunction
 
doPost(HttpServletRequest, HttpServletResponse) - Method in class org.h2.server.web.JakartaWebServlet
 
doPost(HttpServletRequest, HttpServletResponse) - Method in class org.h2.server.web.WebServlet
 
DOT - Static variable in class org.h2.command.Token
The token ".".
DOUBLE - Static variable in class org.h2.mvstore.db.ValueDataType
 
DOUBLE - Static variable in class org.h2.value.Transfer
 
DOUBLE - Static variable in class org.h2.value.Value
The value type for DOUBLE PRECISION values.
DOUBLE_0_1 - Static variable in class org.h2.mvstore.db.ValueDataType
 
DOUBLE_ONE_BITS - Static variable in class org.h2.mvstore.type.ObjectDataType
 
DOUBLE_PRECISION - Static variable in class org.h2.api.H2Type
The DOUBLE PRECISION data type.
DOUBLE_ZERO_BITS - Static variable in class org.h2.mvstore.type.ObjectDataType
 
DoubleType() - Constructor for class org.h2.mvstore.type.ObjectDataType.DoubleType
 
doubleValue - Variable in class org.h2.expression.aggregate.AggregateDataAvg
 
doUpdate(Prepared, SessionLocal, Table, LocalResult) - Static method in class org.h2.command.dml.Update
 
DOW - Static variable in class org.h2.expression.function.DateTimeFunction
Day of week (locale-specific) for PostgreSQL compatibility.
download(String, String) - Static method in class org.h2.tools.Upgrade
 
downloadUsingMaven(String, String, String, String) - Static method in class org.h2.tools.Upgrade
 
doyValid - Variable in class org.h2.mode.ToDateParser
 
driver - Variable in class org.h2.command.ddl.CreateLinkedTable
 
driver - Variable in class org.h2.server.web.ConnectionInfo
The driver class name.
driver - Variable in class org.h2.table.TableLink
 
driver - Variable in class org.h2.table.TableLinkConnection
The connection information.
driver - Variable in class org.h2.util.OsgiDataSourceFactory
 
Driver - Class in org.h2
The database driver.
Driver() - Constructor for class org.h2.Driver
 
DRIVER_VERSION_ERROR_2 - Static variable in class org.h2.api.ErrorCode
The error with code 90047 is thrown when trying to connect to a TCP server with an incompatible client.
DRIVERS - Static variable in class org.h2.util.JdbcUtils
 
drop - Variable in class org.h2.command.dml.ScriptCommand
 
DROP_AGGREGATE - Static variable in interface org.h2.command.CommandInterface
The type of a DROP AGGREGATE statement.
DROP_ALIAS - Static variable in interface org.h2.command.CommandInterface
The type of a DROP ALIAS statement.
DROP_ALL_OBJECTS - Static variable in interface org.h2.command.CommandInterface
The type of a DROP ALL OBJECTS statement.
DROP_CONSTANT - Static variable in interface org.h2.command.CommandInterface
The type of a DROP CONSTANT statement.
DROP_DOMAIN - Static variable in interface org.h2.command.CommandInterface
The type of a DROP DOMAIN statement.
DROP_INDEX - Static variable in interface org.h2.command.CommandInterface
The type of a DROP INDEX statement.
DROP_ROLE - Static variable in interface org.h2.command.CommandInterface
The type of a DROP ROLE statement.
DROP_SCHEMA - Static variable in interface org.h2.command.CommandInterface
The type of a DROP SCHEMA statement.
DROP_SEQUENCE - Static variable in interface org.h2.command.CommandInterface
The type of a DROP SEQUENCE statement.
DROP_SYNONYM - Static variable in interface org.h2.command.CommandInterface
The type of a DROP SYNONYM statement.
DROP_TABLE - Static variable in interface org.h2.command.CommandInterface
The type of a DROP TABLE statement.
DROP_TRIGGER - Static variable in interface org.h2.command.CommandInterface
The type of a DROP TRIGGER statement.
DROP_USER - Static variable in interface org.h2.command.CommandInterface
The type of a DROP USER statement.
DROP_VIEW - Static variable in interface org.h2.command.CommandInterface
The type of a DROP VIEW statement.
dropAction - Variable in class org.h2.command.ddl.AlterTableDropConstraint
 
dropAction - Variable in class org.h2.command.ddl.DropDomain
 
dropAction - Variable in class org.h2.command.ddl.DropSchema
 
dropAction - Variable in class org.h2.command.ddl.DropTable
 
dropAction - Variable in class org.h2.command.ddl.DropView
 
DropAggregate - Class in org.h2.command.ddl
This class represents the statement DROP AGGREGATE
DropAggregate(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.DropAggregate
 
dropAll(Connection) - Static method in class org.h2.fulltext.FullText
Drops all full text indexes from the database.
dropAll(Connection) - Static method in class org.h2.fulltext.FullTextLucene
Drops all full text indexes from the database.
dropAllObjects - Variable in class org.h2.command.ddl.DropDatabase
 
dropAllObjects() - Method in class org.h2.command.ddl.DropDatabase
 
DropConstant - Class in org.h2.command.ddl
This class represents the statement DROP CONSTANT
DropConstant(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.DropConstant
 
DropDatabase - Class in org.h2.command.ddl
This class represents the statement DROP ALL OBJECTS
DropDatabase(SessionLocal) - Constructor for class org.h2.command.ddl.DropDatabase
 
DropDomain - Class in org.h2.command.ddl
This class represents the statement DROP DOMAIN
DropDomain(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.DropDomain
 
DropFunctionAlias - Class in org.h2.command.ddl
This class represents the statement DROP ALIAS
DropFunctionAlias(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.DropFunctionAlias
 
dropIndex(Connection, String, String) - Static method in class org.h2.fulltext.FullText
Drop an existing full text index for a table.
dropIndex(Connection, String, String) - Static method in class org.h2.fulltext.FullTextLucene
Drop an existing full text index for a table.
DropIndex - Class in org.h2.command.ddl
This class represents the statement DROP INDEX
DropIndex(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.DropIndex
 
dropMultipleColumnsConstraintsAndIndexes(SessionLocal, ArrayList<Column>) - Method in class org.h2.table.Table
Check that these columns are not referenced by a multi-column constraint or multi-column index.
dropRestrict - Variable in class org.h2.engine.DbSettings
Database setting DROP_RESTRICT (default: true) Whether the default action for DROP TABLE, DROP VIEW, DROP SCHEMA, DROP DOMAIN, and DROP CONSTRAINT is RESTRICT.
DropRole - Class in org.h2.command.ddl
This class represents the statement DROP ROLE
DropRole(SessionLocal) - Constructor for class org.h2.command.ddl.DropRole
 
DropSchema - Class in org.h2.command.ddl
This class represents the statement DROP SCHEMA
DropSchema(SessionLocal) - Constructor for class org.h2.command.ddl.DropSchema
 
DropSequence - Class in org.h2.command.ddl
This class represents the statement DROP SEQUENCE
DropSequence(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.DropSequence
 
DropSynonym - Class in org.h2.command.ddl
This class represents the statement DROP SYNONYM
DropSynonym(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.DropSynonym
 
DropTable - Class in org.h2.command.ddl
This class represents the statement DROP TABLE
DropTable(SessionLocal) - Constructor for class org.h2.command.ddl.DropTable
 
DropTable.SchemaAndTable - Class in org.h2.command.ddl
 
DropTrigger - Class in org.h2.command.ddl
This class represents the statement DROP TRIGGER
DropTrigger(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.DropTrigger
 
dropUnusedChunks() - Method in class org.h2.mvstore.MVStore
 
dropUnusedVersions() - Method in class org.h2.mvstore.MVStore
 
DropUser - Class in org.h2.command.ddl
This class represents the statement DROP USER
DropUser(SessionLocal) - Constructor for class org.h2.command.ddl.DropUser
 
DropView - Class in org.h2.command.ddl
This class represents the statement DROP VIEW
DropView(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.DropView
 
DualCursor - Class in org.h2.index
The cursor implementation for the DUAL index.
DualCursor() - Constructor for class org.h2.index.DualCursor
 
DualIndex - Class in org.h2.index
An index for the DUAL table.
DualIndex(DualTable) - Constructor for class org.h2.index.DualIndex
 
DualTable - Class in org.h2.table
The DUAL table for selects without a FROM clause.
DualTable(Database) - Constructor for class org.h2.table.DualTable
Create a new range with the given start and end expressions.
DUMMY - Static variable in class org.h2.server.TcpServerThread.CachedInputStream
 
dump(StringBuilder) - Method in class org.h2.mvstore.Page
Dump debug data for this page.
dump(StringBuilder) - Method in class org.h2.mvstore.Page.IncompleteNonLeaf
 
dump(StringBuilder) - Method in class org.h2.mvstore.Page.Leaf
 
dump(StringBuilder) - Method in class org.h2.mvstore.Page.NonLeaf
 
dump(String, boolean) - Static method in class org.h2.mvstore.MVStoreTool
Read the contents of the file and write them to system out.
dump(String, Writer, boolean) - Static method in class org.h2.mvstore.MVStoreTool
Read the contents of the file and display them in a human-readable format.
dumpAllThreadsAndLocks(String) - Static method in class org.h2.util.ThreadDeadlockDetector
Dump all deadlocks (if any).
dumpAllThreadsAndLocks(String, PrintStream) - Static method in class org.h2.util.ThreadDeadlockDetector
Dump all deadlocks (if any).
dumpDomains(ArrayList<Schema>) - Method in class org.h2.command.dml.ScriptCommand
 
dumpLayout(PrintWriter, MVStore) - Static method in class org.h2.tools.Recover
 
dumpLobMaps(PrintWriter, MVStore) - Method in class org.h2.tools.Recover
 
dumpMeta(PrintWriter, MVStore) - Static method in class org.h2.tools.Recover
 
dumpMVStoreFile(PrintWriter, String) - Method in class org.h2.tools.Recover
 
dumpRights(Database) - Method in class org.h2.command.dml.ScriptCommand
 
dumpStackTraceElement(ThreadInfo, StringBuilder, int, StackTraceElement) - Static method in class org.h2.util.AbbaLockingDetector
 
dumpThreadsAndLocks(String, ThreadMXBean, long[], PrintStream) - Static method in class org.h2.util.ThreadDeadlockDetector
 
dumpTypes(PrintWriter, MVStore) - Static method in class org.h2.tools.Recover
 
DUPLICATE_COLUMN_NAME_1 - Static variable in class org.h2.api.ErrorCode
The error with code 42121 is thrown when trying to create a table or insert into a table and use the same column name twice.
DUPLICATE_KEY_1 - Static variable in class org.h2.api.ErrorCode
The error with code 23505 is thrown when trying to insert a row that would violate a unique index or primary key.
DUPLICATE_PROPERTY_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90066 is thrown when the same property appears twice in the database URL or in the connection properties.
duplicateKeyAssignmentMap - Variable in class org.h2.command.dml.Insert
For MySQL-style INSERT ...
durationToValue(Duration) - Static method in class org.h2.util.JSR310Utils
Converts a Duration to a Value.
DY - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
DYNAMIC_CACHE - Static variable in class org.h2.value.ValueInteger
 
DYNAMIC_SIZE - Static variable in class org.h2.value.ValueInteger
 
dynamicSettings - Variable in class org.h2.engine.SessionRemote
 
DynamicSettings(Mode, TimeZoneProvider) - Constructor for class org.h2.engine.Session.DynamicSettings
Creates new instance of dynamic settings.

E

E - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
editResult() - Method in class org.h2.server.web.WebApp
 
EE - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
EFFECTIVE - Static variable in class org.h2.result.RowFactory.Holder
 
ELEMENT_TYPES - Static variable in class org.h2.table.InformationSchemaTable
 
elements - Variable in class org.h2.command.ddl.Analyze.SelectivityData
 
elements - Variable in class org.h2.util.json.JSONArray
 
elementType - Variable in class org.h2.mvstore.type.ObjectDataType.ObjectArrayType
 
elementTypes(SessionLocal, ArrayList<Row>, String, String, String, String, String, String, String, String, TypeInfo) - Method in class org.h2.table.InformationSchemaTable
 
elementTypesFields(SessionLocal, ArrayList<Row>, String, int) - Method in class org.h2.table.InformationSchemaTable
 
elementTypesFieldsForTable(SessionLocal, ArrayList<Row>, String, int, String, String, String, Table) - Method in class org.h2.table.InformationSchemaTable
 
elementTypesFieldsRow(SessionLocal, ArrayList<Row>, String, int, String, String, String, String, String, String, TypeInfo) - Method in class org.h2.table.InformationSchemaTable
 
ELSE - Static variable in class org.h2.util.ParserUtil
The token "ELSE".
elseResult - Variable in class org.h2.expression.SimpleCase
 
embedded - Variable in class org.h2.engine.SessionRemote
 
emitUpdates - Variable in class org.h2.command.ddl.CreateLinkedTable
 
emitUpdates - Variable in class org.h2.table.TableLink
 
empty() - Static method in class org.h2.mvstore.Page.PageReference
Get an empty page reference.
EMPTY - org.h2.engine.Mode.ExpressionNames
Generate empty name.
EMPTY - Static variable in class org.h2.mvstore.Page.PageReference
Singleton object used when arrays of PageReference have not yet been filled.
EMPTY - Static variable in class org.h2.value.ValueArray
Empty array.
EMPTY - Static variable in class org.h2.value.ValueJavaObject
 
EMPTY - Static variable in class org.h2.value.ValueRow
Empty row.
EMPTY - Static variable in class org.h2.value.ValueVarbinary
Empty value.
EMPTY - Static variable in class org.h2.value.ValueVarchar
Empty string.
EMPTY - Static variable in class org.h2.value.ValueVarcharIgnoreCase
 
EMPTY_BYTES - Static variable in class org.h2.util.Utils
An 0-size byte array.
EMPTY_INT_ARRAY - Static variable in class org.h2.util.Utils
An 0-size int array.
EMPTY_LONG_ARR - Static variable in class org.h2.mvstore.type.LongDataType
 
EMPTY_SESSION_ARRAY - Static variable in class org.h2.engine.Database
 
EMPTY_STRING_ARR - Static variable in class org.h2.mvstore.type.StringDataType
 
EMPTY_VALUES - Static variable in class org.h2.value.Value
Empty array of values.
ENABLE_ANONYMOUS_TLS - Static variable in class org.h2.engine.SysProperties
System property h2.enableAnonymousTLS (default: true).
enableAnonymous(String[], String[]) - Static method in class org.h2.security.CipherFactory
 
enabled - Variable in class org.h2.util.geometry.GeometryUtils.EnvelopeTarget
Enables or disables the envelope calculation.
ENABLED - Static variable in class org.h2.util.MemoryUnmapper
 
encKey - Variable in class org.h2.security.AES
 
encodeLength(int) - Static method in class org.h2.mvstore.DataUtils
Convert the length to a length code 0..31.
encoder - Variable in class org.h2.store.CountingReaderInputStream
 
ENCODER - Static variable in class org.h2.jdbcx.JdbcXid
 
encodeString(ByteArrayOutputStream, String) - Static method in class org.h2.util.json.JSONByteArrayTarget
Encodes a JSON string and appends it to the specified output stream.
encodeString(StringBuilder, String, boolean) - Static method in class org.h2.util.json.JSONStringTarget
Encodes a JSON string and appends it to the specified string builder.
encodingToChar(int) - Static method in class org.h2.mode.FunctionsPostgreSQL
 
encrypt(byte[], int, int) - Method in class org.h2.security.AES
 
encrypt(byte[], int, int) - Method in interface org.h2.security.BlockCipher
Encrypt a number of bytes.
encrypt(byte[], int, int) - Method in class org.h2.security.Fog
 
encrypt(byte[], int, int) - Method in class org.h2.security.XTEA
 
encrypt(long, int, byte[], int) - Method in class org.h2.store.fs.encrypt.XTS
Encrypt the data.
ENCRYPT - Static variable in class org.h2.expression.function.CryptFunction
ENCRYPT() (non-standard).
encryptBlock(byte[], byte[], int) - Method in class org.h2.security.AES
 
encryptBlock(byte[], byte[], int) - Method in class org.h2.security.Fog
 
encryptBlock(byte[], byte[], int) - Method in class org.h2.security.XTEA
 
encrypted - Variable in class org.h2.mvstore.db.Store
 
encryptedFile - Variable in class org.h2.mvstore.FileStore
The encrypted file (if encryption is used).
ENCRYPTION_KEY_HASH_ITERATIONS - Static variable in class org.h2.engine.Constants
The password is hashed this many times to slow down dictionary attacks.
encryptionKey - Variable in class org.h2.store.fs.encrypt.FileEncrypt
 
encryptionKey(char[]) - Method in class org.h2.mvstore.MVStore.Builder
Encrypt / decrypt the file using the given password.
encryptKey - Variable in class org.h2.tools.ChangeFileEncryption
 
end - Variable in class org.h2.index.IndexCursor
 
end - Variable in class org.h2.index.RangeCursor
 
end - Variable in class org.h2.index.SingleRowCursor
 
end(Xid, int) - Method in class org.h2.jdbcx.JdbcXAConnection
End a transaction.
END - Static variable in class org.h2.index.IndexCondition
A bit of a search mask meaning 'smaller or equal'.
END - Static variable in class org.h2.util.ParserUtil
The token "END".
END_OF_INPUT - Static variable in class org.h2.command.Token
End of input.
end1 - Variable in class org.h2.expression.analysis.WindowFrame.BiItr
 
end1 - Variable in class org.h2.expression.analysis.WindowFrame.BiReverseItr
 
end2 - Variable in class org.h2.expression.analysis.WindowFrame.TriItr
 
end2 - Variable in class org.h2.expression.analysis.WindowFrame.TriReverseItr
 
endArray() - Method in class org.h2.util.json.JSONByteArrayTarget
 
endArray() - Method in class org.h2.util.json.JSONStringTarget
 
endArray() - Method in class org.h2.util.json.JSONTarget
End of the current array.
endArray() - Method in class org.h2.util.json.JSONValidationTargetWithoutUniqueKeys
 
endArray() - Method in class org.h2.util.json.JSONValidationTargetWithUniqueKeys
 
endArray() - Method in class org.h2.util.json.JSONValueTarget
 
endCollectionItem(GeometryUtils.Target, int, int, int) - Method in class org.h2.util.geometry.EWKTUtils.EWKTTarget
 
endCollectionItem(GeometryUtils.Target, int, int, int) - Method in class org.h2.util.geometry.GeometryUtils.Target
Invoked after writing of a collection item.
endCollectionItem(GeometryUtils.Target, int, int, int) - Method in class org.h2.util.geometry.JTSUtils.GeometryTarget
 
endElement(String, String, String) - Method in class org.h2.security.auth.H2AuthConfigXml
 
endIndex - Variable in class org.h2.expression.analysis.WindowFrame.PlainItr
 
endLeftoverTransactions() - Method in class org.h2.mvstore.tx.TransactionStore
Commit all transactions that are in the committed state, and rollback all open transactions.
endNonEmptyPolygon() - Method in class org.h2.util.geometry.EWKTUtils.EWKTTarget
 
endNonEmptyPolygon() - Method in class org.h2.util.geometry.GeoJsonUtils.GeoJsonTarget
 
endNonEmptyPolygon() - Method in class org.h2.util.geometry.GeometryUtils.Target
Invoked after writing of non-empty POLYGON.
endObject() - Method in class org.h2.util.json.JSONByteArrayTarget
 
endObject() - Method in class org.h2.util.json.JSONStringTarget
 
endObject() - Method in class org.h2.util.json.JSONTarget
End of the current object.
endObject() - Method in class org.h2.util.json.JSONValidationTargetWithoutUniqueKeys
 
endObject() - Method in class org.h2.util.json.JSONValidationTargetWithUniqueKeys
 
endObject() - Method in class org.h2.util.json.JSONValueTarget
 
endObject(int) - Method in class org.h2.util.geometry.EWKTUtils.EWKTTarget
 
endObject(int) - Method in class org.h2.util.geometry.GeoJsonUtils.GeoJsonTarget
 
endObject(int) - Method in class org.h2.util.geometry.GeometryUtils.Target
Invoked after writing of the object.
endOfFile - Variable in class org.h2.store.FileStoreInputStream
 
endOfFile - Variable in class org.h2.tools.Csv
 
endOfFile - Variable in class org.h2.util.ScriptReader
True if we have read past the end of file
EndOfInputToken(int) - Constructor for class org.h2.command.Token.EndOfInputToken
 
endOfLine - Variable in class org.h2.tools.Csv
 
endRemark() - Method in class org.h2.util.ScriptReader
 
endStatement() - Method in class org.h2.engine.SessionLocal
Mark the statement as completed.
endTransaction() - Method in class org.h2.engine.SessionLocal
 
endTransaction(Transaction, boolean) - Method in class org.h2.mvstore.tx.TransactionStore
End this transaction.
Engine - Class in org.h2.engine
The engine contains a map of all open databases.
Engine() - Constructor for class org.h2.engine.Engine
 
Engine.DatabaseHolder - Class in org.h2.engine
 
engineDigest() - Method in class org.h2.security.SHA3
 
engineGetDigestLength() - Method in class org.h2.security.SHA3
 
engineReset() - Method in class org.h2.security.SHA3
 
engineUpdate(byte) - Method in class org.h2.security.SHA3
 
engineUpdate(byte[], int, int) - Method in class org.h2.security.SHA3
 
enquoteIdentifier(String, boolean) - Method in class org.h2.jdbc.JdbcStatement
 
enquoteIdentifier(String, boolean) - Method in interface org.h2.jdbc.JdbcStatementBackwardsCompat
Enquotes the specified identifier.
ensureCapacity(int) - Method in class org.h2.mvstore.WriteBuffer
 
ensureCapacity(int) - Method in class org.h2.util.IntArray
Ensure the underlying array is large enough for the given number of entries.
ensureOutput(int) - Method in class org.h2.compress.LZFOutputStream
 
ensureSize(byte[], int) - Static method in class org.h2.compress.LZFInputStream
 
entries - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
The map array.
entry - Variable in class org.h2.store.fs.zip.FileZip
 
Entry() - Constructor for class org.h2.mvstore.cache.CacheLongKeyLIRS.Entry
 
Entry(long, V, int) - Constructor for class org.h2.mvstore.cache.CacheLongKeyLIRS.Entry
 
Entry(CacheLongKeyLIRS.Entry<V>) - Constructor for class org.h2.mvstore.cache.CacheLongKeyLIRS.Entry
 
entryIterator(K, K) - Method in class org.h2.mvstore.tx.TransactionMap
Iterate over entries.
entrySet() - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Get the entry set for all resident entries.
entrySet() - Method in class org.h2.mvstore.MVMap
 
entrySet() - Method in class org.h2.mvstore.tx.TransactionMap
 
entrySet() - Method in class org.h2.util.SoftValuesHashMap
 
ENUM - Static variable in class org.h2.api.H2Type
The ENUM data type.
ENUM - Static variable in class org.h2.mvstore.db.ValueDataType
 
ENUM - Static variable in class org.h2.value.Transfer
 
ENUM - Static variable in class org.h2.value.Value
The value type for ENUM values.
ENUM_DUPLICATE - Static variable in class org.h2.api.ErrorCode
The error with code 22033 is thrown when an attempt is made to add or modify an ENUM-typed column so that it would have duplicate values.
ENUM_EMPTY - Static variable in class org.h2.api.ErrorCode
The error with code 22032 is thrown when an attempt is made to add or modify an ENUM-typed column so that one or more of its enumerators would be empty.
ENUM_VALUE_NOT_PERMITTED - Static variable in class org.h2.api.ErrorCode
The error with code 22030 is thrown when an attempt is made to INSERT or UPDATE an ENUM-typed cell, but the value is not one of the values enumerated by the type.
ENUM_VALUES - Static variable in class org.h2.table.InformationSchemaTable
 
enumerators - Variable in class org.h2.value.ExtTypeInfoEnum
 
enumerators - Variable in class org.h2.value.ValueEnum
 
enumValues(SessionLocal, ArrayList<Row>, String, String, String, String, String, TypeInfo) - Method in class org.h2.table.InformationSchemaTable
 
envelope - Variable in class org.h2.expression.aggregate.AggregateDataEnvelope
 
envelope - Variable in class org.h2.value.ValueGeometry
The envelope of the value.
ENVELOPE - org.h2.expression.aggregate.AggregateType
The aggregate type for ENVELOPE(expression).
envelope2wkb(double[]) - Static method in class org.h2.util.geometry.EWKBUtils
Converts an envelope to a WKB.
EnvelopeTarget() - Constructor for class org.h2.util.geometry.GeometryUtils.EnvelopeTarget
Creates a new envelope calculation target.
EPOCH - Static variable in class org.h2.expression.function.DateTimeFunction
Epoch.
EPOCH_DATE_VALUE - Static variable in class org.h2.util.DateTimeUtils
Date value for 1970-01-01.
eq(String, String, int, int) - Static method in class org.h2.command.Tokenizer
 
eqCurrent(String, String, int, int) - Static method in class org.h2.command.Tokenizer
 
EQUAL - Static variable in class org.h2.command.Token
The token "=".
EQUAL - Static variable in class org.h2.expression.condition.Comparison
The comparison type meaning = as in ID=1.
EQUAL_NULL_SAFE - Static variable in class org.h2.expression.condition.Comparison
The comparison type meaning ID IS NOT DISTINCT FROM 1.
EQUALITY - Static variable in class org.h2.index.IndexCondition
A bit of a search mask meaning 'equal'.
equals(Object) - Method in class org.h2.api.Interval
 
equals(Object) - Method in class org.h2.engine.SessionLocal.SequenceAndPrepared
 
equals(Object) - Method in class org.h2.expression.function.DateTimeFormatFunction.CacheKey
 
equals(Object) - Method in class org.h2.mvstore.Chunk
 
equals(Object) - Method in class org.h2.mvstore.db.RowDataType
 
equals(Object) - Method in class org.h2.mvstore.db.SpatialKey
 
equals(Object) - Method in class org.h2.mvstore.db.ValueDataType
 
equals(Object) - Method in class org.h2.mvstore.MVMap
 
equals(Object) - Method in class org.h2.mvstore.tx.Snapshot
 
equals(Object) - Method in class org.h2.mvstore.tx.VersionedValueType
 
equals(Object) - Method in class org.h2.mvstore.type.BasicDataType
 
equals(Object) - Method in class org.h2.result.SearchRow
 
equals(Object) - Method in class org.h2.result.SimpleResult.Column
 
equals(Object) - Method in class org.h2.store.fs.mem.FileMemData.CompressItem
 
equals(Object) - Method in class org.h2.store.fs.niomem.FileNioMemData.CompressItem
 
equals(Object) - Method in class org.h2.table.Column
 
equals(Object) - Method in class org.h2.table.TableLinkConnection
 
equals(Object) - Method in class org.h2.table.TableView.CacheKey
 
equals(Object) - Method in class org.h2.util.IntArray
 
equals(Object) - Method in class org.h2.util.SimpleColumnInfo
 
equals(Object) - Method in class org.h2.util.TimeZoneProvider.Simple
 
equals(Object) - Method in class org.h2.util.TimeZoneProvider.WithTimeZone
 
equals(Object) - Method in class org.h2.value.CompareMode
 
equals(Object) - Method in class org.h2.value.ExtTypeInfoEnum
 
equals(Object) - Method in class org.h2.value.ExtTypeInfoGeometry
 
equals(Object) - Method in class org.h2.value.ExtTypeInfoRow
 
equals(Object) - Method in class org.h2.value.TypeInfo
 
equals(Object) - Method in class org.h2.value.Value
Check if the two values have the same hash code.
equals(Object) - Method in class org.h2.value.ValueArray
 
equals(Object) - Method in class org.h2.value.ValueBigint
 
equals(Object) - Method in class org.h2.value.ValueBoolean
 
equals(Object) - Method in class org.h2.value.ValueBytesBase
 
equals(Object) - Method in class org.h2.value.ValueDate
 
equals(Object) - Method in class org.h2.value.ValueDecfloat
 
equals(Object) - Method in class org.h2.value.ValueDouble
 
equals(Object) - Method in class org.h2.value.ValueEnumBase
 
equals(Object) - Method in class org.h2.value.ValueInteger
 
equals(Object) - Method in class org.h2.value.ValueInterval
 
equals(Object) - Method in class org.h2.value.ValueLob
 
equals(Object) - Method in class org.h2.value.ValueNull
 
equals(Object) - Method in class org.h2.value.ValueNumeric
 
equals(Object) - Method in class org.h2.value.ValueReal
 
equals(Object) - Method in class org.h2.value.ValueRow
 
equals(Object) - Method in class org.h2.value.ValueSmallint
 
equals(Object) - Method in class org.h2.value.ValueStringBase
 
equals(Object) - Method in class org.h2.value.ValueTime
 
equals(Object) - Method in class org.h2.value.ValueTimestamp
 
equals(Object) - Method in class org.h2.value.ValueTimestampTimeZone
 
equals(Object) - Method in class org.h2.value.ValueTimeTimeZone
 
equals(Object) - Method in class org.h2.value.ValueTinyint
 
equals(Object) - Method in class org.h2.value.ValueUuid
 
equals(Object) - Method in class org.h2.value.ValueVarcharIgnoreCase
 
equals(Object, Object) - Method in class org.h2.mvstore.rtree.SpatialDataType
Check whether two spatial values are equal.
equalsChars(String, int, String, int, boolean) - Method in class org.h2.value.CompareMode
Compare two characters in a string.
equalsChars(String, int, String, int, boolean) - Method in class org.h2.value.CompareModeDefault
 
equalsChars(String, int, String, int, boolean) - Method in class org.h2.value.CompareModeIcu4J
 
EqualsDecisionMaker(DataType<V>, V) - Constructor for class org.h2.mvstore.MVMap.EqualsDecisionMaker
 
equalsIdentifiers(String, String) - Method in class org.h2.engine.Database
Compare two identifiers (table names, column names,...) and verify they are equal.
equalsIgnoringId(Spatial) - Method in class org.h2.mvstore.db.SpatialKey
Check whether two objects are equals, but do not compare the id fields.
equalsIgnoringId(Spatial) - Method in class org.h2.mvstore.rtree.DefaultSpatial
 
equalsIgnoringId(Spatial) - Method in interface org.h2.mvstore.rtree.Spatial
Check whether two objects are equals, but do not compare the id fields.
equalsToken(String, String) - Method in class org.h2.command.Parser
 
err - Variable in class org.h2.tools.Shell
 
error(Throwable, String) - Method in class org.h2.message.Trace
Write a message with trace level ERROR to the trace system.
error(Throwable, String, Object...) - Method in class org.h2.message.Trace
Write a message with trace level ERROR to the trace system.
ERROR - Static variable in class org.h2.message.TraceSystem
This trace level means only errors should be written.
ERROR_ACCESSING_LINKED_TABLE_2 - Static variable in class org.h2.api.ErrorCode
The error with code 90111 is thrown when an exception occurred while accessing a linked table.
ERROR_BLOCK_NOT_FOUND - Static variable in class org.h2.mvstore.DataUtils
The block in the stream store was not found.
ERROR_CHUNK_NOT_FOUND - Static variable in class org.h2.mvstore.DataUtils
The application was trying to read data from a chunk that is no longer available.
ERROR_CLOSED - Static variable in class org.h2.mvstore.DataUtils
The object is already closed.
ERROR_CREATING_TRIGGER_OBJECT_3 - Static variable in class org.h2.api.ErrorCode
The error with code 90043 is thrown when there is an error initializing the trigger, for example because the class does not implement the Trigger interface.
ERROR_EXECUTING_TRIGGER_3 - Static variable in class org.h2.api.ErrorCode
The error with code 90044 is thrown when an exception or error occurred while calling the triggers fire method.
ERROR_FILE_CORRUPT - Static variable in class org.h2.mvstore.DataUtils
The file is corrupt or (for encrypted files) the encryption key is wrong.
ERROR_FILE_LOCKED - Static variable in class org.h2.mvstore.DataUtils
The file is locked.
ERROR_INTERNAL - Static variable in class org.h2.mvstore.DataUtils
An internal error occurred.
ERROR_OPENING_DATABASE_1 - Static variable in class org.h2.api.ErrorCode
The error with code 8000 is thrown when there was a problem trying to create a database lock.
ERROR_READING_FAILED - Static variable in class org.h2.mvstore.DataUtils
An error occurred while reading from the file.
ERROR_SERIALIZATION - Static variable in class org.h2.mvstore.DataUtils
An error occurred when serializing or de-serializing.
ERROR_SETTING_DATABASE_EVENT_LISTENER_2 - Static variable in class org.h2.api.ErrorCode
The error with code 90099 is thrown when an error occurred trying to initialize the database event listener.
ERROR_TOO_MANY_OPEN_TRANSACTIONS - Static variable in class org.h2.mvstore.DataUtils
There are too many open transactions.
ERROR_TRANSACTION_CORRUPT - Static variable in class org.h2.mvstore.DataUtils
The transaction store is corrupt.
ERROR_TRANSACTION_ILLEGAL_STATE - Static variable in class org.h2.mvstore.DataUtils
The transaction store is in an illegal state (for example, not yet initialized).
ERROR_TRANSACTION_LOCKED - Static variable in class org.h2.mvstore.DataUtils
An entry is still locked by another transaction.
ERROR_TRANSACTION_TOO_BIG - Static variable in class org.h2.mvstore.DataUtils
The transaction contains too many changes.
ERROR_TRANSACTIONS_DEADLOCK - Static variable in class org.h2.mvstore.DataUtils
Deadlock discovered and one of transactions involved chosen as victim and rolled back.
ERROR_UNKNOWN_DATA_TYPE - Static variable in class org.h2.mvstore.DataUtils
The transaction store can not be initialized because data type is not found in type registry.
ERROR_UNSUPPORTED_FORMAT - Static variable in class org.h2.mvstore.DataUtils
The file format is not supported.
ERROR_WRITING_FAILED - Static variable in class org.h2.mvstore.DataUtils
An error occurred when trying to write to the file.
errorArea - Variable in class org.h2.tools.GUIConsole
 
errorCode - Variable in exception org.h2.mvstore.MVStoreException
 
ErrorCode - Class in org.h2.api
This class defines the error codes used for SQL exceptions.
ErrorCode() - Constructor for class org.h2.api.ErrorCode
 
escape - Variable in class org.h2.expression.condition.CompareLike
 
escape(String) - Method in class org.h2.tools.Csv
 
escapeCharacter - Variable in class org.h2.tools.Csv
 
escapeData(ResultSet, int) - Static method in class org.h2.server.web.WebApp
 
escapeHtml(String) - Static method in class org.h2.server.web.PageParser
Convert data to HTML, including newlines and multiple spaces.
escapeHtml(String, boolean) - Static method in class org.h2.server.web.PageParser
 
escapeHtmlData(String) - Static method in class org.h2.server.web.PageParser
Convert data to HTML, but don't convert newlines and multiple spaces.
escapeIdentifier(String) - Static method in class org.h2.server.web.WebApp
 
escapeJavaScript(String) - Static method in class org.h2.server.web.PageParser
Escape text as a the javascript string.
escapeMetaDataPattern(String) - Static method in class org.h2.util.StringUtils
Escape table or schema patterns used for DatabaseMetaData functions.
escapeProcessing - Variable in class org.h2.jdbc.JdbcStatement
 
ESTIMATED_ENVELOPE - Static variable in class org.h2.expression.function.TableInfoFunction
ESTIMATED_ENVELOPE().
estimatedFunctionTableRows - Variable in class org.h2.engine.DbSettings
Database setting ESTIMATED_FUNCTION_TABLE_ROWS (default: 1000).
estimateMemory(AtomicLong, DataType<T>, T) - Static method in class org.h2.util.MemoryEstimator
Estimates memory size of the data based on previous values.
estimateMemory(AtomicLong, DataType<T>, T[], int) - Static method in class org.h2.util.MemoryEstimator
Estimates memory size of the data set based on previous values.
evaluatable - Variable in class org.h2.table.TableFilter
 
EVALUATABLE - Static variable in class org.h2.expression.ExpressionVisitor
Can the expression be evaluated, that means are all columns set to 'evaluatable'?
EVALUATABLE_VISITOR - Static variable in class org.h2.expression.ExpressionVisitor
The visitor singleton for the type EVALUATABLE.
EVALUATABLE_VISITORS - Static variable in class org.h2.expression.ExpressionVisitor
EVALUATABLE listeners with query level 0, 1, ...
evaluatedAt - Variable in class org.h2.index.ViewIndex
The time in nanoseconds when this index (and its cost) was calculated.
evaluateMemoryForKey(K) - Method in class org.h2.mvstore.MVMap
 
evaluateMemoryForKeys(K[], int) - Method in class org.h2.mvstore.MVMap
 
evaluateMemoryForValue(V) - Method in class org.h2.mvstore.MVMap
 
evaluateMemoryForValues(V[], int) - Method in class org.h2.mvstore.MVMap
 
evaluateTriggerMasks() - Method in class org.h2.command.dml.MergeUsing
 
evaluateTriggerMasks() - Method in class org.h2.command.dml.MergeUsing.When
Evaluates trigger mask (UPDATE, INSERT, DELETE).
evaluateTriggerMasks() - Method in class org.h2.command.dml.MergeUsing.WhenMatchedThenDelete
 
evaluateTriggerMasks() - Method in class org.h2.command.dml.MergeUsing.WhenMatchedThenUpdate
 
evaluateTriggerMasks() - Method in class org.h2.command.dml.MergeUsing.WhenNotMatched
 
eventListener - Variable in class org.h2.engine.Database
 
eventListener - Variable in class org.h2.engine.SessionRemote
 
eventText - Variable in enum org.h2.mvstore.db.MVTable.TraceLockEvent
 
EVERY - org.h2.expression.aggregate.AggregateType
The aggregate type for EVERY(expression).
evict() - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
Evict cold entries (resident and non-resident) until the memory limit is reached.
evictBlock() - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
 
ewkb - Variable in class org.h2.util.geometry.EWKBUtils.EWKBSource
 
EWKB_M - Static variable in class org.h2.util.geometry.EWKBUtils
Geometry type mask that indicates presence of dimension M.
EWKB_SRID - Static variable in class org.h2.util.geometry.EWKBUtils
Geometry type mask that indicates presence of SRID.
EWKB_Z - Static variable in class org.h2.util.geometry.EWKBUtils
Geometry type mask that indicates presence of dimension Z.
ewkb2ewkb(byte[]) - Static method in class org.h2.util.geometry.EWKBUtils
Converts any supported EWKB to EWKB representation that is used by this class.
ewkb2ewkb(byte[], int) - Static method in class org.h2.util.geometry.EWKBUtils
Converts any supported EWKB to EWKB representation that is used by this class.
ewkb2ewkt(byte[]) - Static method in class org.h2.util.geometry.EWKTUtils
Converts EWKB to EWKT.
ewkb2ewkt(byte[], int) - Static method in class org.h2.util.geometry.EWKTUtils
Converts EWKB to EWKT.
ewkb2geometry(byte[]) - Static method in class org.h2.util.geometry.JTSUtils
Converts EWKB to a JTS geometry object.
ewkb2geometry(byte[], int) - Static method in class org.h2.util.geometry.JTSUtils
Converts EWKB to a JTS geometry object.
EWKBSource(byte[]) - Constructor for class org.h2.util.geometry.EWKBUtils.EWKBSource
Creates new instance of EWKB source.
EWKBTarget(ByteArrayOutputStream, int) - Constructor for class org.h2.util.geometry.EWKBUtils.EWKBTarget
Creates a new EWKB output target.
ewkbToGeoJson(byte[], int) - Static method in class org.h2.util.geometry.GeoJsonUtils
Converts EWKB with known dimension system to GeoJson.
EWKBUtils - Class in org.h2.util.geometry
EWKB format support for GEOMETRY data type.
EWKBUtils() - Constructor for class org.h2.util.geometry.EWKBUtils
 
EWKBUtils.EWKBSource - Class in org.h2.util.geometry
Helper source object for EWKB reading.
EWKBUtils.EWKBTarget - Class in org.h2.util.geometry
Converter output target that writes a EWKB.
ewkt - Variable in class org.h2.util.geometry.EWKTUtils.EWKTSource
 
ewkt2ewkb(String) - Static method in class org.h2.util.geometry.EWKTUtils
Converts EWKT to EWKB.
ewkt2ewkb(String, int) - Static method in class org.h2.util.geometry.EWKTUtils
Converts EWKT to EWKB.
EWKTSource(String) - Constructor for class org.h2.util.geometry.EWKTUtils.EWKTSource
 
EWKTTarget(StringBuilder, int) - Constructor for class org.h2.util.geometry.EWKTUtils.EWKTTarget
Creates a new EWKT output target.
EWKTUtils - Class in org.h2.util.geometry
EWKT format support for GEOMETRY data type.
EWKTUtils() - Constructor for class org.h2.util.geometry.EWKTUtils
 
EWKTUtils.EWKTSource - Class in org.h2.util.geometry
Helper source object for EWKT reading.
EWKTUtils.EWKTTarget - Class in org.h2.util.geometry
Converter output target that writes a EWKT.
ex - Variable in class org.h2.util.Task
 
EXCEPT - org.h2.command.query.SelectUnion.UnionType
The type of an EXCEPT statement.
EXCEPT - Static variable in class org.h2.util.ParserUtil
The token "EXCEPT".
exceptColumns - Variable in class org.h2.expression.Wildcard
 
EXCEPTION - org.h2.engine.Mode.ViewExpressionNames
Throw exception for unspecified names.
EXCEPTION_IN_FUNCTION_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90105 is thrown when an exception occurred in a user-defined method.
EXCEPTION_OPENING_PORT_2 - Static variable in class org.h2.api.ErrorCode
The error with code 90061 is thrown when trying to start a server if a server is already running at the same port.
exceptionHandler - Variable in class org.h2.mvstore.type.MetaType
 
exceptionThrown(SQLException, String) - Method in interface org.h2.api.DatabaseEventListener
This method is called if an exception occurred.
exceptionThrown(SQLException, String) - Method in class org.h2.engine.Database
This method is called after an exception occurred, to inform the database event listener (if one is set).
EXCLUDE_CURRENT_ROW - org.h2.expression.analysis.WindowFrameExclusion
EXCLUDE CURRENT ROW exclusion clause.
EXCLUDE_GROUP - org.h2.expression.analysis.WindowFrameExclusion
EXCLUDE GROUP exclusion clause.
EXCLUDE_NO_OTHERS - org.h2.expression.analysis.WindowFrameExclusion
EXCLUDE NO OTHERS exclusion clause.
EXCLUDE_TIES - org.h2.expression.analysis.WindowFrameExclusion
EXCLUDE TIES exclusion clause.
EXCLUDED - org.h2.expression.aggregate.AggregateDataCollecting.NullCollectionMode
Rows with NULL values are processed causing the result to be not NULL, but NULL values aren't collected.
excludeSchema(Schema) - Method in class org.h2.command.dml.ScriptCommand
 
excludeTable(Table) - Method in class org.h2.command.dml.ScriptCommand
 
exclusion - Variable in class org.h2.expression.analysis.WindowFrame
 
EXCLUSIVE - Static variable in class org.h2.command.dml.SetTypes
The type of a SET EXCLUSIVE statement.
EXCLUSIVE_LOCK - Static variable in class org.h2.table.Table
Exclusive lock.
EXCLUSIVE_LOCKS - Static variable in class org.h2.mvstore.db.MVTable
The table names this thread has exclusively locked.
exclusiveSession - Variable in class org.h2.engine.Database
 
exec(String...) - Static method in class org.h2.util.Profiler
 
exec(String...) - Static method in class org.h2.util.SourceCompiler
 
exec(ArrayList<String>) - Static method in class org.h2.tools.Upgrade
 
execute() - Method in class org.h2.jdbc.JdbcPreparedStatement
Executes an arbitrary statement.
execute() - Method in class org.h2.util.Task
Start the thread.
execute(String) - Method in class org.h2.command.ddl.AlterTableAlterColumn
 
execute(String) - Method in class org.h2.command.dml.RunScriptCommand
 
execute(String) - Method in class org.h2.jdbc.JdbcStatement
Executes a statement and returns type of its result.
execute(String) - Method in class org.h2.tools.Shell
 
execute(String) - Method in class org.h2.util.Task
Start the thread.
execute(String, int) - Method in class org.h2.jdbc.JdbcStatement
Executes a statement and returns type of its result.
execute(String, int[]) - Method in class org.h2.jdbc.JdbcStatement
Executes a statement and returns type of its result.
execute(String, String) - Static method in class org.h2.tools.Recover
Dumps the contents of a database to a SQL script file.
execute(String, String[]) - Method in class org.h2.jdbc.JdbcStatement
Executes a statement and returns type of its result.
execute(String, String, boolean) - Static method in class org.h2.tools.DeleteDbFiles
Deletes the database files.
execute(String, String, String) - Static method in class org.h2.tools.Restore
Restores database files.
execute(String, String, String, boolean) - Static method in class org.h2.tools.Backup
Backs up database files.
execute(String, String, String, char[], char[], boolean) - Static method in class org.h2.tools.ChangeFileEncryption
Changes the password for a database.
execute(String, String, String, String, String) - Method in class org.h2.tools.CreateCluster
Creates a cluster.
execute(String, String, String, String, Charset, boolean) - Static method in class org.h2.tools.RunScript
Executes the SQL commands in a script file against a database.
execute(String, ArrayList<Value>, boolean, SessionLocal) - Method in class org.h2.table.TableLink
Execute a SQL statement using the given parameters.
execute(Connection, Reader) - Static method in class org.h2.tools.RunScript
Executes the SQL commands read from the reader against a database.
execute(Database, Prepared, DatabaseEventListener, String) - Static method in class org.h2.engine.MetaRecord
Execute the meta data statement.
execute(SessionLocal, Expression[], boolean) - Method in class org.h2.schema.FunctionAlias.JavaMethod
 
EXECUTE - Static variable in interface org.h2.command.CommandInterface
The type of an EXECUTE statement.
EXECUTE_IMMEDIATELY - Static variable in interface org.h2.command.CommandInterface
The type of an EXECUTE IMMEDIATELY statement.
executeBatch() - Method in class org.h2.jdbc.JdbcPreparedStatement
Executes the batch.
executeBatch() - Method in class org.h2.jdbc.JdbcStatement
Executes the batch.
executeBatchElement(String, SQLException) - Method in class org.h2.jdbc.JdbcStatement
 
executeBatchElement(Value[], SQLException) - Method in class org.h2.jdbc.JdbcPreparedStatement
 
executeCommand - Variable in class org.h2.command.dml.Explain
 
executeCount - Variable in class org.h2.tools.ConvertTraceFile.Stat
 
executeDrop() - Method in class org.h2.command.ddl.DropTable
 
executeExists() - Method in class org.h2.command.query.Query
 
ExecuteImmediate - Class in org.h2.command.dml
This class represents the statement EXECUTE IMMEDIATE.
ExecuteImmediate(SessionLocal, Expression) - Constructor for class org.h2.command.dml.ExecuteImmediate
 
executeInternal(String, Object) - Method in class org.h2.jdbc.JdbcStatement
 
executeLargeBatch() - Method in class org.h2.jdbc.JdbcPreparedStatement
Executes the batch.
executeLargeBatch() - Method in class org.h2.jdbc.JdbcStatement
Executes the batch.
executeLargeUpdate() - Method in class org.h2.jdbc.JdbcCallableStatement
Executes a statement (insert, update, delete, create, drop) and returns the update count.
executeLargeUpdate() - Method in class org.h2.jdbc.JdbcPreparedStatement
Executes a statement (insert, update, delete, create, drop) and returns the update count.
executeLargeUpdate(String) - Method in class org.h2.jdbc.JdbcStatement
Executes a statement (insert, update, delete, create, drop) and returns the update count.
executeLargeUpdate(String, int) - Method in class org.h2.jdbc.JdbcStatement
Executes a statement and returns the update count.
executeLargeUpdate(String, int[]) - Method in class org.h2.jdbc.JdbcStatement
Executes a statement and returns the update count.
executeLargeUpdate(String, String[]) - Method in class org.h2.jdbc.JdbcStatement
Executes a statement and returns the update count.
executeLoop(Connection, int, String) - Method in class org.h2.server.web.WebApp
 
executeMeta() - Method in class org.h2.engine.Database
 
executeMeta(ArrayList<MetaRecord>) - Method in class org.h2.engine.Database
 
ExecuteProcedure - Class in org.h2.command.dml
This class represents the statement EXECUTE
ExecuteProcedure(SessionLocal) - Constructor for class org.h2.command.dml.ExecuteProcedure
 
executeQuery() - Method in class org.h2.jdbc.JdbcPreparedStatement
Executes a query (select statement) and returns the result set.
executeQuery(int, Value...) - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
executeQuery(long, boolean) - Method in class org.h2.command.Command
Execute a query and return the result.
executeQuery(long, boolean) - Method in interface org.h2.command.CommandInterface
Execute the query.
executeQuery(long, boolean) - Method in class org.h2.command.CommandRemote
 
executeQuery(String) - Method in class org.h2.jdbc.JdbcPreparedStatement
Calling this method is not legal on a PreparedStatement.
executeQuery(String) - Method in class org.h2.jdbc.JdbcStatement
Executes a query (select statement) and returns the result set.
executeQuery(String, Value...) - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
executeQuery(PgServerThread.Prepared, CommandInterface, int[], int) - Method in class org.h2.server.pg.PgServerThread
 
executeRemaining() - Method in class org.h2.command.CommandList
 
executeUpdate() - Method in class org.h2.jdbc.JdbcCallableStatement
Executes a statement (insert, update, delete, create, drop) and returns the update count.
executeUpdate() - Method in class org.h2.jdbc.JdbcPreparedStatement
Executes a statement (insert, update, delete, create, drop) and returns the update count.
executeUpdate(Object) - Method in class org.h2.command.Command
 
executeUpdate(Object) - Method in interface org.h2.command.CommandInterface
Execute the statement
executeUpdate(Object) - Method in class org.h2.command.CommandRemote
 
executeUpdate(String) - Method in class org.h2.jdbc.JdbcStatement
Executes a statement (insert, update, delete, create, drop) and returns the update count.
executeUpdate(String, int) - Method in class org.h2.jdbc.JdbcStatement
Executes a statement and returns the update count.
executeUpdate(String, int[]) - Method in class org.h2.jdbc.JdbcStatement
Executes a statement and returns the update count.
executeUpdate(String, String[]) - Method in class org.h2.jdbc.JdbcStatement
Executes a statement and returns the update count.
executeUpdateInternal() - Method in class org.h2.jdbc.JdbcPreparedStatement
 
executeUpdateInternal(String, Object) - Method in class org.h2.jdbc.JdbcStatement
 
executeUpdateWithGeneratedKeys(DataChangeStatement, Object) - Method in class org.h2.command.CommandContainer
 
executingCommand - Variable in class org.h2.jdbc.JdbcStatement
 
executingStatement - Variable in class org.h2.jdbc.JdbcConnection
 
executingStatement - Variable in class org.h2.server.web.WebSession
The currently executing statement.
executionTimeCumulativeNanos - Variable in class org.h2.engine.QueryStatisticsData.QueryEntry
The total execution time.
executionTimeM2Nanos - Variable in class org.h2.engine.QueryStatisticsData.QueryEntry
 
executionTimeMaxNanos - Variable in class org.h2.engine.QueryStatisticsData.QueryEntry
The maximum execution time, in nanoseconds.
executionTimeMeanNanos - Variable in class org.h2.engine.QueryStatisticsData.QueryEntry
The mean execution time.
executionTimeMinNanos - Variable in class org.h2.engine.QueryStatisticsData.QueryEntry
The minimum execution time, in nanoseconds.
EXHAUSTED - org.h2.schema.Sequence.Cycle
Sequence is not cycled and was already exhausted.
exists() - Method in class org.h2.command.query.Query
Execute the EXISTS predicate over the query.
exists() - Method in class org.h2.store.fs.disk.FilePathDisk
 
exists() - Method in class org.h2.store.fs.FilePath
Checks if a file exists.
exists() - Method in class org.h2.store.fs.FilePathWrapper
 
exists() - Method in class org.h2.store.fs.mem.FilePathMem
 
exists() - Method in class org.h2.store.fs.niomem.FilePathNioMem
 
exists() - Method in class org.h2.store.fs.zip.FilePathZip
 
exists(String) - Static method in class org.h2.store.fs.FileUtils
Checks if a file exists.
EXISTS - Static variable in class org.h2.util.ParserUtil
The token "EXISTS".
ExistsPredicate - Class in org.h2.expression.condition
Exists predicate as in EXISTS(SELECT ...)
ExistsPredicate(Query) - Constructor for class org.h2.expression.condition.ExistsPredicate
 
existsRow(SessionLocal, Index, SearchRow, Row) - Method in class org.h2.constraint.ConstraintReferential
 
EXP - Static variable in class org.h2.expression.function.MathFunction1
EXP().
expand(byte[]) - Method in class org.h2.tools.CompressTool
Expands the compressed data.
expand(byte[], byte[], int) - Static method in class org.h2.tools.CompressTool
INTERNAL
expand(byte[], int, int, byte[], int, int) - Method in class org.h2.compress.CompressDeflate
 
expand(byte[], int, int, byte[], int, int) - Method in class org.h2.compress.CompressLZF
 
expand(byte[], int, int, byte[], int, int) - Method in class org.h2.compress.CompressNo
 
expand(byte[], int, int, byte[], int, int) - Method in interface org.h2.compress.Compressor
Expand a number of compressed bytes.
expand(int) - Method in class org.h2.store.Data
 
expand(int) - Method in class org.h2.store.fs.mem.FileMemData
 
expand(int, Object[], Object[]) - Method in class org.h2.mvstore.Page.NonLeaf
 
expand(int, K[], V[]) - Method in class org.h2.mvstore.Page
Append additional key/value mappings to this Page.
expand(int, K[], V[]) - Method in class org.h2.mvstore.Page.Leaf
 
expand(ByteBuffer, ByteBuffer) - Static method in class org.h2.compress.CompressLZF
Expand a number of compressed bytes.
EXPAND - Static variable in class org.h2.expression.function.CompressFunction
EXPAND() (non-standard).
expandColumnList() - Method in class org.h2.command.query.Select
 
expandColumnList(TableFilter, int, boolean, HashMap<Column, ExpressionColumn>) - Method in class org.h2.command.query.Select
 
expandKeys(int, K[]) - Method in class org.h2.mvstore.Page
Expand the keys array.
expandPage(int) - Method in class org.h2.store.fs.niomem.FileNioMemData
 
expandUserHomeDirectory(String) - Static method in class org.h2.store.fs.disk.FilePathDisk
Expand '~' to the user home directory.
expectedList - Variable in class org.h2.command.Parser
 
expectedValue - Variable in class org.h2.mvstore.MVMap.EqualsDecisionMaker
 
Explain - Class in org.h2.command.dml
This class represents the statement EXPLAIN
Explain(SessionLocal) - Constructor for class org.h2.command.dml.Explain
 
EXPLAIN - Static variable in interface org.h2.command.CommandInterface
The type of an EXPLAIN statement.
EXPLAIN_ANALYZE - Static variable in interface org.h2.command.CommandInterface
The type of an EXPLAIN ANALYZE statement.
expr - Variable in class org.h2.command.ddl.SetComment
 
expr - Variable in class org.h2.constraint.ConstraintCheck
 
expr - Variable in class org.h2.constraint.ConstraintDomain
 
expr - Variable in class org.h2.expression.Alias
 
expression - Variable in class org.h2.command.ddl.AlterDomainExpressions
 
expression - Variable in class org.h2.command.ddl.CreateConstant
 
expression - Variable in class org.h2.command.dml.Call
 
expression - Variable in class org.h2.command.dml.Set
 
expression - Variable in class org.h2.command.dml.SetClauseList.RowExpression
 
expression - Variable in class org.h2.command.dml.SetClauseList.SetSimple
 
expression - Variable in class org.h2.command.query.QueryOrderBy
The order by expression.
expression - Variable in class org.h2.expression.Subquery
 
expression - Variable in class org.h2.index.IndexCondition
 
expression - Variable in class org.h2.schema.Constant
 
Expression - Class in org.h2.expression
An expression is a operation, a value, or a function in a query.
Expression() - Constructor for class org.h2.expression.Expression
 
expressionArray - Variable in class org.h2.command.query.Query
Array of expressions.
ExpressionColumn - Class in org.h2.expression
A column reference expression that represents a column of a table or view.
ExpressionColumn(Database, String, String) - Constructor for class org.h2.expression.ExpressionColumn
Creates a new instance of column reference for _ROWID_ column as normal expression.
ExpressionColumn(Database, String, String, String) - Constructor for class org.h2.expression.ExpressionColumn
Creates a new instance of column reference for regular columns as normal expression.
ExpressionColumn(Database, String, String, String, boolean) - Constructor for class org.h2.expression.ExpressionColumn
Creates a new instance of column reference for regular columns as normal expression.
ExpressionColumn(Database, Column) - Constructor for class org.h2.expression.ExpressionColumn
Creates a new column reference for metadata of queries; should not be used as normal expression.
expressionIndex - Variable in class org.h2.expression.analysis.WindowFrameBound
 
expressionList - Variable in class org.h2.index.IndexCondition
 
ExpressionList - Class in org.h2.expression
A list of expressions, as in (ID, NAME).
ExpressionList(Expression[], boolean) - Constructor for class org.h2.expression.ExpressionList
 
expressionNames - Variable in class org.h2.engine.Mode
How column names are generated for expressions.
ExpressionNames() - Constructor for enum org.h2.engine.Mode.ExpressionNames
 
expressionQuery - Variable in class org.h2.index.IndexCondition
 
expressions - Variable in class org.h2.command.dml.Call
 
expressions - Variable in class org.h2.command.dml.ExecuteProcedure
 
expressions - Variable in class org.h2.command.dml.Help
 
expressions - Variable in class org.h2.command.query.Query
The column list, including invisible expressions such as order by expressions.
expressions - Variable in class org.h2.command.query.SelectGroups
The query's column list, including invisible expressions such as order by expressions.
expressions - Variable in class org.h2.command.query.SelectListColumnResolver
 
expressions - Variable in class org.h2.expression.condition.ConditionAndOrN
Use an ArrayDeque because we primarily insert at the front.
expressions - Variable in class org.h2.mvstore.db.MVTempResult
Column expressions.
expressions - Variable in class org.h2.result.LazyResult
 
expressions - Variable in class org.h2.result.LocalResult
 
expressions - Variable in class org.h2.table.DataChangeDeltaTable
 
ExpressionVisitor - Class in org.h2.expression
The visitor pattern is used to iterate through all expressions of a query to optimize a statement.
ExpressionVisitor(int) - Constructor for class org.h2.expression.ExpressionVisitor
 
ExpressionVisitor(int, int) - Constructor for class org.h2.expression.ExpressionVisitor
 
ExpressionVisitor(int, int, HashSet<?>, AllColumnsForPlan, Table, ColumnResolver, long[]) - Constructor for class org.h2.expression.ExpressionVisitor
 
ExpressionWithFlags - Interface in org.h2.expression
Expression with flags.
ExpressionWithVariableParameters - Interface in org.h2.expression
An expression with variable number of parameters.
exprToIndexInGroupByData - Variable in class org.h2.command.query.SelectGroups
Maps an expression object to an index, to use in accessing the Object[] pointed to by groupByData.
external - Variable in class org.h2.result.LocalResult
 
EXTERNAL_TABLE_ENGINE - org.h2.table.TableType
The table type name for external table engines.
externalNames - Variable in class org.h2.server.web.WebServer
 
extraArguments - Variable in class org.h2.expression.aggregate.Aggregate
 
EXTRACT - Static variable in class org.h2.expression.function.DateTimeFunction
EXTRACT().
extractDateTime(SessionLocal, Value, int) - Static method in class org.h2.expression.function.DateTimeFunction
 
extractEpoch(SessionLocal, Value) - Static method in class org.h2.expression.function.DateTimeFunction
 
extractIdentifier(String, int, int) - Method in class org.h2.command.Tokenizer
 
extractInteger(SessionLocal, Value, int) - Static method in class org.h2.expression.function.DateTimeFunction
Get the specified field of a date, however with years normalized to positive or negative, and month starting with 1.
extractInterval(Value, int) - Static method in class org.h2.expression.function.DateTimeFunction
 
extractPKFromRow(SearchRow, long) - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
extractTableOrViewName(String) - Static method in class org.h2.tools.Recover
 
extTypeInfo - Variable in class org.h2.value.TypeInfo
 
ExtTypeInfo - Class in org.h2.value
Extended parameters of a data type.
ExtTypeInfo() - Constructor for class org.h2.value.ExtTypeInfo
 
ExtTypeInfoEnum - Class in org.h2.value
Extended parameters of the ENUM data type.
ExtTypeInfoEnum(String[]) - Constructor for class org.h2.value.ExtTypeInfoEnum
Creates new instance of extended parameters of the ENUM data type.
ExtTypeInfoGeometry - Class in org.h2.value
Extended parameters of the GEOMETRY data type.
ExtTypeInfoGeometry(int, Integer) - Constructor for class org.h2.value.ExtTypeInfoGeometry
Creates new instance of extended parameters of the GEOMETRY data type.
ExtTypeInfoNumeric - Class in org.h2.value
Extended parameters of the NUMERIC data type.
ExtTypeInfoNumeric() - Constructor for class org.h2.value.ExtTypeInfoNumeric
 
ExtTypeInfoRow - Class in org.h2.value
Extended parameters of the ROW data type.
ExtTypeInfoRow(LinkedHashMap<String, TypeInfo>) - Constructor for class org.h2.value.ExtTypeInfoRow
Creates new instance of extended parameters of ROW data type.
ExtTypeInfoRow(Typed[]) - Constructor for class org.h2.value.ExtTypeInfoRow
Creates new instance of extended parameters of ROW data type.
ExtTypeInfoRow(Typed[], int) - Constructor for class org.h2.value.ExtTypeInfoRow
Creates new instance of extended parameters of ROW data type.

F

factory - Variable in class org.h2.jdbcx.JdbcDataSource
 
factory - Variable in class org.h2.jdbcx.JdbcXAConnection
 
factory - Variable in class org.h2.mvstore.tx.VersionedValueType
 
factory - Variable in class org.h2.util.geometry.JTSUtils.GeometryTarget
 
Factory() - Constructor for class org.h2.mvstore.db.RowDataType.Factory
 
Factory() - Constructor for class org.h2.mvstore.db.ValueDataType.Factory
 
Factory() - Constructor for class org.h2.mvstore.tx.VersionedValueType.Factory
 
FACTORY - Static variable in class org.h2.mvstore.db.RowDataType
 
FACTORY - Static variable in class org.h2.mvstore.db.ValueDataType
 
failureFlags - Variable in class org.h2.mvstore.FreeSpaceBitSet
Left-shifting register, which holds outcomes of recent allocations.
FakeFileChannel - Class in org.h2.store.fs
Fake file channel to use by in-memory and ZIP file systems.
FakeFileChannel() - Constructor for class org.h2.store.fs.FakeFileChannel
 
FALSE - Static variable in class org.h2.expression.condition.Comparison
This is a pseudo comparison type that is only used for index conditions.
FALSE - Static variable in class org.h2.expression.ValueExpression
The expression represents ValueBoolean.FALSE.
FALSE - Static variable in class org.h2.util.json.JSONBoolean
false value.
FALSE - Static variable in class org.h2.util.ParserUtil
The token "FALSE".
FALSE - Static variable in class org.h2.value.ValueBoolean
FALSE value.
FALSE - Static variable in class org.h2.value.ValueJson
false JSON value.
FALSE_BYTES - Static variable in class org.h2.util.json.JSONByteArrayTarget
 
FALSE_BYTES - Static variable in class org.h2.value.ValueJson
 
fastCompare - Variable in class org.h2.expression.condition.CompareLike
 
FastEOFException() - Constructor for exception org.h2.store.DataReader.FastEOFException
 
FEATURE_NOT_SUPPORTED_1 - Static variable in class org.h2.api.ErrorCode
The error with code 50100 is thrown when calling an unsupported JDBC method or database feature.
fetch - Variable in class org.h2.command.query.Query.OffsetFetch
FETCH value.
fetch() - Method in class org.h2.store.CountingReaderInputStream
 
FETCH - Static variable in class org.h2.util.ParserUtil
The token "FETCH".
fetchAdditionalRows() - Method in class org.h2.result.ResultRemote
 
FetchedResult - Class in org.h2.result
Abstract fetched result.
FetchedResult() - Constructor for class org.h2.result.FetchedResult
 
fetchExpr - Variable in class org.h2.command.dml.FilteredDataChangeStatement
The expression with optional maximum number of rows.
fetchExpr - Variable in class org.h2.command.query.Query
The fetch expression as specified in the FETCH, LIMIT, or TOP clause.
fetchNext() - Method in class org.h2.mvstore.db.MVSpatialIndex.SpatialKeyIterator
 
fetchNext() - Method in class org.h2.mvstore.rtree.MVRTreeMap.RTreeCursor
Fetch the next entry if there is one.
fetchNext() - Method in class org.h2.mvstore.tx.TransactionMap.CommittedIterator
 
fetchNext() - Method in class org.h2.mvstore.tx.TransactionMap.RepeatableIterator
 
fetchNext() - Method in class org.h2.mvstore.tx.TransactionMap.TMIterator
Fetches a next entry.
fetchNext() - Method in class org.h2.mvstore.tx.TransactionMap.UncommittedIterator
 
fetchNextRow() - Method in class org.h2.command.query.Select.LazyResultGroupSorted
 
fetchNextRow() - Method in class org.h2.command.query.Select.LazyResultQueryFlat
 
fetchNextRow() - Method in class org.h2.command.query.SelectUnion.LazyResultUnion
 
fetchNextRow() - Method in class org.h2.result.LazyResult
Fetch next row or null if none available.
fetchPercent - Variable in class org.h2.command.query.Query
Whether limit expression specifies percentage of rows.
fetchPercent - Variable in class org.h2.command.query.Query.OffsetFetch
Whether FETCH value is a PERCENT value.
fetchPercent - Variable in class org.h2.result.LocalResult
 
fetchRows(int) - Method in class org.h2.result.ResultRemote
 
fetchSize - Variable in class org.h2.command.CommandRemote
 
fetchSize - Variable in class org.h2.command.ddl.CreateLinkedTable
 
fetchSize - Variable in class org.h2.jdbc.JdbcStatement
 
fetchSize - Variable in class org.h2.result.ResultRemote
 
fetchSize - Variable in class org.h2.table.TableLink
 
fetchSnapshot() - Method in class org.h2.mvstore.tx.TransactionMap.RepeatableIterator
 
fetchUncommitted() - Method in class org.h2.mvstore.tx.TransactionMap.RepeatableIterator
 
FF - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
field - Variable in class org.h2.api.H2Type
 
field - Variable in class org.h2.expression.function.DateTimeFunction
 
FIELD_COLUMNS - Static variable in class org.h2.fulltext.FullText
A column name of the result set returned by the searchData method.
FIELD_KEYS - Static variable in class org.h2.fulltext.FullText
A column name of the result set returned by the searchData method.
FIELD_NAMES - Static variable in class org.h2.expression.function.DateTimeFunction
 
FIELD_QUERY - Static variable in class org.h2.fulltext.FullText
The column name of the result set returned by the search method.
FIELD_SCHEMA - Static variable in class org.h2.fulltext.FullText
A column name of the result set returned by the searchData method.
FIELD_SCORE - Static variable in class org.h2.fulltext.FullText
The hit score.
FIELD_TABLE - Static variable in class org.h2.fulltext.FullText
A column name of the result set returned by the searchData method.
fieldDelimiter - Variable in class org.h2.tools.Csv
 
fieldName - Variable in class org.h2.expression.FieldReference
 
FieldReference - Class in org.h2.expression
Field reference.
FieldReference(Expression, String) - Constructor for class org.h2.expression.FieldReference
 
fields - Variable in class org.h2.value.ExtTypeInfoRow
 
fields(SessionLocal, ArrayList<Row>, String, String, String, String, String, String, String, String, int, String, TypeInfo) - Method in class org.h2.table.InformationSchemaTable
 
FIELDS - Static variable in class org.h2.table.InformationSchemaTable
 
FIELDS_COUNT - Static variable in class org.h2.expression.function.DateTimeFunction
 
fieldSeparatorRead - Variable in class org.h2.tools.Csv
 
fieldSeparatorWrite - Variable in class org.h2.tools.Csv
 
fifo - Variable in class org.h2.util.CacheLRU
Use First-In-First-Out (don't move recently used items to the front of the queue).
fifo - Variable in class org.h2.util.CacheTQ
 
file - Variable in class org.h2.mvstore.FileStore
The file.
file - Variable in class org.h2.server.web.WebServer.TranslateThread
 
file - Variable in class org.h2.store.FileStore
 
file - Variable in class org.h2.store.fs.mem.FileMemData.CompressItem
The file.
file - Variable in class org.h2.store.fs.zip.FileZip
 
FILE - org.h2.store.FileLockMethod
This locking method means the cooperative file locking protocol should be used.
FILE - Static variable in class org.h2.store.FileLock
 
FILE_BLOCK_SIZE - Static variable in class org.h2.engine.Constants
The block of a file.
FILE_CORRUPTED_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90030 is thrown when the database engine has detected a checksum mismatch in the data or index.
FILE_CREATION_FAILED_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90062 is thrown when a directory or file could not be created.
FILE_DELETE_FAILED_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90025 is thrown when a file could not be deleted, because it is still in use (only in Windows), or because an error occurred when deleting.
FILE_ENCRYPTION_ERROR_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90049 is thrown when trying to open an encrypted database with the wrong file encryption password or algorithm.
FILE_LOCK - Static variable in class org.h2.message.Trace
The trace module id for file locks.
FILE_NOT_FOUND_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90124 is thrown when trying to access a file that doesn't exist.
FILE_READ - Static variable in class org.h2.expression.function.FileFunction
FILE_READ() (non-standard).
FILE_RENAME_FAILED_2 - Static variable in class org.h2.api.ErrorCode
The error with code 90024 is thrown when a file could not be renamed.
FILE_VERSION_ERROR_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90048 is thrown when the file header of a database files (*.db) does not match the expected version, or if it is corrupted.
FILE_WRITE - Static variable in class org.h2.expression.function.FileFunction
FILE_WRITE() (non-standard).
FileAsync - Class in org.h2.store.fs.async
File which uses NIO2 AsynchronousFileChannel.
FileAsync(String, String) - Constructor for class org.h2.store.fs.async.FileAsync
 
FileBase - Class in org.h2.store.fs
The base class for file implementations.
FileBase() - Constructor for class org.h2.store.fs.FileBase
 
FileBaseDefault - Class in org.h2.store.fs
Default implementation of the slow operations that need synchronization because they involve the file position.
FileBaseDefault() - Constructor for class org.h2.store.fs.FileBaseDefault
 
FileCache(FileChannel) - Constructor for class org.h2.mvstore.cache.FilePathCache.FileCache
 
FileChannelInputStream - Class in org.h2.store.fs
Allows to read from a file channel like an input stream.
FileChannelInputStream(FileChannel, boolean) - Constructor for class org.h2.store.fs.FileChannelInputStream
Create a new file object input stream from the file channel.
FileEncrypt - Class in org.h2.store.fs.encrypt
An encrypted file with a read cache.
FileEncrypt(String, byte[], FileChannel) - Constructor for class org.h2.store.fs.encrypt.FileEncrypt
 
fileEncryptionKey - Variable in class org.h2.engine.ConnectionInfo
 
fileEncryptionKey - Variable in class org.h2.engine.Database
 
fileEncryptionKey - Variable in class org.h2.engine.SessionRemote
 
FileFunction - Class in org.h2.expression.function
A FILE_READ or FILE_WRITE function.
FileFunction(Expression, Expression, int) - Constructor for class org.h2.expression.function.FileFunction
 
fileLength - Variable in class org.h2.store.FileStore
 
fileLength - Variable in class org.h2.store.fs.niomapped.FileNioMapped
 
FileLister - Class in org.h2.store
Utility class to list the files of a database.
FileLister() - Constructor for class org.h2.store.FileLister
 
fileLock - Variable in class org.h2.mvstore.FileStore
The file lock.
FileLock - Class in org.h2.store
The file lock is used to lock a database so that only one process can write to it.
FileLock(TraceSystem, String, int) - Constructor for class org.h2.store.FileLock
Create a new file locking object.
fileLockMethod - Variable in class org.h2.engine.Database
 
FileLockMethod - Enum in org.h2.store
 
FileLockMethod() - Constructor for enum org.h2.store.FileLockMethod
 
FileLockRetry(FileLock, FileChannel) - Constructor for class org.h2.store.fs.retry.FileRetryOnInterrupt.FileLockRetry
 
FileMem - Class in org.h2.store.fs.mem
This class represents an in-memory file.
FileMem(FileMemData, boolean) - Constructor for class org.h2.store.fs.mem.FileMem
 
FileMemData - Class in org.h2.store.fs.mem
This class contains the data of an in-memory random access file.
FileMemData(String, boolean) - Constructor for class org.h2.store.fs.mem.FileMemData
 
FileMemData.Cache<K,​V> - Class in org.h2.store.fs.mem
This small cache compresses the data if an element leaves the cache.
FileMemData.CompressItem - Class in org.h2.store.fs.mem
Points to a block of bytes that needs to be compressed.
fileName - Variable in class org.h2.command.dml.ScriptBase
 
fileName - Variable in class org.h2.message.TraceSystem
 
fileName - Variable in class org.h2.mvstore.db.MVTempResult.CloseImpl
File name.
fileName - Variable in class org.h2.mvstore.db.Store
 
fileName - Variable in class org.h2.mvstore.FileStore
The file name.
fileName - Variable in class org.h2.store.FileLock
The lock file name.
fileName - Variable in class org.h2.store.fs.retry.FileRetryOnInterrupt
 
fileName - Variable in class org.h2.tools.Csv
 
fileName - Variable in class org.h2.value.lob.LobDataFile
If the LOB is a temporary LOB being managed by a temporary ResultSet, it is stored in a temporary file.
fileName(String) - Method in class org.h2.mvstore.MVStore.Builder
Use the following file name.
fileNameExpr - Variable in class org.h2.command.dml.BackupCommand
 
fileNameExpr - Variable in class org.h2.command.dml.ScriptBase
The file name (if set).
FileNioMapped - Class in org.h2.store.fs.niomapped
Uses memory mapped files.
FileNioMapped(String, String) - Constructor for class org.h2.store.fs.niomapped.FileNioMapped
 
FileNioMem - Class in org.h2.store.fs.niomem
This class represents an in-memory file.
FileNioMem(FileNioMemData, boolean) - Constructor for class org.h2.store.fs.niomem.FileNioMem
 
FileNioMemData - Class in org.h2.store.fs.niomem
This class contains the data of an in-memory random access file.
FileNioMemData(String, boolean, float) - Constructor for class org.h2.store.fs.niomem.FileNioMemData
 
FileNioMemData.CompressItem - Class in org.h2.store.fs.niomem
Represents a compressed item.
FileNioMemData.CompressLaterCache<K,​V> - Class in org.h2.store.fs.niomem
This small cache compresses the data if an element leaves the cache.
filePasswordHash - Variable in class org.h2.engine.ConnectionInfo
 
filePasswordHash - Variable in class org.h2.engine.Database
 
filePath - Variable in class org.h2.store.fs.split.FileSplit
 
FilePath - Class in org.h2.store.fs
A path to a file.
FilePath() - Constructor for class org.h2.store.fs.FilePath
 
FilePathAsync - Class in org.h2.store.fs.async
This file system stores files on disk and uses java.nio.channels.AsynchronousFileChannel to access the files.
FilePathAsync() - Constructor for class org.h2.store.fs.async.FilePathAsync
 
FilePathCache - Class in org.h2.mvstore.cache
A file with a read cache.
FilePathCache() - Constructor for class org.h2.mvstore.cache.FilePathCache
 
FilePathCache.FileCache - Class in org.h2.mvstore.cache
A file with a read cache.
FilePathDisk - Class in org.h2.store.fs.disk
This file system stores files on disk.
FilePathDisk() - Constructor for class org.h2.store.fs.disk.FilePathDisk
 
FilePathEncrypt - Class in org.h2.store.fs.encrypt
An encrypted file.
FilePathEncrypt() - Constructor for class org.h2.store.fs.encrypt.FilePathEncrypt
 
FilePathMem - Class in org.h2.store.fs.mem
This file system keeps files fully in memory.
FilePathMem() - Constructor for class org.h2.store.fs.mem.FilePathMem
 
FilePathMemLZF - Class in org.h2.store.fs.mem
A memory file system that compresses blocks to conserve memory.
FilePathMemLZF() - Constructor for class org.h2.store.fs.mem.FilePathMemLZF
 
FilePathNioMapped - Class in org.h2.store.fs.niomapped
This file system stores files on disk and uses java.nio to access the files.
FilePathNioMapped() - Constructor for class org.h2.store.fs.niomapped.FilePathNioMapped
 
FilePathNioMem - Class in org.h2.store.fs.niomem
This file system keeps files fully in off-java-heap memory.
FilePathNioMem() - Constructor for class org.h2.store.fs.niomem.FilePathNioMem
 
FilePathNioMemLZF - Class in org.h2.store.fs.niomem
A memory file system that compresses blocks to conserve memory.
FilePathNioMemLZF() - Constructor for class org.h2.store.fs.niomem.FilePathNioMemLZF
 
FilePathRec - Class in org.h2.store.fs.rec
A file system that records all write operations and can re-play them.
FilePathRec() - Constructor for class org.h2.store.fs.rec.FilePathRec
 
FilePathRetryOnInterrupt - Class in org.h2.store.fs.retry
A file system that re-opens and re-tries the operation if the file was closed, because a thread was interrupted.
FilePathRetryOnInterrupt() - Constructor for class org.h2.store.fs.retry.FilePathRetryOnInterrupt
 
FilePathSplit - Class in org.h2.store.fs.split
A file system that may split files into multiple smaller files.
FilePathSplit() - Constructor for class org.h2.store.fs.split.FilePathSplit
 
FilePathWrapper - Class in org.h2.store.fs
The base class for wrapping / delegating file systems such as the split file system.
FilePathWrapper() - Constructor for class org.h2.store.fs.FilePathWrapper
 
FilePathZip - Class in org.h2.store.fs.zip
This is a read-only file system that allows to access databases stored in a .zip or .jar file.
FilePathZip() - Constructor for class org.h2.store.fs.zip.FilePathZip
 
filePos - Variable in class org.h2.store.FileStore
 
FileRec - Class in org.h2.store.fs.rec
A file object that records all write operations and can re-play them.
FileRec(FilePathRec, FileChannel, String) - Constructor for class org.h2.store.fs.rec.FileRec
 
fileRef - Variable in class org.h2.mvstore.db.MVTempResult
Reference to the record in the temporary file deleter.
FileRetryOnInterrupt - Class in org.h2.store.fs.retry
A file object that re-opens and re-tries the operation if the file was closed.
FileRetryOnInterrupt(String, String) - Constructor for class org.h2.store.fs.retry.FileRetryOnInterrupt
 
FileRetryOnInterrupt.FileLockRetry - Class in org.h2.store.fs.retry
A wrapped file lock.
fileSize - Variable in class org.h2.mvstore.FileStore
The file size (cached).
FileSplit - Class in org.h2.store.fs.split
A file that may be split into multiple smaller files.
FileSplit(FilePathSplit, String, FileChannel[], long, long) - Constructor for class org.h2.store.fs.split.FileSplit
 
fileStore - Variable in class org.h2.mvstore.MVStore
 
fileStore(FileStore) - Method in class org.h2.mvstore.MVStore.Builder
Use the provided file store instead of the default one.
FileStore - Class in org.h2.mvstore
The default storage mechanism of the MVStore.
FileStore - Class in org.h2.store
This class is an abstraction of a random access file.
FileStore() - Constructor for class org.h2.mvstore.FileStore
 
FileStore(DataHandler, String, String) - Constructor for class org.h2.store.FileStore
Create a new file using the given settings.
FileStoreInputStream - Class in org.h2.store
An input stream that is backed by a file store.
FileStoreInputStream(FileStore, boolean, boolean) - Constructor for class org.h2.store.FileStoreInputStream
 
fileStoreIsProvided - Variable in class org.h2.mvstore.MVStore
 
FileStoreOutputStream - Class in org.h2.store
An output stream that is backed by a file store.
FileStoreOutputStream(FileStore, String) - Constructor for class org.h2.store.FileStoreOutputStream
 
FileUtils - Class in org.h2.store.fs
This utility class contains utility functions that use the file system abstraction.
FileUtils() - Constructor for class org.h2.store.fs.FileUtils
 
fileWriter - Variable in class org.h2.message.TraceSystem
 
FileZip - Class in org.h2.store.fs.zip
The file is read from a stream.
FileZip(ZipFile, ZipEntry) - Constructor for class org.h2.store.fs.zip.FileZip
 
fillAligned() - Method in class org.h2.store.Data
Fill up the buffer with empty space and an (initially empty) checksum until the size is a multiple of Constants.FILE_BLOCK_SIZE.
fillBuffer() - Method in class org.h2.compress.LZFInputStream
 
fillBuffer() - Method in class org.h2.store.CountingReaderInputStream
 
fillBuffer() - Method in class org.h2.store.FileStoreInputStream
 
fillInStackTrace() - Method in exception org.h2.store.DataReader.FastEOFException
 
fillMap() - Method in class org.h2.mode.PgCatalogSchema
 
fillMap(boolean) - Method in class org.h2.schema.InformationSchema
 
filter - Variable in class org.h2.constraint.ConstraintCheck
 
filter - Variable in class org.h2.expression.aggregate.ListaggArguments
 
filter - Variable in class org.h2.mvstore.rtree.MVRTreeMap.RTreeCursor
 
filterConcurrentUpdate(DbException, long) - Method in class org.h2.command.Command
 
filterCondition - Variable in class org.h2.expression.aggregate.AbstractAggregate
FILTER condition for aggregate
filterCondition - Variable in class org.h2.table.TableFilter
Additional conditions that can't be used for index lookup, but for row filter for this table (ID=ID, NAME LIKE '%X%')
FilteredDataChangeStatement - Class in org.h2.command.dml
Data change statement with WHERE criteria and possibly limited number of rows.
FilteredDataChangeStatement(SessionLocal) - Constructor for class org.h2.command.dml.FilteredDataChangeStatement
Creates new instance of FilteredDataChangeStatement.
filters - Variable in class org.h2.command.query.AllColumnsForPlan
 
filters - Variable in class org.h2.command.query.Optimizer
 
filters - Variable in class org.h2.command.query.Select
 
filters - Variable in class org.h2.table.Plan
 
filterSQL(String) - Static method in exception org.h2.message.DbException
 
FINAL - org.h2.table.DataChangeDeltaTable.ResultOption
FINAL rows after triggers.
finalize() - Method in class org.h2.store.FileStoreInputStream
 
find(int) - Method in interface org.h2.util.Cache
Get an element from the cache if it is available.
find(int) - Method in class org.h2.util.CacheLRU
 
find(int) - Method in class org.h2.util.CacheSecondLevel
 
find(int) - Method in class org.h2.util.CacheTQ
 
find(long) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
 
find(long, int) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
Try to find an entry in the map.
find(SessionLocal, Long, Long) - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
find(SessionLocal, ArrayList<IndexCondition>) - Method in class org.h2.index.IndexCursor
Re-evaluate the start and end values of the index search for rows.
find(SessionLocal, SearchRow, boolean, SearchRow) - Method in class org.h2.mvstore.db.MVSecondaryIndex
 
find(SessionLocal, SearchRow, SearchRow) - Method in class org.h2.index.DualIndex
 
find(SessionLocal, SearchRow, SearchRow) - Method in class org.h2.index.Index
Find a row or a list of rows and create a cursor to iterate over the result.
find(SessionLocal, SearchRow, SearchRow) - Method in class org.h2.index.LinkedIndex
 
find(SessionLocal, SearchRow, SearchRow) - Method in class org.h2.index.MetaIndex
 
find(SessionLocal, SearchRow, SearchRow) - Method in class org.h2.index.RangeIndex
 
find(SessionLocal, SearchRow, SearchRow) - Method in class org.h2.index.ViewIndex
 
find(SessionLocal, SearchRow, SearchRow) - Method in class org.h2.index.VirtualConstructedTableIndex
 
find(SessionLocal, SearchRow, SearchRow) - Method in class org.h2.mvstore.db.MVDelegateIndex
 
find(SessionLocal, SearchRow, SearchRow) - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
find(SessionLocal, SearchRow, SearchRow) - Method in class org.h2.mvstore.db.MVSecondaryIndex
 
find(SessionLocal, SearchRow, SearchRow) - Method in class org.h2.mvstore.db.MVSpatialIndex
 
find(SessionLocal, SearchRow, SearchRow, SearchRow) - Method in class org.h2.index.ViewIndex
 
find(Value) - Method in class org.h2.index.IndexCursor
 
findAggregate(String) - Method in class org.h2.schema.Schema
Get the user defined aggregate function if it exists.
FindBoundsCursor(Page<Spatial, VersionedValue<Value>>, Spatial, SessionLocal, TransactionMap<Spatial, Value>, int) - Constructor for class org.h2.mvstore.db.MVSpatialIndex.FindBoundsCursor
 
findByGeometry(SessionLocal, SearchRow, SearchRow, SearchRow) - Method in interface org.h2.index.SpatialIndex
Find a row or a list of rows and create a cursor to iterate over the result.
findByGeometry(SessionLocal, SearchRow, SearchRow, SearchRow) - Method in class org.h2.index.ViewIndex
 
findByGeometry(SessionLocal, SearchRow, SearchRow, SearchRow) - Method in class org.h2.mvstore.db.MVSpatialIndex
 
findChunksToMove(long, long) - Method in class org.h2.mvstore.MVStore
 
findColumn(String) - Method in class org.h2.command.query.SelectListColumnResolver
 
findColumn(String) - Method in class org.h2.command.query.TableValueConstructor.TableValueColumnResolver
 
findColumn(String) - Method in class org.h2.constraint.DomainColumnResolver
 
findColumn(String) - Method in class org.h2.jdbc.JdbcResultSet
Searches for a specific column in the result set.
findColumn(String) - Method in interface org.h2.table.ColumnResolver
Get the column with the specified name.
findColumn(String) - Method in class org.h2.table.GeneratedColumnResolver
 
findColumn(String) - Method in class org.h2.table.Table
Get the column with the given name if it exists.
findColumn(String) - Method in class org.h2.table.TableFilter
 
findColumn(String) - Method in class org.h2.tools.SimpleResultSet
Searches for a specific column in the result set.
findColumnIndex(String) - Method in class org.h2.result.UpdatableRow
 
findComment(DbObject) - Method in class org.h2.engine.Database
Get the comment for the given database object if one exists, or null if not.
findConstant(String) - Method in class org.h2.schema.Schema
Try to find a user defined constant with this name.
findConstraint(SessionLocal, String) - Method in class org.h2.schema.Schema
Try to find a constraint with this name.
findContainedKeys(Spatial) - Method in class org.h2.mvstore.rtree.MVRTreeMap
Iterate over all keys that are fully contained within the given rectangle.
findDecimalSeparator(String) - Static method in class org.h2.expression.function.ToCharFunction
 
findDomain(String) - Method in class org.h2.schema.Schema
Get the domain if it exists, or null if not.
findFirstOrLast(SessionLocal, boolean) - Method in class org.h2.index.DualIndex
 
findFirstOrLast(SessionLocal, boolean) - Method in class org.h2.index.Index
Find the first (or last) value of this index.
findFirstOrLast(SessionLocal, boolean) - Method in class org.h2.index.RangeIndex
 
findFirstOrLast(SessionLocal, boolean) - Method in class org.h2.mvstore.db.MVDelegateIndex
 
findFirstOrLast(SessionLocal, boolean) - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
findFirstOrLast(SessionLocal, boolean) - Method in class org.h2.mvstore.db.MVSecondaryIndex
 
findFunction(String) - Method in class org.h2.schema.Schema
Try to find a user defined function with this name.
findFunctionOrAggregate(String) - Method in class org.h2.schema.Schema
Try to find a user defined function or aggregate function with the specified name.
findIdentifierEnd(String, int, int) - Method in class org.h2.command.Tokenizer
 
findIndex(SessionLocal, String) - Method in class org.h2.schema.Schema
Try to find an index with this name.
findIntersectingKeys(Spatial) - Method in class org.h2.mvstore.rtree.MVRTreeMap
Iterate over all keys that have an intersection with the given rectangle.
findJavaMethod(Expression[]) - Method in class org.h2.schema.FunctionAlias
Find the Java method that matches the arguments.
findLastChunkWithCompleteValidChunkSet(Chunk[], Map<Long, Chunk>, Map<Integer, Chunk>, boolean) - Method in class org.h2.mvstore.MVStore
 
findLocalTempTable(String) - Method in class org.h2.engine.SessionLocal
Get the local temporary table if one exists with that name, or null if not.
findLocalTempTableConstraint(String) - Method in class org.h2.engine.SessionLocal
Get the local temporary constraint if one exists with that name, or null if not.
findLocalTempTableIndex(String) - Method in class org.h2.engine.SessionLocal
Get the local temporary index if one exists with that name, or null if not.
findMiddle(int, int) - Static method in class org.h2.tools.MultiDimension
 
findNext(SessionLocal, SearchRow, SearchRow) - Method in class org.h2.index.Index
Find a row or a list of rows that is larger and create a cursor to iterate over the result.
findNext(SessionLocal, SearchRow, SearchRow) - Method in class org.h2.mvstore.db.MVSecondaryIndex
 
findOldChunks(int, int) - Method in class org.h2.mvstore.MVStore
 
findPrimaryKey() - Method in class org.h2.table.Table
Get the primary key index if there is one, or null if there is none.
findRecursive(SearchRow, SearchRow) - Method in class org.h2.index.ViewIndex
 
findRole(String) - Method in class org.h2.engine.Database
Get the role if it exists, or null if not.
findSchema(String) - Method in class org.h2.command.Parser
 
findSchema(String) - Method in class org.h2.engine.Database
Get the schema if it exists, or null if not.
findSequence(String) - Method in class org.h2.schema.Schema
Try to find a sequence with this name.
findSequence(String, String) - Method in class org.h2.command.Parser
 
findSetting(String) - Method in class org.h2.engine.Database
Get the setting if it exists, or null if not.
findTableNameCandidates(String, String, Set<String>) - Method in class org.h2.command.Parser
 
findTableOrView(SessionLocal, String) - Method in class org.h2.schema.MetaSchema
 
findTableOrView(SessionLocal, String) - Method in class org.h2.schema.Schema
Try to find a table or view with this name.
findTrigger(String) - Method in class org.h2.schema.Schema
Try to find a trigger with this name.
findUser(String) - Method in class org.h2.engine.Database
Get the user if it exists, or null if not.
findUserDefinedFunctionWithinPath(Schema, String) - Method in class org.h2.command.Parser
 
findUserOrRole(String) - Method in class org.h2.engine.Database
Get the user or role if it exists, or null if not.
finishBigInteger(String, int, int, int, int, boolean, int, ArrayList<Token>) - Static method in class org.h2.command.Tokenizer
 
finished - Variable in class org.h2.util.Task
 
finishResult(LocalResult, long, long, boolean, ResultTarget) - Method in class org.h2.command.query.Query
Applies limits, if any, to a result and makes it ready for value retrieval.
fire(Connection, Object[], Object[]) - Method in interface org.h2.api.Trigger
This method is called for each triggered action.
fire(Connection, Object[], Object[]) - Method in class org.h2.fulltext.FullText.FullTextTrigger
INTERNAL
fire(Connection, Object[], Object[]) - Method in class org.h2.fulltext.FullTextLucene.FullTextTrigger
INTERNAL
fire(Connection, Object[], Object[]) - Method in class org.h2.tools.TriggerAdapter
 
fire(Connection, ResultSet, ResultSet) - Method in class org.h2.tools.TriggerAdapter
This method is called for each triggered action by the default fire(Connection conn, Object[] oldRow, Object[] newRow) method.
fire(SessionLocal, int, boolean) - Method in class org.h2.schema.TriggerObject
Call the trigger class if required.
fire(SessionLocal, int, boolean) - Method in class org.h2.table.Table
Fire the triggers for this table.
fireAfterRow(SessionLocal, Row, Row, boolean) - Method in class org.h2.table.Table
Fire all triggers that need to be called after a row is updated.
fireBeforeRow(SessionLocal, Row, Row) - Method in class org.h2.table.Table
Fire all triggers that need to be called before a row is updated.
fireBeforeSelectTriggers() - Method in class org.h2.command.query.Query
Call the before triggers on all tables.
fireBeforeSelectTriggers() - Method in class org.h2.command.query.Select
 
fireBeforeSelectTriggers() - Method in class org.h2.command.query.SelectUnion
 
fireBeforeSelectTriggers() - Method in class org.h2.command.query.TableValueConstructor
 
fireConstraints(SessionLocal, Row, Row, boolean) - Method in class org.h2.table.Table
 
fireRow() - Method in class org.h2.table.Table
Check if row based triggers or constraints are defined.
fireRow(SessionLocal, Row, Row, boolean, boolean) - Method in class org.h2.table.Table
 
fireRow(SessionLocal, Table, Row, Row, boolean, boolean) - Method in class org.h2.schema.TriggerObject
Call the fire method of the user-defined trigger class if required.
first - Variable in class org.h2.command.dml.SetClauseList.SetMultiple
 
first - Variable in class org.h2.index.ViewCursor
 
first - Variable in class org.h2.index.VirtualTableCursor
 
first() - Method in class org.h2.jdbc.JdbcResultSet
Moves the current position to the first row.
first() - Method in class org.h2.tools.SimpleResultSet
INTERNAL
first(byte[], int) - Static method in class org.h2.compress.CompressLZF
Return the integer with the first two bytes 0, then the bytes at the index, then at index+1.
first(ByteBuffer, int) - Static method in class org.h2.compress.CompressLZF
Return the integer with the first two bytes 0, then the bytes at the index, then at index+1.
FIRST - org.h2.mode.DefaultNullOrdering
NULL values are sorted before other values, no matter if ascending or descending order is used.
FIRST_KEYWORD - Static variable in class org.h2.util.ParserUtil
The ordinal number of the first keyword.
FIRST_VALUE - org.h2.expression.analysis.WindowFunctionType
The type for FIRST_VALUE() window function.
firstChar - Variable in class org.h2.bnf.Bnf
 
firstEntry() - Method in class org.h2.mvstore.tx.TransactionMap
Get the first entry.
firstFreeBlock - Variable in class org.h2.mvstore.FreeSpaceBitSet
The first usable block.
firstKey() - Method in class org.h2.mvstore.MVMap
Get the first key, or null if the map is empty.
firstKey() - Method in class org.h2.mvstore.tx.TransactionMap
Get the first key.
flags - Variable in class org.h2.expression.aggregate.Aggregate
 
flags - Variable in class org.h2.expression.function.JsonConstructorFunction
 
flags - Variable in class org.h2.expression.function.TrimFunction
 
flipCommittingTransactionsBit(int, boolean) - Method in class org.h2.mvstore.tx.TransactionStore
 
FLOAT_ONE_BITS - Static variable in class org.h2.mvstore.type.ObjectDataType
 
FLOAT_ZERO_BITS - Static variable in class org.h2.mvstore.type.ObjectDataType
Constants for floating point synchronization.
FloatType() - Constructor for class org.h2.mvstore.type.ObjectDataType.FloatType
 
FLOOR - Static variable in class org.h2.expression.function.MathFunction
FLOOR().
floorEntry(K) - Method in class org.h2.mvstore.tx.TransactionMap
Get the entry with largest key that is smaller than or equal to this key, or null if no such key exists.
floorKey(K) - Method in class org.h2.mvstore.MVMap
Get the largest key that is smaller or equal to this key.
floorKey(K) - Method in class org.h2.mvstore.tx.TransactionMap
Get the largest key that is smaller than or equal to this key, or null if no such key exists.
flush() - Method in class org.h2.compress.LZFOutputStream
 
flush() - Method in class org.h2.engine.Database
Flush all pending changes to the transaction log.
flush() - Method in class org.h2.mvstore.db.Store
Store all pending changes.
flush() - Method in class org.h2.value.Transfer
Write pending changes.
flush(SessionLocal) - Method in class org.h2.schema.Sequence
Flush the current value, including the margin, to disk.
flushAndGetRoot() - Method in class org.h2.mvstore.MVMap
Get the root reference, flushing any current append buffer.
flushAppendBuffer(RootReference<K, V>, boolean) - Method in class org.h2.mvstore.MVMap
If map was used in append mode, this method will ensure that append buffer is flushed - emptied with all entries inserted into map as a new leaf.
flushInternal(SessionLocal) - Method in class org.h2.schema.Sequence
 
flushLog() - Method in interface org.h2.util.CacheWriter
Flush the transaction log, so that entries can be removed from the cache.
flushWithoutMargin() - Method in class org.h2.schema.Sequence
Flush the current value to disk.
Fog - Class in org.h2.security
A pseudo-encryption algorithm that makes the data appear to be encrypted.
Fog() - Constructor for class org.h2.security.Fog
 
following - Variable in class org.h2.expression.analysis.WindowFrame
 
FOLLOWING - org.h2.expression.analysis.WindowFrameBoundType
FOLLOWING clause.
font - Variable in class org.h2.tools.GUIConsole
 
FOOTER_LENGTH - Static variable in class org.h2.mvstore.Chunk
The length of the chunk footer.
FOR - Static variable in class org.h2.util.ParserUtil
The token "FOR".
FOR_UPDATE_IS_NOT_ALLOWED_IN_DISTINCT_OR_GROUPED_SELECT - Static variable in class org.h2.api.ErrorCode
The error with code 90145 is thrown when trying to execute a SELECT statement with non-window aggregates, DISTINCT, GROUP BY, or HAVING clauses together with FOR UPDATE clause.
forAllDependencies(SessionLocal, Domain, BiPredicate<Domain, Column>, BiPredicate<Domain, Domain>, boolean) - Static method in class org.h2.command.ddl.AlterDomain
Processes all columns and domains that use the specified domain.
FORBID_ANY_DUPLICATES - org.h2.engine.Mode.UniqueIndexNullsHandling
Multiple rows with identical values in indexed columns are not allowed in unique index.
forBitData - Variable in class org.h2.engine.Mode
If true 'FOR BIT DATA' clauses are allowed for character string data types.
force - Variable in class org.h2.command.ddl.CreateAggregate
 
force - Variable in class org.h2.command.ddl.CreateFunctionAlias
 
force - Variable in class org.h2.command.ddl.CreateLinkedTable
 
force - Variable in class org.h2.command.ddl.CreateTrigger
 
force - Variable in class org.h2.command.ddl.CreateView
 
force(boolean) - Method in class org.h2.mvstore.cache.FilePathCache.FileCache
 
force(boolean) - Method in class org.h2.store.fs.async.FileAsync
 
force(boolean) - Method in class org.h2.store.fs.encrypt.FileEncrypt
 
force(boolean) - Method in class org.h2.store.fs.FakeFileChannel
 
force(boolean) - Method in class org.h2.store.fs.FileBase
 
force(boolean) - Method in class org.h2.store.fs.mem.FileMem
 
force(boolean) - Method in class org.h2.store.fs.niomapped.FileNioMapped
 
force(boolean) - Method in class org.h2.store.fs.niomem.FileNioMem
 
force(boolean) - Method in class org.h2.store.fs.rec.FileRec
 
force(boolean) - Method in class org.h2.store.fs.retry.FileRetryOnInterrupt
 
force(boolean) - Method in class org.h2.store.fs.split.FileSplit
 
force(boolean) - Method in class org.h2.store.fs.zip.FileZip
 
FORCE_AUTOCOMMIT_OFF_ON_COMMIT - Static variable in class org.h2.engine.SysProperties
System property h2.forceAutoCommitOffOnCommit (default: false).
forcedType - Variable in class org.h2.expression.BinaryOperation
 
forcedType - Variable in class org.h2.expression.IntervalOperation
 
forDataChangeDeltaTable - Variable in class org.h2.result.LocalResult
 
FOREIGN - Static variable in class org.h2.util.ParserUtil
The token "FOREIGN".
forEntries - Variable in class org.h2.mvstore.tx.TransactionMap.TMIterator
 
forget(Xid) - Method in class org.h2.jdbcx.JdbcXAConnection
Forget a transaction.
format - Variable in class org.h2.expression.Format
 
format - Variable in class org.h2.expression.function.DateTimeFormatFunction.CacheKey
 
format(String, String) - Method in class org.h2.message.TraceSystem
 
Format - Class in org.h2.expression
A format clause such as FORMAT JSON.
Format(Expression, Format.FormatEnum) - Constructor for class org.h2.expression.Format
 
FORMAT_READ_MAX - Static variable in class org.h2.mvstore.MVStore
 
FORMAT_READ_MIN - Static variable in class org.h2.mvstore.MVStore
 
FORMAT_REPLACE - Static variable in class org.h2.mode.FunctionsMySQL
Format replacements for MySQL date formats.
FORMAT_TYPE - Static variable in class org.h2.mode.FunctionsPostgreSQL
 
FORMAT_WRITE_MAX - Static variable in class org.h2.mvstore.MVStore
 
FORMAT_WRITE_MIN - Static variable in class org.h2.mvstore.MVStore
 
Format.FormatEnum - Enum in org.h2.expression
Supported formats.
formatAsError(String) - Static method in class org.h2.server.web.WebApp
 
formatAsText(int, int[], int) - Static method in class org.h2.server.pg.PgServerThread
Check whether the given type should be formatted as text.
formatDateTime(SessionLocal, Value, String, String, String) - Static method in class org.h2.expression.function.DateTimeFormatFunction
Formats a date using a format string.
FORMATDATETIME - Static variable in class org.h2.expression.function.DateTimeFormatFunction
FORMATDATETIME() (non-standard).
FormatEnum() - Constructor for enum org.h2.expression.Format.FormatEnum
 
formatGeometryTypeAndDimensionSystem(StringBuilder, int) - Static method in class org.h2.util.geometry.EWKTUtils
Formats type and dimension system as a string.
formatId - Variable in class org.h2.jdbcx.JdbcXid
 
formatMessage(int, String, Object...) - Static method in class org.h2.mvstore.DataUtils
Format an error message.
formatNonKeywords(BitSet) - Static method in class org.h2.command.Parser
Formats a comma-separated list of keywords.
formatParams(ArrayList<? extends ParameterInterface>) - Static method in class org.h2.message.Trace
Format the parameter list.
formatStr - Variable in class org.h2.mode.ToDateParser
 
formatter - Variable in class org.h2.expression.function.DateTimeFormatFunction.CacheValue
 
formatTimestamp(long, long) - Static method in class org.h2.mvstore.MVStoreTool
 
FormatTokenEnum(ToDateTokenizer.ToDateParslet) - Constructor for enum org.h2.mode.ToDateTokenizer.FormatTokenEnum
Construct a format token.
FormatTokenEnum(ToDateTokenizer.ToDateParslet, Pattern) - Constructor for enum org.h2.mode.ToDateTokenizer.FormatTokenEnum
Construct a format token.
formatType(int) - Static method in class org.h2.server.pg.PgServer
Returns the name of the given type.
forTable(SessionLocal, Domain, BiPredicate<Domain, Column>, boolean, Table) - Static method in class org.h2.command.ddl.AlterDomain
 
forTable(SessionLocal, Table) - Static method in class org.h2.result.LocalResult
Constructs a new local result object for the specified table.
forUpdate - Variable in class org.h2.command.query.Select.LazyResultQueryFlat
 
found(String, int, String) - Static method in class org.h2.jdbc.JdbcConnection
 
FOUND - Static variable in class org.h2.table.TableFilter
 
foundOne - Variable in class org.h2.table.TableFilter
 
FRACTIONAL_SECONDS_TABLE - Static variable in class org.h2.util.DateTimeUtils
frame - Variable in class org.h2.expression.analysis.Window
 
free() - Method in class org.h2.jdbc.JdbcArray
Release all resources of this object.
free() - Method in class org.h2.jdbc.JdbcLob
Release all resources of this object.
free() - Method in class org.h2.tools.SimpleResultSet.SimpleArray
INTERNAL
free(long, int) - Method in class org.h2.mvstore.FileStore
Mark the space as free.
free(long, int) - Method in class org.h2.mvstore.FreeSpaceBitSet
Mark the space as free.
free(long, int) - Method in class org.h2.mvstore.OffHeapStore
 
freeChunkSpace(Chunk) - Method in class org.h2.mvstore.MVStore
 
freeFileSpace(long, int) - Method in class org.h2.mvstore.MVStore
 
freeMemoryAndFinalize() - Static method in class org.h2.store.fs.disk.FilePathDisk
Call the garbage collection and run finalization.
freeObject(int) - Method in class org.h2.util.SmallMap
Remove an object from the map.
freeSpace - Variable in class org.h2.mvstore.FileStore
The free spaces between the chunks.
FreeSpaceBitSet - Class in org.h2.mvstore
A free space bit set.
FreeSpaceBitSet(int, int) - Constructor for class org.h2.mvstore.FreeSpaceBitSet
Create a new free space map.
freeUniqueName(String) - Method in class org.h2.schema.Schema
Release a unique object name.
from(IntervalQualifier, boolean, long, long) - Static method in class org.h2.value.ValueInterval
Create a ValueInterval instance.
FROM - Static variable in class org.h2.util.ParserUtil
The token "FROM".
FROM_UNIXTIME - Static variable in class org.h2.mode.FunctionsMySQL
 
from1X - Variable in class org.h2.command.dml.RunScriptCommand
 
fromDate(CastDataProvider, TimeZone, Date) - Static method in class org.h2.util.LegacyDateTimeUtils
Get or create a date value for the given date.
fromDateValue(long) - Static method in class org.h2.value.ValueDate
Get or create a date value for the given date.
fromDateValueAndNanos(long, long) - Static method in class org.h2.value.ValueTimestamp
Get or create a date value for the given date.
fromDateValueAndNanos(long, long, int) - Static method in class org.h2.value.ValueTimestampTimeZone
Get or create a date value for the given date.
fromEnvelope(double[]) - Static method in class org.h2.value.ValueGeometry
Creates a geometry value for the given envelope.
fromJdbc(int) - Static method in enum org.h2.engine.IsolationLevel
Returns the isolation level from LOCK_MODE equivalent for PageStore and old versions of H2.
fromJson(byte[]) - Static method in class org.h2.value.ValueJson
Returns JSON value with the specified content.
fromJson(String) - Static method in class org.h2.value.ValueJson
Returns JSON value with the specified content.
fromLast - Variable in class org.h2.expression.analysis.WindowFunction
 
fromLines(String) - Static method in class org.h2.util.SortedProperties
Convert a String to a map.
fromLockMode(int) - Static method in enum org.h2.engine.IsolationLevel
Returns the isolation level from LOCK_MODE equivalent for PageStore and old versions of H2.
fromNanos(long) - Static method in class org.h2.value.ValueTime
Get or create a time value.
fromNanos(long, int) - Static method in class org.h2.value.ValueTimeTimeZone
Get or create a time value.
fromSql(String) - Static method in enum org.h2.engine.IsolationLevel
Returns the isolation level from its SQL name.
fromString(String) - Static method in class org.h2.mvstore.Chunk
Build a block from the given string.
fromString(String) - Static method in class org.h2.mvstore.MVStore.Builder
Read the configuration from a string.
fromTableFilter - Variable in class org.h2.command.dml.Update
 
fromTime(CastDataProvider, TimeZone, Time) - Static method in class org.h2.util.LegacyDateTimeUtils
Get or create a time value for the given time.
fromTimestamp(CastDataProvider, long, int) - Static method in class org.h2.util.LegacyDateTimeUtils
Get or create a timestamp value for the given date/time in millis.
fromTimestamp(CastDataProvider, TimeZone, Timestamp) - Static method in class org.h2.util.LegacyDateTimeUtils
Get or create a timestamp value for the given timestamp.
fromUnixTime(int) - Static method in class org.h2.mode.FunctionsMySQL
See https://dev.mysql.com/doc/refman/5.1/en/date-and-time-functions.html#function_from-unixtime
fromUnixTime(int, String) - Static method in class org.h2.mode.FunctionsMySQL
See https://dev.mysql.com/doc/refman/5.1/en/date-and-time-functions.html#function_from-unixtime
fromUser(String, String) - Static method in exception org.h2.message.DbException
Create a database exception for an arbitrary SQLState.
FS - org.h2.store.FileLockMethod
Use the file system to lock the file; don't use a separate lock file.
FS - Static variable in class org.h2.security.AES
 
FT0 - Static variable in class org.h2.security.AES
 
FT1 - Static variable in class org.h2.security.AES
 
FT2 - Static variable in class org.h2.security.AES
 
FT3 - Static variable in class org.h2.security.AES
 
FULL - Static variable in class org.h2.util.ParserUtil
The token "FULL".
FULL_VERSION - Static variable in class org.h2.engine.Constants
The complete version number of this database, consisting of the major version, the minor version, the build id, and the build date.
fullCondition - Variable in class org.h2.table.TableFilter
 
FullText - Class in org.h2.fulltext
This class implements the native full text search.
FullText() - Constructor for class org.h2.fulltext.FullText
 
FullText.FullTextTrigger - Class in org.h2.fulltext
Trigger updates the index when a inserting, updating, or deleting a row.
FullTextLucene - Class in org.h2.fulltext
This class implements the full text search based on Apache Lucene.
FullTextLucene() - Constructor for class org.h2.fulltext.FullTextLucene
 
FullTextLucene.FullTextTrigger - Class in org.h2.fulltext
Trigger updates the index when a inserting, updating, or deleting a row.
FullTextLucene.IndexAccess - Class in org.h2.fulltext
A wrapper for the Lucene writer and searcher.
FullTextSettings - Class in org.h2.fulltext
The global settings of a full text search.
FullTextSettings() - Constructor for class org.h2.fulltext.FullTextSettings
Create a new instance.
FullTextTrigger() - Constructor for class org.h2.fulltext.FullText.FullTextTrigger
 
FullTextTrigger() - Constructor for class org.h2.fulltext.FullTextLucene.FullTextTrigger
 
function - Variable in class org.h2.expression.function.ArrayFunction
 
function - Variable in class org.h2.expression.function.BitFunction
 
function - Variable in class org.h2.expression.function.CoalesceFunction
 
function - Variable in class org.h2.expression.function.CompressFunction
 
function - Variable in class org.h2.expression.function.ConcatFunction
 
function - Variable in class org.h2.expression.function.CryptFunction
 
function - Variable in class org.h2.expression.function.CurrentDateTimeValueFunction
 
function - Variable in class org.h2.expression.function.DateTimeFormatFunction
 
function - Variable in class org.h2.expression.function.DateTimeFunction
 
function - Variable in class org.h2.expression.function.DayMonthNameFunction
 
function - Variable in class org.h2.expression.function.DBObjectFunction
 
function - Variable in class org.h2.expression.function.FileFunction
 
function - Variable in class org.h2.expression.function.HashFunction
 
function - Variable in class org.h2.expression.function.LengthFunction
 
function - Variable in class org.h2.expression.function.MathFunction
 
function - Variable in class org.h2.expression.function.MathFunction1
 
function - Variable in class org.h2.expression.function.MathFunction2
 
function - Variable in class org.h2.expression.function.RandFunction
 
function - Variable in class org.h2.expression.function.RegexpFunction
 
function - Variable in class org.h2.expression.function.SessionControlFunction
 
function - Variable in class org.h2.expression.function.SoundexFunction
 
function - Variable in class org.h2.expression.function.StringFunction
 
function - Variable in class org.h2.expression.function.StringFunction1
 
function - Variable in class org.h2.expression.function.StringFunction2
 
function - Variable in class org.h2.expression.function.SysInfoFunction
 
function - Variable in class org.h2.expression.function.table.ArrayTableFunction
 
function - Variable in class org.h2.expression.function.TableInfoFunction
 
function - Variable in class org.h2.expression.function.XMLFunction
 
function - Variable in class org.h2.table.FunctionTable
 
FUNCTION - Static variable in class org.h2.bnf.Sentence
The token type for a function name.
FUNCTION - Static variable in class org.h2.message.Trace
The trace module id for functions.
FUNCTION_ALIAS - Static variable in class org.h2.engine.DbObject
This object is an alias for a Java function.
FUNCTION_ALIAS_ALREADY_EXISTS_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90076 is thrown when trying to create a function alias for a system function or for a function that is already defined.
FUNCTION_ALIAS_NOT_FOUND_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90077 is thrown when trying to drop a system function or a function alias that does not exist.
FUNCTION_ALIASES - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
FUNCTION_COLUMNS - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
FUNCTION_MUST_RETURN_RESULT_SET_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90000 is thrown when a function that does not return a result set was used in the FROM clause.
FUNCTION_NOT_FOUND_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90022 is thrown when trying to call a unknown function.
Function0_1 - Class in org.h2.expression.function
Function with one optional argument.
Function0_1(Expression) - Constructor for class org.h2.expression.function.Function0_1
 
Function1 - Class in org.h2.expression.function
Function with one argument.
Function1(Expression) - Constructor for class org.h2.expression.function.Function1
 
Function1_2 - Class in org.h2.expression.function
Function with two arguments.
Function1_2(Expression, Expression) - Constructor for class org.h2.expression.function.Function1_2
 
Function2 - Class in org.h2.expression.function
Function with two arguments.
Function2(Expression, Expression) - Constructor for class org.h2.expression.function.Function2
 
functionAlias - Variable in class org.h2.expression.function.JavaFunction
 
functionAlias - Variable in class org.h2.expression.function.table.JavaTableFunction
 
FunctionAlias - Class in org.h2.schema
Represents a user-defined function, or alias.
FunctionAlias(Schema, int, String) - Constructor for class org.h2.schema.FunctionAlias
 
FunctionAlias.JavaMethod - Class in org.h2.schema
There may be multiple Java methods that match a function name.
FunctionInfo - Class in org.h2.mode
This class contains information about a built-in function.
FunctionInfo(String, int, int, int, boolean, boolean) - Constructor for class org.h2.mode.FunctionInfo
Creates new instance of built-in function information.
FunctionInfo(FunctionInfo, String) - Constructor for class org.h2.mode.FunctionInfo
Creates a copy of built-in function information with a different name.
FunctionN - Class in org.h2.expression.function
Function with many arguments.
FunctionN(Expression[]) - Constructor for class org.h2.expression.function.FunctionN
 
functionName - Variable in class org.h2.mode.ToDateParser
 
FUNCTIONS - Static variable in class org.h2.expression.function.BuiltinFunctions
 
FUNCTIONS - Static variable in class org.h2.mode.FunctionsDB2Derby
 
FUNCTIONS - Static variable in class org.h2.mode.FunctionsLegacy
 
FUNCTIONS - Static variable in class org.h2.mode.FunctionsMSSQLServer
 
FUNCTIONS - Static variable in class org.h2.mode.FunctionsMySQL
 
FUNCTIONS - Static variable in class org.h2.mode.FunctionsOracle
 
FUNCTIONS - Static variable in class org.h2.mode.FunctionsPostgreSQL
 
functionsAndAggregates - Variable in class org.h2.schema.Schema
 
FunctionsDB2Derby - Class in org.h2.mode
Functions for Mode.ModeEnum.DB2 and Mode.ModeEnum.Derby compatibility modes.
FunctionsDB2Derby(FunctionInfo) - Constructor for class org.h2.mode.FunctionsDB2Derby
 
FunctionsLegacy - Class in org.h2.mode
This class implements some legacy functions not available in Regular mode.
FunctionsLegacy(FunctionInfo) - Constructor for class org.h2.mode.FunctionsLegacy
 
FunctionsMSSQLServer - Class in org.h2.mode
Functions for Mode.ModeEnum.MSSQLServer compatibility mode.
FunctionsMSSQLServer(FunctionInfo) - Constructor for class org.h2.mode.FunctionsMSSQLServer
 
FunctionsMySQL - Class in org.h2.mode
This class implements some MySQL-specific functions.
FunctionsMySQL(FunctionInfo) - Constructor for class org.h2.mode.FunctionsMySQL
 
FunctionsOracle - Class in org.h2.mode
Functions for Mode.ModeEnum.Oracle compatibility mode.
FunctionsOracle(FunctionInfo) - Constructor for class org.h2.mode.FunctionsOracle
 
FunctionsPostgreSQL - Class in org.h2.mode
Functions for Mode.ModeEnum.PostgreSQL compatibility mode.
FunctionsPostgreSQL(FunctionInfo) - Constructor for class org.h2.mode.FunctionsPostgreSQL
 
FunctionTable - Class in org.h2.table
A table backed by a system or user-defined function that returns a result set.
FunctionTable(Schema, SessionLocal, TableFunction) - Constructor for class org.h2.table.FunctionTable
 

G

gatherGroup(int, int) - Method in class org.h2.command.query.Select
 
GC_TIMEOUT_MS - Static variable in class org.h2.store.fs.niomapped.FileNioMapped
 
GENERAL_ERROR_1 - Static variable in class org.h2.api.ErrorCode
The error with code 50000 is thrown when something unexpected occurs, for example an internal stack overflow.
generateAlternativeSeed() - Static method in class org.h2.util.MathUtils
Generate a seed value, using as much unpredictable data as possible.
generateColumnsFromQuery() - Method in class org.h2.command.ddl.CreateTable
 
generateConstraintName(Domain) - Method in class org.h2.command.ddl.AlterDomainAddConstraint
 
generateConstraintName(Table) - Method in class org.h2.command.ddl.AlterTableAddConstraint
 
GENERATED_COLUMN_CANNOT_BE_ASSIGNED_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90154 is thrown when trying to assign a value to a generated column.
GENERATED_COLUMN_CANNOT_BE_UPDATABLE_BY_CONSTRAINT_2 - Static variable in class org.h2.api.ErrorCode
The error with code 90155 is thrown when trying to create a referential constraint that can update a referenced generated column.
GeneratedColumnResolver - Class in org.h2.table
Column resolver for generated columns.
GeneratedColumnResolver(Table) - Constructor for class org.h2.table.GeneratedColumnResolver
Column resolver for generated columns.
generatedKeyAlwaysReturned() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether database always returns generated keys if valid names or indexes of columns were specified and command was completed successfully.
generatedKeys - Variable in class org.h2.jdbc.JdbcStatement
 
generatedKeys - Variable in class org.h2.result.ResultWithGeneratedKeys.WithKeys
 
GeneratedKeysCollector(int[], LocalResult) - Constructor for class org.h2.command.CommandContainer.GeneratedKeysCollector
 
GeneratedKeysMode - Class in org.h2.engine
Modes of generated keys' gathering.
GeneratedKeysMode() - Constructor for class org.h2.engine.GeneratedKeysMode
 
generatedKeysRequest - Variable in class org.h2.jdbc.JdbcPreparedStatement
 
generatedTableFilter - Variable in class org.h2.table.Column
 
generateInsertValues(int, Table) - Method in class org.h2.command.dml.ScriptCommand
 
generateLobId() - Method in class org.h2.mvstore.db.LobStorageMap
 
generateOrdering(List<String>, ThreadInfo) - Static method in class org.h2.util.AbbaLockingDetector
We cannot simply call getLockedMonitors because it is not guaranteed to return the locks in the correct order.
generatePreparedQuery(String, String, String[]) - Method in class org.h2.tools.MultiDimension
Generates an optimized multi-dimensional range query.
generateRows(SessionLocal, SearchRow, SearchRow) - Method in class org.h2.mode.PgCatalogTable
 
generateRows(SessionLocal, SearchRow, SearchRow) - Method in class org.h2.table.InformationSchemaTable
 
generateRows(SessionLocal, SearchRow, SearchRow) - Method in class org.h2.table.InformationSchemaTableLegacy
 
generateRows(SessionLocal, SearchRow, SearchRow) - Method in class org.h2.table.MetaTable
Generate the data for the given metadata table using the given first and last row filters.
generateSalt() - Method in class org.h2.security.SecureFileStore
 
generateSalt() - Method in class org.h2.store.FileStore
Generate the random salt bytes if required.
generateSequences(ArrayList<Column>, boolean) - Method in class org.h2.command.ddl.CommandWithColumns
For the given list of columns, create sequences for identity columns (if needed), and then get the list of all sequences of the columns.
generateSessionId() - Static method in class org.h2.server.web.WebServer
 
GENERIC - Static variable in class org.h2.server.web.WebServer
 
GenericDataType() - Constructor for class org.h2.mvstore.MVStoreTool.GenericDataType
 
GeoJsonTarget(JSONByteArrayTarget, int) - Constructor for class org.h2.util.geometry.GeoJsonUtils.GeoJsonTarget
Creates new GeoJson output target.
geoJsonToEwkb(byte[], int) - Static method in class org.h2.util.geometry.GeoJsonUtils
Converts EWKB with known dimension system to GeoJson.
GeoJsonUtils - Class in org.h2.util.geometry
GeoJson format support for GEOMETRY data type.
GeoJsonUtils() - Constructor for class org.h2.util.geometry.GeoJsonUtils
 
GeoJsonUtils.GeoJsonTarget - Class in org.h2.util.geometry
Converter output target that writes a GeoJson.
geometry - Variable in class org.h2.value.ValueGeometry
The value.
GEOMETRY - Static variable in class org.h2.api.H2Type
The GEOMETRY data type.
GEOMETRY - Static variable in class org.h2.mvstore.db.ValueDataType
 
GEOMETRY - Static variable in class org.h2.value.Transfer
 
GEOMETRY - Static variable in class org.h2.value.Value
The value type for string values with a fixed size.
GEOMETRY_CLASS - Static variable in class org.h2.value.ValueToObjectConverter
The Geometry class.
GEOMETRY_CLASS_NAME - Static variable in class org.h2.value.ValueToObjectConverter
 
GEOMETRY_COLLECTION - Static variable in class org.h2.util.geometry.GeometryUtils
GEOMETRYCOLLECTION geometry type.
geometry2ewkb(Geometry) - Static method in class org.h2.util.geometry.JTSUtils
Converts Geometry to EWKB.
geometry2ewkb(Geometry, int) - Static method in class org.h2.util.geometry.JTSUtils
Converts Geometry to EWKB.
geometrySrid - Variable in class org.h2.table.InformationSchemaTable.DataTypeInformation
GEOMETRY_SRID.
GeometryTarget(int) - Constructor for class org.h2.util.geometry.JTSUtils.GeometryTarget
Creates a new instance of JTS Geometry target.
GeometryTarget(int, GeometryFactory) - Constructor for class org.h2.util.geometry.JTSUtils.GeometryTarget
 
geometryType - Variable in class org.h2.table.InformationSchemaTable.DataTypeInformation
GEOMETRY_TYPE.
GeometryUtils - Class in org.h2.util.geometry
Utilities for GEOMETRY data type.
GeometryUtils() - Constructor for class org.h2.util.geometry.GeometryUtils
 
GeometryUtils.DimensionSystemTarget - Class in org.h2.util.geometry
Converter output target that determines minimal dimension system for a geometry.
GeometryUtils.EnvelopeTarget - Class in org.h2.util.geometry
Converter output target that calculates an envelope.
GeometryUtils.Target - Class in org.h2.util.geometry
Converter output target.
get() - Method in interface org.h2.index.Cursor
Get the complete current row.
get() - Method in class org.h2.index.DualCursor
 
get() - Method in class org.h2.index.IndexCursor
 
get() - Method in class org.h2.index.LinkedCursor
 
get() - Method in class org.h2.index.MetaCursor
 
get() - Method in class org.h2.index.RangeCursor
 
get() - Method in class org.h2.index.SingleRowCursor
 
get() - Method in class org.h2.index.ViewCursor
 
get() - Method in class org.h2.index.VirtualTableCursor
 
get() - Method in class org.h2.jdbc.JdbcArray
 
get() - Method in class org.h2.mvstore.db.MVPrimaryIndex.MVStoreCursor
 
get() - Method in class org.h2.mvstore.db.MVSecondaryIndex.MVStoreCursor
 
get() - Method in class org.h2.mvstore.db.MVSpatialIndex.MVStoreCursor
 
get() - Method in class org.h2.mvstore.MVStore.TxCounter
 
get() - Method in class org.h2.table.TableFilter
Get the current row.
get() - Method in class org.h2.util.DebuggingThreadLocal
 
get() - Method in class org.h2.util.Task
Calling this method will set the stop flag and wait until the thread is stopped.
get(boolean) - Static method in class org.h2.value.ValueBoolean
Get the boolean value for the given boolean.
get(boolean) - Static method in class org.h2.value.ValueJson
Returns JSON value with the specified boolean content.
get(byte) - Static method in class org.h2.value.ValueTinyint
Get or create a TINYINT value for the given byte.
get(byte[]) - Method in class org.h2.mvstore.StreamStore
Open an input stream to read data.
get(byte[]) - Method in class org.h2.mvstore.WriteBuffer
Copy the data into the destination array.
get(byte[]) - Static method in class org.h2.value.ValueBinary
Get or create a VARBINARY value for the given byte array.
get(byte[]) - Static method in class org.h2.value.ValueGeometry
Get or create a geometry value for the given internal EWKB representation.
get(byte[]) - Static method in class org.h2.value.ValueUuid
Get or create a UUID for the given 16 bytes.
get(byte[]) - Static method in class org.h2.value.ValueVarbinary
Get or create a VARBINARY value for the given byte array.
get(double) - Static method in class org.h2.value.ValueDouble
Get or create a DOUBLE PRECISION value for the given double.
get(float) - Static method in class org.h2.value.ValueReal
Get or create a REAL value for the given float.
get(int) - Method in class org.h2.expression.condition.ConditionInParameter.ParameterList
 
get(int) - Method in class org.h2.jdbc.JdbcResultSet
 
get(int) - Static method in exception org.h2.message.DbException
Create a database exception for a specific error code.
get(int) - Method in class org.h2.tools.SimpleResultSet
 
get(int) - Method in interface org.h2.util.Cache
Get an element in the cache if it is available.
get(int) - Method in class org.h2.util.CacheLRU
 
get(int) - Method in class org.h2.util.CacheSecondLevel
 
get(int) - Method in class org.h2.util.CacheTQ
 
get(int) - Method in class org.h2.util.IntArray
Get the value at the given index.
get(int) - Static method in class org.h2.value.ValueInteger
Get or create an INTEGER value for the given int.
get(int) - Static method in class org.h2.value.ValueJson
Returns JSON value with the specified numeric content.
get(int, String) - Static method in exception org.h2.message.DbException
Create a database exception for a specific error code.
get(int, String...) - Static method in exception org.h2.message.DbException
Create a database exception for a specific error code.
get(int, Throwable, String...) - Static method in exception org.h2.message.DbException
Create a database exception for a specific error code.
get(int, ExpressionColumn, Expression) - Static method in class org.h2.index.IndexCondition
Create an index condition with the given parameters.
get(long) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Get the value for the given key if the entry is cached.
get(long) - Static method in class org.h2.value.ValueBigint
Get or create a BIGINT value for the given long.
get(long) - Static method in class org.h2.value.ValueJson
Returns JSON value with the specified numeric content.
get(long, int) - Method in class org.h2.jdbc.JdbcArray
 
get(long, long) - Static method in class org.h2.value.ValueUuid
Get or create a UUID for the given high and low order values.
get(short) - Static method in class org.h2.value.ValueSmallint
Get or create a SMALLINT value for the given short.
get(Object) - Method in class org.h2.mvstore.MVMap
Get the value for the given key, or null if not found.
get(Object) - Method in class org.h2.mvstore.tx.TransactionMap
Get the effective value for the given key.
get(Object) - Method in class org.h2.util.SoftValuesHashMap
 
get(Object) - Method in class org.h2.value.CaseInsensitiveConcurrentMap
 
get(Object) - Method in class org.h2.value.CaseInsensitiveMap
 
get(String) - Static method in enum org.h2.expression.analysis.WindowFunctionType
Returns the type of window function with the specified name, or null.
get(String) - Method in class org.h2.server.web.PageParser
 
get(String) - Method in class org.h2.server.web.WebSession
Get the value for the given key.
get(String) - Static method in class org.h2.store.fs.FilePath
Get the file path object for the given path.
get(String) - Static method in class org.h2.value.ValueChar
Get or create a CHAR value for the given string.
get(String) - Static method in class org.h2.value.ValueGeometry
Get or create a geometry value for the given geometry.
get(String) - Static method in class org.h2.value.ValueJson
Returns JSON value with the specified string content.
get(String) - Static method in class org.h2.value.ValueUuid
Get or create a UUID for the given text representation.
get(String) - Static method in class org.h2.value.ValueVarchar
Get or create a VARCHAR value for the given string.
get(String) - Static method in class org.h2.value.ValueVarcharIgnoreCase
Get or create a VARCHAR_IGNORECASE value for the given string.
get(String[], int) - Static method in class org.h2.server.web.ConnectionInfo
 
get(String, boolean) - Method in class org.h2.engine.SettingsBase
Get the setting for the given key.
get(String, int) - Method in class org.h2.engine.SettingsBase
Get the setting for the given key.
get(String, int) - Static method in class org.h2.value.ValueEnumBase
Get or create an enum value with the given label and ordinal.
get(String, String) - Method in class org.h2.engine.SettingsBase
Get the setting for the given key.
get(String, CastDataProvider) - Static method in class org.h2.value.ValueVarchar
Get or create a VARCHAR value for the given string.
get(BigDecimal) - Static method in class org.h2.value.ValueDecfloat
Get or create a DECFLOAT value for the given big decimal.
get(BigDecimal) - Static method in class org.h2.value.ValueJson
Returns JSON value with the specified numeric content.
get(BigDecimal) - Static method in class org.h2.value.ValueNumeric
Get or create a NUMERIC value for the given big decimal.
get(BigInteger) - Static method in class org.h2.value.ValueNumeric
Get or create a NUMERIC value for the given big integer.
get(UUID) - Static method in class org.h2.value.ValueUuid
Get or create a UUID for the given Java UUID.
get(CacheLongKeyLIRS.Entry<V>) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
Get the value from the given entry.
get(Page<K, V>, K) - Method in class org.h2.mvstore.MVMap
Get the value for the given key from a snapshot, or null if not found.
get(Page<K, V>, K) - Static method in class org.h2.mvstore.Page
Get the value for the given key, or null if not found.
get(Page<Spatial, V>, Spatial) - Method in class org.h2.mvstore.rtree.MVRTreeMap
Get the object for the given key.
get(ResultInterface) - Static method in class org.h2.result.ResultWithPaddedStrings
Returns wrapped result if necessary, or original result if it does not contain visible CHAR columns.
get(Table) - Method in class org.h2.command.query.AllColumnsForPlan
Used by index to calculate the cost of a scan.
get(ExtTypeInfoRow, Value[]) - Static method in class org.h2.value.ValueRow
Get or create a typed row value for the given value array.
get(TypeInfo, Value[]) - Static method in class org.h2.value.ValueRow
Get or create a typed row value for the given value array.
get(TypeInfo, Value[], CastDataProvider) - Static method in class org.h2.value.ValueArray
Get or create a array value for the given value array.
get(Value) - Static method in class org.h2.expression.ValueExpression
Create a new expression with the given value.
get(Value[]) - Static method in class org.h2.value.ValueRow
Get or create a row value for the given value array.
get(Value[], int) - Static method in class org.h2.result.Row
Creates a new row.
get(Value[], int, long) - Static method in class org.h2.result.Row
Creates a new row with the specified key.
get(Value[], CastDataProvider) - Static method in class org.h2.value.ValueArray
Get or create a array value for the given value array.
get(Value, TypeInfo) - Static method in class org.h2.expression.TypedValueExpression
Create a new expression with the given value and type.
GET_ATTRIBUTES_4 - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_BEST_ROW_IDENTIFIER_5 - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_CATALOGS - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_COLUMN_PRIVILEGES_4 - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_COLUMNS_4 - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_COLUMNS1 - Static variable in class org.h2.expression.ExpressionVisitor
Get all referenced columns for the optimiser.
GET_COLUMNS2 - Static variable in class org.h2.expression.ExpressionVisitor
Get all referenced columns.
GET_CROSS_REFERENCE_6 - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_DATABASE_MAJOR_VERSION - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_DATABASE_MINOR_VERSION - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_DATABASE_PRODUCT_VERSION - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_DEPENDENCIES - Static variable in class org.h2.expression.ExpressionVisitor
Request to get the set of dependencies (addDependency).
GET_EXPORTED_KEYS_3 - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_FUNCTION_COLUMNS_4 - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_FUNCTIONS_3 - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_IMPORTED_KEYS_3 - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_INDEX_INFO_5 - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_JDBC_META - Static variable in class org.h2.engine.SessionRemote
 
GET_NUMERIC_FUNCTIONS - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_PRIMARY_KEYS_3 - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_PROCEDURE_COLUMNS_4 - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_PROCEDURES_3 - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_PSEUDO_COLUMNS_4 - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_SCHEMAS - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_SCHEMAS_2 - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_SEARCH_STRING_ESCAPE - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_SQL_KEYWORDS - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_STRING_FUNCTIONS - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_SUPER_TABLES_3 - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_SUPER_TYPES_3 - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_SYSTEM_FUNCTIONS - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_TABLE_PRIVILEGES_3 - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_TABLE_TYPES - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_TABLES_4 - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_TIME_DATE_FUNCTIONS - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_TYPE_INFO - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_UDTS_4 - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
GET_VERSION_COLUMNS_3 - Static variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getActiveConnections() - Method in class org.h2.jdbcx.JdbcConnectionPool
Returns the number of active (open) connections of this pool.
getAdditional(SessionLocal, Comparison) - Method in class org.h2.expression.condition.ConditionInConstantSet
Add an additional element if possible.
getAdditional(Comparison) - Method in class org.h2.expression.condition.ConditionIn
Add an additional element if possible.
getAdditionalAnd(SessionLocal, Comparison) - Method in class org.h2.expression.condition.Comparison
Get an additional condition if possible.
getAdminPassword() - Method in class org.h2.server.web.WebServer
 
getAfterLastBlock() - Method in class org.h2.mvstore.FileStore
 
getAfterLastBlock() - Method in class org.h2.mvstore.FreeSpaceBitSet
Get the index of the first block after last occupied one.
getAfterLastBlock() - Method in class org.h2.mvstore.MVStore
Get the index of the first block after last occupied one.
getAggregatedValue(SessionLocal, Object) - Method in class org.h2.expression.aggregate.Aggregate
 
getAggregatedValue(SessionLocal, Object) - Method in class org.h2.expression.aggregate.JavaAggregate
 
getAggregatedValue(SessionLocal, Object) - Method in class org.h2.expression.analysis.DataAnalysisOperation
Returns aggregated value.
getAggregatedValue(SessionLocal, Object) - Method in class org.h2.expression.analysis.WindowFunction
 
getAggregateType() - Method in class org.h2.expression.aggregate.Aggregate
Returns the type of this aggregate.
getAggregateType(String) - Static method in class org.h2.expression.aggregate.Aggregate
Get the aggregate type for this name, or -1 if no aggregate has been found.
getAlgorithm() - Method in class org.h2.compress.CompressDeflate
 
getAlgorithm() - Method in class org.h2.compress.CompressLZF
 
getAlgorithm() - Method in class org.h2.compress.CompressNo
 
getAlgorithm() - Method in interface org.h2.compress.Compressor
Get the compression algorithm type.
getAlias(int) - Method in class org.h2.result.LazyResult
 
getAlias(int) - Method in class org.h2.result.LocalResult
 
getAlias(int) - Method in interface org.h2.result.ResultInterface
Get the column alias name for the column.
getAlias(int) - Method in class org.h2.result.ResultRemote
 
getAlias(int) - Method in class org.h2.result.ResultWithPaddedStrings
 
getAlias(int) - Method in class org.h2.result.SimpleResult
 
getAlias(SessionLocal, int) - Method in class org.h2.expression.Alias
 
getAlias(SessionLocal, int) - Method in class org.h2.expression.Expression
Get the alias name of a column or SQL expression if it is not an aliased expression.
getAlias(SessionLocal, int) - Method in class org.h2.expression.ExpressionColumn
 
getAliases() - Method in class org.h2.bnf.Sentence
Get the alias map.
getAll(int, ArrayList<SchemaObject>) - Method in class org.h2.schema.Schema
Get all objects of the given type.
getAll(ArrayList<SchemaObject>) - Method in class org.h2.schema.Schema
Get all objects.
getAllChanged() - Method in interface org.h2.util.Cache
Get all objects in the cache that have been changed.
getAllChanged() - Method in class org.h2.util.CacheLRU
 
getAllChanged() - Method in class org.h2.util.CacheSecondLevel
 
getAllChanged() - Method in class org.h2.util.CacheTQ
 
getAllComments() - Method in class org.h2.engine.Database
 
getAllConstants() - Method in class org.h2.schema.Schema
 
getAllConstraints() - Method in class org.h2.schema.Schema
 
getAllDomains() - Method in class org.h2.schema.Schema
 
getAllFunctionsAndAggregates() - Method in class org.h2.schema.Schema
 
getAllIndexes() - Method in class org.h2.schema.Schema
 
getAllowChunked() - Method in class org.h2.server.web.WebServer
 
getAllowedFile(HttpServletRequest, String) - Method in class org.h2.server.web.JakartaWebServlet
 
getAllowedFile(String) - Method in class org.h2.server.web.WebThread
 
getAllowedFile(HttpServletRequest, String) - Method in class org.h2.server.web.WebServlet
 
getAllowedIndexes() - Method in class org.h2.table.IndexHints
 
getAllowLiterals() - Method in class org.h2.engine.Database
 
getAllowLiterals() - Method in class org.h2.engine.SessionLocal
 
getAllowOthers() - Method in class org.h2.server.pg.PgServer
 
getAllowOthers() - Method in interface org.h2.server.Service
Check if remote connections are allowed.
getAllowOthers() - Method in class org.h2.server.TcpServer
 
getAllowOthers() - Method in class org.h2.server.web.WebServer
 
getAllRights() - Method in class org.h2.engine.Database
 
getAllRows(SessionLocal) - Method in class org.h2.expression.Subquery
Evaluates and returns all rows of the subquery.
getAllSchemaObjects(int) - Method in class org.h2.table.InformationSchemaTableLegacy
 
getAllSchemas() - Method in class org.h2.engine.Database
 
getAllSchemasNoMeta() - Method in class org.h2.engine.Database
 
getAllSequences() - Method in class org.h2.schema.Schema
 
getAllSettings() - Method in class org.h2.engine.Database
 
getAllSynonyms() - Method in class org.h2.engine.Database
Get all synonyms.
getAllSynonyms() - Method in class org.h2.schema.Schema
 
getAllTables(SessionLocal) - Method in class org.h2.table.InformationSchemaTableLegacy
Get all tables of this database, including local temporary tables for the session.
getAllTablesAndViews() - Method in class org.h2.engine.Database
Get all tables and views.
getAllTablesAndViews(SessionLocal) - Method in class org.h2.schema.MetaSchema
 
getAllTablesAndViews(SessionLocal) - Method in class org.h2.schema.Schema
Get all tables and views.
getAllTriggers() - Method in class org.h2.schema.Schema
 
getAllUsersAndRoles() - Method in class org.h2.engine.Database
 
getAlterTableAlterColumnDropDefaultExpression(Schema, String, boolean, Column, int) - Method in class org.h2.command.Parser
 
getAndIncrementNextKey() - Method in class org.h2.mvstore.StreamStore
Generate a new key.
getAndOrType() - Method in class org.h2.expression.condition.ConditionAndOr
 
getAndOrType() - Method in class org.h2.expression.condition.ConditionAndOrN
 
getAnyScale(BigDecimal) - Static method in class org.h2.value.ValueNumeric
Get or create a NUMERIC value for the given big decimal with possibly negative scale.
getAppendCounter() - Method in class org.h2.mvstore.RootReference
 
getAppendCursorPos(CursorPos<K, V>) - Method in class org.h2.mvstore.Page
Extend path from a given CursorPos chain to "append point" in a B-tree, rooted at this Page.
getAppendCursorPos(CursorPos<K, V>) - Method in class org.h2.mvstore.Page.Leaf
 
getAppendCursorPos(CursorPos<K, V>) - Method in class org.h2.mvstore.Page.NonLeaf
 
getArea(Spatial) - Method in class org.h2.mvstore.rtree.SpatialDataType
 
getAreaIncrease(Object, Object) - Method in class org.h2.mvstore.rtree.SpatialDataType
Get the area increase by extending a to contain b.
getArgumentsValues(SessionLocal, Expression[]) - Method in class org.h2.mode.ModeFunction
Gets values of arguments and checks them for NULL values if function returns NULL on NULL argument.
getArray() - Method in class org.h2.expression.aggregate.AggregateDataCollecting
Returns array with values or null.
getArray() - Method in class org.h2.jdbc.JdbcArray
Returns the value as a Java array.
getArray() - Method in class org.h2.tools.SimpleResultSet.SimpleArray
Get the object array.
getArray() - Method in class org.h2.util.json.JSONArray
Returns the value.
getArray(int) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as an Array.
getArray(int) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as an Array.
getArray(int) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a java.sql.Array.
getArray(int, int) - Method in class org.h2.jdbc.JdbcResultSet
 
getArray(long, int) - Method in class org.h2.jdbc.JdbcArray
Returns the value as a Java array.
getArray(long, int) - Method in class org.h2.tools.SimpleResultSet.SimpleArray
INTERNAL
getArray(long, int, Map<String, Class<?>>) - Method in class org.h2.jdbc.JdbcArray
Returns the value as a Java array.
getArray(long, int, Map<String, Class<?>>) - Method in class org.h2.tools.SimpleResultSet.SimpleArray
INTERNAL
getArray(String) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as an Array.
getArray(String) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as an Array.
getArray(String) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a java.sql.Array.
getArray(Map<String, Class<?>>) - Method in class org.h2.jdbc.JdbcArray
Returns the value as a Java array.
getArray(Map<String, Class<?>>) - Method in class org.h2.tools.SimpleResultSet.SimpleArray
INTERNAL
getAsciiReader(InputStream) - Static method in class org.h2.util.IOUtils
Wrap an input stream in a reader.
getAsciiStream() - Method in class org.h2.jdbc.JdbcClob
Returns the input stream.
getAsciiStream(int) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as an input stream.
getAsciiStream(int) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
getAsciiStream(String) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as an input stream.
getAsciiStream(String) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
getAttributes(String, String, String, String) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
[Not supported]
getAttributes(String, String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getAttributes(String, String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLocalBase
 
getAttributes(String, String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getAttributeValueOr(String, Attributes, String) - Static method in class org.h2.security.auth.H2AuthConfigXml
 
getAuthenticator() - Method in class org.h2.engine.Database
get authenticator for database users
getAutoClose() - Method in class org.h2.tools.SimpleResultSet
Get the current auto-close behavior.
getAutocommit() - Method in class org.h2.table.TableLink
The autocommit mode
getAutocommit() - Method in class org.h2.table.TableLinkConnection
The autocommit mode
getAutoCommit() - Method in class org.h2.engine.Session
Check if this session is in auto-commit mode.
getAutoCommit() - Method in class org.h2.engine.SessionLocal
 
getAutoCommit() - Method in class org.h2.engine.SessionRemote
 
getAutoCommit() - Method in class org.h2.jdbc.JdbcConnection
Gets the current setting for auto commit.
getAutoCommitDelay() - Method in class org.h2.mvstore.MVStore
Get the auto-commit delay.
getAutoCommitMemory() - Method in class org.h2.mvstore.MVStore
Get the maximum memory (in bytes) used for unsaved pages.
getAutoScaledForMemoryProperty(String, int) - Static method in class org.h2.engine.SysProperties
This method attempts to auto-scale some of our properties to take advantage of more powerful machines out of the box.
getAverage(long) - Static method in class org.h2.util.MemoryEstimator
 
getAvgType(TypeInfo) - Static method in class org.h2.expression.aggregate.Aggregate
 
getBackgroundException() - Method in class org.h2.engine.Database
 
getBase() - Method in class org.h2.store.fs.FilePathWrapper
 
getBase(int) - Method in class org.h2.store.fs.split.FilePathSplit
Get the file name of a part file.
getBaseDir() - Static method in class org.h2.engine.SysProperties
INTERNAL
getBaseDir() - Method in class org.h2.server.pg.PgServer
 
getBaseDir() - Method in class org.h2.server.TcpServer
Get the configured base directory.
getBaseType() - Method in class org.h2.jdbc.JdbcArray
Returns the base type of the array.
getBaseType() - Method in class org.h2.tools.SimpleResultSet.SimpleArray
Get the base type of this array.
getBaseTypeName() - Method in class org.h2.jdbc.JdbcArray
Returns the base type name of the array.
getBaseTypeName() - Method in class org.h2.tools.SimpleResultSet.SimpleArray
Get the base type name of this array.
getBaseValue() - Method in class org.h2.schema.Sequence
 
getBelongsToConstraint() - Method in class org.h2.index.IndexType
If the index is created because of a constraint.
getBelongsToTable() - Method in class org.h2.schema.Sequence
 
getBestPlanItem(SessionLocal, int[], TableFilter[], int, SortOrder, AllColumnsForPlan) - Method in class org.h2.table.Table
Get the best plan for the given search mask.
getBestPlanItem(SessionLocal, int[], TableFilter[], int, SortOrder, AllColumnsForPlan) - Method in class org.h2.table.TableView
 
getBestPlanItem(SessionLocal, TableFilter[], int, AllColumnsForPlan) - Method in class org.h2.table.TableFilter
Get the best plan item (index, cost) to use for the current join order.
getBestRowIdentifier(String, String, String, int, boolean) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the list of columns that best identifier a row in a table.
getBestRowIdentifier(String, String, String, int, boolean) - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getBestRowIdentifier(String, String, String, int, boolean) - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getBestRowIdentifier(String, String, String, int, boolean) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getBestRowIdentifier(String, String, String, int, boolean) - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getBigDecimal() - Method in class org.h2.util.json.JSONNumber
Returns the value.
getBigDecimal() - Method in class org.h2.value.Value
 
getBigDecimal() - Method in class org.h2.value.ValueBigint
 
getBigDecimal() - Method in class org.h2.value.ValueBoolean
 
getBigDecimal() - Method in class org.h2.value.ValueDecfloat
 
getBigDecimal() - Method in class org.h2.value.ValueDouble
 
getBigDecimal() - Method in class org.h2.value.ValueEnumBase
 
getBigDecimal() - Method in class org.h2.value.ValueInteger
 
getBigDecimal() - Method in class org.h2.value.ValueInterval
 
getBigDecimal() - Method in class org.h2.value.ValueNull
 
getBigDecimal() - Method in class org.h2.value.ValueNumeric
 
getBigDecimal() - Method in class org.h2.value.ValueReal
 
getBigDecimal() - Method in class org.h2.value.ValueSmallint
 
getBigDecimal() - Method in class org.h2.value.ValueStringBase
 
getBigDecimal() - Method in class org.h2.value.ValueTinyint
 
getBigDecimal(int) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a BigDecimal.
getBigDecimal(int) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a BigDecimal.
getBigDecimal(int) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a java.math.BigDecimal.
getBigDecimal(int, int) - Method in class org.h2.jdbc.JdbcCallableStatement
getBigDecimal(int, int) - Method in class org.h2.jdbc.JdbcResultSet
getBigDecimal(int, int) - Method in class org.h2.tools.SimpleResultSet
Deprecated.
INTERNAL
getBigDecimal(String) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a BigDecimal.
getBigDecimal(String) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a BigDecimal.
getBigDecimal(String) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a java.math.BigDecimal.
getBigDecimal(String, int) - Method in class org.h2.jdbc.JdbcResultSet
getBigDecimal(String, int) - Method in class org.h2.tools.SimpleResultSet
Deprecated.
INTERNAL
getBinaryStream() - Method in class org.h2.jdbc.JdbcBlob
 
getBinaryStream() - Method in class org.h2.jdbc.JdbcLob
Returns the input stream.
getBinaryStream() - Method in class org.h2.jdbc.JdbcSQLXML
 
getBinaryStream(int) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as an input stream.
getBinaryStream(int) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a java.io.InputStream.
getBinaryStream(long, long) - Method in class org.h2.jdbc.JdbcBlob
Returns the input stream, starting from an offset.
getBinaryStream(String) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as an input stream.
getBinaryStream(String) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a java.io.InputStream.
getBinaryString(int, TypeInfo, Value, Value) - Static method in class org.h2.expression.function.BitFunction
 
getBinaryTooLong(long) - Method in class org.h2.value.ValueLob
 
getBindAddress() - Static method in class org.h2.util.NetUtils
Get the bind address if the system property h2.bindAddress is set, or null if not.
getBitsPerValue(int) - Static method in class org.h2.tools.MultiDimension
 
getBitwise(int, TypeInfo, Value, Value) - Static method in class org.h2.expression.function.BitFunction
Computes the value of bitwise function.
getBlob(int) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a Blob.
getBlob(int) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a Blob.
getBlob(int) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a java.sql.Blob.
getBlob(int, int) - Method in class org.h2.jdbc.JdbcResultSet
 
getBlob(String) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a Blob.
getBlob(String) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a Blob.
getBlob(String) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a java.sql.Blob.
getBlock(long) - Method in class org.h2.mvstore.FreeSpaceBitSet
 
getBlock(long) - Method in class org.h2.mvstore.StreamStore
Get the block.
getBlockCipher(String) - Static method in class org.h2.security.CipherFactory
Get a new block cipher object for the given algorithm.
getBlockCount(int) - Method in class org.h2.mvstore.FreeSpaceBitSet
 
getBlockerId() - Method in class org.h2.mvstore.tx.Transaction
 
getBlockingSessionId() - Method in class org.h2.engine.SessionLocal
 
getBlockingTransaction() - Method in class org.h2.mvstore.tx.TxDecisionMaker
 
getBnf() - Method in class org.h2.server.web.WebSession
Get the BNF object.
getBoolean() - Method in class org.h2.util.json.JSONBoolean
Returns the value.
getBoolean() - Method in class org.h2.value.Value
Returns this value as a Java boolean value.
getBoolean() - Method in class org.h2.value.ValueBoolean
 
getBoolean() - Method in class org.h2.value.ValueNull
 
getBoolean() - Method in class org.h2.value.ValueStringBase
 
getBoolean(boolean) - Static method in class org.h2.expression.ValueExpression
Create a new expression with the given boolean value.
getBoolean(int) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a boolean.
getBoolean(int) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a boolean.
getBoolean(int) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a boolean.
getBoolean(String) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a boolean.
getBoolean(String) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a boolean.
getBoolean(String) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a boolean.
getBoolean(Value) - Static method in class org.h2.expression.ValueExpression
Create a new expression with the given boolean value.
getBooleanInternal(int) - Method in class org.h2.jdbc.JdbcResultSet
 
getBooleanProperty(Properties, String, boolean) - Static method in class org.h2.util.SortedProperties
Get a boolean property value from a properties object.
getBooleanValue(String, boolean) - Method in class org.h2.security.auth.ConfigProperties
Returns the boolean value of specified property.
getBooleanValue(SessionLocal) - Method in class org.h2.expression.Expression
Get the value in form of a boolean expression.
getBounds() - Method in class org.h2.command.ddl.SequenceOptions
 
getBounds() - Method in class org.h2.mvstore.db.MVSpatialIndex.FindBoundsCursor
 
getBounds(SessionLocal) - Method in class org.h2.mvstore.db.MVSpatialIndex
Returns the minimum bounding box that encloses all keys.
getBounds(Page<Spatial, V>) - Method in class org.h2.mvstore.rtree.MVRTreeMap
 
getBounds(TypeInfo) - Static method in class org.h2.command.ddl.SequenceOptions
Get the bounds (min, max) of a data type.
getBranchQualifier() - Method in class org.h2.jdbcx.JdbcXid
The transaction branch identifier.
getBuffer() - Method in class org.h2.mvstore.WriteBuffer
Get the byte buffer.
getBuffer(int) - Method in class org.h2.tools.CompressTool
 
getBufferedWriter(OutputStream) - Static method in class org.h2.util.IOUtils
Create a buffered writer to write to an output stream using the UTF-8 format.
getBufferSize(DataHandler, long) - Static method in class org.h2.value.ValueLob
 
getByte() - Method in class org.h2.value.Value
Returns this value as a Java byte value.
getByte() - Method in class org.h2.value.ValueBoolean
 
getByte() - Method in class org.h2.value.ValueNull
 
getByte() - Method in class org.h2.value.ValueStringBase
 
getByte() - Method in class org.h2.value.ValueTinyint
 
getByte(int) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a byte.
getByte(int) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a byte.
getByte(int) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a byte.
getByte(String) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a byte.
getByte(String) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a byte.
getByte(String) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a byte.
getByteArray(SessionLocal, Expression) - Static method in class org.h2.command.ddl.CreateUser
 
getByteArrayHash(byte[]) - Static method in class org.h2.util.Utils
Calculate the hash code of the given byte array.
getByteInternal(int) - Method in class org.h2.jdbc.JdbcResultSet
 
getBytes() - Method in class org.h2.store.Data
Get the byte array used for this page.
getBytes() - Method in class org.h2.util.SourceCompiler.JavaClassObject
 
getBytes() - Method in class org.h2.value.Value
 
getBytes() - Method in class org.h2.value.ValueBigint
 
getBytes() - Method in class org.h2.value.ValueBytesBase
 
getBytes() - Method in class org.h2.value.ValueInteger
 
getBytes() - Method in class org.h2.value.ValueLob
 
getBytes() - Method in class org.h2.value.ValueNull
 
getBytes() - Method in class org.h2.value.ValueSmallint
 
getBytes() - Method in class org.h2.value.ValueStringBase
 
getBytes() - Method in class org.h2.value.ValueTinyint
 
getBytes() - Method in class org.h2.value.ValueUuid
 
getBytes(int) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a byte array.
getBytes(int) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a byte array.
getBytes(int) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a byte array.
getBytes(long, int) - Method in class org.h2.jdbc.JdbcBlob
Returns some bytes of the object.
getBytes(String) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a byte array.
getBytes(String) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a byte array.
getBytes(String) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a byte array.
getBytesInternal() - Method in class org.h2.value.ValueBlob
 
getBytesInternal() - Method in class org.h2.value.ValueClob
 
getBytesInternal() - Method in class org.h2.value.ValueLob
 
getBytesNoCopy() - Method in class org.h2.value.Value
 
getBytesNoCopy() - Method in class org.h2.value.ValueBytesBase
 
getBytesNoCopy() - Method in class org.h2.value.ValueLob
 
getCache() - Method in class org.h2.mvstore.MVStore
Get the cache.
getCache() - Method in class org.h2.server.web.WebApp
 
getCache() - Static method in class org.h2.util.StringUtils
 
getCache(CacheWriter, String, int) - Static method in class org.h2.util.CacheLRU
Create a cache of the given type and size.
getCacheHitRatio() - Method in class org.h2.mvstore.MVStore
 
getCacheHitRatio(CacheLongKeyLIRS<?>) - Static method in class org.h2.mvstore.MVStore
 
getCachePos(long) - Static method in class org.h2.mvstore.cache.FilePathCache.FileCache
 
getCacheSize() - Method in class org.h2.jmx.DatabaseInfo
 
getCacheSize() - Method in interface org.h2.jmx.DatabaseInfoMBean
The current cache size in KB.
getCacheSize() - Method in class org.h2.mvstore.MVStore
Get the maximum cache size, in MB.
getCacheSize() - Method in class org.h2.schema.Sequence
 
getCacheSize(SessionLocal) - Method in class org.h2.command.ddl.SequenceOptions
Gets cache size.
getCacheSizeMax() - Method in class org.h2.jmx.DatabaseInfo
 
getCacheSizeMax() - Method in interface org.h2.jmx.DatabaseInfoMBean
The maximum cache size in KB.
getCacheSizeUsed() - Method in class org.h2.mvstore.MVStore
Get the amount of memory used for caching, in MB.
getCacheType() - Method in class org.h2.engine.Database
 
getCancel() - Method in class org.h2.engine.SessionLocal
Get the cancel time.
getCanonicalPath(String) - Static method in class org.h2.store.fs.mem.FilePathMem
Get the canonical path for this file name.
getCanonicalPath(String) - Static method in class org.h2.store.fs.niomem.FilePathNioMem
Get the canonical path of a file (with backslashes replaced with forward slashes).
getCaseSensitiveColumnNames() - Method in class org.h2.tools.Csv
Get the current case sensitive column names setting.
getCatalog() - Method in class org.h2.jdbc.JdbcConnection
Gets the current catalog name.
getCatalogName(int) - Method in class org.h2.jdbc.JdbcResultSetMetaData
Returns the catalog name.
getCatalogName(int) - Method in class org.h2.tools.SimpleResultSet
Returns empty string.
getCatalogPattern(String) - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getCatalogs() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the list of catalogs.
getCatalogs() - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getCatalogs() - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getCatalogs() - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getCatalogs() - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getCatalogSeparator() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the catalog separator.
getCatalogTerm() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the term for "catalog".
getChanges(long) - Method in class org.h2.mvstore.tx.Transaction
Get the list of changes, starting with the latest change, up to the given savepoint (in reverse order than they occurred).
getChanges(Transaction, long, long) - Method in class org.h2.mvstore.tx.TransactionStore
Get the changes of the given transaction, starting from the latest log id back to the given log id.
getCharacterStream() - Method in class org.h2.jdbc.JdbcClob
 
getCharacterStream() - Method in class org.h2.jdbc.JdbcLob
Returns the reader.
getCharacterStream() - Method in class org.h2.jdbc.JdbcSQLXML
 
getCharacterStream(int) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a reader.
getCharacterStream(int) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a reader.
getCharacterStream(int) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a java.io.Reader.
getCharacterStream(long, long) - Method in class org.h2.jdbc.JdbcClob
Returns the reader, starting from an offset.
getCharacterStream(String) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a reader.
getCharacterStream(String) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a reader.
getCharacterStream(String) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a java.io.Reader.
getCharContent(boolean) - Method in class org.h2.util.SourceCompiler.StringJavaFileObject
 
getCharset() - Method in class org.h2.value.CharsetCollator
 
getCheckConstraint(SessionLocal, String) - Method in class org.h2.constraint.ConstraintDomain
Get the check constraint expression for this column.
getCheckedMetaData() - Method in class org.h2.jdbc.JdbcCallableStatement
 
getCheckForeignKeyConstraints() - Method in class org.h2.table.Table
 
getCheckValue(int) - Static method in class org.h2.mvstore.DataUtils
Calculate a check value for the given integer.
getChildPage(int) - Method in class org.h2.mvstore.Page
Get the child page at the given index.
getChildPage(int) - Method in class org.h2.mvstore.Page.Leaf
 
getChildPage(int) - Method in class org.h2.mvstore.Page.NonLeaf
 
getChildPageCount(Page<K, V>) - Method in class org.h2.mvstore.MVMap
Get the child page count for this page.
getChildPageCount(Page<Spatial, V>) - Method in class org.h2.mvstore.rtree.MVRTreeMap
 
getChildPagePos(int) - Method in class org.h2.mvstore.Page
Get the position of the child.
getChildPagePos(int) - Method in class org.h2.mvstore.Page.Leaf
 
getChildPagePos(int) - Method in class org.h2.mvstore.Page.NonLeaf
 
getChildren() - Method in class org.h2.engine.DbObject
Get the list of dependent children (for tables, this includes indexes and so on).
getChildren() - Method in class org.h2.engine.Role
 
getChildren() - Method in class org.h2.engine.User
 
getChildren() - Method in class org.h2.schema.Schema
 
getChildren() - Method in class org.h2.table.Table
 
getChunk(long) - Method in class org.h2.mvstore.MVStore
Get the chunk for the given position.
getChunkCount() - Method in class org.h2.mvstore.MVStore
Get data chunks count.
getChunkForVersion(long) - Method in class org.h2.mvstore.MVStore
 
getChunksFillRate() - Method in class org.h2.mvstore.MVStore
Get the current fill rate (percentage of used space in the file).
getChunksFillRate(boolean) - Method in class org.h2.mvstore.MVStore
 
getClass(String) - Method in class org.h2.util.SourceCompiler
Get the class object for the given name.
getClassLoader(JavaFileManager.Location) - Method in class org.h2.util.SourceCompiler.ClassFileManager
 
getClassName() - Method in class org.h2.security.auth.UserToRolesMapperConfig
 
getClient() - Method in class org.h2.util.NetworkConnectionInfo
Returns the client address and port.
getClientAddr() - Method in class org.h2.util.NetworkConnectionInfo
Returns the client address.
getClientInfo() - Method in class org.h2.jdbc.JdbcConnection
Get the client properties.
getClientInfo() - Method in class org.h2.util.NetworkConnectionInfo
Returns additional client information, or null.
getClientInfo(String) - Method in class org.h2.jdbc.JdbcConnection
Get a client property.
getClientInfoProperties() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
 
getClientPort() - Method in class org.h2.util.NetworkConnectionInfo
Returns the client port.
getClientVersion() - Method in class org.h2.engine.SessionRemote
Returns the TCP protocol version of remote connection.
getClob(int) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a Clob.
getClob(int) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a Clob.
getClob(int) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a java.sql.Clob.
getClob(int, int) - Method in class org.h2.jdbc.JdbcResultSet
 
getClob(String) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a Clob.
getClob(String) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a Clob.
getClob(String) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a java.sql.Clob.
getClone() - Method in class org.h2.table.Column
 
getCloseable() - Method in class org.h2.util.CloseWatcher
 
getCluster() - Method in class org.h2.engine.Database
 
getClusterServers() - Method in class org.h2.engine.Session
Get the list of the cluster servers for this session.
getClusterServers() - Method in class org.h2.engine.SessionLocal
 
getClusterServers() - Method in class org.h2.engine.SessionRemote
 
getCollationKey(String) - Method in class org.h2.value.CharsetCollator
 
getCollationLocales(boolean) - Static method in class org.h2.value.CompareMode
Returns available locales for collations.
getCollator(String) - Static method in class org.h2.value.CompareMode
Get the collator object for the given language name or language / country combination.
getColumn() - Method in class org.h2.expression.ExpressionColumn
 
getColumn() - Method in class org.h2.index.IndexCondition
Get the referenced column.
getColumn(int) - Method in class org.h2.table.Table
Get the column at the given index.
getColumn(int) - Method in class org.h2.tools.SimpleResultSet
 
getColumn(int, TableFilter) - Method in class org.h2.result.SortOrder
Get the column for the given table filter, if the sort column is for this filter.
getColumn(String) - Method in class org.h2.table.Table
Get the column with the given name.
getColumn(String, boolean) - Method in class org.h2.table.Table
Get the column with the given name.
getColumn(String, boolean) - Method in class org.h2.table.TableFilter
Get the column with the given name.
getColumn(String, int) - Method in class org.h2.jdbc.JdbcResultSetMetaData
Writes trace information and checks validity of this object and parameter.
getColumn(DbContents, ResultSet) - Static method in class org.h2.bnf.context.DbColumn
Create a column from a DatabaseMetaData.getColumns row.
getColumnClasses() - Method in class org.h2.schema.FunctionAlias.JavaMethod
 
getColumnClassName(int) - Method in class org.h2.jdbc.JdbcResultSetMetaData
Gets the Java class name of the object that will be returned if ResultSet.getObject is called.
getColumnClassName(int) - Method in class org.h2.tools.SimpleResultSet
Returns the Java class name if this column.
getColumnCount() - Method in class org.h2.command.query.Query
Get the column count of this query.
getColumnCount() - Method in class org.h2.jdbc.JdbcResultSetMetaData
Returns the number of columns.
getColumnCount() - Method in class org.h2.mvstore.db.RowDataType
 
getColumnCount() - Method in class org.h2.result.DefaultRow
 
getColumnCount() - Method in class org.h2.result.RowFactory.DefaultRowFactory
 
getColumnCount() - Method in class org.h2.result.RowFactory
 
getColumnCount() - Method in class org.h2.result.SearchRow
Get the column count.
getColumnCount() - Method in class org.h2.result.SimpleRowValue
 
getColumnCount() - Method in class org.h2.result.Sparse
 
getColumnCount() - Method in class org.h2.tools.SimpleResultSet
Returns the column count.
getColumnDisplaySize(int) - Method in class org.h2.jdbc.JdbcResultSetMetaData
Gets the maximum display size for this column.
getColumnDisplaySize(int) - Method in class org.h2.tools.SimpleResultSet
Returns 15.
getColumnException(int) - Method in class org.h2.expression.ExpressionColumn
Get exception to throw, with column and table info added
getColumnId() - Method in class org.h2.table.Column
 
getColumnIndex(String) - Method in class org.h2.jdbc.JdbcResultSet
 
getColumnIndex(String) - Method in class org.h2.result.UpdatableRow
 
getColumnIndex(Database, Expression) - Static method in class org.h2.expression.aggregate.Percentile
Get the index (if any) for the column specified in the inverse distribution function.
getColumnIndex(Column) - Method in class org.h2.index.Index
Get the index of a column in the list of index columns
getColumnIndex(Column) - Method in class org.h2.index.MetaIndex
 
getColumnIndex(Column) - Method in class org.h2.mvstore.db.MVDelegateIndex
 
getColumnIndex(Column) - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
getColumnLabel(int) - Method in class org.h2.jdbc.JdbcResultSetMetaData
Returns the column label.
getColumnLabel(int) - Method in class org.h2.tools.SimpleResultSet
Returns the column label.
getColumnListSQL(StringBuilder, int) - Method in class org.h2.index.Index
Get the list of columns as a string.
getColumnName() - Method in class org.h2.constraint.DomainColumnResolver
Return column name to use or null.
getColumnName(int) - Method in class org.h2.jdbc.JdbcResultSetMetaData
Returns the column name.
getColumnName(int) - Method in class org.h2.result.LazyResult
 
getColumnName(int) - Method in class org.h2.result.LocalResult
 
getColumnName(int) - Method in interface org.h2.result.ResultInterface
Get the column name.
getColumnName(int) - Method in class org.h2.result.ResultRemote
 
getColumnName(int) - Method in class org.h2.result.ResultWithPaddedStrings
 
getColumnName(int) - Method in class org.h2.result.SimpleResult
 
getColumnName(int) - Method in class org.h2.tools.SimpleResultSet
Returns the column name.
getColumnName(Object) - Static method in class org.h2.value.Value
 
getColumnName(SessionLocal, int) - Method in class org.h2.expression.Alias
 
getColumnName(SessionLocal, int) - Method in class org.h2.expression.Expression
Get the column name or alias name of this expression.
getColumnName(SessionLocal, int) - Method in class org.h2.expression.ExpressionColumn
 
getColumnName(SessionLocal, int) - Method in class org.h2.expression.Format
 
getColumnName(Column) - Method in interface org.h2.table.ColumnResolver
Get the name of the specified column.
getColumnName(Column) - Method in class org.h2.table.TableFilter
 
getColumnNameForView(SessionLocal, int) - Method in class org.h2.expression.Alias
 
getColumnNameForView(SessionLocal, int) - Method in class org.h2.expression.Expression
Get the column name of this expression for a view.
getColumnNameForView(SessionLocal, int) - Method in class org.h2.expression.ExpressionColumn
 
getColumnPrivileges(String, String, String, String) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the list of column privileges.
getColumnPrivileges(String, String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getColumnPrivileges(String, String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getColumnPrivileges(String, String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getColumnPrivileges(String, String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getColumnResolvers() - Method in class org.h2.expression.ExpressionVisitor
Get the set of column resolvers.
getColumns() - Method in class org.h2.bnf.context.DbTableOrView
 
getColumns() - Method in class org.h2.command.ddl.CreateTable
 
getColumns() - Method in class org.h2.command.query.SelectListColumnResolver
 
getColumns() - Method in class org.h2.command.query.TableValueConstructor.TableValueColumnResolver
 
getColumns() - Method in class org.h2.constraint.ConstraintReferential
 
getColumns() - Method in class org.h2.constraint.ConstraintUnique
 
getColumns() - Method in class org.h2.constraint.DomainColumnResolver
 
getColumns() - Method in class org.h2.index.Index
Get the indexed columns.
getColumns() - Method in interface org.h2.table.ColumnResolver
Get the column list.
getColumns() - Method in class org.h2.table.GeneratedColumnResolver
 
getColumns() - Method in class org.h2.table.Table
 
getColumns() - Method in class org.h2.table.TableFilter
 
getColumns(String, String, String, String) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the list of columns.
getColumns(String, String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getColumns(String, String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getColumns(String, String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getColumns(String, String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getColumnsAdd(SimpleResult, Value, Value, Value, Table, CompareLike) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getColumnsVisitor(HashSet<Column>, Table) - Static method in class org.h2.expression.ExpressionVisitor
Create a new visitor to get all referenced columns.
getColumnsVisitor(AllColumnsForPlan) - Static method in class org.h2.expression.ExpressionVisitor
Create a new visitor to get all referenced columns.
getColumnType(int) - Method in class org.h2.jdbc.JdbcResultSetMetaData
Returns the data type of a column.
getColumnType(int) - Method in class org.h2.result.LazyResult
 
getColumnType(int) - Method in class org.h2.result.LocalResult
 
getColumnType(int) - Method in interface org.h2.result.ResultInterface
Get the column data type.
getColumnType(int) - Method in class org.h2.result.ResultRemote
 
getColumnType(int) - Method in class org.h2.result.ResultWithPaddedStrings
 
getColumnType(int) - Method in class org.h2.result.SimpleResult
 
getColumnType(int) - Method in class org.h2.tools.SimpleResultSet
Returns the SQL type.
getColumnTypeName(int) - Method in class org.h2.jdbc.JdbcResultSetMetaData
Returns the data type name of a column.
getColumnTypeName(int) - Method in class org.h2.tools.SimpleResultSet
Returns the data type name of a column.
getColumnTypes() - Method in class org.h2.result.RowFactory.DefaultRowFactory
 
getColumnTypes() - Method in class org.h2.result.RowFactory
 
getColumnWithDomain(String, Domain) - Static method in class org.h2.command.Parser
 
getCombinedArea(Object, Object) - Method in class org.h2.mvstore.rtree.SpatialDataType
Get the combined area of both objects.
getComboBox(String[][], String) - Static method in class org.h2.server.web.WebApp
 
getComboBox(String[], String) - Static method in class org.h2.server.web.WebApp
 
getCommand() - Method in class org.h2.command.dml.Explain
 
getCommand(int) - Method in class org.h2.server.web.WebSession
Get the SQL statement from history.
getCommandHistory() - Method in class org.h2.server.web.WebSession
Get the list of SQL statements in the history.
getCommandHistoryList() - Method in class org.h2.server.web.WebServer
 
getCommandHistoryString() - Method in class org.h2.server.web.WebApp
 
getCommandStartOrEnd() - Method in class org.h2.engine.SessionLocal
 
getCommandType() - Method in class org.h2.command.CommandContainer
 
getCommandType() - Method in interface org.h2.command.CommandInterface
Get command type.
getCommandType() - Method in class org.h2.command.CommandList
 
getCommandType() - Method in class org.h2.command.CommandRemote
 
getComment() - Method in class org.h2.engine.DbObject
Get the current comment of this object.
getComment() - Method in class org.h2.table.Column
 
getCommittedValue() - Method in class org.h2.mvstore.tx.VersionedValueCommitted
 
getCommittedValue() - Method in class org.h2.mvstore.tx.VersionedValueUncommitted
 
getCommittedValue() - Method in class org.h2.value.VersionedValue
 
getCommonClassId(Class<?>) - Static method in class org.h2.mvstore.type.ObjectDataType.Holder
Get the class id, or null if not found.
getCommonJoinColumns() - Method in class org.h2.table.TableFilter
Returns common join columns map.
getCommonJoinColumnsFilter() - Method in class org.h2.table.TableFilter
Returns common join columns table filter.
getCommonType(Expression, Expression) - Static method in class org.h2.expression.function.BitFunction
 
getCompareMode() - Method in class org.h2.engine.Database
 
getCompareMode() - Method in class org.h2.engine.SessionRemote
 
getCompareMode() - Method in class org.h2.jdbc.JdbcConnection
 
getCompareMode() - Method in interface org.h2.store.DataHandler
Return compare mode.
getCompareMode() - Method in class org.h2.table.Table
 
getCompareMode() - Method in class org.h2.tools.Recover
 
getCompareRow(SessionLocal, ArrayList<Value[]>, SortOrder, int, WindowFrameBound, boolean) - Static method in class org.h2.expression.analysis.WindowFrame
Appends bound value to the current row and produces row for comparison operations.
getCompareType() - Method in class org.h2.index.IndexCondition
 
getCompareType(int) - Static method in class org.h2.command.Parser
 
getCompatibilityModeFunction(String, Mode.ModeEnum) - Static method in class org.h2.mode.ModeFunction
 
getCompiledScript(String) - Method in class org.h2.util.SourceCompiler
Get the compiled script.
getCompiler() - Method in class org.h2.engine.Database
 
getCompleteSourceCode(String, String, String) - Static method in class org.h2.util.SourceCompiler
Get the complete source code (including package name, imports, and so on).
getComponentType() - Method in class org.h2.value.ValueArray
 
getCompressAlgorithm(String) - Static method in class org.h2.tools.CompressTool
INTERNAL
getCompressionLevel() - Method in class org.h2.mvstore.MVStore
 
getCompressor(boolean) - Static method in class org.h2.mvstore.MVStoreTool
 
getCompressor(int) - Static method in class org.h2.tools.CompressTool
 
getCompressor(String) - Static method in class org.h2.tools.CompressTool
 
getCompressorFast() - Method in class org.h2.mvstore.MVStore
 
getCompressorHigh() - Method in class org.h2.mvstore.MVStore
 
getConcurrency() - Method in class org.h2.jdbc.JdbcResultSet
Gets the result set concurrency.
getConcurrency() - Method in class org.h2.tools.SimpleResultSet
Returns ResultSet.CONCUR_READ_ONLY.
getCondition() - Method in class org.h2.command.dml.FilteredDataChangeStatement
 
getCondition() - Method in class org.h2.command.query.Select
 
getConditionIn(Expression, Expression, Expression) - Static method in class org.h2.expression.condition.Comparison
 
getConfigParam(Map<String, ?>, String, int) - Static method in class org.h2.mvstore.DataUtils
Get the configuration parameter value, or default.
getConnection() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the connection that created this object.
getConnection() - Method in class org.h2.jdbc.JdbcStatement
Returns the connection that created this object.
getConnection() - Method in class org.h2.jdbcx.JdbcConnectionPool
Retrieves a connection from the connection pool.
getConnection() - Method in class org.h2.jdbcx.JdbcDataSource
Open a new connection using the current URL, user name and password.
getConnection() - Method in class org.h2.jdbcx.JdbcXAConnection
Get a connection that is a handle to the physical connection.
getConnection() - Method in class org.h2.server.web.DbStarter
Get the connection.
getConnection() - Method in class org.h2.server.web.JakartaDbStarter
Get the connection.
getConnection() - Method in class org.h2.server.web.WebSession
 
getConnection() - Method in class org.h2.table.TableLinkConnection
Get the connection.
getConnection(String, String) - Method in class org.h2.jdbcx.JdbcConnectionPool
INTERNAL
getConnection(String, String) - Method in class org.h2.jdbcx.JdbcDataSource
Open a new connection using the current URL and the specified user name and password.
getConnection(String, String, String, String) - Static method in class org.h2.util.JdbcUtils
Open a new database connection with the given settings.
getConnection(String, String, String, String, String, NetworkConnectionInfo) - Method in class org.h2.server.web.WebServer
Open a database connection.
getConnection(String, String, String, String, NetworkConnectionInfo, boolean) - Static method in class org.h2.util.JdbcUtils
Open a new database connection with the given settings.
getConnectionInfo() - Method in class org.h2.security.auth.AuthenticationInfo
 
getConnectionNow() - Method in class org.h2.jdbcx.JdbcConnectionPool
 
getConstant(String) - Method in class org.h2.schema.Schema
Get the user defined constant with the given name.
getConstraint(String) - Method in class org.h2.schema.Schema
Get the constraint with the given name.
getConstraintCommands() - Method in class org.h2.command.ddl.CommandWithColumns
 
getConstraintName() - Method in class org.h2.command.ddl.AlterDomainAddConstraint
 
getConstraintName() - Method in class org.h2.command.ddl.AlterTableAddConstraint
 
getConstraints() - Method in class org.h2.schema.Domain
 
getConstraints() - Method in class org.h2.table.Table
 
getConstraintType() - Method in class org.h2.constraint.Constraint
The constraint type name
getConstraintType() - Method in class org.h2.constraint.ConstraintCheck
 
getConstraintType() - Method in class org.h2.constraint.ConstraintDomain
 
getConstraintType() - Method in class org.h2.constraint.ConstraintReferential
 
getConstraintType() - Method in class org.h2.constraint.ConstraintUnique
 
getContainsLargeObject() - Method in class org.h2.mvstore.db.MVTable
 
getContents() - Method in class org.h2.bnf.context.DbSchema
 
getContents() - Method in class org.h2.server.web.WebSession
 
getCost() - Method in class org.h2.command.query.Optimizer
 
getCost() - Method in class org.h2.command.query.Query
Calculate the cost to execute this query.
getCost() - Method in class org.h2.command.query.Select
 
getCost() - Method in class org.h2.command.query.SelectUnion
 
getCost() - Method in class org.h2.command.query.TableValueConstructor
 
getCost() - Method in class org.h2.expression.aggregate.Aggregate
 
getCost() - Method in class org.h2.expression.aggregate.JavaAggregate
 
getCost() - Method in class org.h2.expression.Alias
 
getCost() - Method in class org.h2.expression.analysis.WindowFunction
 
getCost() - Method in class org.h2.expression.ArrayConstructorByQuery
 
getCost() - Method in class org.h2.expression.condition.BetweenPredicate
 
getCost() - Method in class org.h2.expression.condition.CompareLike
 
getCost() - Method in class org.h2.expression.condition.Comparison
 
getCost() - Method in class org.h2.expression.condition.ConditionAndOr
 
getCost() - Method in class org.h2.expression.condition.ConditionAndOrN
 
getCost() - Method in class org.h2.expression.condition.ConditionIn
 
getCost() - Method in class org.h2.expression.condition.ConditionInConstantSet
 
getCost() - Method in class org.h2.expression.condition.ConditionInParameter
 
getCost() - Method in class org.h2.expression.condition.ConditionInQuery
 
getCost() - Method in class org.h2.expression.condition.ConditionLocalAndGlobal
 
getCost() - Method in class org.h2.expression.condition.ConditionNot
 
getCost() - Method in class org.h2.expression.condition.IsJsonPredicate
 
getCost() - Method in class org.h2.expression.condition.PredicateWithSubquery
 
getCost() - Method in class org.h2.expression.condition.SimplePredicate
 
getCost() - Method in class org.h2.expression.DomainValueExpression
 
getCost() - Method in class org.h2.expression.Expression
Estimate the cost to process the expression.
getCost() - Method in class org.h2.expression.ExpressionColumn
 
getCost() - Method in class org.h2.expression.ExpressionList
 
getCost() - Method in class org.h2.expression.function.CurrentDateTimeValueFunction
 
getCost() - Method in class org.h2.expression.function.CurrentGeneralValueSpecification
 
getCost() - Method in class org.h2.expression.function.Function0_1
 
getCost() - Method in class org.h2.expression.function.JavaFunction
 
getCost() - Method in class org.h2.expression.function.SysInfoFunction
 
getCost() - Method in class org.h2.expression.Operation1_2
 
getCost() - Method in class org.h2.expression.Operation1
 
getCost() - Method in class org.h2.expression.Operation2
 
getCost() - Method in class org.h2.expression.OperationN
 
getCost() - Method in class org.h2.expression.Parameter
 
getCost() - Method in class org.h2.expression.Rownum
 
getCost() - Method in class org.h2.expression.SequenceValue
 
getCost() - Method in class org.h2.expression.SimpleCase
 
getCost() - Method in class org.h2.expression.Subquery
 
getCost() - Method in class org.h2.expression.ValueExpression
 
getCost() - Method in class org.h2.expression.Variable
 
getCost() - Method in class org.h2.expression.Wildcard
 
getCost() - Method in class org.h2.mode.OnDuplicateKeyValues
 
getCost() - Method in class org.h2.mode.Regclass
 
getCost(SessionLocal, int[], TableFilter[], int, SortOrder, AllColumnsForPlan) - Method in class org.h2.index.DualIndex
 
getCost(SessionLocal, int[], TableFilter[], int, SortOrder, AllColumnsForPlan) - Method in class org.h2.index.Index
Estimate the cost to search for rows given the search mask.
getCost(SessionLocal, int[], TableFilter[], int, SortOrder, AllColumnsForPlan) - Method in class org.h2.index.LinkedIndex
 
getCost(SessionLocal, int[], TableFilter[], int, SortOrder, AllColumnsForPlan) - Method in class org.h2.index.MetaIndex
 
getCost(SessionLocal, int[], TableFilter[], int, SortOrder, AllColumnsForPlan) - Method in class org.h2.index.RangeIndex
 
getCost(SessionLocal, int[], TableFilter[], int, SortOrder, AllColumnsForPlan) - Method in class org.h2.index.ViewIndex
 
getCost(SessionLocal, int[], TableFilter[], int, SortOrder, AllColumnsForPlan) - Method in class org.h2.index.VirtualConstructedTableIndex
 
getCost(SessionLocal, int[], TableFilter[], int, SortOrder, AllColumnsForPlan) - Method in class org.h2.mvstore.db.MVDelegateIndex
 
getCost(SessionLocal, int[], TableFilter[], int, SortOrder, AllColumnsForPlan) - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
getCost(SessionLocal, int[], TableFilter[], int, SortOrder, AllColumnsForPlan) - Method in class org.h2.mvstore.db.MVSecondaryIndex
 
getCost(SessionLocal, int[], TableFilter[], int, SortOrder, AllColumnsForPlan) - Method in class org.h2.mvstore.db.MVSpatialIndex
 
getCostAsExpression() - Method in class org.h2.command.query.Query
Calculate the cost when used as a subquery.
getCostRangeIndex(int[], long, TableFilter[], int, SortOrder, boolean, AllColumnsForPlan) - Method in class org.h2.index.Index
Calculate the cost for the given mask as if this index was a typical b-tree range index.
getCostRangeIndex(int[], Column[]) - Static method in class org.h2.mvstore.db.MVSpatialIndex
Compute spatial index cost
getCount() - Method in class org.h2.expression.aggregate.AggregateDataCollecting
Returns the count of values.
getCount() - Method in class org.h2.value.ExtTypeInfoEnum
Get count of elements in enumeration.
getCounter(long) - Static method in class org.h2.util.MemoryEstimator
 
getCounts(int) - Method in class org.h2.mvstore.Page
Get the number of key-value pairs for a given child.
getCounts(int) - Method in class org.h2.mvstore.Page.Leaf
 
getCounts(int) - Method in class org.h2.mvstore.Page.NonLeaf
 
getCreateOrder() - Method in class org.h2.engine.MetaRecord
Get the sort order id for this object type.
getCreateSQL() - Method in class org.h2.constraint.ConstraintCheck
 
getCreateSQL() - Method in class org.h2.constraint.ConstraintDomain
 
getCreateSQL() - Method in class org.h2.constraint.ConstraintReferential
 
getCreateSQL() - Method in class org.h2.constraint.ConstraintUnique
 
getCreateSQL() - Method in class org.h2.engine.Comment
 
getCreateSQL() - Method in class org.h2.engine.DbObject
Construct the CREATE ...
getCreateSQL() - Method in class org.h2.engine.Right
 
getCreateSQL() - Method in class org.h2.engine.Role
 
getCreateSQL() - Method in class org.h2.engine.Setting
 
getCreateSQL() - Method in class org.h2.engine.User
 
getCreateSQL() - Method in class org.h2.index.DualIndex
 
getCreateSQL() - Method in class org.h2.index.Index
 
getCreateSQL() - Method in class org.h2.index.LinkedIndex
 
getCreateSQL() - Method in class org.h2.index.MetaIndex
 
getCreateSQL() - Method in class org.h2.index.RangeIndex
 
getCreateSQL() - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
getCreateSQL() - Method in class org.h2.schema.Constant
 
getCreateSQL() - Method in class org.h2.schema.Domain
 
getCreateSQL() - Method in class org.h2.schema.FunctionAlias
 
getCreateSQL() - Method in class org.h2.schema.Schema
 
getCreateSQL() - Method in class org.h2.schema.Sequence
 
getCreateSQL() - Method in class org.h2.schema.TriggerObject
 
getCreateSQL() - Method in class org.h2.schema.UserAggregate
 
getCreateSQL() - Method in class org.h2.table.Column
 
getCreateSQL() - Method in class org.h2.table.MetaTable
 
getCreateSQL() - Method in class org.h2.table.TableBase
 
getCreateSQL() - Method in class org.h2.table.TableLink
 
getCreateSQL() - Method in class org.h2.table.TableSynonym
 
getCreateSQL() - Method in class org.h2.table.TableView
 
getCreateSQL() - Method in class org.h2.table.VirtualTable
 
getCreateSQL(boolean) - Method in class org.h2.engine.Role
Get the CREATE SQL statement for this object.
getCreateSQL(boolean) - Method in class org.h2.engine.User
Get the CREATE SQL statement for this object.
getCreateSQL(boolean) - Method in class org.h2.table.Column
Get this columns part of CREATE TABLE SQL statement.
getCreateSQL(boolean) - Method in class org.h2.table.TableBase
 
getCreateSQL(boolean, boolean) - Method in class org.h2.table.TableView
Generate "CREATE" SQL statement for the view.
getCreateSQL(boolean, boolean, String) - Method in class org.h2.table.TableView
 
getCreateSQL(StringBuilder, boolean) - Method in class org.h2.table.Column
 
getCreateSQLForCopy(DbObject) - Method in class org.h2.engine.Right
 
getCreateSQLForCopy(Table, String) - Method in class org.h2.constraint.ConstraintCheck
 
getCreateSQLForCopy(Table, String) - Method in class org.h2.constraint.ConstraintDomain
 
getCreateSQLForCopy(Table, String) - Method in class org.h2.constraint.ConstraintReferential
Create the SQL statement of this object so a copy of the table can be made.
getCreateSQLForCopy(Table, String) - Method in class org.h2.constraint.ConstraintUnique
 
getCreateSQLForCopy(Table, String) - Method in class org.h2.engine.Comment
 
getCreateSQLForCopy(Table, String) - Method in class org.h2.engine.DbObject
Build a SQL statement to re-create the object, or to create a copy of the object with a different name or referencing a different table
getCreateSQLForCopy(Table, String) - Method in class org.h2.engine.Right
 
getCreateSQLForCopy(Table, String) - Method in class org.h2.engine.Role
 
getCreateSQLForCopy(Table, String) - Method in class org.h2.engine.Setting
 
getCreateSQLForCopy(Table, String) - Method in class org.h2.engine.User
 
getCreateSQLForCopy(Table, String) - Method in class org.h2.index.Index
 
getCreateSQLForCopy(Table, String) - Method in class org.h2.schema.Constant
 
getCreateSQLForCopy(Table, String) - Method in class org.h2.schema.Domain
 
getCreateSQLForCopy(Table, String) - Method in class org.h2.schema.Schema
 
getCreateSQLForCopy(Table, String) - Method in class org.h2.schema.Sequence
 
getCreateSQLForCopy(Table, String) - Method in class org.h2.schema.TriggerObject
 
getCreateSQLForCopy(Table, String) - Method in class org.h2.schema.UserDefinedFunction
 
getCreateSQLForCopy(Table, String) - Method in class org.h2.table.Table
 
getCreateSQLForCopy(Table, String) - Method in class org.h2.table.TableSynonym
 
getCreateSQLForCopy(Table, String) - Method in class org.h2.table.TableView
 
getCreateSQLForCopy(Table, String, boolean) - Method in class org.h2.constraint.ConstraintUnique
 
getCreateSQLForCopy(Table, Table, String, boolean) - Method in class org.h2.constraint.ConstraintReferential
Create the SQL statement of this object so a copy of the table can be made.
getCreateSQLForMeta() - Method in class org.h2.engine.DbObject
Construct the CREATE ...
getCreateSQLForMeta() - Method in class org.h2.table.TableBase
 
getCreateSQLWithoutIndexes() - Method in class org.h2.constraint.Constraint
Get the SQL statement to create this constraint.
getCreateSQLWithoutIndexes() - Method in class org.h2.constraint.ConstraintCheck
 
getCreateSQLWithoutIndexes() - Method in class org.h2.constraint.ConstraintDomain
 
getCreateSQLWithoutIndexes() - Method in class org.h2.constraint.ConstraintReferential
 
getCreateSQLWithoutIndexes() - Method in class org.h2.constraint.ConstraintUnique
 
getCreateSQLWithoutName() - Method in class org.h2.table.Column
 
getCreateVersion() - Method in class org.h2.mvstore.MVMap
 
getCrossReference(String, String, String, String, String, String) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the list of foreign key columns that references a table, as well as the list of primary key columns that are references by a table.
getCrossReference(String, String, String, String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getCrossReference(String, String, String, String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getCrossReference(String, String, String, String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getCrossReference(String, String, String, String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getCteCleanups() - Method in class org.h2.command.Prepared
 
getCumeDist(HashMap<Integer, Value>, ArrayList<Value[]>, int) - Method in class org.h2.expression.analysis.WindowFunction
 
getCumeDist(Value[], Value, Comparator<Value>) - Static method in class org.h2.expression.aggregate.Aggregate
 
getCurrency() - Static method in class org.h2.expression.function.ToCharFunction
 
getCurrentCommand() - Method in class org.h2.engine.SessionLocal
 
getCurrentGroupExprData(Expression) - Method in class org.h2.command.query.SelectGroups
Get the group-by data for the current group and the passed in expression.
getCurrentGroupRowId() - Method in class org.h2.command.query.SelectGroups
Returns identity of the current row.
getCurrentId() - Method in class org.h2.engine.SessionRemote
 
getCurrentKey(SessionLocal) - Method in class org.h2.expression.analysis.Window
Returns the key for the current group.
getCurrentMonth() - Method in class org.h2.mode.ToDateParser
 
getCurrentPrepared() - Method in class org.h2.command.Parser
 
getCurrentResult() - Method in class org.h2.index.IndexCondition
Get the current result of the expression.
getCurrentRowNumber() - Method in class org.h2.command.Prepared
Get the current row number.
getCurrentSchemaName() - Method in class org.h2.engine.Session
Get current schema.
getCurrentSchemaName() - Method in class org.h2.engine.SessionLocal
 
getCurrentSchemaName() - Method in class org.h2.engine.SessionRemote
 
getCurrentStart(Sequence, SessionLocal) - Method in class org.h2.command.ddl.SequenceOptions
 
getCurrentValue() - Method in class org.h2.mvstore.tx.VersionedValueCommitted
 
getCurrentValue() - Method in class org.h2.schema.Sequence
 
getCurrentValue() - Method in class org.h2.value.VersionedValue
 
getCurrentValue(SessionLocal) - Method in class org.h2.index.IndexCondition
Get the current value of the expression.
getCurrentValueFor(Sequence) - Method in class org.h2.engine.SessionLocal
Returns the current value of the sequence in this session.
getCurrentValueList(SessionLocal) - Method in class org.h2.index.IndexCondition
Get the current value list of the expression.
getCurrentVersion() - Method in class org.h2.mvstore.MVStore
Get the current version of the data.
getCurrentYear() - Method in class org.h2.mode.ToDateParser
 
getCursorName() - Method in class org.h2.jdbc.JdbcResultSet
[Not supported] Gets the cursor name if it was defined.
getCursorName() - Method in class org.h2.tools.SimpleResultSet
INTERNAL
getCycle() - Method in class org.h2.command.ddl.SequenceOptions
Gets cycle option.
getCycle() - Method in class org.h2.schema.Sequence
 
getData() - Method in class org.h2.expression.analysis.PartitionData
Returns the aggregate data.
getDatabase() - Method in class org.h2.engine.DbObject
Get the database.
getDatabase() - Method in class org.h2.engine.SessionLocal
 
getDatabaseFiles(String, String, boolean) - Static method in class org.h2.store.FileLister
Get the list of database files.
getDatabaseMajorVersion() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the major version of the database.
getDatabaseMajorVersion() - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getDatabaseMajorVersion() - Method in class org.h2.jdbc.meta.DatabaseMetaLocalBase
 
getDatabaseMajorVersion() - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getDatabaseMeta() - Method in class org.h2.engine.Session
Returns database meta information.
getDatabaseMeta() - Method in class org.h2.engine.SessionLocal
 
getDatabaseMeta() - Method in class org.h2.engine.SessionRemote
 
getDatabaseMinorVersion() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the minor version of the database.
getDatabaseMinorVersion() - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getDatabaseMinorVersion() - Method in class org.h2.jdbc.meta.DatabaseMetaLocalBase
 
getDatabaseMinorVersion() - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getDatabaseNameFromFileName(String) - Static method in class org.h2.tools.Restore
Extract the name of the database from a given file name.
getDatabasePath() - Method in class org.h2.engine.Database
 
getDatabasePath() - Method in class org.h2.engine.SessionRemote
 
getDatabasePath() - Method in interface org.h2.store.DataHandler
Get the database path.
getDatabasePath() - Method in class org.h2.tools.Recover
INTERNAL
getDatabaseProductName() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the database product name.
getDatabaseProductVersion() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the product version of the database.
getDatabaseProductVersion() - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getDatabaseProductVersion() - Method in class org.h2.jdbc.meta.DatabaseMetaLocalBase
 
getDatabaseProductVersion() - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getDataConversionError(int) - Method in class org.h2.value.Value
Creates new instance of the DbException for data conversion error.
getDataConversionError(TypeInfo) - Method in class org.h2.value.Value
Creates new instance of the DbException for data conversion error.
getDataConversionError(Value, DbException) - Method in class org.h2.table.Column
 
getDataHandler() - Method in class org.h2.engine.Session
Get the data handler object.
getDataHandler() - Method in class org.h2.engine.SessionLocal
 
getDataHandler() - Method in class org.h2.engine.SessionRemote
 
getDataHandler() - Method in class org.h2.value.lob.LobData
 
getDataHandler() - Method in class org.h2.value.lob.LobDataDatabase
 
getDataHandler() - Method in class org.h2.value.lob.LobDataFetchOnDemand
 
getDataHandler() - Method in class org.h2.value.lob.LobDataFile
 
getDataType() - Method in class org.h2.bnf.context.DbColumn
 
getDataType() - Method in class org.h2.command.ddl.SequenceOptions
 
getDataType() - Method in class org.h2.schema.Domain
 
getDataType() - Method in class org.h2.schema.FunctionAlias.JavaMethod
Returns data type information for regular functions or null for table value functions.
getDataType() - Method in class org.h2.schema.Sequence
 
getDataType(int) - Static method in class org.h2.value.DataType
Get the data type object for the given value type.
getDataTypeCombinationException(int, int) - Static method in class org.h2.value.Value
 
getDataTypeName(TypeInfo) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getDataTypeRegistrationKey(DataType<?>) - Static method in class org.h2.mvstore.tx.TransactionStore.TxMapBuilder
 
getDate(int) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a java.sql.Date.
getDate(int) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a java.sql.Date.
getDate(int) - Method in class org.h2.tools.SimpleResultSet
Returns the value as an java.sql.Date.
getDate(int, Calendar) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a java.sql.Date using a specified time zone.
getDate(int, Calendar) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a java.sql.Date using a specified time zone.
getDate(int, Calendar) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
getDate(String) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a java.sql.Date.
getDate(String) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a java.sql.Date.
getDate(String) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a java.sql.Date.
getDate(String, Calendar) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a java.sql.Date using a specified time zone.
getDate(String, Calendar) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a java.sql.Date using a specified time zone.
getDate(String, Calendar) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
GETDATE - Static variable in class org.h2.mode.FunctionsMSSQLServer
 
getDateFormat(String, String, String) - Static method in class org.h2.expression.function.DateTimeFormatFunction
 
getDateNames(int) - Static method in class org.h2.expression.function.ToCharFunction
Get the date (month / weekday / ...) names.
getDateTimeWithInterval(SessionLocal, Value, Value, int, int) - Method in class org.h2.expression.IntervalOperation
 
getDateValue() - Method in class org.h2.value.ValueDate
 
getDateValue() - Method in class org.h2.value.ValueTimestamp
A bit field with bits for the year, month, and day (see DateTimeUtils for encoding).
getDateValue() - Method in class org.h2.value.ValueTimestampTimeZone
A bit field with bits for the year, month, and day (see DateTimeUtils for encoding).
getDayOfWeek(long, int) - Static method in class org.h2.util.DateTimeUtils
Returns day of week.
getDayOfWeekFromAbsolute(long, int) - Static method in class org.h2.util.DateTimeUtils
Get the day of the week from the absolute day value.
getDayOfYear(long) - Static method in class org.h2.util.DateTimeUtils
Returns number of day in year.
getDays() - Method in class org.h2.api.Interval
Returns days value, if any.
getDaysInMonth(int, int) - Static method in class org.h2.util.DateTimeUtils
Returns number of days in month.
getDbSettings() - Method in class org.h2.engine.ConnectionInfo
 
getDeadlockDetails(ArrayList<SessionLocal>, int) - Static method in class org.h2.mvstore.db.MVTable
Formats details of a deadlock.
getDec(int) - Static method in class org.h2.security.AES
 
getDecimalPrecision() - Method in class org.h2.value.TypeInfo
Returns approximate precision in decimal digits for binary numeric data types and precision for all other types.
getDecision() - Method in class org.h2.mvstore.MVMap.EqualsDecisionMaker
 
getDecision() - Method in class org.h2.mvstore.MVMap.RewriteDecisionMaker
 
getDecision() - Method in class org.h2.mvstore.tx.TxDecisionMaker
 
getDeclaredPrecision() - Method in class org.h2.value.TypeInfo
Returns the precision, or -1L if not specified in data type definition.
getDeclaredScale() - Method in class org.h2.value.TypeInfo
Returns the scale, or -1 if not specified in data type definition.
getDeclaredTypeName() - Method in class org.h2.value.TypeInfo
Returns the declared name of this data type with precision, scale, length, cardinality etc.
getDecrementQueryLevelVisitor(HashSet<ColumnResolver>, int) - Static method in class org.h2.expression.ExpressionVisitor
Create a new visitor to decrement query level in columns with the specified resolvers.
getDefault() - Static method in class org.h2.util.TimeZoneProvider
Returns the time zone provider for the system default time zone.
getDefaultClass(int, boolean) - Static method in class org.h2.value.ValueToObjectConverter
Get the name of the Java class for the given value type.
getDefaultExpression() - Method in class org.h2.schema.Domain
 
getDefaultExpression() - Method in class org.h2.table.Column
 
getDefaultExpression() - Method in interface org.h2.table.ColumnTemplate
 
getDefaultFormatStr() - Method in enum org.h2.mode.ToDateParser.ConfigParam
 
getDefaultForPrimitiveType(Class<?>) - Static method in class org.h2.value.DataType
Get the default value in the form of a Java object for the given Java class.
getDefaultMaxLength() - Method in class org.h2.store.fs.split.FilePathSplit
 
getDefaultMaxValue(Long, long, long[]) - Static method in class org.h2.schema.Sequence
Calculates default max value.
getDefaultMinValue(Long, long, long[]) - Static method in class org.h2.schema.Sequence
Calculates default min value.
getDefaultNullOrdering() - Method in class org.h2.engine.Database
 
getDefaultOrGenerated(SessionLocal, Row) - Method in class org.h2.table.Column
 
getDefaultRetentionTime() - Method in class org.h2.mvstore.FileStore
Get the default retention time for this store in milliseconds.
getDefaultRetentionTime() - Method in class org.h2.mvstore.OffHeapStore
 
getDefaultRowFactory() - Static method in class org.h2.result.RowFactory
 
getDefaultSchema() - Method in class org.h2.bnf.context.DbContents
 
getDefaultSchemaName(DatabaseMetaData) - Method in class org.h2.bnf.context.DbContents
 
getDefaultSQL() - Method in class org.h2.schema.Domain
 
getDefaultSQL() - Method in class org.h2.table.Column
 
getDefaultSQL() - Method in interface org.h2.table.ColumnTemplate
 
getDefaultTableType() - Method in class org.h2.engine.Database
 
getDefaultTransactionIsolation() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the default transaction isolation level.
getDelegatedValue(Column) - Method in class org.h2.table.TableFilter
 
getDelete(SessionLocal) - Method in class org.h2.constraint.ConstraintReferential
 
getDeleteAction() - Method in class org.h2.constraint.ConstraintReferential
 
getDependencies() - Method in class org.h2.command.Command
 
getDependencies() - Method in class org.h2.command.CommandContainer
 
getDependencies() - Method in class org.h2.command.CommandList
 
getDependencies() - Method in class org.h2.expression.ExpressionVisitor
Get the dependency set.
getDependenciesVisitor(HashSet<DbObject>) - Static method in class org.h2.expression.ExpressionVisitor
Create a new visitor object to collect dependencies.
getDependentTable(SchemaObject, Table) - Method in class org.h2.engine.Database
Get the first table that depends on this object.
getDependentViews() - Method in class org.h2.table.Table
 
getDescription() - Method in class org.h2.jdbcx.JdbcDataSource
Get the current description.
getDescription(MBeanAttributeInfo) - Method in class org.h2.jmx.DocumentedMBean
 
getDescription(MBeanInfo) - Method in class org.h2.jmx.DocumentedMBean
 
getDescription(MBeanOperationInfo) - Method in class org.h2.jmx.DocumentedMBean
 
getDifference(String, String) - Static method in class org.h2.expression.function.SoundexFunction
 
getDimensionSystem() - Method in class org.h2.util.geometry.GeometryUtils.DimensionSystemTarget
Returns the minimal dimension system.
getDimensionSystem() - Method in class org.h2.value.ValueGeometry
Return a minimal dimension system that can be used for this geometry.
getDimensionSystem(byte[]) - Static method in class org.h2.util.geometry.EWKBUtils
Reads the dimension system from EWKB.
getDimensionSystem(String) - Static method in class org.h2.util.geometry.EWKTUtils
Reads the dimension system from EWKT.
getDimensionSystem(Geometry) - Static method in class org.h2.util.geometry.JTSUtils
Determines a dimension system of a JTS Geometry object.
getDimensionSystem1(Geometry) - Static method in class org.h2.util.geometry.JTSUtils
 
getDimensionSystemFromCoordinate(CoordinateSequence, int) - Static method in class org.h2.util.geometry.JTSUtils
 
getDimensionSystemFromSequence(CoordinateSequence) - Static method in class org.h2.util.geometry.JTSUtils
 
getDir(String) - Static method in class org.h2.store.FileLister
Normalize the directory name.
getDiskSpaceUsed() - Method in class org.h2.index.Index
Get the used disk space for this index.
getDiskSpaceUsed() - Method in class org.h2.index.MetaIndex
 
getDiskSpaceUsed() - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
getDiskSpaceUsed() - Method in class org.h2.mvstore.db.MVSecondaryIndex
 
getDiskSpaceUsed() - Method in class org.h2.mvstore.db.MVSpatialIndex
 
getDiskSpaceUsed() - Method in class org.h2.mvstore.db.MVTable
 
getDiskSpaceUsed() - Method in class org.h2.mvstore.Page
Amount of used disk space in persistent case including child pages.
getDiskSpaceUsed() - Method in class org.h2.table.Table
 
getDisplaySize() - Method in class org.h2.value.TypeInfo
Returns the display size in characters.
getDisplaySize(int, int, int) - Static method in class org.h2.value.ValueInterval
Returns display size for the specified qualifier, precision and fractional seconds precision.
getDistinctRow(Value[]) - Method in class org.h2.result.LocalResult
 
getDomain() - Method in class org.h2.constraint.ConstraintDomain
Returns the domain of this constraint.
getDomain() - Method in class org.h2.schema.Domain
 
getDomain() - Method in class org.h2.table.Column
 
getDomain() - Method in interface org.h2.table.ColumnTemplate
 
getDomain(String) - Method in class org.h2.schema.Schema
Get the domain with the given name.
getDouble() - Method in class org.h2.value.Value
Returns this value as a Java double value.
getDouble() - Method in class org.h2.value.ValueBigint
 
getDouble() - Method in class org.h2.value.ValueBoolean
 
getDouble() - Method in class org.h2.value.ValueDecfloat
 
getDouble() - Method in class org.h2.value.ValueDouble
 
getDouble() - Method in class org.h2.value.ValueEnumBase
 
getDouble() - Method in class org.h2.value.ValueInteger
 
getDouble() - Method in class org.h2.value.ValueInterval
 
getDouble() - Method in class org.h2.value.ValueNull
 
getDouble() - Method in class org.h2.value.ValueNumeric
 
getDouble() - Method in class org.h2.value.ValueReal
 
getDouble() - Method in class org.h2.value.ValueSmallint
 
getDouble() - Method in class org.h2.value.ValueStringBase
 
getDouble() - Method in class org.h2.value.ValueTinyint
 
getDouble(int) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a double.
getDouble(int) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a double.
getDouble(int) - Method in class org.h2.tools.SimpleResultSet
Returns the value as an double.
getDouble(String) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a double.
getDouble(String) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a double.
getDouble(String) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a double.
getDoubleInternal(int) - Method in class org.h2.jdbc.JdbcResultSet
 
getDriver(String) - Static method in class org.h2.util.JdbcUtils
Get the driver class name for the given URL, or null if the URL is unknown.
getDriverMajorVersion() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the major version of this driver.
getDriverMinorVersion() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the minor version of this driver.
getDriverName() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the name of the JDBC driver.
getDriverVersion() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the version number of the driver.
getDropSQL() - Method in class org.h2.engine.DbObject
Construct a DROP ...
getDropSQL() - Method in class org.h2.schema.Domain
 
getDropSQL() - Method in class org.h2.schema.FunctionAlias
 
getDropSQL() - Method in class org.h2.schema.Sequence
 
getDropSQL() - Method in class org.h2.schema.UserAggregate
 
getDropSQL() - Method in class org.h2.table.TableBase
 
getDropSQL() - Method in class org.h2.table.TableLink
 
getDropSQL() - Method in class org.h2.table.TableSynonym
 
getDropSQL() - Method in class org.h2.table.TableView
 
getDuplicateKeyException(String) - Method in class org.h2.index.Index
Create a duplicate key exception with a message that contains the index name.
getDuplicatePrimaryKeyMessage(int) - Method in class org.h2.index.Index
Get "PRIMARY KEY ON <table> [(column)]".
getDynamicSettings() - Method in class org.h2.engine.Session
Returns dynamic settings.
getDynamicSettings() - Method in class org.h2.engine.SessionLocal
 
getDynamicSettings() - Method in class org.h2.engine.SessionRemote
 
getEffectiveDefaultExpression() - Method in class org.h2.schema.Domain
 
getEffectiveDefaultExpression() - Method in class org.h2.table.Column
 
getEffectiveDefaultExpression() - Method in interface org.h2.table.ColumnTemplate
 
getEffectiveFilter() - Method in class org.h2.expression.aggregate.ListaggArguments
Returns the effective LISTAGG truncation filter.
getEffectiveOnUpdateExpression() - Method in class org.h2.schema.Domain
 
getEffectiveOnUpdateExpression() - Method in class org.h2.table.Column
 
getEffectiveOnUpdateExpression() - Method in interface org.h2.table.ColumnTemplate
 
getEffectivePrecision() - Method in class org.h2.schema.Sequence
 
getEffectiveSeparator() - Method in class org.h2.expression.aggregate.ListaggArguments
Returns the effective LISTAGG separator.
getEmptyResult() - Method in class org.h2.command.query.SelectUnion
 
getEnclosedSQL(StringBuilder, int) - Method in class org.h2.expression.Expression
Get the SQL statement of this expression.
getEncoding() - Method in class org.h2.server.pg.PgServerThread
 
getEncryptedFile() - Method in class org.h2.mvstore.FileStore
Get the encrypted file instance, if encryption is used.
getEnd() - Method in class org.h2.index.IndexCursor
Get end search row.
getEndIndex(SessionLocal, ArrayList<Value[]>, SortOrder, int) - Method in class org.h2.expression.analysis.WindowFrame
Returns end index of this frame,
getEndIndex(Window, SessionLocal, ArrayList<Value[]>, SortOrder, int) - Static method in class org.h2.expression.analysis.WindowFrame
Returns end index for the specified frame, or default end index if frame is null.
getEntryName() - Method in class org.h2.store.fs.zip.FilePathZip
 
getEnum() - Method in class org.h2.engine.Mode
 
getEnumerator(int) - Method in class org.h2.value.ExtTypeInfoEnum
Returns an enumerator with specified 0-based ordinal value.
getEnumerators() - Method in class org.h2.value.ValueEnum
 
getEnumeratorsForBinaryOperation(Value, Value) - Static method in class org.h2.value.ExtTypeInfoEnum
Returns enumerators for the two specified values for a binary operation.
getEnvelope() - Method in class org.h2.util.geometry.GeometryUtils.EnvelopeTarget
Returns the envelope.
getEnvelope(byte[]) - Static method in class org.h2.util.geometry.GeometryUtils
Calculates an envelope of a specified geometry.
getEnvelopeNoCopy() - Method in class org.h2.value.ValueGeometry
Return an envelope of this geometry.
getEnvelopeUnion(ValueGeometry) - Method in class org.h2.value.ValueGeometry
Get the union.
getEpochSeconds(long, long, int) - Static method in class org.h2.util.DateTimeUtils
Calculates the seconds since epoch for the specified date value, nanoseconds since midnight, and time zone offset.
getEpochSecondsFromLocal(long, long) - Method in class org.h2.util.TimeZoneProvider
Calculates the epoch seconds from local date and time.
getEpochSecondsFromLocal(long, long) - Method in class org.h2.util.TimeZoneProvider.Simple
 
getEpochSecondsFromLocal(long, long) - Method in class org.h2.util.TimeZoneProvider.WithTimeZone
 
getErrorCode() - Method in interface org.h2.jdbc.JdbcException
Returns the H2-specific error code.
getErrorCode() - Method in exception org.h2.message.DbException
Get the error code.
getErrorCode() - Method in exception org.h2.mvstore.MVStoreException
 
getErrorExecutingTrigger(Throwable) - Method in class org.h2.schema.TriggerObject
 
getEscapeChar(String) - Static method in class org.h2.expression.condition.CompareLike
 
getEscapeChar(Value) - Method in class org.h2.expression.condition.CompareLike
 
getEscapeCharacter() - Method in class org.h2.tools.Csv
Get the current escape character.
getEstimatedBounds(SessionLocal) - Method in class org.h2.mvstore.db.MVSpatialIndex
Returns the estimated minimum bounding box that encloses all keys.
getEventText() - Method in enum org.h2.mvstore.db.MVTable.TraceLockEvent
 
getExceptColumns() - Method in class org.h2.expression.Wildcard
 
getException() - Method in class org.h2.util.Task
Get the exception that was thrown in the call (if any).
getExceptionAlreadyInUse(String) - Method in class org.h2.store.FileLock
 
getExceptionFatal(String, Throwable) - Static method in class org.h2.store.FileLock
 
getExclusion() - Method in class org.h2.expression.analysis.WindowFrame
Returns the exclusion clause.
getExclusiveSession() - Method in class org.h2.engine.Database
 
getExecutionTimeStandardDeviation() - Method in class org.h2.engine.QueryStatisticsData.QueryEntry
 
getExportedKeys(String, String, String) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the list of foreign key columns that reference a table.
getExportedKeys(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getExportedKeys(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getExportedKeys(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getExportedKeys(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getExpression() - Method in class org.h2.constraint.Constraint
Returns the CHECK expression or null.
getExpression() - Method in class org.h2.constraint.ConstraintCheck
 
getExpression() - Method in class org.h2.constraint.ConstraintDomain
 
getExpression() - Method in class org.h2.index.IndexCondition
Get expression.
getExpressionIndex() - Method in class org.h2.expression.analysis.WindowFrameBound
Returns the index of preserved expression.
getExpressionList() - Method in class org.h2.index.IndexCondition
Get expression list.
getExpressionQuery() - Method in class org.h2.index.IndexCondition
Get expression query.
getExpressions() - Method in class org.h2.command.query.Query
The the list of select expressions.
getExternalNames() - Method in class org.h2.server.web.WebServer
 
getExtraArguments() - Method in class org.h2.expression.aggregate.Aggregate
Returns the additional arguments.
getExtraNameCharacters() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the characters that are allowed for identifiers in addiction to A-Z, a-z, 0-9 and '_'.
getExtremes(ArrayList<Object>) - Method in class org.h2.mvstore.rtree.SpatialDataType
Get the most extreme pair (elements that are as far apart as possible).
getExtTypeInfo() - Method in class org.h2.value.TypeInfo
Returns the extended type information, or null.
getFactory() - Method in class org.h2.mvstore.db.RowDataType
 
getFactory() - Method in class org.h2.mvstore.db.ValueDataType
 
getFactory() - Method in class org.h2.mvstore.tx.VersionedValueType
 
getFactory() - Method in interface org.h2.mvstore.type.StatefulDataType
 
getFetch() - Method in class org.h2.command.query.Query
 
getFetchDirection() - Method in class org.h2.jdbc.JdbcResultSet
Gets the fetch direction.
getFetchDirection() - Method in class org.h2.jdbc.JdbcStatement
Gets the fetch direction.
getFetchDirection() - Method in class org.h2.tools.SimpleResultSet
Returns ResultSet.FETCH_FORWARD.
getFetchSize() - Method in class org.h2.jdbc.JdbcResultSet
Gets the number of rows suggested to read in one step.
getFetchSize() - Method in class org.h2.jdbc.JdbcStatement
Gets the number of rows suggested to read in one step.
getFetchSize() - Method in class org.h2.result.LazyResult
 
getFetchSize() - Method in class org.h2.result.LocalResult
 
getFetchSize() - Method in interface org.h2.result.ResultInterface
Get the current fetch size for this result set.
getFetchSize() - Method in class org.h2.result.ResultRemote
 
getFetchSize() - Method in class org.h2.result.ResultWithPaddedStrings
 
getFetchSize() - Method in class org.h2.result.SimpleResult
 
getFetchSize() - Method in class org.h2.table.TableLink
The number of rows to fetch default is 0
getFetchSize() - Method in class org.h2.tools.SimpleResultSet
Returns 0.
getField(String) - Static method in class org.h2.expression.function.DateTimeFunction
Get date-time field for the specified name.
getFieldDelimiter() - Method in class org.h2.tools.Csv
Get the current field delimiter.
getFieldName(int) - Static method in class org.h2.expression.function.DateTimeFunction
Get the name of the specified date-time field.
getFields() - Method in class org.h2.value.ExtTypeInfoRow
Returns fields.
getFieldSeparatorRead() - Method in class org.h2.tools.Csv
Get the current field separator for reading.
getFieldSeparatorWrite() - Method in class org.h2.tools.Csv
Get the current field separator for writing.
getFile() - Method in class org.h2.mvstore.FileStore
Get the file instance in use.
getFile(String) - Method in class org.h2.server.web.WebServer
Read the given file from the file system or from the resources.
getFileChannel(long) - Method in class org.h2.store.fs.split.FileSplit
 
getFileChannel(String, String, byte[]) - Static method in class org.h2.tools.ChangeFileEncryption
 
getFileEncryptionKey() - Method in class org.h2.engine.ConnectionInfo
 
getFileEncryptionKey() - Method in class org.h2.engine.Database
 
getFileLengthInUse() - Method in class org.h2.mvstore.FileStore
 
getFileLengthInUse() - Method in class org.h2.mvstore.MVStore
Get the position right after the last used byte.
getFileLockMethod(String) - Static method in class org.h2.store.FileLock
Get the file locking method type given a method name.
getFileName() - Method in class org.h2.command.dml.ScriptBase
 
getFileName() - Method in class org.h2.mvstore.FileStore
Get the file name.
getFileName() - Method in class org.h2.server.web.WebServer.TranslateThread
 
getFilePasswordHash() - Method in class org.h2.engine.ConnectionInfo
Get the file password hash if it is set.
getFilePointer() - Method in class org.h2.store.FileStore
Get the current location of the file pointer.
getFilePrefix(String) - Method in class org.h2.engine.SessionRemote
 
getFileReadCount() - Method in class org.h2.jmx.DatabaseInfo
 
getFileReadCount() - Method in interface org.h2.jmx.DatabaseInfoMBean
The file read count since the database was opened.
getFileSize() - Method in class org.h2.jmx.DatabaseInfo
 
getFileSize() - Method in interface org.h2.jmx.DatabaseInfoMBean
The database file size in KB.
getFileStore() - Method in class org.h2.mvstore.MVStore
Get the file store.
getFileVersionError(String) - Static method in exception org.h2.message.DbException
Gets a file version exception.
getFileWriteCount() - Method in class org.h2.jmx.DatabaseInfo
 
getFileWriteCount() - Method in interface org.h2.jmx.DatabaseInfoMBean
The number of write operations since the database was opened.
getFillRate() - Method in class org.h2.mvstore.Chunk
Calculate the fill rate in %.
getFillRate() - Method in class org.h2.mvstore.FileStore
 
getFillRate() - Method in class org.h2.mvstore.FreeSpaceBitSet
Get the fill rate of the space in percent.
getFillRate() - Method in class org.h2.mvstore.MVStore
 
getFilter() - Method in class org.h2.expression.aggregate.ListaggArguments
Returns the LISTAGG truncation filter.
getFilterCondition() - Method in class org.h2.table.TableFilter
 
getFilters() - Method in class org.h2.table.Plan
The the list of tables.
getFilterSQL(StringBuilder, String, Expression[], Expression, int, int) - Static method in class org.h2.command.query.Select
 
getFilterSQL(StringBuilder, String, Expression, int) - Static method in class org.h2.command.query.Select
 
getFirst(String) - Method in class org.h2.util.json.JSONObject
Returns value of the first member with the specified name.
getFirstFree() - Method in class org.h2.mvstore.FileStore
 
getFirstFree() - Method in class org.h2.mvstore.FreeSpaceBitSet
Get the position of the first free space.
getFirstLast(boolean) - Method in class org.h2.mvstore.MVMap
Get the first (lowest) or last (largest) key.
getFirstLast(Page<K, V>, boolean) - Method in class org.h2.mvstore.MVMap
 
getFirstUserTable() - Method in class org.h2.engine.Database
Get the first user defined table, excluding the LOB_BLOCKS table that the Recover tool creates.
getFlags() - Method in class org.h2.expression.aggregate.Aggregate
 
getFlags() - Method in interface org.h2.expression.ExpressionWithFlags
Returns the flags.
getFlags() - Method in class org.h2.expression.function.JsonConstructorFunction
 
getFletcher32(byte[], int, int) - Static method in class org.h2.mvstore.DataUtils
Calculate the Fletcher32 checksum.
getFloat() - Method in class org.h2.value.Value
Returns this value as a Java float value.
getFloat() - Method in class org.h2.value.ValueBigint
 
getFloat() - Method in class org.h2.value.ValueBoolean
 
getFloat() - Method in class org.h2.value.ValueDecfloat
 
getFloat() - Method in class org.h2.value.ValueDouble
 
getFloat() - Method in class org.h2.value.ValueEnumBase
 
getFloat() - Method in class org.h2.value.ValueInteger
 
getFloat() - Method in class org.h2.value.ValueInterval
 
getFloat() - Method in class org.h2.value.ValueNull
 
getFloat() - Method in class org.h2.value.ValueNumeric
 
getFloat() - Method in class org.h2.value.ValueReal
 
getFloat() - Method in class org.h2.value.ValueSmallint
 
getFloat() - Method in class org.h2.value.ValueStringBase
 
getFloat() - Method in class org.h2.value.ValueTinyint
 
getFloat(int) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a float.
getFloat(int) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a float.
getFloat(int) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a float.
getFloat(String) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a float.
getFloat(String) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a float.
getFloat(String) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a float.
getFloatInternal(int) - Method in class org.h2.jdbc.JdbcResultSet
 
getFollowing() - Method in class org.h2.expression.analysis.WindowFrame
Returns the following clause.
getFooterBytes() - Method in class org.h2.mvstore.Chunk
 
getForcedTypeSQL(StringBuilder, TypeInfo) - Static method in class org.h2.expression.IntervalOperation
 
getFormatException() - Method in class org.h2.engine.ConnectionInfo
Generate a URL format exception.
getFormatException(String, int) - Static method in class org.h2.util.StringUtils
 
getFormatId() - Method in class org.h2.jdbcx.JdbcXid
Get the format id.
getFormatStr() - Method in class org.h2.mode.ToDateParser
 
getFromEWKB(byte[]) - Static method in class org.h2.value.ValueGeometry
Get or create a geometry value for the given EWKB value.
getFromGeometry(Object) - Static method in class org.h2.value.ValueGeometry
Get or create a geometry value for the given geometry.
getFromIndex(SessionLocal, Expression, int, ArrayList<QueryOrderBy>, BigDecimal, boolean) - Static method in class org.h2.expression.aggregate.Percentile
Get the result from the index.
getFromMap(String, String) - Static method in class org.h2.mvstore.DataUtils
Parse a specified pair from key-value pair list.
getFromSnapshot(K) - Method in class org.h2.mvstore.tx.TransactionMap
Get the value for the given key, or null if value does not exist in accordance with transactional rules.
getFromSnapshot(RootReference<K, VersionedValue<V>>, BitSet, K) - Method in class org.h2.mvstore.tx.TransactionMap
 
getFullyQualifiedName() - Method in class org.h2.security.auth.AuthenticationInfo
 
getFunction(String) - Static method in class org.h2.mode.FunctionsDB2Derby
Returns mode-specific function for a given name, or null.
getFunction(String) - Static method in class org.h2.mode.FunctionsLegacy
Returns mode-specific function for a given name, or null.
getFunction(String) - Static method in class org.h2.mode.FunctionsMSSQLServer
Returns mode-specific function for a given name, or null.
getFunction(String) - Static method in class org.h2.mode.FunctionsMySQL
Returns mode-specific function for a given name, or null.
getFunction(String) - Static method in class org.h2.mode.FunctionsOracle
Returns mode-specific function for a given name, or null.
getFunction(String) - Static method in class org.h2.mode.FunctionsPostgreSQL
Returns mode-specific function for a given name, or null.
getFunction(Database, String) - Static method in class org.h2.mode.ModeFunction
Get an instance of the given function for this database.
getFunctionAliasWithinPath(String, Schema) - Method in class org.h2.command.Parser
 
getFunctionColumns(String, String, String, String) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
[Not supported] Gets the list of function columns.
getFunctionColumns(String, String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getFunctionColumns(String, String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLocalBase
 
getFunctionColumns(String, String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getFunctionName() - Method in class org.h2.mode.ToDateParser
 
getFunctions(String) - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getFunctions(String) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getFunctions(String, String, String) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
[Not supported] Gets the list of functions.
getFunctions(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getFunctions(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLocalBase
 
getFunctions(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getFunctionType() - Method in class org.h2.expression.analysis.WindowFunction
Returns the type of this function.
getFunctionType() - Method in class org.h2.expression.function.table.ArrayTableFunction
 
getGarbageCollectionCount() - Static method in class org.h2.util.Utils
 
getGarbageCollectionTime() - Static method in class org.h2.util.Utils
 
getGeneratedKeys - Variable in class org.h2.jdbc.JdbcConnection
 
getGeneratedKeys() - Method in class org.h2.jdbc.JdbcPreparedStatement
 
getGeneratedKeys() - Method in class org.h2.jdbc.JdbcStatement
Return a result set with generated keys from the latest executed command or an empty result set if keys were not generated or were not requested with Statement.RETURN_GENERATED_KEYS, column indexes, or column names.
getGeneratedKeys() - Method in class org.h2.result.ResultWithGeneratedKeys
Returns generated keys, or null.
getGeneratedKeys() - Method in class org.h2.result.ResultWithGeneratedKeys.WithKeys
 
getGenericMapBuilder() - Static method in class org.h2.mvstore.MVStoreTool
 
getGeometry() - Method in class org.h2.util.geometry.JTSUtils.GeometryTarget
 
getGeometry() - Method in class org.h2.value.ValueGeometry
Get a copy of geometry object.
getGeometryColumnIndex(Expression) - Static method in class org.h2.expression.aggregate.AggregateDataEnvelope
Get the index (if any) for the column specified in the geometry aggregate.
getGeometryType() - Method in class org.h2.value.ValueGeometry
Returns geometry type.
getGlobalTransactionId() - Method in class org.h2.jdbcx.JdbcXid
The global transaction identifier.
getGrantedObject() - Method in class org.h2.engine.Right
 
getGrantedRole() - Method in class org.h2.engine.Right
 
getGrantee() - Method in class org.h2.engine.Right
 
getGroupBy() - Method in class org.h2.command.query.Select
 
getGroupData(SelectGroups, boolean) - Method in class org.h2.expression.analysis.DataAnalysisOperation
Get the aggregate group data object from the collector object.
getGroupDataIfCurrent(boolean) - Method in class org.h2.command.query.Select
Get the group data if there is currently a group-by active.
getGroupSortedIndex() - Method in class org.h2.command.query.Select
 
getHash(byte[], boolean) - Static method in class org.h2.security.SHA256
Calculate the hash code for the given data.
getHash(long) - Static method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Get the hash code for the given key.
getHash(String, Value, int) - Static method in class org.h2.expression.function.HashFunction
 
getHashWithSalt(byte[], byte[]) - Static method in class org.h2.security.SHA256
Calculate the hash code by using the given salt.
getHaving() - Method in class org.h2.command.query.Select
 
getHeaderLineValue(String) - Static method in class org.h2.server.web.WebThread
 
getHexStringException(int, String, int, int) - Static method in class org.h2.util.StringUtils
 
getHigh() - Method in class org.h2.value.ValueUuid
Get the most significant 64 bits of this UUID.
getHigherArray(TypeInfo, TypeInfo, int, int) - Static method in class org.h2.value.TypeInfo
 
getHigherDateTime(int, int, int) - Static method in class org.h2.value.Value
 
getHigherIntervalDayTime(int, int, int) - Static method in class org.h2.value.Value
 
getHigherIntervalYearMonth(int, int, int) - Static method in class org.h2.value.Value
 
getHigherNumeric(int, int, int) - Static method in class org.h2.value.Value
 
getHigherOrder(int, int) - Static method in class org.h2.value.Value
Get the higher value order type of two value types.
getHigherOrderKnown(int, int) - Static method in class org.h2.value.Value
 
getHigherOther(int, int, int) - Static method in class org.h2.value.Value
 
getHigherRow(TypeInfo, TypeInfo) - Static method in class org.h2.value.TypeInfo
 
getHigherType(Typed[]) - Static method in class org.h2.value.TypeInfo
Get the higher data type of all values.
getHigherType(TypeInfo, TypeInfo) - Static method in class org.h2.value.TypeInfo
Get the higher data type of two data types.
getHistogram(SessionLocal, AggregateData) - Method in class org.h2.expression.aggregate.Aggregate
 
getHistory() - Method in class org.h2.server.web.WebApp
 
getHits() - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Get the number of cache hits.
getHMAC(byte[], byte[]) - Static method in class org.h2.security.SHA256
Calculate the hash-based message authentication code.
getHoldability() - Method in class org.h2.jdbc.JdbcConnection
Returns the current result set holdability.
getHoldability() - Method in class org.h2.jdbc.JdbcResultSet
Returns the current result set holdability.
getHoldability() - Method in class org.h2.tools.SimpleResultSet
Returns the current result set holdability.
getHost() - Method in class org.h2.server.web.WebServer
 
getHostName(String) - Static method in class org.h2.util.NetUtils
Get the host name of a local address, if available.
getHours() - Method in class org.h2.api.Interval
Returns hours value, if any.
getHypotheticalSet(SessionLocal, AggregateData) - Method in class org.h2.expression.aggregate.Aggregate
 
getIcu4jCollator(String, int) - Static method in class org.h2.value.CompareModeIcu4J
 
getId() - Method in class org.h2.engine.DbObject
Get the unique object id.
getId() - Method in class org.h2.engine.MetaRecord
 
getId() - Method in class org.h2.engine.SessionLocal
 
getId() - Method in class org.h2.mvstore.db.SpatialKey
 
getId() - Method in class org.h2.mvstore.MVMap
Get the map id.
getId() - Method in class org.h2.mvstore.rtree.DefaultSpatial
 
getId() - Method in interface org.h2.mvstore.rtree.Spatial
Get id of this Spatial object
getId() - Method in class org.h2.mvstore.tx.Transaction
 
getId() - Method in class org.h2.store.fs.mem.FileMemData
 
getId() - Method in class org.h2.util.TimeZoneProvider
Returns the ID of the time zone.
getId() - Method in class org.h2.util.TimeZoneProvider.Simple
 
getId() - Method in class org.h2.util.TimeZoneProvider.WithTimeZone
 
getIdentifierQuoteString() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the string used to quote identifiers.
getIdentityColumn() - Method in class org.h2.table.Table
Returns first identity column, or null.
getIdentityOptions() - Method in class org.h2.table.Column
Returns identity column options, or null if sequence was already created or this column is not an identity column.
getIfEquals(Expression) - Method in class org.h2.expression.condition.Comparison
Get the other expression if this is an equals comparison and the other expression matches.
getIfExists() - Method in class org.h2.server.pg.PgServer
 
getIfExists() - Method in class org.h2.server.TcpServer
 
getIfSingleRow() - Method in class org.h2.command.query.Query
If this query is determined as a single-row query, returns a replacement expression.
getIfSingleRow() - Method in class org.h2.command.query.Select
 
getIfSingleRow() - Method in class org.h2.command.query.TableValueConstructor
 
getIgnoreCase() - Method in class org.h2.engine.Database
 
getIgnoreCatalogs() - Method in class org.h2.engine.Database
 
getImmediate(K) - Method in class org.h2.mvstore.tx.TransactionMap
Get the value for the given key, or null if not found.
getImpact(MBeanOperationInfo) - Method in class org.h2.jmx.DocumentedMBean
 
getImpl(Value, TypeInfo, boolean) - Static method in class org.h2.expression.TypedValueExpression
 
getImportedKeys(String, String, String) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the list of primary key columns that are referenced by a table.
getImportedKeys(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getImportedKeys(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getImportedKeys(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getImportedKeys(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getIncrement() - Method in class org.h2.schema.Sequence
 
getIncrement(SessionLocal) - Method in class org.h2.command.ddl.SequenceOptions
Gets increment value.
getIndex() - Method in class org.h2.constraint.Constraint
Get the index of this constraint in the source table, or null if no index is used.
getIndex() - Method in class org.h2.constraint.ConstraintReferential
 
getIndex() - Method in class org.h2.constraint.ConstraintUnique
 
getIndex() - Method in class org.h2.expression.Parameter
 
getIndex() - Method in class org.h2.table.PlanItem
 
getIndex() - Method in class org.h2.table.TableFilter
 
getIndex(String) - Method in class org.h2.schema.Schema
Get the index with the given name.
getIndex(String) - Method in class org.h2.table.Table
Get an index by name.
getIndex(SessionLocal, ArrayList<Value[]>, SortOrder, int, WindowFrameBound, boolean) - Method in class org.h2.expression.analysis.WindowFrame
Returns starting or ending index of a window frame.
getIndex(Table, IndexColumn[], boolean) - Static method in class org.h2.command.ddl.AlterTableAddConstraint
 
getIndexAccess(Connection) - Static method in class org.h2.fulltext.FullTextLucene
Get the index writer/searcher wrapper for the given connection.
getIndexColumns() - Method in class org.h2.command.ddl.AlterTableAddConstraint
 
getIndexColumns() - Method in class org.h2.index.Index
Get the indexed columns as index columns (with ordering information).
getIndexConditions() - Method in class org.h2.table.TableFilter
 
getIndexCursor() - Method in class org.h2.table.TableFilter
 
getIndexdef(SessionLocal, int, Value, Value) - Static method in class org.h2.mode.FunctionsPostgreSQL
 
getIndexes() - Method in class org.h2.mvstore.db.MVTable
 
getIndexes() - Method in class org.h2.mvstore.db.RowDataType
 
getIndexes() - Method in class org.h2.result.RowFactory.DefaultRowFactory
 
getIndexes() - Method in class org.h2.result.RowFactory
 
getIndexes() - Method in class org.h2.table.MetaTable
 
getIndexes() - Method in class org.h2.table.RangeTable
 
getIndexes() - Method in class org.h2.table.Table
Get all indexes for this table.
getIndexes() - Method in class org.h2.table.TableLink
 
getIndexes() - Method in class org.h2.table.TableView
 
getIndexes() - Method in class org.h2.table.VirtualTable
 
getIndexForColumn(Column, boolean, boolean) - Method in class org.h2.table.Table
Get the index that has the given column as the first element.
getIndexForName(String) - Method in class org.h2.jdbc.JdbcCallableStatement
 
getIndexHints() - Method in class org.h2.table.TableFilter
 
getIndexHints(TableFilter[], int) - Static method in class org.h2.table.Table
 
getIndexInfo(int) - Method in class org.h2.fulltext.FullTextSettings
Get the index information for the given index id.
getIndexInfo(String, String, String, boolean, boolean) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the list of indexes for this database.
getIndexInfo(String, String, String, boolean, boolean) - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getIndexInfo(String, String, String, boolean, boolean) - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getIndexInfo(String, String, String, boolean, boolean) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getIndexInfo(String, String, String, boolean, boolean) - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getIndexInfo(Value, Value, Table, boolean, boolean, SimpleResult, Database) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getIndexPath(Connection) - Static method in class org.h2.fulltext.FullTextLucene
Get the path of the Lucene index for this database.
getIndexPath(Connection) - Static method in class org.h2.fulltext.FullTextSettings
Get the file system path.
getIndexType() - Method in class org.h2.index.Index
Get the index type.
getInDoubtTransactions() - Method in class org.h2.engine.Database
Get the list of in-doubt transactions.
getInDoubtTransactions() - Method in class org.h2.mvstore.db.Store
 
getInfo() - Method in class org.h2.server.web.WebSession
Update session meta data information and get the information in a map.
getInList(ExpressionColumn, List<Expression>) - Static method in class org.h2.index.IndexCondition
Create an index condition with the compare type IN_LIST and with the given parameters.
getInnerSQL2(StringBuilder, int) - Method in class org.h2.expression.IntervalOperation
 
getInputStr() - Method in class org.h2.mode.ToDateParser
 
getInputStream() - Method in class org.h2.mvstore.db.Store
 
getInputStream() - Method in class org.h2.value.Value
 
getInputStream() - Method in class org.h2.value.ValueBlob
 
getInputStream() - Method in class org.h2.value.ValueClob
 
getInputStream() - Method in class org.h2.value.ValueNull
 
getInputStream(long) - Method in class org.h2.value.lob.LobData
Get stream to read LOB data from
getInputStream(long) - Method in class org.h2.value.lob.LobDataDatabase
 
getInputStream(long) - Method in class org.h2.value.lob.LobDataFetchOnDemand
 
getInputStream(long) - Method in class org.h2.value.lob.LobDataFile
 
getInputStream(long) - Method in class org.h2.value.lob.LobDataInMemory
 
getInputStream(long, int, long) - Method in class org.h2.mvstore.db.LobStorageMap
 
getInputStream(long, int, long) - Method in class org.h2.store.LobStorageFrontend
 
getInputStream(long, int, long) - Method in interface org.h2.store.LobStorageInterface
Get the input stream for the given lob
getInputStream(long, long) - Method in class org.h2.mvstore.db.LobStorageMap
 
getInputStream(long, long) - Method in class org.h2.store.LobStorageFrontend
 
getInputStream(long, long) - Method in interface org.h2.store.LobStorageInterface
Get the input stream for the given lob, only called on server side of a TCP connection.
getInputStream(long, long) - Method in class org.h2.value.Value
Get the input stream
getInputStream(long, long) - Method in class org.h2.value.ValueBlob
 
getInputStream(long, long) - Method in class org.h2.value.ValueClob
 
getInputStream(long, long) - Method in class org.h2.value.ValueNull
 
getInputStreamFromString(String) - Static method in class org.h2.util.IOUtils
Create an input stream to read from a string.
getInQuery(ExpressionColumn, Query) - Static method in class org.h2.index.IndexCondition
Create an index condition with the compare type IN_QUERY and with the given parameters.
getInstance() - Method in class org.h2.expression.aggregate.JavaAggregate
 
getInstance() - Method in class org.h2.schema.UserAggregate
 
getInstance() - Static method in class org.h2.security.auth.DefaultAuthenticator
 
getInstance() - Static method in class org.h2.tools.CompressTool
Get a new instance.
getInstance() - Static method in class org.h2.tools.MultiDimension
Get the singleton.
getInstance() - Static method in class org.h2.util.TempFileDeleter
 
getInstance(long, X, X) - Static method in class org.h2.mvstore.tx.VersionedValueUncommitted
Create new VersionedValueUncommitted.
getInstance(Reader) - Static method in class org.h2.bnf.Bnf
Create an instance using the grammar specified in the CSV file.
getInstance(String) - Static method in class org.h2.engine.Mode
Get the mode with the given name.
getInstance(String, int) - Static method in class org.h2.value.CompareMode
Create a new compare mode with the given collator and strength.
getInstance(Connection) - Static method in class org.h2.fulltext.FullTextSettings
Get or create the fulltext settings for this database.
getInstance(HashMap<String, String>) - Static method in class org.h2.engine.DbSettings
INTERNAL.
getInstance(SessionLocal, ArrayList<Expression>, boolean, int[]) - Static method in class org.h2.command.query.SelectGroups
Creates new instance of grouped data.
getInstance(Transaction) - Method in class org.h2.mvstore.tx.TransactionMap
Get a clone of this map for the given transaction.
getInstance(X) - Static method in class org.h2.mvstore.tx.VersionedValueCommitted
Either cast to VersionedValue, or wrap in VersionedValueCommitted
getInstrumentation() - Static method in class org.h2.util.Profiler
Get the instrumentation object if started as an agent.
getInt() - Method in class org.h2.value.Value
Returns this value as a Java int value.
getInt() - Method in class org.h2.value.ValueBoolean
 
getInt() - Method in class org.h2.value.ValueEnumBase
 
getInt() - Method in class org.h2.value.ValueInteger
 
getInt() - Method in class org.h2.value.ValueNull
 
getInt() - Method in class org.h2.value.ValueSmallint
 
getInt() - Method in class org.h2.value.ValueStringBase
 
getInt() - Method in class org.h2.value.ValueTinyint
 
getInt(int) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as an int.
getInt(int) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as an int.
getInt(int) - Method in class org.h2.tools.SimpleResultSet
Returns the value as an int.
getInt(String) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as an int.
getInt(String) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as an int.
getInt(String) - Method in class org.h2.tools.SimpleResultSet
Returns the value as an int.
getIntArray(int[]) - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getInternal(byte[]) - Static method in class org.h2.value.ValueJson
Returns JSON value with the specified content.
getInternal(int) - Method in class org.h2.jdbc.JdbcResultSet
INTERNAL
getInternalError() - Static method in exception org.h2.message.DbException
Gets an internal error.
getInternalError(String) - Static method in exception org.h2.message.DbException
Gets an internal error.
getInternalType(int[]) - Method in interface org.h2.api.Aggregate
This method must return the H2 data type, Value, of the aggregate function, given the H2 data type of the input data.
getInternalType(int[]) - Method in class org.h2.schema.UserAggregate.AggregateWrapper
 
getInterval() - Method in class org.h2.value.ValueInterval
Returns the interval.
getIntInternal(int) - Method in class org.h2.jdbc.JdbcResultSet
 
getIntOffset(WindowFrameBound, Value[], SessionLocal) - Static method in class org.h2.expression.analysis.WindowFrame
 
getIntProperty(int, int) - Method in class org.h2.engine.ConnectionInfo
Get the value of the given property.
getIntProperty(Properties, String, int) - Static method in class org.h2.util.SortedProperties
Get an int property value from a properties object.
getIntValue() - Method in class org.h2.command.dml.Set
 
getIntValue() - Method in class org.h2.engine.Setting
 
getIntValue(String) - Method in class org.h2.security.auth.ConfigProperties
Returns the integer value of specified property.
getIntValue(String, int) - Method in class org.h2.security.auth.ConfigProperties
Returns the integer value of specified property.
getInvalidExpressionTypeException(String, Typed) - Static method in exception org.h2.message.DbException
Gets a SQL exception meaning the type of expression is invalid or unknown.
getInvalidNumericPrecisionException(long) - Static method in class org.h2.command.Parser
 
getInvalidPrecisionException(DataType, long) - Static method in class org.h2.command.Parser
 
getInvalidValueException(String, Object) - Static method in exception org.h2.message.DbException
Gets a SQL exception meaning this value is invalid.
getIsoDayOfWeek(long) - Static method in class org.h2.util.DateTimeUtils
Returns ISO day of week.
getIsolationLevel() - Method in class org.h2.engine.Session
Returns the isolation level.
getIsolationLevel() - Method in class org.h2.engine.SessionLocal
 
getIsolationLevel() - Method in class org.h2.engine.SessionRemote
 
getIsolationLevel() - Method in class org.h2.mvstore.tx.Transaction
Returns the isolation level of this transaction.
getISOString() - Method in class org.h2.value.ValueTimestamp
Returns value as string in ISO format.
getISOString() - Method in class org.h2.value.ValueTimestampTimeZone
Returns value as string in ISO format.
getIsoWeekOfYear(long) - Static method in class org.h2.util.DateTimeUtils
Returns ISO number of week in year.
getIsoWeekYear(long) - Static method in class org.h2.util.DateTimeUtils
Returns ISO week year.
getItem(TableFilter) - Method in class org.h2.table.Plan
Get the plan item for the given table.
getItemCount() - Method in class org.h2.util.geometry.EWKTUtils.EWKTSource
 
getItemType() - Method in class org.h2.value.ValueJson
Returns JSON item type.
getJavaClassName() - Method in class org.h2.schema.UserDefinedFunction
 
getJavaFileForOutput(JavaFileManager.Location, String, JavaFileObject.Kind, FileObject) - Method in class org.h2.util.SourceCompiler.ClassFileManager
 
getJavaMethodName() - Method in class org.h2.schema.FunctionAlias
 
getJavaMethods() - Method in class org.h2.schema.FunctionAlias
Get the Java methods mapped by this function.
getJavaObjectSerializer() - Method in interface org.h2.engine.CastDataProvider
Returns the custom Java object serializer, or null.
getJavaObjectSerializer() - Method in class org.h2.engine.Database
 
getJavaObjectSerializer() - Method in class org.h2.engine.SessionLocal
 
getJavaObjectSerializer() - Method in class org.h2.engine.SessionRemote
 
getJavaObjectSerializer() - Method in class org.h2.jdbc.JdbcConnection
 
getJdbc() - Method in enum org.h2.engine.IsolationLevel
Returns the JDBC constant for this isolation level.
getJDBCMajorVersion() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the major version of the supported JDBC API.
getJDBCMinorVersion() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the minor version of the supported JDBC API.
getJdbcSQLException(int) - Static method in exception org.h2.message.DbException
Gets the SQL exception object for a specific error code.
getJdbcSQLException(int, String) - Static method in exception org.h2.message.DbException
Gets the SQL exception object for a specific error code.
getJdbcSQLException(int, Throwable, String...) - Static method in exception org.h2.message.DbException
Gets the SQL exception object for a specific error code.
getJdbcSQLException(String, String, String, int, Throwable, String) - Static method in exception org.h2.message.DbException
Creates a SQLException.
getJoin() - Method in class org.h2.table.TableFilter
 
getJoinCondition() - Method in class org.h2.table.TableFilter
 
getJoinPlan() - Method in class org.h2.table.PlanItem
 
getJsonFunctionFlagsSQL(StringBuilder, int, boolean) - Static method in class org.h2.expression.function.JsonConstructorFunction
Appends flags of a JSON function to the specified string builder.
getKey() - Method in class org.h2.mvstore.Cursor
Get the last read key if there was one.
getKey() - Method in class org.h2.result.SearchRow
Get the unique key of the row.
getKey() - Method in class org.h2.server.web.WebServer
Returns the key for privileged connections.
getKey(int) - Method in class org.h2.mvstore.Page
Get the key at the given index.
getKey(long) - Method in class org.h2.mvstore.MVMap
Get the key at the given index.
getKey(Object[]) - Method in class org.h2.fulltext.FullText.FullTextTrigger
 
getKey(String) - Method in class org.h2.value.CompareModeDefault
 
getKey(DbObject) - Static method in class org.h2.engine.Comment
Get the comment key name for the given database object.
getKey(SearchRow) - Method in class org.h2.mvstore.db.MVSpatialIndex
 
getKey(Value[]) - Method in class org.h2.mvstore.db.MVSortedTempResult
Reorder values if required and convert them into ValueRow.
getKeyCount() - Method in class org.h2.mvstore.Page
Get the number of keys in this page.
getKeyIndex(K) - Method in class org.h2.mvstore.MVMap
Get the index of the given key in the map.
getKeyLength() - Method in class org.h2.security.AES
 
getKeyLength() - Method in interface org.h2.security.BlockCipher
Get the length of the key in bytes.
getKeyLength() - Method in class org.h2.security.Fog
 
getKeyLength() - Method in class org.h2.security.XTEA
 
getKeyPasswordHash(String, char[]) - Static method in class org.h2.security.SHA256
Calculate the hash of a password by prepending the user name and a '@' character.
getKeys() - Method in class org.h2.engine.ConnectionInfo
Get the property keys.
getKeysPerPage() - Method in class org.h2.mvstore.MVStore
 
getKeyStore(String) - Static method in class org.h2.security.CipherFactory
Get the keystore object using the given password.
getKeyStoreBytes(KeyStore, String) - Static method in class org.h2.security.CipherFactory
 
getKeyType() - Method in class org.h2.mvstore.MVMap.BasicBuilder
 
getKeyType() - Method in class org.h2.mvstore.MVMap
Get the key type.
getKeyType() - Method in interface org.h2.mvstore.MVMap.MapBuilder
 
getKeyType() - Method in class org.h2.mvstore.tx.TransactionMap
 
getLargeMaxRows() - Method in class org.h2.jdbc.JdbcStatement
Gets the maximum number of rows for a ResultSet.
getLargeUpdateCount() - Method in class org.h2.jdbc.JdbcStatement
Returns the last update count of this statement.
getLastFree() - Method in class org.h2.mvstore.FreeSpaceBitSet
Get the position of the last (infinite) free space.
getLastIdentity() - Method in class org.h2.engine.SessionLocal
 
getLastMatchedSchema() - Method in class org.h2.bnf.Sentence
Get the last matched schema if the last match was a schema.
getLastMatchedTable() - Method in class org.h2.bnf.Sentence
Get the last matched table if the last match was a table.
getLastModified() - Method in class org.h2.store.fs.mem.FileMemData
Get the last modified time.
getLastModified() - Method in class org.h2.store.fs.niomem.FileNioMemData
Get the last modified time.
getLastParseIndex() - Method in class org.h2.command.Parser
Returns the last parse index.
getLastReconnect() - Method in class org.h2.engine.SessionRemote
 
getLastTable() - Method in class org.h2.bnf.Sentence
Get the last added table.
getLastValue() - Method in class org.h2.mvstore.tx.TxDecisionMaker
 
getLayoutMap() - Method in class org.h2.mvstore.MVStore
Get this store's layout map.
getLayoutMap(long) - Method in class org.h2.mvstore.MVStore
 
getLeading() - Method in class org.h2.api.Interval
Returns value of leading field of this interval.
getLeading() - Method in class org.h2.value.ValueInterval
Returns value of leading field of this interval.
getLeadLag(HashMap<Integer, Value>, ArrayList<Value[]>, int, SessionLocal) - Method in class org.h2.expression.analysis.WindowFunction
 
getLeafRatio() - Method in class org.h2.mvstore.MVStore
 
getLeft() - Method in class org.h2.command.query.SelectUnion
 
getLegacyAlgorithmsSilently() - Static method in class org.h2.security.CipherFactory
Returns the security property "jdk.tls.legacyAlgorithms".
getLength() - Method in class org.h2.store.CountingReaderInputStream
The number of characters read so far (but there might still be some bytes in the buffer).
getLevelFile() - Method in class org.h2.message.TraceSystem
 
getLike(String) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getLineCommentCharacter() - Method in class org.h2.tools.Csv
Get the line comment character.
getLineSeparator() - Method in class org.h2.tools.Csv
Get the line separator used for writing.
getLinkConnection(String, String, String, String) - Method in class org.h2.engine.Database
Open a new connection or get an existing connection to another database.
getList() - Method in class org.h2.value.ValueCollectionBase
 
getListagg(SessionLocal, AggregateData) - Method in class org.h2.expression.aggregate.Aggregate
 
getListaggError(Value[], String) - Method in class org.h2.expression.aggregate.Aggregate
 
getListaggItem(Value) - Method in class org.h2.expression.aggregate.Aggregate
 
getListaggTruncate(Value[], String, String, boolean) - Method in class org.h2.expression.aggregate.Aggregate
 
getLivePageCount() - Method in class org.h2.mvstore.MVStore
Get live data pages count.
getLobData() - Method in class org.h2.value.ValueLob
 
getLobFileListCache() - Method in class org.h2.engine.Database
 
getLobFileListCache() - Method in class org.h2.engine.SessionRemote
 
getLobFileListCache() - Method in interface org.h2.store.DataHandler
Get the lob file list cache if it is used.
getLobFileListCache() - Method in class org.h2.tools.Recover
INTERNAL
getLobId() - Method in class org.h2.value.lob.LobDataDatabase
 
getLobId() - Method in class org.h2.value.lob.LobDataFetchOnDemand
 
getLobSession() - Method in class org.h2.engine.Database
 
getLobStorage() - Method in class org.h2.engine.Database
 
getLobStorage() - Method in class org.h2.engine.SessionRemote
 
getLobStorage() - Method in interface org.h2.store.DataHandler
Get the lob storage mechanism to use.
getLobStorage() - Method in class org.h2.tools.Recover
INTERNAL
getLobStream(Connection, String, int) - Static method in class org.h2.command.dml.ScriptCommand
 
getLobSyncObject() - Method in class org.h2.engine.Database
 
getLobSyncObject() - Method in class org.h2.engine.SessionRemote
 
getLobSyncObject() - Method in interface org.h2.store.DataHandler
Get the synchronization object for lob operations.
getLobSyncObject() - Method in class org.h2.tools.Recover
INTERNAL
getLocalAddress() - Static method in class org.h2.util.NetUtils
Get the local host address as a string.
getLocalDayOfWeek(long) - Static method in class org.h2.expression.function.DateTimeFunction
 
getLocalTempTableConstraints() - Method in class org.h2.engine.SessionLocal
Get the map of constraints for all constraints on local, temporary tables, if any.
getLocalTempTableIndexes() - Method in class org.h2.engine.SessionLocal
 
getLocalTempTables() - Method in class org.h2.engine.SessionLocal
 
getLocalTimeNanos(CastDataProvider) - Method in class org.h2.value.Value
 
getLocalWeekOfYear(long) - Static method in class org.h2.expression.function.DateTimeFunction
 
getLockMode() - Method in class org.h2.engine.Database
 
getLockMode() - Method in enum org.h2.engine.IsolationLevel
Returns the LOCK_MODE equivalent for PageStore and old versions of H2.
getLocks() - Method in class org.h2.engine.SessionLocal
 
getLockTimeout() - Method in class org.h2.engine.Database
 
getLockTimeout() - Method in class org.h2.engine.SessionLocal
 
getLogId() - Method in class org.h2.mvstore.tx.Transaction
 
getLogId(long) - Static method in class org.h2.mvstore.tx.Transaction
 
getLogId(long) - Static method in class org.h2.mvstore.tx.TransactionStore
Get the log id for the given operation id.
getLoginError(Exception, boolean) - Method in class org.h2.server.web.WebApp
Get the formatted login error message.
getLoginTimeout() - Method in class org.h2.jdbcx.JdbcConnectionPool
Gets the maximum time in seconds to wait for a free connection.
getLoginTimeout() - Method in class org.h2.jdbcx.JdbcDataSource
Get the login timeout in seconds, 0 meaning no timeout.
getLogWriter() - Method in class org.h2.jdbcx.JdbcConnectionPool
INTERNAL
getLogWriter() - Method in class org.h2.jdbcx.JdbcDataSource
Get the current log writer for this object.
getLong() - Method in class org.h2.value.Value
Returns this value as a Java long value.
getLong() - Method in class org.h2.value.ValueBigint
 
getLong() - Method in class org.h2.value.ValueBoolean
 
getLong() - Method in class org.h2.value.ValueEnumBase
 
getLong() - Method in class org.h2.value.ValueInteger
 
getLong() - Method in class org.h2.value.ValueInterval
 
getLong() - Method in class org.h2.value.ValueNull
 
getLong() - Method in class org.h2.value.ValueSmallint
 
getLong() - Method in class org.h2.value.ValueStringBase
 
getLong() - Method in class org.h2.value.ValueTinyint
 
getLong(int) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a long.
getLong(int) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a long.
getLong(int) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a long.
getLong(String) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a long.
getLong(String) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a long.
getLong(String) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a long.
getLong(SessionLocal, Expression) - Static method in class org.h2.command.ddl.SequenceOptions
 
getLongInternal(int) - Method in class org.h2.jdbc.JdbcResultSet
 
getLow() - Method in class org.h2.value.ValueUuid
Get the least significant 64 bits of this UUID.
getMainIndexColumn() - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
getMainIndexColumn() - Method in class org.h2.mvstore.db.MVTable
 
getMainIndexColumn() - Method in class org.h2.table.Table
Returns ID of main index column, or SearchRow.ROWID_INDEX.
getMainIndexColumn(IndexType, IndexColumn[]) - Static method in class org.h2.table.TableBase
Returns main index column if index is an primary key index and has only one column with _ROWID_ compatible data type.
getMainSchema() - Method in class org.h2.engine.Database
Returns main schema (usually PUBLIC).
getMajorVersion() - Method in class org.h2.Driver
Get the major version number of the driver.
getManagementDbName(int) - Static method in class org.h2.server.TcpServer
Get the database name of the management database.
getMandatoryAttributeValue(String, Attributes) - Static method in class org.h2.security.auth.H2AuthConfigXml
 
getMap() - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Convert this cache to a map.
getMap() - Method in class org.h2.mvstore.StreamStore
 
getMap(int) - Method in class org.h2.engine.Database
 
getMap(int) - Method in class org.h2.mvstore.MVStore
Get map by id.
getMap(int) - Method in class org.h2.mvstore.tx.TransactionStore
 
getMap(int) - Method in class org.h2.schema.Schema
 
getMap(SessionLocal) - Method in class org.h2.mode.PgCatalogSchema
 
getMap(SessionLocal) - Method in class org.h2.mvstore.db.MVPrimaryIndex
Get the map to store the data.
getMap(SessionLocal) - Method in class org.h2.mvstore.db.MVSecondaryIndex
Get the map to store the data.
getMap(SessionLocal) - Method in class org.h2.mvstore.db.MVSpatialIndex
Get the map to store the data.
getMap(SessionLocal) - Method in class org.h2.schema.InformationSchema
 
getMap(SessionLocal) - Method in class org.h2.schema.MetaSchema
Returns map of tables in this schema.
getMapId() - Method in class org.h2.mvstore.Page
Get the id of the page's owner map
getMapId(String) - Method in class org.h2.mvstore.MVStore
 
getMapKey(int) - Static method in class org.h2.mvstore.MVMap
Get the metadata key for the given map id.
getMapName() - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
getMapName() - Method in class org.h2.mvstore.db.MVTable
 
getMapName(int) - Method in class org.h2.mvstore.MVStore
Get the name of the given map.
getMapName(String) - Static method in class org.h2.mvstore.DataUtils
Parse a name from key-value pair list.
getMapNames() - Method in class org.h2.mvstore.MVStore
Get the set of all map names.
getMapRootKey(int) - Static method in class org.h2.mvstore.MVMap
Get the metadata key for the root of the given map id.
getMask(ArrayList<IndexCondition>) - Method in class org.h2.index.IndexCondition
Get the comparison bit mask.
getMasks() - Method in class org.h2.table.PlanItem
 
getMasks() - Method in class org.h2.table.TableFilter
 
getMax(SessionLocal) - Method in class org.h2.table.RangeTable
Calculate and get the end value of this range.
getMax(Value, Value, boolean) - Method in class org.h2.index.IndexCursor
 
getMaxArgumentCount(WindowFunctionType) - Static method in class org.h2.expression.analysis.WindowFunction
Returns maximal number of arguments for the specified type.
getMaxBinaryLiteralLength() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the maximum length for hex values (characters).
getMaxBlockKey(byte[]) - Method in class org.h2.mvstore.StreamStore
Get the key of the biggest block, of -1 for inline data.
getMaxBlockSize() - Method in class org.h2.mvstore.StreamStore
 
getMaxBruteForceFilters(int) - Static method in class org.h2.command.query.Optimizer
How many filter to calculate using brute force.
getMaxCacheSize(long, long) - Static method in class org.h2.schema.Sequence
 
getMaxCatalogNameLength() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the maximum length for a catalog name.
getMaxCharLiteralLength() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the maximum length for literals.
getMaxColumnNameLength() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the maximum length for column names.
getMaxColumnsInGroupBy() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the maximum number of columns in GROUP BY.
getMaxColumnsInIndex() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the maximum number of columns in CREATE INDEX.
getMaxColumnsInOrderBy() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the maximum number of columns in ORDER BY.
getMaxColumnsInSelect() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the maximum number of columns in SELECT.
getMaxColumnsInTable() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the maximum number of columns in CREATE TABLE.
getMaxConnections() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the maximum number of open connection.
getMaxConnections() - Method in class org.h2.jdbcx.JdbcConnectionPool
Gets the maximum number of connections to use.
getMaxCursorNameLength() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the maximum length for a cursor name.
getMaxDataModificationId() - Method in class org.h2.command.query.Query
 
getMaxDataModificationId() - Method in class org.h2.expression.ExpressionVisitor
Get the last data modification.
getMaxDataModificationId() - Method in class org.h2.mode.PgCatalogTable
 
getMaxDataModificationId() - Method in class org.h2.mvstore.db.MVTable
 
getMaxDataModificationId() - Method in class org.h2.table.DualTable
 
getMaxDataModificationId() - Method in class org.h2.table.InformationSchemaTable
 
getMaxDataModificationId() - Method in class org.h2.table.InformationSchemaTableLegacy
 
getMaxDataModificationId() - Method in class org.h2.table.RangeTable
 
getMaxDataModificationId() - Method in class org.h2.table.Table
Get the last data modification id.
getMaxDataModificationId() - Method in class org.h2.table.TableLink
 
getMaxDataModificationId() - Method in class org.h2.table.TableView
 
getMaxDataModificationId() - Method in class org.h2.table.VirtualConstructedTable
 
getMaxFieldSize() - Method in class org.h2.jdbc.JdbcStatement
Gets the maximum number of bytes for a result set column.
getMaxIndexLength() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the maximum length for an index (in bytes).
getMaxItemSize() - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Determines max size of the data item size to fit into cache
getMaxLengthInplaceLob() - Method in class org.h2.engine.Database
 
getMaxLengthInplaceLob() - Method in class org.h2.engine.SessionRemote
 
getMaxLengthInplaceLob() - Method in interface org.h2.store.DataHandler
Get the maximum length of a in-place large object
getMaxLengthInplaceLob() - Method in class org.h2.tools.Recover
INTERNAL
getMaxMemory() - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Get the maximum memory to use.
getMaxMemory() - Method in interface org.h2.util.Cache
Get the maximum memory to be used.
getMaxMemory() - Method in class org.h2.util.CacheLRU
 
getMaxMemory() - Method in class org.h2.util.CacheSecondLevel
 
getMaxMemory() - Method in class org.h2.util.CacheTQ
 
getMaxMemoryRows() - Method in class org.h2.engine.Database
 
getMaxModificationIdVisitor() - Static method in class org.h2.expression.ExpressionVisitor
 
getMaxOperationMemory() - Method in class org.h2.engine.Database
 
getMaxPageSize() - Method in class org.h2.mvstore.MVStore
 
getMaxParameterIndex(ArrayList<Parameter>) - Static method in class org.h2.table.TableView
 
getMaxProcedureNameLength() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the maximum length for a procedure name.
getMaxrows() - Method in class org.h2.server.web.WebApp
 
getMaxRows() - Method in class org.h2.jdbc.JdbcStatement
Gets the maximum number of rows for a ResultSet.
getMaxRowSize() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the maximum size of a row (in bytes).
getMaxSchemaNameLength() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the maximum length for a schema name.
getMaxStatementLength() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the maximum length of a statement.
getMaxStatements() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the maximum number of open statements.
getMaxTableNameLength() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the maximum length for a table name.
getMaxTablesInSelect() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the maximum number of tables in a SELECT.
getMaxTransactionId() - Method in class org.h2.mvstore.tx.TransactionStore
 
getMaxUserNameLength() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the maximum length for a user name.
getMaxValue() - Method in class org.h2.schema.Sequence
 
getMaxValue(int) - Method in class org.h2.tools.MultiDimension
Get the maximum value for the given dimension count.
getMaxValue(Sequence, SessionLocal) - Method in class org.h2.command.ddl.SequenceOptions
Gets max value.
getMembers() - Method in class org.h2.util.json.JSONObject
Returns the value.
getMemory() - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS.Entry
 
getMemory() - Method in class org.h2.mvstore.Page
 
getMemory() - Method in class org.h2.result.DefaultRow
 
getMemory() - Method in class org.h2.result.SearchRow
Get the estimated memory used for this row, in bytes.
getMemory() - Method in class org.h2.result.SimpleRowValue
 
getMemory() - Method in interface org.h2.util.Cache
Get the used size in KB.
getMemory() - Method in class org.h2.util.CacheHead
 
getMemory() - Method in class org.h2.util.CacheLRU
 
getMemory() - Method in class org.h2.util.CacheObject
Get the estimated used memory.
getMemory() - Method in class org.h2.util.CacheSecondLevel
 
getMemory() - Method in class org.h2.util.CacheTQ
 
getMemory() - Method in class org.h2.value.lob.LobData
Get the memory used by this object.
getMemory() - Method in class org.h2.value.lob.LobDataInMemory
 
getMemory() - Method in class org.h2.value.Value
Get the memory used by this object.
getMemory() - Method in class org.h2.value.ValueBoolean
 
getMemory() - Method in class org.h2.value.ValueBytesBase
 
getMemory() - Method in class org.h2.value.ValueCollectionBase
 
getMemory() - Method in class org.h2.value.ValueDecfloat
 
getMemory() - Method in class org.h2.value.ValueEnumBase
 
getMemory() - Method in class org.h2.value.ValueGeometry
 
getMemory() - Method in class org.h2.value.ValueInterval
 
getMemory() - Method in class org.h2.value.ValueLob
 
getMemory() - Method in class org.h2.value.ValueNull
 
getMemory() - Method in class org.h2.value.ValueNumeric
 
getMemory() - Method in class org.h2.value.ValueStringBase
 
getMemory() - Method in class org.h2.value.ValueTimestamp
 
getMemory() - Method in class org.h2.value.ValueTimestampTimeZone
 
getMemory() - Method in class org.h2.value.ValueTimeTimeZone
 
getMemory() - Method in class org.h2.value.ValueUuid
 
getMemory(byte[]) - Method in class org.h2.mvstore.MVStoreTool.GenericDataType
 
getMemory(byte[]) - Method in class org.h2.mvstore.type.ByteArrayDataType
 
getMemory(long) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Get the memory used for the given key.
getMemory(Boolean) - Method in class org.h2.mvstore.type.ObjectDataType.BooleanType
 
getMemory(Byte) - Method in class org.h2.mvstore.type.ObjectDataType.ByteType
 
getMemory(Character) - Method in class org.h2.mvstore.type.ObjectDataType.CharacterType
 
getMemory(Double) - Method in class org.h2.mvstore.type.ObjectDataType.DoubleType
 
getMemory(Float) - Method in class org.h2.mvstore.type.ObjectDataType.FloatType
 
getMemory(Integer) - Method in class org.h2.mvstore.type.ObjectDataType.IntegerType
 
getMemory(Long) - Method in class org.h2.mvstore.type.LongDataType
 
getMemory(Long) - Method in class org.h2.mvstore.type.ObjectDataType.LongType
 
getMemory(Object) - Method in class org.h2.mvstore.type.ObjectDataType
 
getMemory(Object) - Method in class org.h2.mvstore.type.ObjectDataType.NullType
 
getMemory(Object) - Method in class org.h2.mvstore.type.ObjectDataType.ObjectArrayType
 
getMemory(Object) - Method in class org.h2.mvstore.type.ObjectDataType.SerializedObjectType
 
getMemory(Short) - Method in class org.h2.mvstore.type.ObjectDataType.ShortType
 
getMemory(String) - Method in class org.h2.mvstore.type.ObjectDataType.StringType
 
getMemory(String) - Method in class org.h2.mvstore.type.StringDataType
 
getMemory(BigDecimal) - Method in class org.h2.mvstore.type.ObjectDataType.BigDecimalType
 
getMemory(BigInteger) - Method in class org.h2.mvstore.type.ObjectDataType.BigIntegerType
 
getMemory(Date) - Method in class org.h2.mvstore.type.ObjectDataType.DateType
 
getMemory(UUID) - Method in class org.h2.mvstore.type.ObjectDataType.UUIDType
 
getMemory(LobStorageMap.BlobMeta) - Method in class org.h2.mvstore.db.LobStorageMap.BlobMeta.Type
 
getMemory(LobStorageMap.BlobReference) - Method in class org.h2.mvstore.db.LobStorageMap.BlobReference.Type
 
getMemory(Spatial) - Method in class org.h2.mvstore.rtree.SpatialDataType
 
getMemory(Record<K, V>) - Method in class org.h2.mvstore.tx.Record.Type
 
getMemory(DataType<?>) - Method in class org.h2.mvstore.type.MetaType
 
getMemory(SearchRow) - Method in class org.h2.mvstore.db.RowDataType
 
getMemory(Value) - Method in class org.h2.mvstore.db.NullValueDataType
 
getMemory(Value) - Method in class org.h2.mvstore.db.ValueDataType
 
getMemory(VersionedValue<T>) - Method in class org.h2.mvstore.tx.VersionedValueType
 
getMemory(T) - Method in class org.h2.mvstore.type.BasicDataType
 
getMemory(T) - Method in interface org.h2.mvstore.type.DataType
Calculates the amount of used memory in bytes.
getMemory(T) - Method in class org.h2.mvstore.type.ObjectDataType.AutoDetectDataType
 
getMemoryFile() - Method in class org.h2.store.fs.mem.FilePathMem
 
getMemoryFile() - Method in class org.h2.store.fs.niomem.FilePathNioMem
 
getMemoryFree() - Static method in class org.h2.util.Utils
Get the free memory in KB.
getMemoryMax() - Static method in class org.h2.util.Utils
Get the maximum memory in KB.
getMemoryUsed() - Static method in class org.h2.util.Utils
Get the used memory in KB.
getMessage() - Method in exception org.h2.jdbc.JdbcSQLDataException
 
getMessage() - Method in exception org.h2.jdbc.JdbcSQLException
 
getMessage() - Method in exception org.h2.jdbc.JdbcSQLFeatureNotSupportedException
 
getMessage() - Method in exception org.h2.jdbc.JdbcSQLIntegrityConstraintViolationException
 
getMessage() - Method in exception org.h2.jdbc.JdbcSQLInvalidAuthorizationSpecException
 
getMessage() - Method in exception org.h2.jdbc.JdbcSQLNonTransientConnectionException
 
getMessage() - Method in exception org.h2.jdbc.JdbcSQLNonTransientException
 
getMessage() - Method in exception org.h2.jdbc.JdbcSQLSyntaxErrorException
 
getMessage() - Method in exception org.h2.jdbc.JdbcSQLTimeoutException
 
getMessage() - Method in exception org.h2.jdbc.JdbcSQLTransactionRollbackException
 
getMessage() - Method in exception org.h2.jdbc.JdbcSQLTransientException
 
getMetaData() - Method in class org.h2.command.Command
 
getMetaData() - Method in interface org.h2.command.CommandInterface
Get an empty result set containing the meta data of the result.
getMetaData() - Method in class org.h2.command.CommandRemote
 
getMetaData() - Method in class org.h2.jdbc.JdbcConnection
Gets the database meta data for this database.
getMetaData() - Method in class org.h2.jdbc.JdbcPreparedStatement
Gets the result set metadata of the query returned when the statement is executed.
getMetaData() - Method in class org.h2.jdbc.JdbcResultSet
Gets the meta data of this result set.
getMetaData() - Method in class org.h2.server.web.WebSession
 
getMetaData() - Method in class org.h2.tools.SimpleResultSet
Returns a reference to itself.
getMetaKey(int) - Static method in class org.h2.mvstore.Chunk
Get the metadata key for the given chunk id.
getMetaMap() - Method in class org.h2.mvstore.MVStore
Get the metadata map.
getMetaResultSet(Connection, String) - Static method in class org.h2.util.JdbcUtils
Get metadata from the database.
getMethod(String) - Method in class org.h2.util.SourceCompiler
Get the first public static method of the given class.
getMethodSignature(Method) - Static method in class org.h2.schema.FunctionAlias
 
getMillis(CastDataProvider, TimeZone, long, long) - Static method in class org.h2.util.LegacyDateTimeUtils
Calculate the milliseconds since 1970-01-01 (UTC) for the given date and time (in the specified timezone).
getMimeType() - Method in class org.h2.server.web.WebApp
Get the current mime type.
getMin(SessionLocal) - Method in class org.h2.table.RangeTable
Calculate and get the start value of this range.
getMinArgumentCount(WindowFunctionType) - Static method in class org.h2.expression.analysis.WindowFunction
Returns minimal number of arguments for the specified type.
getMinBlockSize() - Method in class org.h2.mvstore.StreamStore
 
getMinMax(K, boolean, boolean) - Method in class org.h2.mvstore.MVMap
Get the smallest or largest key using the given bounds.
getMinMax(Page<K, V>, K, boolean, boolean) - Method in class org.h2.mvstore.MVMap
 
getMinMax(RootReference<K, V>, K, boolean, boolean) - Method in class org.h2.mvstore.MVMap
 
getMinMaxColumnIndex() - Method in class org.h2.expression.aggregate.Aggregate
 
getMinorVersion() - Method in class org.h2.Driver
Get the minor version number of the driver.
getMinutes() - Method in class org.h2.api.Interval
Returns minutes value, if any.
getMinValue() - Method in class org.h2.schema.Sequence
 
getMinValue(Sequence, SessionLocal) - Method in class org.h2.command.ddl.SequenceOptions
Gets min value.
getMisses() - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Get the number of cache misses.
getMode() - Method in interface org.h2.engine.CastDataProvider
Returns the database mode.
getMode() - Method in class org.h2.engine.Database
 
getMode() - Method in class org.h2.engine.SessionLocal
 
getMode() - Method in class org.h2.engine.SessionRemote
 
getMode() - Method in class org.h2.jdbc.JdbcConnection
 
getMode() - Method in class org.h2.jmx.DatabaseInfo
 
getMode() - Method in interface org.h2.jmx.DatabaseInfoMBean
The database compatibility mode (REGULAR if no compatibility mode is used).
getMode(SessionLocal, AggregateData) - Method in class org.h2.expression.aggregate.Aggregate
 
getModificationDataId() - Method in class org.h2.engine.Database
 
getModificationId() - Method in class org.h2.engine.DbObject
 
getModificationId() - Method in class org.h2.engine.SessionLocal
 
getModificationMetaId() - Method in class org.h2.command.Prepared
Get the meta data modification id of the database when this statement was compiled.
getModificationMetaId() - Method in class org.h2.engine.Database
 
getMonths() - Method in class org.h2.api.Interval
Returns months value, if any.
getMonthsAndWeeks(int) - Static method in class org.h2.expression.function.DayMonthNameFunction
Return names of month or weeks.
getMoreResults() - Method in class org.h2.jdbc.JdbcStatement
Moves to the next result set - however there is always only one result set.
getMoreResults(int) - Method in class org.h2.jdbc.JdbcStatement
Move to the next result set.
getMortonRanges(int[], int[]) - Method in class org.h2.tools.MultiDimension
Gets a list of ranges to be searched for a multi-dimensional range query where min <= value <= max.
getMovePriority(int) - Method in class org.h2.mvstore.FileStore
Calculates relative "priority" for chunk to be moved.
getMovePriority(int) - Method in class org.h2.mvstore.FreeSpaceBitSet
Calculates relative "priority" for chunk to be moved.
getMovePriority(Chunk) - Method in class org.h2.mvstore.MVStore
 
getMVMap() - Method in class org.h2.mvstore.db.MVDelegateIndex
 
getMVMap() - Method in class org.h2.mvstore.db.MVIndex
 
getMVMap() - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
getMVMap() - Method in class org.h2.mvstore.db.MVSecondaryIndex
 
getMVMap() - Method in class org.h2.mvstore.db.MVSpatialIndex
 
getMvStore() - Method in class org.h2.mvstore.db.Store
 
getName() - Method in class org.h2.api.H2Type
 
getName() - Method in class org.h2.bnf.context.DbColumn
 
getName() - Method in class org.h2.bnf.context.DbProcedure
 
getName() - Method in class org.h2.bnf.context.DbTableOrView
 
getName() - Method in class org.h2.engine.ConnectionInfo
Get the unique and normalized database name (excluding settings).
getName() - Method in class org.h2.engine.Database
 
getName() - Method in class org.h2.engine.DbObject
Get the name.
getName() - Method in class org.h2.engine.Mode
 
getName() - Method in class org.h2.engine.Procedure
 
getName() - Method in class org.h2.expression.function.ArrayFunction
 
getName() - Method in class org.h2.expression.function.BitFunction
 
getName() - Method in class org.h2.expression.function.CardinalityExpression
 
getName() - Method in class org.h2.expression.function.CastSpecification
 
getName() - Method in class org.h2.expression.function.CoalesceFunction
 
getName() - Method in class org.h2.expression.function.CompatibilitySequenceValueFunction
 
getName() - Method in class org.h2.expression.function.CompressFunction
 
getName() - Method in class org.h2.expression.function.ConcatFunction
 
getName() - Method in class org.h2.expression.function.CryptFunction
 
getName() - Method in class org.h2.expression.function.CSVWriteFunction
 
getName() - Method in class org.h2.expression.function.CurrentDateTimeValueFunction
 
getName() - Method in class org.h2.expression.function.CurrentGeneralValueSpecification
 
getName() - Method in class org.h2.expression.function.DataTypeSQLFunction
 
getName() - Method in class org.h2.expression.function.DateTimeFormatFunction
 
getName() - Method in class org.h2.expression.function.DateTimeFunction
 
getName() - Method in class org.h2.expression.function.DayMonthNameFunction
 
getName() - Method in class org.h2.expression.function.DBObjectFunction
 
getName() - Method in class org.h2.expression.function.FileFunction
 
getName() - Method in class org.h2.expression.function.HashFunction
 
getName() - Method in class org.h2.expression.function.JavaFunction
 
getName() - Method in class org.h2.expression.function.JsonConstructorFunction
 
getName() - Method in class org.h2.expression.function.LengthFunction
 
getName() - Method in class org.h2.expression.function.MathFunction
 
getName() - Method in class org.h2.expression.function.MathFunction1
 
getName() - Method in class org.h2.expression.function.MathFunction2
 
getName() - Method in interface org.h2.expression.function.NamedExpression
Get the name.
getName() - Method in class org.h2.expression.function.NullIfFunction
 
getName() - Method in class org.h2.expression.function.RandFunction
 
getName() - Method in class org.h2.expression.function.RegexpFunction
 
getName() - Method in class org.h2.expression.function.SessionControlFunction
 
getName() - Method in class org.h2.expression.function.SetFunction
 
getName() - Method in class org.h2.expression.function.SignalFunction
 
getName() - Method in class org.h2.expression.function.SoundexFunction
 
getName() - Method in class org.h2.expression.function.StringFunction
 
getName() - Method in class org.h2.expression.function.StringFunction1
 
getName() - Method in class org.h2.expression.function.StringFunction2
 
getName() - Method in class org.h2.expression.function.SubstringFunction
 
getName() - Method in class org.h2.expression.function.SysInfoFunction
 
getName() - Method in class org.h2.expression.function.table.ArrayTableFunction
 
getName() - Method in class org.h2.expression.function.table.CSVReadFunction
 
getName() - Method in class org.h2.expression.function.table.JavaTableFunction
 
getName() - Method in class org.h2.expression.function.table.LinkSchemaFunction
 
getName() - Method in class org.h2.expression.function.TableInfoFunction
 
getName() - Method in class org.h2.expression.function.ToCharFunction
 
getName() - Method in class org.h2.expression.function.TrimFunction
 
getName() - Method in class org.h2.expression.function.TruncateValueFunction
 
getName() - Method in class org.h2.expression.function.XMLFunction
 
getName() - Method in class org.h2.expression.Variable
 
getName() - Method in class org.h2.mode.ModeFunction
 
getName() - Method in class org.h2.mvstore.MVMap
Get the map name.
getName() - Method in class org.h2.mvstore.tx.Transaction
 
getName() - Method in class org.h2.security.auth.PropertyConfig
 
getName() - Method in class org.h2.security.auth.RealmConfig
Gets realm's name.
getName() - Method in class org.h2.server.pg.PgServer
 
getName() - Method in interface org.h2.server.Service
Get the human readable name of the service.
getName() - Method in class org.h2.server.TcpServer
 
getName() - Method in class org.h2.server.web.WebServer
 
getName() - Method in class org.h2.store.fs.FilePath
Get the file or directory name (the last element of the path).
getName() - Method in class org.h2.store.fs.mem.FileMemData
Get the file name
getName() - Method in class org.h2.store.fs.niomem.FileNioMemData
Get the file name
getName() - Method in class org.h2.table.Column
 
getName() - Method in class org.h2.value.CompareMode
 
getName(int) - Static method in class org.h2.expression.function.CurrentDateTimeValueFunction
Get the name for this function id.
getName(int) - Static method in class org.h2.expression.function.SysInfoFunction
Get the name for this function id.
getName(int) - Method in class org.h2.store.fs.split.FilePathSplit
 
getName(String) - Static method in class org.h2.store.fs.FileUtils
Get the file or directory name (the last element of the path).
getName(String, int) - Static method in class org.h2.jdbc.JdbcSavepoint
Get the savepoint name for this name or id.
getName(Locale) - Static method in class org.h2.value.CompareMode
Get the collation name.
getNanos() - Method in class org.h2.value.ValueTime
 
getNanos() - Method in class org.h2.value.ValueTimeTimeZone
 
getNanosOfSecond() - Method in class org.h2.api.Interval
Returns value of fractional part of seconds (in nanoseconds), if any.
getNCharacterStream(int) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a reader.
getNCharacterStream(int) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a reader.
getNCharacterStream(int) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
getNCharacterStream(String) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a reader.
getNCharacterStream(String) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a reader.
getNCharacterStream(String) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
getNClob(int) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a Clob.
getNClob(int) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a Clob.
getNClob(int) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
getNClob(String) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a Clob.
getNClob(String) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a Clob.
getNClob(String) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
getNestedIdentity() - Method in class org.h2.security.auth.AuthenticationInfo
Gets nested identity object that can be used by authenticator to hold information.
getNestedJoin() - Method in class org.h2.table.TableFilter
 
getNestedJoinPlan() - Method in class org.h2.table.PlanItem
 
getNetworkConnectionInfo() - Method in class org.h2.engine.ConnectionInfo
Returns the network connection information, or null.
getNetworkConnectionInfo() - Method in class org.h2.engine.SessionLocal
Returns the network connection information, or null.
getNetworkTimeout() - Method in class org.h2.jdbc.JdbcConnection
[Not supported]
getNewMapLen() - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
Calculate the new number of hash table buckets if the internal map should be re-sized.
getNewRandom() - Static method in class org.h2.value.ValueUuid
Create a new UUID using the pseudo random number generator.
getNewValue(VersionedValue<V>) - Method in class org.h2.mvstore.tx.TxDecisionMaker
Get the new value.
getNewValue(VersionedValue<V>) - Method in class org.h2.mvstore.tx.TxDecisionMaker.LockDecisionMaker
 
getNext() - Method in class org.h2.bnf.Sentence
Get the map of next tokens.
getNext(SessionLocal) - Method in class org.h2.schema.Sequence
Get the next value for this sequence.
getNextId() - Method in class org.h2.engine.SessionRemote
 
getNextId(int) - Static method in class org.h2.message.TraceObject
Get the next trace object id for this object type.
getNextKey() - Method in class org.h2.mvstore.StreamStore
 
getNextModificationDataId() - Method in class org.h2.engine.Database
 
getNextModificationMetaId() - Method in class org.h2.engine.Database
 
getNextRemoteSettingsId() - Method in class org.h2.engine.Database
 
getNextSystemIdentifier(String) - Method in class org.h2.engine.SessionLocal
Get the next system generated identifiers.
getNextTempFileNamePart(boolean) - Static method in class org.h2.store.fs.FilePath
Get the next temporary file name part (the part in the middle).
getNextTokenList(String) - Method in class org.h2.bnf.Bnf
Get the list of tokens that can follow.
getNextValueFor(Sequence, Prepared) - Method in class org.h2.engine.SessionLocal
Returns the next value of the sequence in this session.
getNoCopy(byte[]) - Static method in class org.h2.value.ValueBinary
Get or create a VARBINARY value for the given byte array.
getNoCopy(byte[]) - Static method in class org.h2.value.ValueJavaObject
Get or create a java object value for the given byte array.
getNoCopy(byte[]) - Static method in class org.h2.value.ValueVarbinary
Get or create a VARBINARY value for the given byte array.
getNodeType() - Method in class org.h2.mvstore.Page
 
getNodeType() - Method in class org.h2.mvstore.Page.Leaf
 
getNodeType() - Method in class org.h2.mvstore.Page.NonLeaf
 
getNonAliasExpression() - Method in class org.h2.expression.Alias
 
getNonAliasExpression() - Method in class org.h2.expression.Expression
Returns the main expression, skipping aliases.
getNonKeywords() - Method in class org.h2.engine.SessionLocal
Gets bit set of non-keywords.
getNonPrimitiveClass(Class<?>) - Static method in class org.h2.util.Utils
Convert primitive class names to java.lang.* class names.
getNotCompareType() - Method in class org.h2.expression.condition.Comparison
 
getNotFromResolverVisitor(ColumnResolver) - Static method in class org.h2.expression.ExpressionVisitor
Create a new visitor to check if no expression depends on the given resolver.
getNotIfPossible(SessionLocal) - Method in class org.h2.expression.condition.BetweenPredicate
 
getNotIfPossible(SessionLocal) - Method in class org.h2.expression.condition.BooleanTest
 
getNotIfPossible(SessionLocal) - Method in class org.h2.expression.condition.CompareLike
 
getNotIfPossible(SessionLocal) - Method in class org.h2.expression.condition.Comparison
 
getNotIfPossible(SessionLocal) - Method in class org.h2.expression.condition.ConditionAndOr
 
getNotIfPossible(SessionLocal) - Method in class org.h2.expression.condition.ConditionAndOrN
 
getNotIfPossible(SessionLocal) - Method in class org.h2.expression.condition.ConditionIn
 
getNotIfPossible(SessionLocal) - Method in class org.h2.expression.condition.ConditionInConstantSet
 
getNotIfPossible(SessionLocal) - Method in class org.h2.expression.condition.ConditionInParameter
 
getNotIfPossible(SessionLocal) - Method in class org.h2.expression.condition.ConditionInQuery
 
getNotIfPossible(SessionLocal) - Method in class org.h2.expression.condition.ConditionNot
 
getNotIfPossible(SessionLocal) - Method in class org.h2.expression.condition.IsJsonPredicate
 
getNotIfPossible(SessionLocal) - Method in class org.h2.expression.condition.NullPredicate
 
getNotIfPossible(SessionLocal) - Method in class org.h2.expression.condition.TypePredicate
 
getNotIfPossible(SessionLocal) - Method in class org.h2.expression.Expression
If it is possible, return the negated expression.
getNotIfPossible(SessionLocal) - Method in class org.h2.expression.ExpressionColumn
 
getNotIfPossible(SessionLocal) - Method in class org.h2.expression.Parameter
 
getNotIfPossible(SessionLocal) - Method in class org.h2.expression.ValueExpression
 
getNotNull(ArrayList<Object>) - Static method in class org.h2.mvstore.rtree.SpatialDataType
 
getNString(int) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a String.
getNString(int) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a String.
getNString(int) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
getNString(String) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a String.
getNString(String) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a String.
getNString(String) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
getNth(SessionLocal, HashMap<Integer, Value>, ArrayList<Value[]>, int) - Method in class org.h2.expression.analysis.WindowFunction
 
getNthValue(Iterator<Value[]>, int, boolean) - Static method in class org.h2.expression.analysis.WindowFunction
 
getNtile(HashMap<Integer, Value>, ArrayList<Value[]>, int) - Static method in class org.h2.expression.analysis.WindowFunction
 
getNullable() - Method in class org.h2.expression.Alias
 
getNullable() - Method in class org.h2.expression.Expression
Check whether this expression is a column and can store NULL.
getNullable() - Method in class org.h2.expression.ExpressionColumn
 
getNullable() - Method in class org.h2.expression.Format
 
getNullable() - Method in interface org.h2.expression.ParameterInterface
Check if this column is nullable.
getNullable() - Method in class org.h2.expression.ParameterRemote
 
getNullable(int) - Method in class org.h2.result.LazyResult
 
getNullable(int) - Method in class org.h2.result.LocalResult
 
getNullable(int) - Method in interface org.h2.result.ResultInterface
Check if this column is nullable.
getNullable(int) - Method in class org.h2.result.ResultRemote
 
getNullable(int) - Method in class org.h2.result.ResultWithPaddedStrings
 
getNullable(int) - Method in class org.h2.result.SimpleResult
 
getNullOrValue(SessionLocal, Expression[], Value[], int) - Static method in class org.h2.mode.ModeFunction
Get value transformed by expression, or null if i is out of range or the input value is null.
getNullRow() - Method in class org.h2.table.Table
 
getNullSafeValueSlow(SessionLocal, ResultInterface, Value) - Method in class org.h2.expression.condition.ConditionInQuery
 
getNullString() - Method in class org.h2.tools.Csv
Get the current null string.
getNumber(String) - Static method in class org.h2.value.ValueJson
 
getNumeric(int, TypeInfo, Value, Value) - Static method in class org.h2.expression.function.BitFunction
 
getNumericFunctions() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the list of numeric functions supported by this database.
getNumericFunctions() - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getNumericFunctions() - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getNumericFunctions() - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getNumericFunctions() - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getNumExpressions() - Method in class org.h2.expression.aggregate.Aggregate
 
getNumExpressions() - Method in class org.h2.expression.aggregate.JavaAggregate
 
getNumExpressions() - Method in class org.h2.expression.analysis.DataAnalysisOperation
Returns the number of expressions, excluding OVER clause.
getNumExpressions() - Method in class org.h2.expression.analysis.WindowFunction
 
getNumFrameExpressions() - Method in class org.h2.expression.analysis.DataAnalysisOperation
Returns the number of window frame expressions.
getObject(int) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns a column value as a Java object.
getObject(int) - Method in class org.h2.jdbc.JdbcResultSet
Returns a column value as a Java object.
getObject(int) - Method in class org.h2.tools.SimpleResultSet
Returns the value as an Object.
getObject(int, boolean) - Method in class org.h2.util.SmallMap
Get an object from the map if it is stored.
getObject(int, Class<T>) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a Java object of the specified type.
getObject(int, Class<T>) - Method in class org.h2.jdbc.JdbcResultSet
Returns a column value as a Java object of the specified type.
getObject(int, Class<T>) - Method in class org.h2.tools.SimpleResultSet
Returns the value as an Object of the specified type.
getObject(int, Map<String, Class<?>>) - Method in class org.h2.jdbc.JdbcCallableStatement
[Not supported] Gets a column as a object using the specified type mapping.
getObject(int, Map<String, Class<?>>) - Method in class org.h2.jdbc.JdbcResultSet
[Not supported] Gets a column as a object using the specified type mapping.
getObject(int, Map<String, Class<?>>) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
getObject(String) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns a column value as a Java object.
getObject(String) - Method in class org.h2.jdbc.JdbcResultSet
Returns a column value as a Java object.
getObject(String) - Method in class org.h2.tools.SimpleResultSet
Returns the value as an Object.
getObject(String, Class<T>) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a Java object of the specified type.
getObject(String, Class<T>) - Method in class org.h2.jdbc.JdbcResultSet
Returns a column value as a Java object of the specified type.
getObject(String, Class<T>) - Method in class org.h2.tools.SimpleResultSet
Returns the value as an Object of the specified type.
getObject(String, Map<String, Class<?>>) - Method in class org.h2.jdbc.JdbcCallableStatement
[Not supported] Gets a column as a object using the specified type mapping.
getObject(String, Map<String, Class<?>>) - Method in class org.h2.jdbc.JdbcResultSet
[Not supported] Gets a column as a object using the specified type mapping.
getObject(String, Map<String, Class<?>>) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
getObjectId() - Method in class org.h2.command.Prepared
Get the current object id, or get a new id from the database.
getObjectInstance(Object, Name, Context, Hashtable<?, ?>) - Method in class org.h2.jdbcx.JdbcDataSourceFactory
Creates a new object using the specified location or reference information.
getObjectName(MonitorInfo) - Static method in class org.h2.util.AbbaLockingDetector
 
getObjectName(Object) - Static method in class org.h2.util.AbbaDetector
 
getObjectName(String, String) - Static method in class org.h2.jmx.DatabaseInfo
Returns a JMX new ObjectName instance.
getObjectType() - Method in class org.h2.engine.MetaRecord
 
getOffset() - Method in class org.h2.command.query.Query
 
getOffsetFetch(long) - Method in class org.h2.command.query.Query
Evaluates OFFSET and FETCH expressions.
getOldestVersionToKeep() - Method in class org.h2.mvstore.MVStore
Get the oldest version to retain.
getOnCommitDrop() - Method in class org.h2.table.Table
 
getOnCommitTruncate() - Method in class org.h2.table.Table
 
getOnCondition() - Method in class org.h2.command.dml.MergeUsing
 
getOnDuplicateKeyInsert() - Method in class org.h2.command.dml.Update
 
getOnDuplicateKeyValue(int) - Method in class org.h2.command.dml.Insert
Get the value to use for the specified column in case of a duplicate key.
getOnOverflowTruncate() - Method in class org.h2.expression.aggregate.ListaggArguments
Returns the LISTAGG overflow behavior.
getOnUpdateExpression() - Method in class org.h2.schema.Domain
 
getOnUpdateExpression() - Method in class org.h2.table.Column
 
getOnUpdateExpression() - Method in interface org.h2.table.ColumnTemplate
 
getOnUpdateSQL() - Method in class org.h2.schema.Domain
 
getOnUpdateSQL() - Method in class org.h2.table.Column
 
getOnUpdateSQL() - Method in interface org.h2.table.ColumnTemplate
 
getOpenResultSet() - Method in class org.h2.jdbc.JdbcCallableStatement
 
getOpenStackTrace() - Method in class org.h2.util.CloseWatcher
Get the open stack trace or null if none.
getOpenTransactions() - Method in class org.h2.mvstore.tx.TransactionStore
Get the list of unclosed transactions that have pending writes.
getOperationId() - Method in class org.h2.mvstore.tx.VersionedValueUncommitted
 
getOperationId() - Method in class org.h2.value.VersionedValue
 
getOperationId(int, long) - Static method in class org.h2.mvstore.tx.TransactionStore
Combine the transaction id and the log id to an operation id.
getOperationToken() - Method in class org.h2.expression.BinaryOperation
 
getOperationToken() - Method in class org.h2.expression.IntervalOperation
 
getOperationType() - Method in class org.h2.expression.BinaryOperation
Returns the type of this binary operation.
getOptimizableVisitor(Table) - Static method in class org.h2.expression.ExpressionVisitor
Create a new visitor to check if all aggregates are for the given table.
getOptimizeReuseResults() - Method in class org.h2.engine.Database
 
getOrderBy() - Method in class org.h2.expression.analysis.Window
Returns ORDER BY clause.
getOrderedResult() - Method in class org.h2.expression.analysis.PartitionData
Returns the ordered result.
getOrderedResult(SessionLocal, SelectGroups, PartitionData, Object) - Method in class org.h2.expression.analysis.DataAnalysisOperation
 
getOrderedResultLoop(SessionLocal, HashMap<Integer, Value>, ArrayList<Value[]>, int) - Method in class org.h2.expression.aggregate.AbstractAggregate
 
getOrderedResultLoop(SessionLocal, HashMap<Integer, Value>, ArrayList<Value[]>, int) - Method in class org.h2.expression.analysis.DataAnalysisOperation
Returns result of this window function or window aggregate.
getOrderedResultLoop(SessionLocal, HashMap<Integer, Value>, ArrayList<Value[]>, int) - Method in class org.h2.expression.analysis.WindowFunction
 
getOrderInFrom() - Method in class org.h2.table.TableFilter
Get the order number (index) of this table filter in the "from" clause of the query.
getOrderList() - Method in class org.h2.result.SortOrder
Returns the original query order list.
getOriginalColumnName() - Method in class org.h2.expression.ExpressionColumn
 
getOriginalDbName(String, String) - Static method in class org.h2.tools.Restore
 
getOriginalMessage() - Method in interface org.h2.jdbc.JdbcException
INTERNAL
getOriginalMessage() - Method in exception org.h2.jdbc.JdbcSQLDataException
 
getOriginalMessage() - Method in exception org.h2.jdbc.JdbcSQLException
 
getOriginalMessage() - Method in exception org.h2.jdbc.JdbcSQLFeatureNotSupportedException
 
getOriginalMessage() - Method in exception org.h2.jdbc.JdbcSQLIntegrityConstraintViolationException
 
getOriginalMessage() - Method in exception org.h2.jdbc.JdbcSQLInvalidAuthorizationSpecException
 
getOriginalMessage() - Method in exception org.h2.jdbc.JdbcSQLNonTransientConnectionException
 
getOriginalMessage() - Method in exception org.h2.jdbc.JdbcSQLNonTransientException
 
getOriginalMessage() - Method in exception org.h2.jdbc.JdbcSQLSyntaxErrorException
 
getOriginalMessage() - Method in exception org.h2.jdbc.JdbcSQLTimeoutException
 
getOriginalMessage() - Method in exception org.h2.jdbc.JdbcSQLTransactionRollbackException
 
getOriginalMessage() - Method in exception org.h2.jdbc.JdbcSQLTransientException
 
getOriginalTableAliasName() - Method in class org.h2.expression.ExpressionColumn
 
getOriginalURL() - Method in class org.h2.engine.ConnectionInfo
Get the complete original database URL.
getOverflow() - Method in class org.h2.value.ValueBigint
 
getOverOrderBySort() - Method in class org.h2.expression.analysis.DataAnalysisOperation
Returns the sort order for OVER clause.
getOwner() - Method in class org.h2.schema.Schema
Get the owner of this schema.
getOwner() - Method in class org.h2.table.TableView
 
getPaddedArrayCopy(byte[], int) - Static method in class org.h2.expression.function.CryptFunction
 
getPage() - Method in class org.h2.mvstore.Cursor
Get the page where last retrieved key is located.
getPage() - Method in class org.h2.mvstore.Page.PageReference
 
getPage(int) - Method in class org.h2.store.fs.mem.FileMemData
Get the page if it exists.
getPageChunkId() - Method in class org.h2.mvstore.MVStore.RemovedPageInfo
 
getPageChunkId(long) - Static method in class org.h2.mvstore.DataUtils
Get the chunk id from the position.
getPageCount() - Method in class org.h2.mvstore.MVStore
Get data pages count.
getPageLength() - Method in class org.h2.mvstore.MVStore.RemovedPageInfo
 
getPageMapId(long) - Static method in class org.h2.mvstore.DataUtils
Get the map id from the chunk's table of content element.
getPageMaxLength(long) - Static method in class org.h2.mvstore.DataUtils
Get the maximum length for the given page position.
getPageNo() - Method in class org.h2.mvstore.MVStore.RemovedPageInfo
 
getPageOffset(long) - Static method in class org.h2.mvstore.DataUtils
Get the offset from the position.
getPagePos(int, int, int, int) - Static method in class org.h2.mvstore.DataUtils
Get the position of this page.
getPagePos(int, long) - Static method in class org.h2.mvstore.DataUtils
Convert tocElement into pagePos by replacing mapId with chunkId.
getPageSize() - Method in class org.h2.engine.Database
 
getPageSplitSize() - Method in class org.h2.mvstore.MVStore
 
getPageType(long) - Static method in class org.h2.mvstore.DataUtils
Get the page type from the position.
getPanicException() - Method in class org.h2.mvstore.MVStore
 
getParameter(int) - Method in class org.h2.jdbc.JdbcParameterMetaData
 
getParameter(ServletContext, String, String) - Static method in class org.h2.server.web.JakartaDbStarter
 
getParameter(ServletContext, String, String) - Static method in class org.h2.server.web.DbStarter
 
getParameterClassName(int) - Method in class org.h2.jdbc.JdbcParameterMetaData
Returns the Java class name of the parameter.
getParameterCount() - Method in class org.h2.jdbc.JdbcParameterMetaData
Returns the number of parameters.
getParameterCount() - Method in class org.h2.schema.FunctionAlias.JavaMethod
 
getParameterMetaData() - Method in class org.h2.jdbc.JdbcPreparedStatement
Get the parameter meta data of this prepared statement.
getParameterMode(int) - Method in class org.h2.jdbc.JdbcParameterMetaData
Returns the parameter mode.
getParameterOffset(ArrayList<Parameter>) - Method in class org.h2.table.TableView
Get the index of the first parameter.
getParameterResultSet(ParameterMetaData) - Static method in class org.h2.server.web.WebApp
 
getParameters() - Method in class org.h2.bnf.context.DbProcedure
 
getParameters() - Method in class org.h2.command.Command
Get the list of parameters.
getParameters() - Method in class org.h2.command.CommandContainer
 
getParameters() - Method in interface org.h2.command.CommandInterface
Get the parameters (if any).
getParameters() - Method in class org.h2.command.CommandList
 
getParameters() - Method in class org.h2.command.CommandRemote
 
getParameters() - Method in class org.h2.command.ddl.PrepareProcedure
 
getParameters() - Method in class org.h2.command.Prepared
Get the parameter list.
getParameterType(int) - Method in class org.h2.jdbc.JdbcParameterMetaData
Returns the parameter type.
getParameterTypeName(int) - Method in class org.h2.jdbc.JdbcParameterMetaData
Returns the parameter type name.
getParameterValues() - Method in class org.h2.command.query.Query
 
getParamValue() - Method in class org.h2.expression.Parameter
 
getParamValue() - Method in interface org.h2.expression.ParameterInterface
Get the value of the parameter if set.
getParamValue() - Method in class org.h2.expression.ParameterRemote
 
getParent() - Method in class org.h2.store.fs.disk.FilePathDisk
 
getParent() - Method in class org.h2.store.fs.FilePath
Get the parent directory of a file or directory.
getParent() - Method in class org.h2.store.fs.FilePathWrapper
 
getParent() - Method in class org.h2.store.fs.mem.FilePathMem
 
getParent() - Method in class org.h2.store.fs.niomem.FilePathNioMem
 
getParent() - Method in class org.h2.store.fs.zip.FilePathZip
 
getParent(String) - Static method in class org.h2.store.fs.FileUtils
Get the parent directory of a file or directory.
getParentLogger() - Method in class org.h2.Driver
[Not supported]
getParentLogger() - Method in class org.h2.jdbcx.JdbcConnectionPool
[Not supported]
getParentLogger() - Method in class org.h2.jdbcx.JdbcDataSource
[Not supported]
getParentSelect() - Method in class org.h2.command.query.Select
Returns parent select, or null.
getPassword() - Method in class org.h2.jdbcx.JdbcDataSource
Get the current password.
getPassword() - Method in class org.h2.security.auth.AuthenticationInfo
 
getPasswordBytes(char[]) - Static method in class org.h2.store.fs.encrypt.FilePathEncrypt
Convert a char array to a byte array, in UTF-16 format.
getPath(String) - Method in class org.h2.store.fs.disk.FilePathDisk
 
getPath(String) - Method in class org.h2.store.fs.FilePath
Convert a file to a path.
getPath(String) - Method in class org.h2.store.fs.FilePathWrapper
 
getPath(String) - Method in class org.h2.store.fs.mem.FilePathMem
 
getPath(String) - Method in class org.h2.store.fs.mem.FilePathMemLZF
 
getPath(String) - Method in class org.h2.store.fs.niomem.FilePathNioMem
 
getPath(String) - Method in class org.h2.store.fs.niomem.FilePathNioMemLZF
 
getPath(String) - Method in class org.h2.store.fs.zip.FilePathZip
 
getPattern(String) - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getPBKDF2(byte[], byte[], int, int) - Static method in class org.h2.security.SHA256
Calculate the hash using the password-based key derivation function 2.
getPercent(long, long) - Static method in class org.h2.mvstore.MVStoreTool
 
getPersistedObjectId() - Method in class org.h2.command.Prepared
Get the object id to use for the database object that is created in this statement.
getPlanFromFilter(StringBuilder, int, TableFilter, boolean) - Static method in class org.h2.command.query.Select
 
getPlanSQL() - Method in class org.h2.index.DualIndex
 
getPlanSQL() - Method in class org.h2.index.Index
Get the message to show in a EXPLAIN statement.
getPlanSQL() - Method in class org.h2.index.MetaIndex
 
getPlanSQL() - Method in class org.h2.index.RangeIndex
 
getPlanSQL() - Method in class org.h2.index.ViewIndex
 
getPlanSQL() - Method in class org.h2.index.VirtualConstructedTableIndex
 
getPlanSQL() - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
getPlanSQL(int) - Method in class org.h2.command.dml.Delete
 
getPlanSQL(int) - Method in class org.h2.command.dml.Insert
 
getPlanSQL(int) - Method in class org.h2.command.dml.Merge
 
getPlanSQL(int) - Method in class org.h2.command.dml.MergeUsing
 
getPlanSQL(int) - Method in class org.h2.command.dml.Update
 
getPlanSQL(int) - Method in class org.h2.command.Prepared
Get the SQL statement with the execution plan.
getPlanSQL(int) - Method in class org.h2.command.query.Select
 
getPlanSQL(int) - Method in class org.h2.command.query.SelectUnion
 
getPlanSQL(int) - Method in class org.h2.command.query.TableValueConstructor
 
getPlanSQL(StringBuilder, boolean, int) - Method in class org.h2.table.TableFilter
Get the query execution plan text to use for this table filter and append it to the specified builder.
getPooledConnection() - Method in class org.h2.jdbcx.JdbcDataSource
Open a new pooled connection using the current URL, user name and password.
getPooledConnection(String, String) - Method in class org.h2.jdbcx.JdbcDataSource
Open a new pooled connection using the current URL and the specified user name and password.
getPort() - Method in class org.h2.server.pg.PgServer
 
getPort() - Method in interface org.h2.server.Service
Gets the port this service is listening on.
getPort() - Method in class org.h2.server.TcpServer
 
getPort() - Method in class org.h2.server.web.WebServer
 
getPort() - Method in class org.h2.tools.Server
Gets the port this server is listening on.
getPos() - Method in class org.h2.mvstore.Page
Get the position of the page
getPos() - Method in class org.h2.mvstore.Page.PageReference
 
getPos() - Method in class org.h2.server.TcpServerThread.CachedInputStream
 
getPos() - Method in class org.h2.util.CacheObject
 
getPos(int) - Method in class org.h2.mvstore.FreeSpaceBitSet
 
getPosition() - Method in class org.h2.bnf.context.DbColumn
 
getPowerOffCount() - Method in class org.h2.engine.Database
 
getPrecision() - Method in class org.h2.value.TypeInfo
Returns the precision.
getPrecision(int) - Method in class org.h2.expression.ConcatenationOperation
 
getPrecision(int) - Method in class org.h2.expression.function.ConcatFunction
 
getPrecision(int) - Method in class org.h2.jdbc.JdbcParameterMetaData
Returns the parameter precision.
getPrecision(int) - Method in class org.h2.jdbc.JdbcResultSetMetaData
Gets the precision for this column.
getPrecision(int) - Method in class org.h2.tools.SimpleResultSet
Returns the precision.
getPrefix() - Method in class org.h2.store.fs.encrypt.FilePathEncrypt
 
getPrefix() - Method in class org.h2.store.fs.FilePathWrapper
 
getPrefix() - Method in class org.h2.store.fs.split.FilePathSplit
 
getPrepared() - Method in class org.h2.engine.Procedure
 
getPrependCursorPos(CursorPos<K, V>) - Method in class org.h2.mvstore.Page
Extend path from a given CursorPos chain to "prepend point" in a B-tree, rooted at this Page.
getPrependCursorPos(CursorPos<K, V>) - Method in class org.h2.mvstore.Page.Leaf
 
getPrependCursorPos(CursorPos<K, V>) - Method in class org.h2.mvstore.Page.NonLeaf
 
getPreserveWhitespace() - Method in class org.h2.tools.Csv
Whether whitespace in unquoted text is preserved.
getPrimaryKey() - Method in class org.h2.command.ddl.CommandWithColumns
 
getPrimaryKey() - Method in class org.h2.table.Table
 
getPrimaryKeys(String, String, String) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the primary key columns for a table.
getPrimaryKeys(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getPrimaryKeys(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getPrimaryKeys(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getPrimaryKeys(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getProcedure(String) - Method in class org.h2.engine.SessionLocal
Get the procedure with the given name, or null if none exists.
getProcedureColumn(DbContents, ResultSet) - Static method in class org.h2.bnf.context.DbColumn
Create a column from a DatabaseMetaData.getProcedureColumns row.
getProcedureColumnAdd(SimpleResult, Value, Value, Value, Value, TypeInfo, boolean, int) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getProcedureColumns(String, String, String, String) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the list of procedure columns.
getProcedureColumns(String, String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getProcedureColumns(String, String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getProcedureColumns(String, String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getProcedureColumns(String, String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getProcedures() - Method in class org.h2.bnf.context.DbSchema
 
getProcedures(String, String, String) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the list of procedures.
getProcedures(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getProcedures(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getProcedures(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getProcedures(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getProceduresAdd(SimpleResult, Value, Value, Value, String, ValueSmallint, Value) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getProcedureTerm() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the term for "procedure".
getProcessId() - Method in class org.h2.server.pg.PgServerThread
 
getProjectedFillRate(int) - Method in class org.h2.mvstore.FileStore
Calculates a prospective fill rate, which store would have after rewrite of sparsely populated chunk(s) and evacuation of still live data into a new chunk.
getProjectedFillRate(int) - Method in class org.h2.mvstore.FreeSpaceBitSet
Calculates a prospective fill rate, which store would have after rewrite of sparsely populated chunk(s) and evacuation of still live data into a new chunk.
getProjectedFillRate(int) - Method in class org.h2.mvstore.MVStore
 
getProperties() - Method in interface org.h2.security.auth.HasConfigProperties
 
getProperties() - Method in class org.h2.security.auth.RealmConfig
 
getProperties() - Method in class org.h2.security.auth.UserToRolesMapperConfig
 
getProperty(int, String) - Method in class org.h2.engine.ConnectionInfo
Get the value of the given property.
getProperty(String) - Method in class org.h2.engine.ConnectionInfo
Get the value of the given property.
getProperty(String, boolean) - Method in class org.h2.engine.ConnectionInfo
Get a boolean property if it is set and return the value.
getProperty(String, boolean) - Static method in class org.h2.util.Utils
Get the system property.
getProperty(String, int) - Method in class org.h2.engine.ConnectionInfo
Get the value of the given property.
getProperty(String, int) - Static method in class org.h2.util.Utils
Get the system property.
getProperty(String, String) - Method in class org.h2.engine.ConnectionInfo
Get the value of the given property.
getProperty(String, String) - Static method in class org.h2.util.Utils
Get the system property.
getPropertyInfo(String, Properties) - Method in class org.h2.Driver
Get the list of supported properties.
getPseudoColumns(String, String, String, String) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the list of pseudo and invisible columns.
getPseudoColumns(String, String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getPseudoColumns(String, String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getPseudoColumns(String, String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getPseudoColumns(String, String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getPseudoColumnsAdd(SimpleResult, Value, Value, Value, CompareLike, Column) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getPseudoColumnsAdd(SimpleResult, Value, Value, Value, Table, CompareLike) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getPseudoColumnsResult() - Method in class org.h2.jdbc.meta.DatabaseMetaLocalBase
 
getPublicRole() - Method in class org.h2.engine.Database
 
getQualifiedTable() - Method in class org.h2.table.TableLink
 
getQualifier() - Method in class org.h2.api.Interval
Returns qualifier of this interval.
getQualifier() - Method in class org.h2.value.ValueInterval
Returns the interval qualifier.
getQualify() - Method in class org.h2.command.query.Select
 
getQueries() - Method in class org.h2.engine.QueryStatisticsData
 
getQuery() - Method in class org.h2.bnf.Sentence
Get the query string.
getQuery() - Method in class org.h2.expression.Subquery
 
getQuery() - Method in class org.h2.index.ViewIndex
 
getQuery() - Method in class org.h2.table.TableView
 
getQuery(Object[]) - Method in class org.h2.fulltext.FullTextLucene.FullTextTrigger
 
getQuery(SessionLocal, int[]) - Method in class org.h2.index.ViewIndex
 
getQueryColumnIndexes() - Method in class org.h2.result.SortOrder
Get the column index list.
getQueryLevel() - Method in class org.h2.expression.ExpressionVisitor
 
getQueryStatistics() - Method in class org.h2.engine.Database
 
getQueryStatisticsData() - Method in class org.h2.engine.Database
 
getQueryTimeout - Variable in class org.h2.jdbc.JdbcConnection
 
getQueryTimeout() - Method in class org.h2.engine.SessionLocal
 
getQueryTimeout() - Method in class org.h2.jdbc.JdbcConnection
INTERNAL
getQueryTimeout() - Method in class org.h2.jdbc.JdbcStatement
Gets the current query timeout in seconds.
getQueryUpper() - Method in class org.h2.bnf.Sentence
Get the uppercase version of the query string.
getQueueSize() - Method in class org.h2.schema.TriggerObject
 
getQuotedName() - Method in class org.h2.bnf.context.DbColumn
 
getQuotedName() - Method in class org.h2.bnf.context.DbProcedure
 
getQuotedName() - Method in class org.h2.bnf.context.DbTableOrView
 
getRadix(int, boolean) - Static method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getRandom() - Method in class org.h2.engine.SessionLocal
 
getRank(HashMap<Integer, Value>, ArrayList<Value[]>, int) - Method in class org.h2.expression.analysis.WindowFunction
 
getRank(Value[], Value, Comparator<Value>) - Method in class org.h2.expression.aggregate.Aggregate
 
getRatioToReport(HashMap<Integer, Value>, ArrayList<Value[]>, int) - Static method in class org.h2.expression.analysis.WindowFunction
 
getRawChildPageCount() - Method in class org.h2.mvstore.Page
 
getRawChildPageCount() - Method in class org.h2.mvstore.Page.Leaf
 
getRawChildPageCount() - Method in class org.h2.mvstore.Page.NonLeaf
 
getReadBytes() - Method in class org.h2.mvstore.FileStore
Get the number of read bytes since this store was opened.
getReadCount() - Method in class org.h2.mvstore.FileStore
Get the number of read operations since this store was opened.
getReader() - Method in class org.h2.value.Value
 
getReader() - Method in class org.h2.value.ValueLob
 
getReader() - Method in class org.h2.value.ValueNull
 
getReader(long, long) - Method in class org.h2.value.Value
Get the reader
getReader(long, long) - Method in class org.h2.value.ValueBlob
 
getReader(long, long) - Method in class org.h2.value.ValueClob
 
getReader(long, long) - Method in class org.h2.value.ValueNull
 
getReader(InputStream) - Static method in class org.h2.util.IOUtils
Create a reader to read from an input stream using the UTF-8 format.
getReadOnly - Variable in class org.h2.jdbc.JdbcConnection
 
getRealm() - Method in class org.h2.security.auth.AuthenticationInfo
 
getRealms() - Method in class org.h2.security.auth.H2AuthConfig
Gets configuration of authentication realms.
getRecursiveResult() - Method in class org.h2.table.TableView
 
getRef(int) - Method in class org.h2.jdbc.JdbcCallableStatement
[Not supported] Gets a column as a reference.
getRef(int) - Method in class org.h2.jdbc.JdbcResultSet
[Not supported] Gets a column as a reference.
getRef(int) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
getRef(String) - Method in class org.h2.jdbc.JdbcCallableStatement
[Not supported] Gets a column as a reference.
getRef(String) - Method in class org.h2.jdbc.JdbcResultSet
[Not supported] Gets a column as a reference.
getRef(String) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
getRefAction(ConstraintActionType) - Static method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getRefAction(ConstraintActionType) - Static method in class org.h2.table.InformationSchemaTableLegacy
 
getRefColumns() - Method in class org.h2.constraint.ConstraintReferential
 
getReference() - Method in class org.h2.jdbcx.JdbcDataSource
Get a new reference for this object, using the current settings.
getReferencedColumns(Table) - Method in class org.h2.constraint.Constraint
Get all referenced columns.
getReferencedColumns(Table) - Method in class org.h2.constraint.ConstraintCheck
 
getReferencedColumns(Table) - Method in class org.h2.constraint.ConstraintDomain
 
getReferencedColumns(Table) - Method in class org.h2.constraint.ConstraintReferential
 
getReferencedColumns(Table) - Method in class org.h2.constraint.ConstraintUnique
 
getReferencedConstraint() - Method in class org.h2.constraint.Constraint
Returns the referenced unique constraint, or null.
getReferencedConstraint() - Method in class org.h2.constraint.ConstraintReferential
 
getReferentialIntegrity() - Method in class org.h2.engine.Database
 
getRefTable() - Method in class org.h2.constraint.Constraint
 
getRefTable() - Method in class org.h2.constraint.ConstraintReferential
 
getRegular() - Static method in class org.h2.engine.Mode
 
getRemaining() - Method in class org.h2.api.Interval
Returns combined value of remaining fields of this interval.
getRemaining() - Method in class org.h2.value.ValueInterval
Returns combined value of remaining fields of this interval.
getRemainingTokens(int) - Method in class org.h2.command.Parser
 
getRemoteSettingsId() - Method in class org.h2.engine.Database
 
getResolver() - Method in class org.h2.expression.ExpressionVisitor
Get the column resolver.
getResource(String) - Static method in class org.h2.util.Utils
Get a resource from the resource map.
getResources() - Method in class org.h2.jmx.DocumentedMBean
 
getRestartValue(SessionLocal, long) - Method in class org.h2.command.ddl.SequenceOptions
Gets restart value.
getResult() - Method in interface org.h2.api.Aggregate
This method returns the computed aggregate value.
getResult() - Method in interface org.h2.api.AggregateFunction
This method returns the computed aggregate value.
getResult() - Method in class org.h2.expression.analysis.PartitionData
Returns the result.
getResult() - Method in class org.h2.jdbc.JdbcResultSet
INTERNAL
getResult() - Method in class org.h2.result.MergedResult
Returns merged results.
getResult() - Method in class org.h2.schema.UserAggregate.AggregateWrapper
 
getResult() - Method in class org.h2.security.auth.H2AuthConfigXml
Returns parsed authenticator configuration.
getResult() - Method in class org.h2.util.json.JSONByteArrayTarget
 
getResult() - Method in class org.h2.util.json.JSONStringTarget
 
getResult() - Method in class org.h2.util.json.JSONTarget
Returns the result.
getResult() - Method in class org.h2.util.json.JSONValidationTarget
 
getResult() - Method in class org.h2.util.json.JSONValidationTargetWithoutUniqueKeys
 
getResult() - Method in class org.h2.util.json.JSONValidationTargetWithUniqueKeys
 
getResult() - Method in class org.h2.util.json.JSONValueTarget
 
getResult() - Method in class org.h2.value.ValueRow
 
getResult(Connection, int, String, boolean, boolean) - Method in class org.h2.server.web.WebApp
 
getResult(PreparedStatement, int[], int[]) - Method in class org.h2.tools.MultiDimension
Executes a prepared query that was generated using generatePreparedQuery.
getResult(SessionLocal) - Method in class org.h2.table.DataChangeDeltaTable
 
getResult(SessionLocal) - Method in class org.h2.table.FunctionTable
 
getResult(SessionLocal) - Method in class org.h2.table.TableValueConstructorTable
 
getResult(SessionLocal) - Method in class org.h2.table.VirtualConstructedTable
Read the rows from the table.
getResultingValue() - Method in class org.h2.mode.ToDateParser
 
getResultingValueWithTimeZone() - Method in class org.h2.mode.ToDateParser
 
getResultSet() - Method in class org.h2.jdbc.JdbcArray
Returns the value as a result set.
getResultSet() - Method in class org.h2.jdbc.JdbcStatement
Returns the last result set produces by this statement.
getResultSet() - Method in class org.h2.tools.SimpleResultSet.SimpleArray
INTERNAL
getResultSet(long, int) - Method in class org.h2.jdbc.JdbcArray
Returns the value as a result set.
getResultSet(long, int) - Method in class org.h2.tools.SimpleResultSet.SimpleArray
INTERNAL
getResultSet(long, int, Map<String, Class<?>>) - Method in class org.h2.jdbc.JdbcArray
Returns the value as a result set.
getResultSet(long, int, Map<String, Class<?>>) - Method in class org.h2.tools.SimpleResultSet.SimpleArray
INTERNAL
getResultSet(String, ResultSet, boolean, boolean, boolean, long, boolean) - Method in class org.h2.server.web.WebApp
 
getResultSet(Map<String, Class<?>>) - Method in class org.h2.jdbc.JdbcArray
Returns the value as a result set.
getResultSet(Map<String, Class<?>>) - Method in class org.h2.tools.SimpleResultSet.SimpleArray
INTERNAL
getResultSet(ResultInterface) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
 
getResultSetConcurrency() - Method in class org.h2.jdbc.JdbcStatement
Gets the result set concurrency created by this object.
getResultSetHoldability() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the result set holdability.
getResultSetHoldability() - Method in class org.h2.jdbc.JdbcStatement
Gets the result set holdability.
getResultSetImpl(long, int) - Method in class org.h2.jdbc.JdbcArray
 
getResultSetType() - Method in class org.h2.jdbc.JdbcStatement
Gets the result set type.
getRetentionTime() - Method in class org.h2.engine.Database
 
getRetentionTime() - Method in class org.h2.mvstore.MVStore
 
getReuseSpace() - Method in class org.h2.mvstore.MVStore
 
getReversedCompareType(int) - Static method in class org.h2.expression.condition.Comparison
 
getRewritableChunksFillRate() - Method in class org.h2.mvstore.MVStore
 
getRight() - Method in class org.h2.command.query.SelectUnion
 
getRightForObject(DbObject) - Method in class org.h2.engine.RightOwner
Get the 'grant schema' right of this object.
getRightForRole(Role) - Method in class org.h2.engine.RightOwner
Get the 'grant role' right of this object.
getRightMask() - Method in class org.h2.engine.Right
 
getRights() - Method in class org.h2.engine.Right
 
getRoot() - Method in class org.h2.mvstore.MVMap
 
getRootPage() - Method in class org.h2.mvstore.MVMap
The current root page (may not be null).
getRootPos(int) - Method in class org.h2.mvstore.MVStore
 
getRow() - Method in class org.h2.jdbc.JdbcResultSet
Gets the current row number.
getRow() - Method in class org.h2.tools.SimpleResultSet
Returns the row number (1, 2,...) or 0 for no row.
getRow(SessionLocal, long) - Method in class org.h2.index.Index
Get the row with the given key.
getRow(SessionLocal, long) - Method in class org.h2.mvstore.db.MVDelegateIndex
 
getRow(SessionLocal, long) - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
getRow(SessionLocal, long) - Method in class org.h2.mvstore.db.MVTable
 
getRow(SessionLocal, long) - Method in class org.h2.table.Table
Get the given row.
getRowCount() - Method in class org.h2.command.CommandContainer.GeneratedKeysCollector
 
getRowCount() - Method in class org.h2.command.dml.Insert
 
getRowCount() - Method in class org.h2.expression.condition.UniquePredicate.Target
 
getRowCount() - Method in class org.h2.result.LazyResult
 
getRowCount() - Method in class org.h2.result.LocalResult
 
getRowCount() - Method in interface org.h2.result.ResultInterface
Get the number of rows in this object.
getRowCount() - Method in class org.h2.result.ResultRemote
 
getRowCount() - Method in interface org.h2.result.ResultTarget
Get the number of rows.
getRowCount() - Method in class org.h2.result.ResultWithPaddedStrings
 
getRowCount() - Method in class org.h2.result.SimpleResult
 
getRowCount(SessionLocal) - Method in class org.h2.index.Index
Get the row count of this table, for the given session.
getRowCount(SessionLocal) - Method in class org.h2.index.LinkedIndex
 
getRowCount(SessionLocal) - Method in class org.h2.index.MetaIndex
 
getRowCount(SessionLocal) - Method in class org.h2.index.ViewIndex
 
getRowCount(SessionLocal) - Method in class org.h2.index.VirtualTableIndex
 
getRowCount(SessionLocal) - Method in class org.h2.mvstore.db.MVDelegateIndex
 
getRowCount(SessionLocal) - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
getRowCount(SessionLocal) - Method in class org.h2.mvstore.db.MVSecondaryIndex
 
getRowCount(SessionLocal) - Method in class org.h2.mvstore.db.MVSpatialIndex
 
getRowCount(SessionLocal) - Method in class org.h2.mvstore.db.MVTable
 
getRowCount(SessionLocal) - Method in class org.h2.table.DataChangeDeltaTable
 
getRowCount(SessionLocal) - Method in class org.h2.table.DualTable
 
getRowCount(SessionLocal) - Method in class org.h2.table.FunctionTable
 
getRowCount(SessionLocal) - Method in class org.h2.table.InformationSchemaTable
 
getRowCount(SessionLocal) - Method in class org.h2.table.MetaTable
 
getRowCount(SessionLocal) - Method in class org.h2.table.RangeTable
 
getRowCount(SessionLocal) - Method in class org.h2.table.Table
Get the row count for this table.
getRowCount(SessionLocal) - Method in class org.h2.table.TableLink
 
getRowCount(SessionLocal) - Method in class org.h2.table.TableValueConstructorTable
 
getRowCount(SessionLocal) - Method in class org.h2.table.TableView
 
getRowCount(SessionLocal, boolean) - Method in class org.h2.table.InformationSchemaTable
 
getRowCountApproximation(SessionLocal) - Method in class org.h2.index.Index
Get the approximated row count for this table.
getRowCountApproximation(SessionLocal) - Method in class org.h2.index.LinkedIndex
 
getRowCountApproximation(SessionLocal) - Method in class org.h2.index.MetaIndex
 
getRowCountApproximation(SessionLocal) - Method in class org.h2.index.ViewIndex
 
getRowCountApproximation(SessionLocal) - Method in class org.h2.index.VirtualTableIndex
 
getRowCountApproximation(SessionLocal) - Method in class org.h2.mvstore.db.MVDelegateIndex
 
getRowCountApproximation(SessionLocal) - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
getRowCountApproximation(SessionLocal) - Method in class org.h2.mvstore.db.MVSecondaryIndex
 
getRowCountApproximation(SessionLocal) - Method in class org.h2.mvstore.db.MVSpatialIndex
 
getRowCountApproximation(SessionLocal) - Method in class org.h2.mvstore.db.MVTable
 
getRowCountApproximation(SessionLocal) - Method in class org.h2.table.DataChangeDeltaTable
 
getRowCountApproximation(SessionLocal) - Method in class org.h2.table.DualTable
 
getRowCountApproximation(SessionLocal) - Method in class org.h2.table.FunctionTable
 
getRowCountApproximation(SessionLocal) - Method in class org.h2.table.InformationSchemaTable
 
getRowCountApproximation(SessionLocal) - Method in class org.h2.table.MetaTable
 
getRowCountApproximation(SessionLocal) - Method in class org.h2.table.RangeTable
 
getRowCountApproximation(SessionLocal) - Method in class org.h2.table.Table
Get the approximated row count for this table.
getRowCountApproximation(SessionLocal) - Method in class org.h2.table.TableLink
 
getRowCountApproximation(SessionLocal) - Method in class org.h2.table.TableValueConstructorTable
 
getRowCountApproximation(SessionLocal) - Method in class org.h2.table.TableView
 
getRowCountMax() - Method in class org.h2.mvstore.db.MVPrimaryIndex
The maximum number of rows, including uncommitted rows of any session.
getRowCountStandardDeviation() - Method in class org.h2.engine.QueryStatisticsData.QueryEntry
 
getRowDataType() - Method in class org.h2.command.query.Query
Returns data type of rows.
getRowDataType() - Method in class org.h2.result.RowFactory.DefaultRowFactory
 
getRowDataType() - Method in class org.h2.result.RowFactory
 
getRowFactory() - Method in class org.h2.engine.Database
 
getRowFactory() - Method in class org.h2.index.Index
 
getRowFactory() - Method in class org.h2.mvstore.db.MVDelegateIndex
 
getRowFactory() - Method in class org.h2.mvstore.db.RowDataType
 
getRowFactory() - Method in class org.h2.mvstore.db.ValueDataType
 
getRowFactory() - Static method in class org.h2.result.RowFactory
 
getRowFactory() - Method in class org.h2.table.Table
 
getRowId() - Method in class org.h2.result.FetchedResult
 
getRowId() - Method in class org.h2.result.LocalResult
 
getRowId() - Method in interface org.h2.result.ResultInterface
Get the current row id, starting with 0.
getRowId() - Method in class org.h2.result.ResultWithPaddedStrings
 
getRowId() - Method in class org.h2.result.SimpleResult
 
getRowId(int) - Method in class org.h2.jdbc.JdbcCallableStatement
[Not supported] Returns the value of the specified column as a row id.
getRowId(int) - Method in class org.h2.jdbc.JdbcResultSet
[Not supported] Returns the value of the specified column as a row id.
getRowId(int) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
getRowId(String) - Method in class org.h2.jdbc.JdbcCallableStatement
[Not supported] Returns the value of the specified column as a row id.
getRowId(String) - Method in class org.h2.jdbc.JdbcResultSet
[Not supported] Returns the value of the specified column as a row id.
getRowId(String) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
getRowIdColumn() - Method in class org.h2.mvstore.db.MVTable
 
getRowIdColumn() - Method in interface org.h2.table.ColumnResolver
Get the row id pseudo column, if there is one.
getRowIdColumn() - Method in class org.h2.table.GeneratedColumnResolver
 
getRowIdColumn() - Method in class org.h2.table.Table
Get the row id column if this table has one.
getRowIdColumn() - Method in class org.h2.table.TableFilter
 
getRowIdLifetime() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Get the lifetime of a rowid.
getRowValueComparator() - Method in class org.h2.result.SortOrder
Returns comparator for row values.
getRule() - Method in class org.h2.bnf.RuleHead
 
getRuleHead(String) - Method in class org.h2.bnf.Bnf
Get the rule head for the given title.
getRuleMapKey(String) - Static method in class org.h2.bnf.Bnf
Convert convert ruleLink to rule_link.
getRunnableStackTraces() - Static method in class org.h2.util.Profiler
 
getSavepointId() - Method in class org.h2.jdbc.JdbcSavepoint
Get the generated id of this savepoint.
getSavepointName() - Method in class org.h2.jdbc.JdbcSavepoint
Get the name of this savepoint.
getScale() - Method in class org.h2.value.TypeInfo
Returns the scale.
getScale(int) - Method in class org.h2.jdbc.JdbcParameterMetaData
Returns the parameter scale.
getScale(int) - Method in class org.h2.jdbc.JdbcResultSetMetaData
Gets the scale for this column.
getScale(int) - Method in class org.h2.tools.SimpleResultSet
Returns the scale.
getScanIndex(SessionLocal) - Method in class org.h2.mvstore.db.MVTable
 
getScanIndex(SessionLocal) - Method in class org.h2.table.DualTable
 
getScanIndex(SessionLocal) - Method in class org.h2.table.MetaTable
 
getScanIndex(SessionLocal) - Method in class org.h2.table.RangeTable
 
getScanIndex(SessionLocal) - Method in class org.h2.table.Table
Get the scan index to iterate through all rows.
getScanIndex(SessionLocal) - Method in class org.h2.table.TableLink
 
getScanIndex(SessionLocal) - Method in class org.h2.table.TableView
 
getScanIndex(SessionLocal) - Method in class org.h2.table.VirtualConstructedTable
 
getScanIndex(SessionLocal, int[], TableFilter[], int, SortOrder, AllColumnsForPlan) - Method in class org.h2.table.Table
Get the scan index for this table.
getScanIndex(SessionLocal, int[], TableFilter[], int, SortOrder, AllColumnsForPlan) - Method in class org.h2.table.TableView
 
getSchema() - Method in class org.h2.bnf.context.DbProcedure
 
getSchema() - Method in class org.h2.bnf.context.DbTableOrView
 
getSchema() - Method in class org.h2.command.ddl.SchemaCommand
Get the schema
getSchema() - Method in class org.h2.command.Parser
 
getSchema() - Method in class org.h2.jdbc.JdbcConnection
Retrieves this current schema name for this connection.
getSchema() - Method in class org.h2.schema.SchemaObject
Get the schema in which this object is defined
getSchema(String) - Method in class org.h2.command.Parser
 
getSchema(String) - Method in class org.h2.engine.Database
Get the schema.
getSchemaName() - Method in class org.h2.expression.Alias
 
getSchemaName() - Method in class org.h2.expression.Expression
Get the schema name, or null
getSchemaName() - Method in class org.h2.expression.ExpressionColumn
 
getSchemaName() - Method in class org.h2.expression.Wildcard
 
getSchemaName() - Method in interface org.h2.table.ColumnResolver
Get the schema name or null.
getSchemaName() - Method in class org.h2.table.TableFilter
 
getSchemaName(int) - Method in class org.h2.jdbc.JdbcResultSetMetaData
Returns the schema name.
getSchemaName(int) - Method in class org.h2.result.LazyResult
 
getSchemaName(int) - Method in class org.h2.result.LocalResult
 
getSchemaName(int) - Method in interface org.h2.result.ResultInterface
Get the schema name for the column, if one exists.
getSchemaName(int) - Method in class org.h2.result.ResultRemote
 
getSchemaName(int) - Method in class org.h2.result.ResultWithPaddedStrings
 
getSchemaName(int) - Method in class org.h2.result.SimpleResult
 
getSchemaName(int) - Method in class org.h2.tools.SimpleResultSet
Returns empty string.
getSchemaNames(DatabaseMetaData) - Method in class org.h2.bnf.context.DbContents
 
getSchemaPattern(String) - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getSchemas() - Method in class org.h2.bnf.context.DbContents
 
getSchemas() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the list of schemas.
getSchemas() - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getSchemas() - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getSchemas() - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getSchemas() - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getSchemas(String) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getSchemas(String, String) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the list of schemas in the database.
getSchemas(String, String) - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getSchemas(String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getSchemas(String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getSchemas(String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getSchemaSearchPath() - Method in class org.h2.engine.SessionLocal
 
getSchemasForPattern(String) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getSchemaTerm() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the term for "schema".
getSchemaWithDefault() - Method in class org.h2.command.Parser
 
getScheme() - Method in class org.h2.mvstore.cache.FilePathCache
 
getScheme() - Method in class org.h2.store.fs.async.FilePathAsync
 
getScheme() - Method in class org.h2.store.fs.disk.FilePathDisk
 
getScheme() - Method in class org.h2.store.fs.encrypt.FilePathEncrypt
 
getScheme() - Method in class org.h2.store.fs.FilePath
Get the scheme (prefix) for this file provider.
getScheme() - Method in class org.h2.store.fs.mem.FilePathMem
 
getScheme() - Method in class org.h2.store.fs.mem.FilePathMemLZF
 
getScheme() - Method in class org.h2.store.fs.niomapped.FilePathNioMapped
 
getScheme() - Method in class org.h2.store.fs.niomem.FilePathNioMem
 
getScheme() - Method in class org.h2.store.fs.niomem.FilePathNioMemLZF
 
getScheme() - Method in class org.h2.store.fs.rec.FilePathRec
Get the prefix for this file system.
getScheme() - Method in class org.h2.store.fs.retry.FilePathRetryOnInterrupt
 
getScheme() - Method in class org.h2.store.fs.split.FilePathSplit
 
getScheme() - Method in class org.h2.store.fs.zip.FilePathZip
 
getScriptDirectory() - Static method in class org.h2.engine.SysProperties
System property h2.scriptDirectory (default: empty string).
getSearcher() - Method in class org.h2.fulltext.FullTextLucene.IndexAccess
Start using the searcher.
getSearchRow() - Method in interface org.h2.index.Cursor
Get the current row.
getSearchRow() - Method in class org.h2.index.DualCursor
 
getSearchRow() - Method in class org.h2.index.IndexCursor
 
getSearchRow() - Method in class org.h2.index.LinkedCursor
 
getSearchRow() - Method in class org.h2.index.MetaCursor
 
getSearchRow() - Method in class org.h2.index.RangeCursor
 
getSearchRow() - Method in class org.h2.index.SingleRowCursor
 
getSearchRow() - Method in class org.h2.index.ViewCursor
 
getSearchRow() - Method in class org.h2.index.VirtualTableCursor
 
getSearchRow() - Method in class org.h2.mvstore.db.MVPrimaryIndex.MVStoreCursor
 
getSearchRow() - Method in class org.h2.mvstore.db.MVSecondaryIndex.MVStoreCursor
 
getSearchRow() - Method in class org.h2.mvstore.db.MVSpatialIndex.MVStoreCursor
 
getSearchRow(SearchRow, int, Value, boolean) - Method in class org.h2.index.IndexCursor
 
getSearchStringEscape() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the default escape character for DatabaseMetaData search patterns.
getSearchStringEscape() - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getSearchStringEscape() - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getSearchStringEscape() - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getSearchStringEscape() - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getSeconds() - Method in class org.h2.api.Interval
Returns value of integer part of seconds, if any.
getSecondsAndNanos() - Method in class org.h2.api.Interval
Returns seconds value measured in nanoseconds, if any.
getSecondValue(SessionLocal, Value[]) - Method in class org.h2.expression.aggregate.Aggregate
 
getSection() - Method in class org.h2.bnf.RuleHead
 
getSecureRandom() - Static method in class org.h2.util.MathUtils
 
getSegment(int) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
 
getSegmentIndex(int) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
 
getSelect() - Method in class org.h2.command.query.SelectListColumnResolver
 
getSelect() - Method in class org.h2.expression.aggregate.Aggregate
Returns the select statement.
getSelect() - Method in interface org.h2.table.ColumnResolver
Get the select statement.
getSelect() - Method in class org.h2.table.TableFilter
 
getSelectivity() - Method in class org.h2.table.Column
Get the selectivity of the column.
getSelectivity(long) - Method in class org.h2.command.ddl.Analyze.SelectivityData
 
getSeparator() - Method in class org.h2.expression.aggregate.ListaggArguments
Returns the LISTAGG separator.
getSequence() - Method in class org.h2.table.Column
 
getSequence(String) - Method in class org.h2.schema.Schema
Get the sequence with the given name.
getSequenceNum() - Method in class org.h2.mvstore.tx.Transaction
 
getSequenceOptionsSQL(StringBuilder) - Method in class org.h2.schema.Sequence
Append the options part of the SQL statement to create the sequence.
getSequenceOptionsSQL(StringBuilder, long) - Method in class org.h2.schema.Sequence
 
getServer() - Method in class org.h2.util.NetworkConnectionInfo
Returns the protocol and port of the server.
getService() - Method in class org.h2.tools.Server
Get the service attached to this server.
getSession() - Method in class org.h2.command.Prepared
 
getSession() - Method in class org.h2.index.ViewIndex
 
getSession() - Method in class org.h2.jdbc.JdbcConnection
INTERNAL
getSession() - Method in class org.h2.server.web.WebApp
 
getSession() - Method in class org.h2.table.TableFilter
 
getSession(String) - Method in class org.h2.server.web.WebServer
Get the web session object for the given session id.
getSessionCount() - Method in class org.h2.engine.Database
 
getSessions() - Method in class org.h2.server.web.WebServer
 
getSessions(boolean) - Method in class org.h2.engine.Database
Get all sessions that are currently connected to the database.
getSessionStart() - Method in class org.h2.engine.SessionLocal
 
getSetting(String) - Method in class org.h2.server.web.WebServer
Get the connection information for this setting.
getSettingNames() - Method in class org.h2.server.web.WebServer
Get the list of connection information setting names.
getSettings() - Method in class org.h2.engine.Database
 
getSettings() - Method in class org.h2.engine.SettingsBase
Get all settings.
getSettings() - Method in class org.h2.server.web.WebServer
Get the list of connection info objects.
getSettingsCommand(String) - Method in class org.h2.engine.SessionRemote
 
getSHA256(byte[]) - Static method in class org.h2.tools.Upgrade
 
getSha3_224() - Static method in class org.h2.security.SHA3
Returns a new instance of SHA3-224 message digest.
getSha3_256() - Static method in class org.h2.security.SHA3
Returns a new instance of SHA3-256 message digest.
getSha3_384() - Static method in class org.h2.security.SHA3
Returns a new instance of SHA3-384 message digest.
getSha3_512() - Static method in class org.h2.security.SHA3
Returns a new instance of SHA3-512 message digest.
getSharedArgument() - Method in class org.h2.expression.aggregate.AggregateDataCollecting
Returns value of a shared argument.
getShort() - Method in class org.h2.value.Value
Returns this value as a Java short value.
getShort() - Method in class org.h2.value.ValueBoolean
 
getShort() - Method in class org.h2.value.ValueNull
 
getShort() - Method in class org.h2.value.ValueSmallint
 
getShort() - Method in class org.h2.value.ValueStringBase
 
getShort() - Method in class org.h2.value.ValueTinyint
 
getShort(int) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a short.
getShort(int) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a short.
getShort(int) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a short.
getShort(String) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a short.
getShort(String) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a short.
getShort(String) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a short.
getShortDescription() - Method in class org.h2.constraint.ConstraintCheck
 
getShortDescription(Index, SearchRow) - Method in class org.h2.constraint.ConstraintReferential
Get a short description of the constraint.
getShortId(long) - Method in class org.h2.util.TimeZoneProvider
Get the standard time name or daylight saving time name of the time zone.
getShortId(long) - Method in class org.h2.util.TimeZoneProvider.Simple
 
getShortId(long) - Method in class org.h2.util.TimeZoneProvider.WithTimeZone
 
getShortInternal(int) - Method in class org.h2.jdbc.JdbcResultSet
 
getShortName() - Method in class org.h2.engine.Database
 
getShutdownServerOnDisconnect() - Method in class org.h2.server.web.WebSession
 
getSignum() - Method in class org.h2.value.Value
 
getSignum() - Method in class org.h2.value.ValueBigint
 
getSignum() - Method in class org.h2.value.ValueDecfloat
 
getSignum() - Method in class org.h2.value.ValueDouble
 
getSignum() - Method in class org.h2.value.ValueEnumBase
 
getSignum() - Method in class org.h2.value.ValueInteger
 
getSignum() - Method in class org.h2.value.ValueInterval
 
getSignum() - Method in class org.h2.value.ValueNumeric
 
getSignum() - Method in class org.h2.value.ValueReal
 
getSignum() - Method in class org.h2.value.ValueSmallint
 
getSignum() - Method in class org.h2.value.ValueTinyint
 
getSimpleSQL(Expression[]) - Static method in class org.h2.command.Prepared
Get the SQL snippet of the expression list.
getSize(int[], int[], int) - Static method in class org.h2.tools.MultiDimension
 
getSkipSum(long) - Static method in class org.h2.util.MemoryEstimator
 
getSmall() - Method in class org.h2.value.lob.LobDataInMemory
Get the data if this a small lob value.
getSmall() - Method in class org.h2.value.ValueLob
 
getSnapshot() - Method in class org.h2.mvstore.tx.TransactionMap
 
getSnapshotDataModificationId() - Method in class org.h2.engine.SessionLocal
Returns the data modification id of transaction's snapshot, or 0 if isolation level doesn't use snapshots.
getSnapshotOfAllThreads() - Method in class org.h2.util.DebuggingThreadLocal
Get a snapshot of the data of all threads.
getSocket() - Method in class org.h2.value.Transfer
Get the socket.
getSortedSettings() - Method in class org.h2.engine.SettingsBase
Get all settings in alphabetical order.
getSortIndex() - Method in class org.h2.command.query.Select
Get the index that matches the ORDER BY list, if one exists.
getSortOrder() - Method in class org.h2.command.query.Select
 
getSortTypes() - Method in class org.h2.result.SortOrder
Get the sort order bit masks.
getSortTypesWithNullOrdering() - Method in class org.h2.result.SortOrder
Returns sort order bit masks with SortOrder.NULLS_FIRST or SortOrder.NULLS_LAST explicitly set.
getSoundex(String) - Static method in class org.h2.expression.function.SoundexFunction
 
getSource() - Method in exception org.h2.message.DbException
 
getSource() - Method in class org.h2.schema.FunctionAlias
 
getSource(Class<T>) - Method in class org.h2.jdbc.JdbcSQLXML
 
getSourceTableFilter() - Method in class org.h2.command.dml.MergeUsing
 
getSpatialSearchRow(SearchRow, int, Value) - Method in class org.h2.index.IndexCursor
 
getSQL() - Method in class org.h2.command.Prepared
Get the SQL statement.
getSQL() - Method in enum org.h2.engine.IsolationLevel
Returns the SQL representation of this isolation level.
getSQL() - Method in class org.h2.engine.MetaRecord
 
getSQL() - Method in enum org.h2.expression.analysis.WindowFrameBoundType
Returns SQL representation.
getSQL() - Method in enum org.h2.expression.analysis.WindowFrameExclusion
Returns SQL representation.
getSQL() - Method in enum org.h2.expression.analysis.WindowFrameUnits
Returns SQL representation.
getSQL() - Method in enum org.h2.expression.analysis.WindowFunctionType
Returns SQL representation.
getSQL() - Method in class org.h2.index.IndexType
Get the SQL snippet to create such an index.
getSQL() - Method in interface org.h2.jdbc.JdbcException
Returns the SQL statement.
getSQL() - Method in exception org.h2.jdbc.JdbcSQLDataException
 
getSQL() - Method in exception org.h2.jdbc.JdbcSQLException
 
getSQL() - Method in exception org.h2.jdbc.JdbcSQLFeatureNotSupportedException
 
getSQL() - Method in exception org.h2.jdbc.JdbcSQLIntegrityConstraintViolationException
 
getSQL() - Method in exception org.h2.jdbc.JdbcSQLInvalidAuthorizationSpecException
 
getSQL() - Method in exception org.h2.jdbc.JdbcSQLNonTransientConnectionException
 
getSQL() - Method in exception org.h2.jdbc.JdbcSQLNonTransientException
 
getSQL() - Method in exception org.h2.jdbc.JdbcSQLSyntaxErrorException
 
getSQL() - Method in exception org.h2.jdbc.JdbcSQLTimeoutException
 
getSQL() - Method in exception org.h2.jdbc.JdbcSQLTransactionRollbackException
 
getSQL() - Method in exception org.h2.jdbc.JdbcSQLTransientException
 
getSQL(int) - Method in class org.h2.engine.DbObject
 
getSQL(int) - Method in class org.h2.engine.Setting
 
getSQL(int) - Method in class org.h2.expression.Expression
 
getSQL(int) - Method in class org.h2.index.IndexCondition
Get the SQL snippet of this comparison.
getSQL(int) - Method in class org.h2.schema.SchemaObject
 
getSQL(int) - Method in class org.h2.table.Column
 
getSQL(int) - Method in class org.h2.table.FunctionTable
 
getSQL(int) - Method in interface org.h2.util.HasSQL
Get the SQL statement of this expression.
getSQL(int, int) - Method in class org.h2.expression.Expression
Get the SQL statement of this expression.
getSQL(String) - Method in class org.h2.server.pg.PgServerThread
 
getSQL(StringBuilder) - Method in class org.h2.value.ValueDecfloat
 
getSQL(StringBuilder) - Method in class org.h2.value.ValueDouble
 
getSQL(StringBuilder) - Method in class org.h2.value.ValueReal
 
getSQL(StringBuilder, boolean, int) - Method in class org.h2.expression.analysis.WindowFrameBound
Appends SQL representation to the specified builder.
getSQL(StringBuilder, int) - Method in class org.h2.command.dml.MergeUsing.When
 
getSQL(StringBuilder, int) - Method in class org.h2.command.dml.MergeUsing.WhenMatchedThenDelete
 
getSQL(StringBuilder, int) - Method in class org.h2.command.dml.MergeUsing.WhenMatchedThenUpdate
 
getSQL(StringBuilder, int) - Method in class org.h2.command.dml.MergeUsing.WhenNotMatched
 
getSQL(StringBuilder, int) - Method in class org.h2.command.dml.SetClauseList
 
getSQL(StringBuilder, int) - Method in class org.h2.command.query.QueryOrderBy
Appends the order by expression to the specified builder.
getSQL(StringBuilder, int) - Method in class org.h2.engine.DbObject
 
getSQL(StringBuilder, int) - Method in class org.h2.engine.Setting
 
getSQL(StringBuilder, int) - Method in class org.h2.expression.analysis.WindowFrame
Append SQL representation to the specified builder.
getSQL(StringBuilder, int) - Method in class org.h2.expression.Expression
 
getSQL(StringBuilder, int) - Method in class org.h2.expression.function.table.ArrayTableFunction
 
getSQL(StringBuilder, int) - Method in class org.h2.expression.function.table.JavaTableFunction
 
getSQL(StringBuilder, int) - Method in class org.h2.expression.function.table.TableFunction
 
getSQL(StringBuilder, int) - Method in class org.h2.mvstore.db.SpatialKey
 
getSQL(StringBuilder, int) - Method in class org.h2.result.SearchRow
 
getSQL(StringBuilder, int) - Method in class org.h2.schema.SchemaObject
 
getSQL(StringBuilder, int) - Method in class org.h2.table.Column
 
getSQL(StringBuilder, int) - Method in class org.h2.table.DataChangeDeltaTable
 
getSQL(StringBuilder, int) - Method in class org.h2.table.DualTable
 
getSQL(StringBuilder, int) - Method in class org.h2.table.FunctionTable
 
getSQL(StringBuilder, int) - Method in class org.h2.table.IndexColumn
Appends the SQL snippet for this index column to the specified string builder.
getSQL(StringBuilder, int) - Method in class org.h2.table.RangeTable
 
getSQL(StringBuilder, int) - Method in class org.h2.table.TableValueConstructorTable
 
getSQL(StringBuilder, int) - Method in class org.h2.table.TableView
 
getSQL(StringBuilder, int) - Method in interface org.h2.util.HasSQL
Appends the SQL statement of this object to the specified builder.
getSQL(StringBuilder, int) - Method in class org.h2.value.ExtTypeInfoEnum
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ExtTypeInfoGeometry
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ExtTypeInfoNumeric
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ExtTypeInfoRow
 
getSQL(StringBuilder, int) - Method in class org.h2.value.TypeInfo
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueArray
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueBigint
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueBinary
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueBlob
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueBoolean
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueBytesBase
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueChar
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueClob
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueDate
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueDecfloat
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueDouble
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueEnum
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueEnumBase
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueGeometry
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueInteger
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueInterval
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueJavaObject
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueJson
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueNull
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueNumeric
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueReal
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueRow
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueSmallint
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueTime
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueTimestamp
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueTimestampTimeZone
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueTimeTimeZone
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueTinyint
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueUuid
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueVarchar
 
getSQL(StringBuilder, int) - Method in class org.h2.value.ValueVarcharIgnoreCase
 
getSQL(StringBuilder, int, boolean) - Method in class org.h2.expression.analysis.Window
Appends SQL representation to the specified builder.
getSQL(StringBuilder, int, int) - Method in class org.h2.expression.Expression
Get the SQL statement of this expression.
getSQL(StringBuilder, int, Column) - Method in class org.h2.command.dml.SetClauseList.SetSimple
 
getSQL(StringBuilder, int, Column) - Method in class org.h2.command.dml.SetClauseList.UpdateAction
 
getSQL(StringBuilder, String, Value) - Method in class org.h2.tools.Recover
 
getSQL(StringBuilder, Expression[], int, int) - Method in class org.h2.result.SortOrder
Create the SQL snippet that describes this sort order.
getSQLArrayAggregate(StringBuilder, int) - Method in class org.h2.expression.aggregate.Aggregate
 
getSQLException() - Method in exception org.h2.message.DbException
Get the SQLException object.
getSQLJsonArrayAggregate(StringBuilder, int) - Method in class org.h2.expression.aggregate.Aggregate
 
getSQLJsonObjectAggregate(StringBuilder, int) - Method in class org.h2.expression.aggregate.Aggregate
 
getSQLKeywords() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the comma-separated list of all SQL keywords that are not supported as unquoted identifiers, in addition to the SQL:2003 reserved words.
getSQLKeywords() - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getSQLKeywords() - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getSQLKeywords() - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getSQLKeywords() - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getSQLListagg(StringBuilder, int) - Method in class org.h2.expression.aggregate.Aggregate
 
getSqlName() - Method in enum org.h2.constraint.Constraint.Type
Get standard SQL type name.
getSqlName() - Method in enum org.h2.constraint.ConstraintActionType
Get standard SQL type name.
getSQLStateType() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the SQL State type.
getSQLTableType() - Method in class org.h2.table.Table
Return SQL table type for INFORMATION_SCHEMA.
getSQLTokens() - Method in class org.h2.command.Prepared
Get the SQL tokens.
getSQLWithTable(StringBuilder, int) - Method in class org.h2.table.Column
Appends the table name and column name to the specified builder.
getSQLXML(int) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a SQLXML object.
getSQLXML(int) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a SQLXML.
getSQLXML(int) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
getSQLXML(String) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a SQLXML object.
getSQLXML(String) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a SQLXML.
getSQLXML(String) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
getSrid() - Method in class org.h2.value.ExtTypeInfoGeometry
Returns the SRID of geometries.
getSRID() - Method in class org.h2.value.ValueGeometry
Return a spatial reference system identifier.
getSSL() - Method in class org.h2.server.TcpServer
Returns whether a secure protocol is used.
getSSL() - Method in class org.h2.server.web.WebServer
 
getStackTrace(int, Throwable, boolean) - Method in class org.h2.server.web.WebApp
 
getStackTraceForThread(ThreadInfo) - Static method in class org.h2.util.AbbaLockingDetector
Dump data in the same format as ThreadInfo.toString(), but with some modifications (no stack frame limit, and removal of uninteresting stack frames)
getStart() - Method in class org.h2.index.IndexCursor
Get start search row.
getStartDateTime() - Method in class org.h2.server.web.WebServer
 
getStartIndex(SessionLocal, ArrayList<Value[]>, SortOrder, int) - Method in class org.h2.expression.analysis.WindowFrame
Returns start index of this frame,
getStarting() - Method in class org.h2.expression.analysis.WindowFrame
Returns the starting clause.
getStartValue() - Method in class org.h2.schema.Sequence
 
getStartValue(SessionLocal) - Method in class org.h2.command.ddl.SequenceOptions
Gets start value.
getState() - Method in class org.h2.engine.SessionLocal
 
getState() - Method in class org.h2.mvstore.db.MVInDoubtTransaction
 
getState() - Method in interface org.h2.store.InDoubtTransaction
Get the state of this transaction.
getState(int) - Static method in class org.h2.api.ErrorCode
INTERNAL
getState(int) - Method in class org.h2.server.TcpServerThread
 
getStateDescription() - Method in interface org.h2.store.InDoubtTransaction
Get the state of this transaction as a text.
getStatement() - Method in class org.h2.jdbc.JdbcResultSet
Returns the statement that created this object.
getStatement() - Method in class org.h2.tools.SimpleResultSet
Returns null.
getStatement(Connection, int) - Static method in class org.h2.fulltext.FullText.FullTextTrigger
 
getStatementName() - Method in class org.h2.command.dml.DataChangeStatement
Return the name of this statement.
getStatementName() - Method in class org.h2.command.dml.Delete
 
getStatementName() - Method in class org.h2.command.dml.Insert
 
getStatementName() - Method in class org.h2.command.dml.Merge
 
getStatementName() - Method in class org.h2.command.dml.MergeUsing
 
getStatementName() - Method in class org.h2.command.dml.Update
 
getStatements() - Method in class org.h2.bnf.Bnf
Get the list of possible statements.
getStatementSavepoint() - Method in class org.h2.engine.SessionLocal
 
getStatementSnapshot() - Method in class org.h2.mvstore.tx.TransactionMap
 
getStaticSettings() - Method in class org.h2.engine.Session
Returns static settings.
getStaticSettings() - Method in class org.h2.engine.SessionLocal
 
getStaticSettings() - Method in class org.h2.engine.SessionRemote
 
getStaticSettings() - Method in class org.h2.jdbc.JdbcConnection
INTERNAL
getStatus() - Method in class org.h2.mvstore.tx.Transaction
 
getStatus() - Method in class org.h2.tools.Server
Get the status of this server.
getStatus(long) - Static method in class org.h2.mvstore.tx.Transaction
 
getStatusName(int) - Static method in class org.h2.mvstore.tx.Transaction
 
getStep(SessionLocal) - Method in class org.h2.table.RangeTable
Get the increment.
getStore() - Method in class org.h2.engine.Database
 
getStore() - Method in class org.h2.mvstore.MVMap
 
getStoreHeader() - Method in class org.h2.mvstore.MVStore
Get the store header.
getStoreKeys() - Method in class org.h2.result.RowFactory.DefaultRowFactory
 
getStoreKeys() - Method in class org.h2.result.RowFactory
 
getStoreVersion() - Method in class org.h2.mvstore.MVStore
Get the store version.
getStrength() - Method in class org.h2.value.CompareMode
 
getString() - Method in class org.h2.jdbc.JdbcSQLXML
 
getString() - Method in class org.h2.mvstore.db.SpatialKey
 
getString() - Method in class org.h2.result.SearchRow
 
getString() - Method in class org.h2.server.web.ConnectionInfo
 
getString() - Method in class org.h2.util.json.JSONString
Returns the value.
getString() - Method in class org.h2.value.Value
Get the value as a string.
getString() - Method in class org.h2.value.ValueArray
 
getString() - Method in class org.h2.value.ValueBigint
 
getString() - Method in class org.h2.value.ValueBinary
 
getString() - Method in class org.h2.value.ValueBlob
 
getString() - Method in class org.h2.value.ValueBoolean
 
getString() - Method in class org.h2.value.ValueClob
 
getString() - Method in class org.h2.value.ValueDate
 
getString() - Method in class org.h2.value.ValueDecfloat
 
getString() - Method in class org.h2.value.ValueDouble
 
getString() - Method in class org.h2.value.ValueEnumBase
 
getString() - Method in class org.h2.value.ValueGeometry
 
getString() - Method in class org.h2.value.ValueInteger
 
getString() - Method in class org.h2.value.ValueInterval
 
getString() - Method in class org.h2.value.ValueJavaObject
 
getString() - Method in class org.h2.value.ValueJson
 
getString() - Method in class org.h2.value.ValueNull
 
getString() - Method in class org.h2.value.ValueNumeric
 
getString() - Method in class org.h2.value.ValueReal
 
getString() - Method in class org.h2.value.ValueRow
 
getString() - Method in class org.h2.value.ValueSmallint
 
getString() - Method in class org.h2.value.ValueStringBase
 
getString() - Method in class org.h2.value.ValueTime
 
getString() - Method in class org.h2.value.ValueTimestamp
 
getString() - Method in class org.h2.value.ValueTimestampTimeZone
 
getString() - Method in class org.h2.value.ValueTimeTimeZone
 
getString() - Method in class org.h2.value.ValueTinyint
 
getString() - Method in class org.h2.value.ValueUuid
 
getString() - Method in class org.h2.value.ValueVarbinary
 
getString(int) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a String.
getString(int) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a String.
getString(int) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a String.
getString(String) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a String.
getString(String) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a String.
getString(String) - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getString(String) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getString(String) - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getString(String) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a String.
getStringArray(String[]) - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getStringFunctions() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the list of string functions supported by this database.
getStringFunctions() - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getStringFunctions() - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getStringFunctions() - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getStringFunctions() - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getStringProperty(Properties, String, String) - Static method in class org.h2.util.SortedProperties
Get a string property value from a properties object.
getStringTooLong(long) - Method in class org.h2.value.ValueLob
 
getStringValue() - Method in class org.h2.engine.Setting
 
getStringValue(String) - Method in class org.h2.security.auth.ConfigProperties
Returns the string value of specified property.
getStringValue(String, String) - Method in class org.h2.security.auth.ConfigProperties
Returns the string value of specified property.
getSubexpression(int) - Method in class org.h2.expression.aggregate.AbstractAggregate
 
getSubexpression(int) - Method in class org.h2.expression.condition.BetweenPredicate
 
getSubexpression(int) - Method in class org.h2.expression.condition.CompareLike
 
getSubexpression(int) - Method in class org.h2.expression.condition.Comparison
 
getSubexpression(int) - Method in class org.h2.expression.condition.ConditionAndOr
 
getSubexpression(int) - Method in class org.h2.expression.condition.ConditionAndOrN
 
getSubexpression(int) - Method in class org.h2.expression.condition.ConditionIn
 
getSubexpression(int) - Method in class org.h2.expression.condition.ConditionInConstantSet
 
getSubexpression(int) - Method in class org.h2.expression.condition.ConditionLocalAndGlobal
 
getSubexpression(int) - Method in class org.h2.expression.condition.ConditionNot
 
getSubexpression(int) - Method in class org.h2.expression.condition.IsJsonPredicate
 
getSubexpression(int) - Method in class org.h2.expression.condition.SimplePredicate
 
getSubexpression(int) - Method in class org.h2.expression.Expression
Returns subexpression with specified index.
getSubexpression(int) - Method in class org.h2.expression.ExpressionList
 
getSubexpression(int) - Method in class org.h2.expression.function.Function0_1
 
getSubexpression(int) - Method in class org.h2.expression.function.JavaFunction
 
getSubexpression(int) - Method in class org.h2.expression.Operation1_2
 
getSubexpression(int) - Method in class org.h2.expression.Operation1
 
getSubexpression(int) - Method in class org.h2.expression.Operation2
 
getSubexpression(int) - Method in class org.h2.expression.OperationN
 
getSubexpression(int) - Method in class org.h2.expression.SimpleCase
 
getSubexpressionCount() - Method in class org.h2.expression.aggregate.AbstractAggregate
 
getSubexpressionCount() - Method in class org.h2.expression.condition.BetweenPredicate
 
getSubexpressionCount() - Method in class org.h2.expression.condition.CompareLike
 
getSubexpressionCount() - Method in class org.h2.expression.condition.Comparison
 
getSubexpressionCount() - Method in class org.h2.expression.condition.ConditionAndOr
 
getSubexpressionCount() - Method in class org.h2.expression.condition.ConditionAndOrN
 
getSubexpressionCount() - Method in class org.h2.expression.condition.ConditionIn
 
getSubexpressionCount() - Method in class org.h2.expression.condition.ConditionInConstantSet
 
getSubexpressionCount() - Method in class org.h2.expression.condition.ConditionLocalAndGlobal
 
getSubexpressionCount() - Method in class org.h2.expression.condition.ConditionNot
 
getSubexpressionCount() - Method in class org.h2.expression.condition.IsJsonPredicate
 
getSubexpressionCount() - Method in class org.h2.expression.condition.SimplePredicate
 
getSubexpressionCount() - Method in class org.h2.expression.Expression
Returns count of subexpressions.
getSubexpressionCount() - Method in class org.h2.expression.ExpressionList
 
getSubexpressionCount() - Method in class org.h2.expression.function.Function0_1
 
getSubexpressionCount() - Method in class org.h2.expression.function.JavaFunction
 
getSubexpressionCount() - Method in class org.h2.expression.Operation1_2
 
getSubexpressionCount() - Method in class org.h2.expression.Operation1
 
getSubexpressionCount() - Method in class org.h2.expression.Operation2
 
getSubexpressionCount() - Method in class org.h2.expression.OperationN
 
getSubexpressionCount() - Method in class org.h2.expression.SimpleCase
 
getSubString(long, int) - Method in class org.h2.jdbc.JdbcClob
Returns a substring.
getSumType(TypeInfo) - Static method in class org.h2.expression.aggregate.Aggregate
 
getSundayDayOfWeek(long) - Static method in class org.h2.util.DateTimeUtils
Returns day of week with Sunday as 1.
getSuperTables(String, String, String) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Get the list of super tables of a table.
getSuperTables(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getSuperTables(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLocalBase
 
getSuperTables(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getSuperTypes(String, String, String) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
[Not supported]
getSuperTypes(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getSuperTypes(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLocalBase
 
getSuperTypes(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getSynonym(String) - Method in class org.h2.schema.Schema
Try to find a synonym with this name.
getSynonymFor() - Method in class org.h2.table.TableSynonym
 
getSynonymForName() - Method in class org.h2.table.TableSynonym
 
getSynonymForSchema() - Method in class org.h2.table.TableSynonym
 
getSyntaxError() - Method in class org.h2.command.Parser
 
getSyntaxError(int, String, int, String...) - Static method in exception org.h2.message.DbException
Create a syntax error exception for a specific error code.
getSyntaxError(String, int) - Static method in exception org.h2.message.DbException
Create a syntax error exception.
getSyntaxError(String, int, String) - Static method in exception org.h2.message.DbException
Create a syntax error exception.
getSystemColumns() - Method in interface org.h2.table.ColumnResolver
Get the list of system columns, if any.
getSystemColumns() - Method in class org.h2.table.TableFilter
Get the system columns that this table understands.
getSystemFunctions() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the list of system functions supported by this database.
getSystemFunctions() - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getSystemFunctions() - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getSystemFunctions() - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getSystemFunctions() - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getSystemSession() - Method in class org.h2.engine.Database
 
getSystemUser() - Method in class org.h2.engine.Database
Returns system user.
getTable() - Method in class org.h2.command.dml.DataChangeStatement
Return the target table.
getTable() - Method in class org.h2.command.dml.FilteredDataChangeStatement
 
getTable() - Static method in class org.h2.command.dml.Help
Returns HELP table.
getTable() - Method in class org.h2.command.dml.Insert
 
getTable() - Method in class org.h2.command.dml.Merge
 
getTable() - Method in class org.h2.command.dml.MergeUsing
 
getTable() - Method in class org.h2.constraint.Constraint
 
getTable() - Method in class org.h2.expression.ExpressionVisitor
Get the table.
getTable() - Method in class org.h2.index.Index
Get the table on which this index is based.
getTable() - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
getTable() - Method in class org.h2.mvstore.db.MVSecondaryIndex
 
getTable() - Method in class org.h2.mvstore.db.MVSpatialIndex
 
getTable() - Method in class org.h2.schema.TriggerObject
Get the table of this trigger.
getTable() - Method in class org.h2.table.Column
 
getTable() - Method in class org.h2.table.TableFilter
 
getTable(String) - Method in class org.h2.mvstore.db.Store
Get MVTable by table name.
getTable(SessionLocal, boolean) - Method in class org.h2.expression.function.table.ArrayTableFunction
 
getTableAlias() - Method in class org.h2.expression.Expression
Get the table alias name or null if this expression does not represent a column.
getTableAlias() - Method in class org.h2.expression.Wildcard
 
getTableAlias() - Method in interface org.h2.table.ColumnResolver
Get the table alias.
getTableAlias() - Method in class org.h2.table.TableFilter
Get the table alias name.
getTableEngine(String) - Method in class org.h2.engine.Database
Get the table engine class, loading it if needed.
getTableEngineParams() - Method in class org.h2.schema.Schema
Get table engine params of this schema.
getTableFilter() - Method in class org.h2.command.dml.FilteredDataChangeStatement
 
getTableFilter() - Method in class org.h2.expression.ExpressionColumn
 
getTableFilter() - Method in interface org.h2.table.ColumnResolver
Get the table filter.
getTableFilter() - Method in class org.h2.table.TableFilter
 
getTableId() - Method in class org.h2.value.lob.LobDataDatabase
Get the current table id of this lob.
getTableId() - Method in class org.h2.value.lob.LobDataFetchOnDemand
Get the current table id of this lob.
getTableName() - Method in class org.h2.expression.Alias
 
getTableName() - Method in class org.h2.expression.Expression
Get the table name, or null
getTableName() - Method in class org.h2.expression.ExpressionColumn
 
getTableName() - Method in class org.h2.expression.Format
 
getTableName(int) - Method in class org.h2.jdbc.JdbcResultSetMetaData
Returns the table name.
getTableName(int) - Method in class org.h2.result.LazyResult
 
getTableName(int) - Method in class org.h2.result.LocalResult
 
getTableName(int) - Method in interface org.h2.result.ResultInterface
Get the table name for the column, if one exists.
getTableName(int) - Method in class org.h2.result.ResultRemote
 
getTableName(int) - Method in class org.h2.result.ResultWithPaddedStrings
 
getTableName(int) - Method in class org.h2.result.SimpleResult
 
getTableName(int) - Method in class org.h2.tools.SimpleResultSet
Returns empty string.
getTableOrView(SessionLocal, String) - Method in class org.h2.schema.MetaSchema
 
getTableOrView(SessionLocal, String) - Method in class org.h2.schema.Schema
Get the table or view with the given name.
getTableOrViewByName(SessionLocal, String) - Method in class org.h2.schema.MetaSchema
 
getTableOrViewByName(SessionLocal, String) - Method in class org.h2.schema.Schema
Get the table with the given name, if any.
getTableOrViewNotFoundDbException(String) - Method in class org.h2.command.Parser
 
getTableOrViewNotFoundDbException(String, String) - Method in class org.h2.command.Parser
 
getTableOrViewNotFoundDbException(Set<String>, String) - Method in class org.h2.command.Parser
 
getTablePrivileges(String, String, String) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the list of table privileges.
getTablePrivileges(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getTablePrivileges(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getTablePrivileges(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getTablePrivileges(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getTables() - Method in class org.h2.bnf.context.DbSchema
 
getTables() - Method in class org.h2.bnf.Sentence
Get the set of tables.
getTables() - Method in class org.h2.command.query.Query
Get all tables that are involved in this query.
getTables() - Method in class org.h2.command.query.Select
 
getTables() - Method in class org.h2.command.query.SelectUnion
 
getTables() - Method in class org.h2.command.query.TableValueConstructor
 
getTables() - Method in class org.h2.table.TableView
 
getTables(String, String, String, String[]) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the list of tables in the database.
getTables(String, String, String, String[]) - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getTables(String, String, String, String[]) - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getTables(String, String, String, String[]) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getTables(String, String, String, String[]) - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getTablesAdd(SimpleResult, Value, Value, Value, Table, boolean, HashSet<String>) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getTablesByName(SessionLocal, String) - Method in class org.h2.table.InformationSchemaTableLegacy
 
getTablesForPattern(Schema, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getTableType() - Method in class org.h2.mvstore.db.MVTable
 
getTableType() - Method in class org.h2.table.DualTable
 
getTableType() - Method in class org.h2.table.MetaTable
 
getTableType() - Method in class org.h2.table.RangeTable
 
getTableType() - Method in class org.h2.table.Table
Get the table type name
getTableType() - Method in class org.h2.table.TableLink
 
getTableType() - Method in class org.h2.table.TableView
 
getTableType() - Method in class org.h2.table.VirtualTable
 
getTableTypes() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the list of table types.
getTableTypes() - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getTableTypes() - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getTableTypes() - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getTableTypes() - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getTableValue(SessionLocal, Expression[], boolean) - Method in class org.h2.schema.FunctionAlias.JavaMethod
Call the table user-defined function and return the value.
getTargetFillRate() - Method in class org.h2.mvstore.MVStore
 
getTargetTableFilter() - Method in class org.h2.command.dml.MergeUsing
 
getTcpQuickack(Socket) - Static method in class org.h2.util.Utils10
Returns the value of TCP_QUICKACK option.
getTempFileDeleter() - Method in class org.h2.engine.Database
 
getTempFileDeleter() - Method in class org.h2.engine.SessionRemote
 
getTempFileDeleter() - Method in interface org.h2.store.DataHandler
Get the temp file deleter mechanism.
getTempFileDeleter() - Method in class org.h2.tools.Recover
INTERNAL
getTemplateRow() - Method in class org.h2.table.Table
 
getTemplateSimpleRow(boolean) - Method in class org.h2.table.Table
Get a new simple row object.
getTempTableName(String, SessionLocal) - Method in class org.h2.engine.Database
Get a unique temporary table name.
getTest(Object) - Static method in class org.h2.util.AbbaDetector
 
getThread() - Method in class org.h2.server.pg.PgServerThread
 
getThread() - Method in class org.h2.server.TcpServerThread
 
getThread(int) - Method in class org.h2.server.pg.PgServer
Get the thread with the given process id.
getThreadLocalSession() - Static method in class org.h2.engine.SessionLocal
 
getTime(int) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a java.sql.Time.
getTime(int) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a java.sql.Time.
getTime(int) - Method in class org.h2.tools.SimpleResultSet
Returns the value as an java.sql.Time.
getTime(int, Calendar) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a java.sql.Time using a specified time zone.
getTime(int, Calendar) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a java.sql.Time using a specified time zone.
getTime(int, Calendar) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
getTime(String) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a java.sql.Time.
getTime(String) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a java.sql.Time.
getTime(String) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a java.sql.Time.
getTime(String, Calendar) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a java.sql.Time using a specified time zone.
getTime(String, Calendar) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a java.sql.Time using a specified time zone.
getTime(String, Calendar) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
getTimeAbsolute() - Method in class org.h2.mvstore.MVStore
 
getTimeDateFunctions() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the list of date and time functions supported by this database.
getTimeDateFunctions() - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getTimeDateFunctions() - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getTimeDateFunctions() - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getTimeDateFunctions() - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getTimeNanos() - Method in class org.h2.value.ValueTimestamp
The nanoseconds since midnight.
getTimeNanos() - Method in class org.h2.value.ValueTimestampTimeZone
The nanoseconds since midnight.
getTimeSinceCreation() - Method in class org.h2.mvstore.MVStore
 
getTimestamp(int) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a java.sql.Timestamp.
getTimestamp(int) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a java.sql.Timestamp.
getTimestamp(int) - Method in class org.h2.tools.SimpleResultSet
Returns the value as an java.sql.Timestamp.
getTimestamp(int, Calendar) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a java.sql.Timestamp using a specified time zone.
getTimestamp(int, Calendar) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a java.sql.Timestamp using a specified time zone.
getTimestamp(int, Calendar) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
getTimestamp(String) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a java.sql.Timestamp.
getTimestamp(String) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a java.sql.Timestamp.
getTimestamp(String) - Method in class org.h2.tools.SimpleResultSet
Returns the value as a java.sql.Timestamp.
getTimestamp(String, Calendar) - Method in class org.h2.jdbc.JdbcCallableStatement
Returns the value of the specified column as a java.sql.Timestamp using a specified time zone.
getTimestamp(String, Calendar) - Method in class org.h2.jdbc.JdbcResultSet
Returns the value of the specified column as a java.sql.Timestamp.
getTimestamp(String, Calendar) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
getTimestampParser(SessionLocal, ToDateParser.ConfigParam, String, String) - Static method in class org.h2.mode.ToDateParser
 
getTimeWithInterval(Value, long) - Method in class org.h2.expression.IntervalOperation
 
getTimeZone() - Method in class org.h2.engine.ConnectionInfo
Returns the time zone.
getTimeZone() - Static method in class org.h2.util.DateTimeUtils
Get the time zone provider for the default time zone.
getTimeZone(SessionLocal, Value, boolean) - Static method in class org.h2.expression.function.ToCharFunction
Returns time zone display name or ID for the specified date-time value.
getTimeZoneOffsetLocal(long, long) - Method in class org.h2.util.TimeZoneProvider
Calculates the time zone offset in seconds for the specified date value and nanoseconds since midnight in local time.
getTimeZoneOffsetLocal(long, long) - Method in class org.h2.util.TimeZoneProvider.Simple
 
getTimeZoneOffsetLocal(long, long) - Method in class org.h2.util.TimeZoneProvider.WithTimeZone
 
getTimeZoneOffsetMillis(CastDataProvider, long) - Static method in class org.h2.util.LegacyDateTimeUtils
Returns local time zone offset for a specified timestamp.
getTimeZoneOffsetSeconds() - Method in class org.h2.value.ValueTimestampTimeZone
The time zone offset in seconds.
getTimeZoneOffsetSeconds() - Method in class org.h2.value.ValueTimeTimeZone
The time zone offset in seconds.
getTimeZoneOffsetUTC(long) - Method in class org.h2.util.TimeZoneProvider
Calculates the time zone offset in seconds for the specified EPOCH seconds.
getTimeZoneOffsetUTC(long) - Method in class org.h2.util.TimeZoneProvider.Simple
 
getTimeZoneOffsetUTC(long) - Method in class org.h2.util.TimeZoneProvider.WithTimeZone
 
getToC(Chunk) - Method in class org.h2.mvstore.MVStore
 
getTocCacheHitRatio() - Method in class org.h2.mvstore.MVStore
 
getTocElement(int, int, int, int) - Static method in class org.h2.mvstore.DataUtils
Create table of content element.
getTokenizer(String) - Static method in class org.h2.bnf.Bnf
Get the tokenizer for the given syntax.
getTokensInQuestion(String) - Static method in enum org.h2.mode.ToDateTokenizer.FormatTokenEnum
Optimization: Only return a list of ToDateTokenizer.FormatTokenEnum that share the same 1st char using the 1st char of the 'to parse' formatStr.
getTokenType(String, boolean, boolean) - Static method in class org.h2.util.ParserUtil
Get the token type.
getTokenTypeCurrent(String, int, int) - Static method in class org.h2.command.Tokenizer
 
getTop(int) - Method in class org.h2.util.Profiler
Get the top stack traces.
getTopFilter() - Method in class org.h2.command.query.Optimizer
 
getTopFilters() - Method in class org.h2.command.query.Select
 
getTopic() - Method in class org.h2.bnf.RuleHead
 
getTopQuery() - Method in class org.h2.table.TableView
 
getTopTableFilter() - Method in class org.h2.command.query.Select
 
getTopTraces(int) - Method in class org.h2.util.Profiler
 
getTotalCount() - Method in class org.h2.mvstore.Page
Get the total number of key-value pairs, including child pages.
getTotalCount() - Method in class org.h2.mvstore.Page.Leaf
 
getTotalCount() - Method in class org.h2.mvstore.Page.NonLeaf
 
getTotalCount() - Method in class org.h2.mvstore.RootReference
 
getTrace() - Method in class org.h2.engine.Session
Get the trace object
getTrace() - Method in class org.h2.engine.SessionLocal
 
getTrace() - Method in class org.h2.engine.SessionRemote
 
getTrace() - Method in class org.h2.jdbcx.JdbcDataSourceFactory
 
getTrace() - Method in class org.h2.server.pg.PgServer
 
getTrace() - Method in interface org.h2.util.CacheWriter
Get the trace writer.
getTrace(int) - Method in class org.h2.engine.Database
Get the trace object for the given module id.
getTrace(int) - Method in class org.h2.message.TraceSystem
Get or create a trace object for this module id.
getTrace(String) - Method in class org.h2.message.TraceSystem
Create a trace object for this module.
getTraceId() - Method in class org.h2.message.TraceObject
INTERNAL
getTraceLevel() - Method in class org.h2.jmx.DatabaseInfo
 
getTraceLevel() - Method in interface org.h2.jmx.DatabaseInfoMBean
The trace level (0 disabled, 1 error, 2 info, 3 debug).
getTraceObjectName() - Method in class org.h2.message.TraceObject
INTERNAL
getTraceSQL() - Method in interface org.h2.util.HasSQL
Get a medium size SQL expression for debugging or tracing.
getTraceSystem() - Method in class org.h2.engine.Database
 
getTraceSystem() - Static method in class org.h2.jdbcx.JdbcDataSourceFactory
INTERNAL
getTransaction() - Method in class org.h2.engine.SessionLocal
Get the transaction to use for this session.
getTransaction() - Method in class org.h2.mvstore.tx.TransactionMap
 
getTransaction(int) - Method in class org.h2.mvstore.tx.TransactionStore
Get Transaction object for a transaction id.
getTransactionBegin() - Method in class org.h2.mvstore.db.MVTable
Get a new transaction.
getTransactionId() - Method in class org.h2.engine.SessionLocal
 
getTransactionId(long) - Static method in class org.h2.mvstore.tx.TransactionStore
Get the transaction id for the given operation id.
getTransactionIsolation() - Method in class org.h2.jdbc.JdbcConnection
Returns the current transaction isolation level.
getTransactionName() - Method in class org.h2.mvstore.db.MVInDoubtTransaction
 
getTransactionName() - Method in interface org.h2.store.InDoubtTransaction
Get the name of the transaction.
getTransactionStore() - Method in class org.h2.mvstore.db.Store
 
getTransactionTimeout() - Method in class org.h2.jdbcx.JdbcXAConnection
Get the transaction timeout.
getTriggerClassName() - Method in class org.h2.schema.TriggerObject
Get the trigger class name.
getTriggers() - Method in class org.h2.table.Table
Return list of triggers.
getTriggerSource() - Method in class org.h2.schema.TriggerObject
 
getType() - Method in class org.h2.command.ddl.AlterDomainAddConstraint
 
getType() - Method in class org.h2.command.ddl.AlterDomainDropConstraint
 
getType() - Method in class org.h2.command.ddl.AlterDomainExpressions
 
getType() - Method in class org.h2.command.ddl.AlterDomainRename
 
getType() - Method in class org.h2.command.ddl.AlterDomainRenameConstraint
 
getType() - Method in class org.h2.command.ddl.AlterIndexRename
 
getType() - Method in class org.h2.command.ddl.AlterSchemaRename
 
getType() - Method in class org.h2.command.ddl.AlterSequence
 
getType() - Method in class org.h2.command.ddl.AlterTableAddConstraint
 
getType() - Method in class org.h2.command.ddl.AlterTableAlterColumn
 
getType() - Method in class org.h2.command.ddl.AlterTableDropConstraint
 
getType() - Method in class org.h2.command.ddl.AlterTableRename
 
getType() - Method in class org.h2.command.ddl.AlterTableRenameColumn
 
getType() - Method in class org.h2.command.ddl.AlterTableRenameConstraint
 
getType() - Method in class org.h2.command.ddl.AlterUser
 
getType() - Method in class org.h2.command.ddl.AlterView
 
getType() - Method in class org.h2.command.ddl.Analyze
 
getType() - Method in class org.h2.command.ddl.CreateAggregate
 
getType() - Method in class org.h2.command.ddl.CreateConstant
 
getType() - Method in class org.h2.command.ddl.CreateDomain
 
getType() - Method in class org.h2.command.ddl.CreateFunctionAlias
 
getType() - Method in class org.h2.command.ddl.CreateIndex
 
getType() - Method in class org.h2.command.ddl.CreateLinkedTable
 
getType() - Method in class org.h2.command.ddl.CreateRole
 
getType() - Method in class org.h2.command.ddl.CreateSchema
 
getType() - Method in class org.h2.command.ddl.CreateSequence
 
getType() - Method in class org.h2.command.ddl.CreateSynonym
 
getType() - Method in class org.h2.command.ddl.CreateTable
 
getType() - Method in class org.h2.command.ddl.CreateTrigger
 
getType() - Method in class org.h2.command.ddl.CreateUser
 
getType() - Method in class org.h2.command.ddl.CreateView
 
getType() - Method in class org.h2.command.ddl.DeallocateProcedure
 
getType() - Method in class org.h2.command.ddl.DropAggregate
 
getType() - Method in class org.h2.command.ddl.DropConstant
 
getType() - Method in class org.h2.command.ddl.DropDatabase
 
getType() - Method in class org.h2.command.ddl.DropDomain
 
getType() - Method in class org.h2.command.ddl.DropFunctionAlias
 
getType() - Method in class org.h2.command.ddl.DropIndex
 
getType() - Method in class org.h2.command.ddl.DropRole
 
getType() - Method in class org.h2.command.ddl.DropSchema
 
getType() - Method in class org.h2.command.ddl.DropSequence
 
getType() - Method in class org.h2.command.ddl.DropSynonym
 
getType() - Method in class org.h2.command.ddl.DropTable
 
getType() - Method in class org.h2.command.ddl.DropTrigger
 
getType() - Method in class org.h2.command.ddl.DropUser
 
getType() - Method in class org.h2.command.ddl.DropView
 
getType() - Method in class org.h2.command.ddl.GrantRevoke
 
getType() - Method in class org.h2.command.ddl.PrepareProcedure
 
getType() - Method in class org.h2.command.ddl.SetComment
 
getType() - Method in class org.h2.command.ddl.TruncateTable
 
getType() - Method in class org.h2.command.dml.AlterTableSet
 
getType() - Method in class org.h2.command.dml.BackupCommand
 
getType() - Method in class org.h2.command.dml.Call
 
getType() - Method in class org.h2.command.dml.Delete
 
getType() - Method in class org.h2.command.dml.ExecuteImmediate
 
getType() - Method in class org.h2.command.dml.ExecuteProcedure
 
getType() - Method in class org.h2.command.dml.Explain
 
getType() - Method in class org.h2.command.dml.Help
 
getType() - Method in class org.h2.command.dml.Insert
 
getType() - Method in class org.h2.command.dml.Merge
 
getType() - Method in class org.h2.command.dml.MergeUsing
 
getType() - Method in class org.h2.command.dml.NoOperation
 
getType() - Method in class org.h2.command.dml.RunScriptCommand
 
getType() - Method in class org.h2.command.dml.ScriptCommand
 
getType() - Method in class org.h2.command.dml.Set
 
getType() - Method in class org.h2.command.dml.SetSessionCharacteristics
 
getType() - Method in class org.h2.command.dml.TransactionCommand
 
getType() - Method in class org.h2.command.dml.Update
 
getType() - Method in class org.h2.command.Prepared
Get the command type as defined in CommandInterface
getType() - Method in class org.h2.command.query.Query
 
getType() - Method in class org.h2.constraint.Constraint
 
getType() - Method in class org.h2.engine.Comment
 
getType() - Method in class org.h2.engine.DbObject
Get the object type.
getType() - Method in class org.h2.engine.Right
 
getType() - Method in class org.h2.engine.Role
 
getType() - Method in class org.h2.engine.Setting
 
getType() - Method in class org.h2.engine.User
 
getType() - Method in class org.h2.expression.aggregate.AbstractAggregate
 
getType() - Method in class org.h2.expression.Alias
 
getType() - Method in class org.h2.expression.analysis.WindowFrameBound
Returns the type
getType() - Method in class org.h2.expression.analysis.WindowFunction
 
getType() - Method in class org.h2.expression.ArrayConstructorByQuery
 
getType() - Method in class org.h2.expression.condition.Condition
 
getType() - Method in class org.h2.expression.DomainValueExpression
 
getType() - Method in class org.h2.expression.Expression
Returns the data type.
getType() - Method in class org.h2.expression.ExpressionColumn
 
getType() - Method in class org.h2.expression.ExpressionList
 
getType() - Method in class org.h2.expression.ExpressionVisitor
Get the visitor type.
getType() - Method in class org.h2.expression.function.CurrentDateTimeValueFunction
 
getType() - Method in class org.h2.expression.function.CurrentGeneralValueSpecification
 
getType() - Method in class org.h2.expression.function.Function0_1
 
getType() - Method in class org.h2.expression.function.JavaFunction
 
getType() - Method in class org.h2.expression.function.SysInfoFunction
 
getType() - Method in class org.h2.expression.Operation1_2
 
getType() - Method in class org.h2.expression.Operation1
 
getType() - Method in class org.h2.expression.Operation2
 
getType() - Method in class org.h2.expression.OperationN
 
getType() - Method in class org.h2.expression.Parameter
 
getType() - Method in interface org.h2.expression.ParameterInterface
Returns the expected data type if no value is set, or the data type of the value if one is set.
getType() - Method in class org.h2.expression.ParameterRemote
 
getType() - Method in class org.h2.expression.Rownum
 
getType() - Method in class org.h2.expression.SequenceValue
 
getType() - Method in class org.h2.expression.SimpleCase
 
getType() - Method in class org.h2.expression.Subquery
 
getType() - Method in class org.h2.expression.TypedValueExpression
 
getType() - Method in class org.h2.expression.ValueExpression
 
getType() - Method in class org.h2.expression.Variable
 
getType() - Method in class org.h2.expression.Wildcard
 
getType() - Method in class org.h2.index.Index
 
getType() - Method in class org.h2.jdbc.JdbcResultSet
Get the result set type.
getType() - Method in class org.h2.mode.OnDuplicateKeyValues
 
getType() - Method in class org.h2.mode.Regclass
 
getType() - Method in class org.h2.mvstore.db.SpatialKey
 
getType() - Method in class org.h2.mvstore.MVMap
Get the map type.
getType() - Method in class org.h2.mvstore.rtree.MVRTreeMap
 
getType() - Method in class org.h2.mvstore.tx.TransactionStore.TxMapBuilder.TMVMap
 
getType() - Method in class org.h2.result.SearchRow
 
getType() - Method in class org.h2.schema.Constant
 
getType() - Method in class org.h2.schema.Domain
 
getType() - Method in class org.h2.schema.FunctionAlias
 
getType() - Method in class org.h2.schema.Schema
 
getType() - Method in class org.h2.schema.Sequence
 
getType() - Method in class org.h2.schema.TriggerObject
 
getType() - Method in class org.h2.schema.UserAggregate
 
getType() - Method in class org.h2.server.pg.PgServer
 
getType() - Method in interface org.h2.server.Service
Get the human readable short name of the service.
getType() - Method in class org.h2.server.TcpServer
 
getType() - Method in class org.h2.server.web.WebServer
 
getType() - Method in class org.h2.table.Column
 
getType() - Method in class org.h2.table.Table
 
getType() - Method in class org.h2.table.TableSynonym
 
getType() - Method in class org.h2.tools.SimpleResultSet
Returns the result set type.
getType() - Method in class org.h2.value.ExtTypeInfoEnum
 
getType() - Method in class org.h2.value.ExtTypeInfoGeometry
Returns the type and dimension system of geometries.
getType() - Method in interface org.h2.value.Typed
Returns the data type.
getType() - Method in class org.h2.value.TypeInfo
Returns this type information.
getType() - Method in class org.h2.value.Value
 
getType() - Method in class org.h2.value.ValueArray
 
getType() - Method in class org.h2.value.ValueBigint
 
getType() - Method in class org.h2.value.ValueBinary
 
getType() - Method in class org.h2.value.ValueBoolean
 
getType() - Method in class org.h2.value.ValueDate
 
getType() - Method in class org.h2.value.ValueDecfloat
 
getType() - Method in class org.h2.value.ValueDouble
 
getType() - Method in class org.h2.value.ValueEnum
 
getType() - Method in class org.h2.value.ValueEnumBase
 
getType() - Method in class org.h2.value.ValueGeometry
 
getType() - Method in class org.h2.value.ValueInteger
 
getType() - Method in class org.h2.value.ValueInterval
 
getType() - Method in class org.h2.value.ValueJavaObject
 
getType() - Method in class org.h2.value.ValueJson
 
getType() - Method in class org.h2.value.ValueLob
 
getType() - Method in class org.h2.value.ValueNull
 
getType() - Method in class org.h2.value.ValueNumeric
 
getType() - Method in class org.h2.value.ValueReal
 
getType() - Method in class org.h2.value.ValueRow
 
getType() - Method in class org.h2.value.ValueSmallint
 
getType() - Method in class org.h2.value.ValueStringBase
 
getType() - Method in class org.h2.value.ValueTime
 
getType() - Method in class org.h2.value.ValueTimestamp
 
getType() - Method in class org.h2.value.ValueTimestampTimeZone
 
getType() - Method in class org.h2.value.ValueTimeTimeZone
 
getType() - Method in class org.h2.value.ValueTinyint
 
getType() - Method in class org.h2.value.ValueUuid
 
getType() - Method in class org.h2.value.ValueVarbinary
 
getType(int[]) - Method in interface org.h2.api.AggregateFunction
This method must return the SQL type of the method, given the SQL type of the input data.
getType(Object) - Method in class org.h2.mvstore.type.ObjectDataType.AutoDetectDataType
Get the type for the given object.
getType(String) - Static method in class org.h2.command.dml.SetTypes
Get the set type number.
getTypeAndDimensionSystem() - Method in class org.h2.value.ValueGeometry
Returns geometry type and dimension system in OGC geometry code format (type + dimensionSystem * 1000).
getTypeByName(String, Mode) - Static method in class org.h2.value.DataType
Get a data type object from a type name.
getTypedIfNull(Value, TypeInfo) - Static method in class org.h2.expression.TypedValueExpression
Create a new typed value expression with the given value and type if value is NULL, or a plain value expression otherwise.
getTypeId(Object) - Static method in class org.h2.mvstore.type.ObjectDataType
 
getTypeInfo() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the list of data types.
getTypeInfo() - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getTypeInfo() - Method in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
getTypeInfo() - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
getTypeInfo() - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getTypeInfo(int) - Static method in class org.h2.value.TypeInfo
Get the data type with parameters object for the given value type and maximum parameters.
getTypeInfo(int, long, int, ExtTypeInfo) - Static method in class org.h2.value.TypeInfo
Get the data type with parameters object for the given value type and the specified parameters.
getTypeMap() - Method in class org.h2.jdbc.JdbcConnection
Gets the type map.
getTypeMask() - Method in class org.h2.schema.TriggerObject
Returns the trigger type.
getTypeName(int) - Static method in class org.h2.command.dml.SetTypes
Get the set type name.
getTypeName(int) - Static method in class org.h2.engine.Comment
 
getTypeName(int) - Static method in class org.h2.value.Value
Returns name of the specified data type.
getTypeName(int, int) - Method in enum org.h2.api.IntervalQualifier
Returns full type name.
getTypeName(StringBuilder, int, int, boolean) - Method in enum org.h2.api.IntervalQualifier
Appends full type name to the specified string builder.
getTypeNameList(StringBuilder) - Method in class org.h2.schema.TriggerObject
Append the trigger types to the given string builder.
getTypes() - Static method in class org.h2.command.dml.SetTypes
 
getTypeSet() - Method in class org.h2.server.pg.PgServer
Get the type hash set.
getTypeSize(int, int) - Static method in class org.h2.server.pg.PgServerThread
 
getUDTs(String, String, String, int[]) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Gets the list of user-defined data types.
getUDTs(String, String, String, int[]) - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getUDTs(String, String, String, int[]) - Method in class org.h2.jdbc.meta.DatabaseMetaLocalBase
 
getUDTs(String, String, String, int[]) - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getUndoLogName(int) - Static method in class org.h2.mvstore.tx.TransactionStore
Generate a string used to name undo log map for a specific transaction.
getUndoLogRootReferences() - Method in class org.h2.mvstore.tx.Transaction
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.aggregate.Aggregate
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.aggregate.JavaAggregate
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.Alias
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.analysis.WindowFunction
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.ArrayConstructorByQuery
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.ArrayElementReference
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.BinaryOperation
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.CompatibilityDatePlusTimeOperation
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.ConcatenationOperation
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.condition.BetweenPredicate
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.condition.BooleanTest
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.condition.CompareLike
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.condition.Comparison
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.condition.ConditionAndOr
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.condition.ConditionAndOrN
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.condition.ConditionIn
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.condition.ConditionInConstantSet
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.condition.ConditionInParameter
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.condition.ConditionInQuery
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.condition.ConditionLocalAndGlobal
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.condition.ConditionNot
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.condition.ExistsPredicate
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.condition.IsJsonPredicate
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.condition.NullPredicate
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.condition.PredicateWithSubquery
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.condition.TypePredicate
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.condition.UniquePredicate
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.DomainValueExpression
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.Expression
Get the SQL statement of this expression.
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.ExpressionColumn
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.ExpressionList
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.FieldReference
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.Format
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.function.CastSpecification
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.function.CurrentDateTimeValueFunction
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.function.CurrentGeneralValueSpecification
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.function.DateTimeFunction
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.function.Function0_1
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.function.Function1_2
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.function.Function1
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.function.Function2
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.function.FunctionN
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.function.JavaFunction
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.function.JsonConstructorFunction
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.function.SubstringFunction
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.function.SysInfoFunction
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.function.TrimFunction
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.IntervalOperation
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.Parameter
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.Rownum
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.SearchedCase
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.SequenceValue
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.SimpleCase
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.Subquery
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.TimeZoneOperation
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.TypedValueExpression
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.UnaryOperation
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.ValueExpression
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.Variable
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.expression.Wildcard
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.mode.OnDuplicateKeyValues
 
getUnenclosedSQL(StringBuilder, int) - Method in class org.h2.mode.Regclass
 
getUnexpectedForcedTypeException() - Method in class org.h2.expression.BinaryOperation
 
getUnicodeStream(int) - Method in class org.h2.jdbc.JdbcResultSet
Deprecated.
since JDBC 2.0, use getCharacterStream
getUnicodeStream(int) - Method in class org.h2.tools.SimpleResultSet
Deprecated.
INTERNAL
getUnicodeStream(String) - Method in class org.h2.jdbc.JdbcResultSet
Deprecated.
since JDBC 2.0, use setCharacterStream
getUnicodeStream(String) - Method in class org.h2.tools.SimpleResultSet
Deprecated.
INTERNAL
getUnionType() - Method in class org.h2.command.query.SelectUnion
 
getUniqueColumnCount() - Method in class org.h2.index.Index
Returns count of unique columns.
getUniqueConstraint(Table, IndexColumn[]) - Static method in class org.h2.command.ddl.AlterTableAddConstraint
 
getUniqueConstraintName(SessionLocal, Table) - Method in class org.h2.schema.Schema
Create a unique constraint name.
getUniqueDomainConstraintName(SessionLocal, Domain) - Method in class org.h2.schema.Schema
Create a unique constraint name.
getUniqueId() - Method in class org.h2.store.FileLock
 
getUniqueIndexName(SessionLocal, Table, String) - Method in class org.h2.schema.Schema
Create a unique index name.
getUniqueName(DbObject, Map<String, ? extends SchemaObject>, String) - Method in class org.h2.schema.Schema
 
getUniqueRowFactory() - Method in class org.h2.index.Index
 
getUnits() - Method in class org.h2.expression.analysis.WindowFrame
Returns the units.
getUnsavedMemory() - Method in class org.h2.mvstore.MVStore
Get the estimated memory (in bytes) of unsaved data.
getUnsupported(int, int) - Method in class org.h2.expression.BinaryOperation
 
getUnsupportedException() - Static method in class org.h2.tools.SimpleResultSet
INTERNAL
getUnsupportedException(String) - Static method in exception org.h2.message.DbException
Gets a SQL exception meaning this feature is not supported.
getUnsupportedExceptionForOperation(String) - Method in class org.h2.value.Value
Create an exception meaning the specified operation is not supported for this data type.
getUnsupportedWriteFormatException(long, int, String) - Method in class org.h2.mvstore.MVStore
 
getUpdatableRow() - Method in class org.h2.jdbc.JdbcResultSet
 
getUpdate(SessionLocal) - Method in class org.h2.constraint.ConstraintReferential
 
getUpdateAction() - Method in class org.h2.constraint.ConstraintReferential
 
getUpdateCount() - Method in class org.h2.jdbc.JdbcStatement
Returns the last update count of this statement.
getUpdateCount() - Method in class org.h2.result.ResultWithGeneratedKeys
Returns update count.
getUpdateFailureRatio() - Method in class org.h2.mvstore.MVStore
 
getUpdateRow() - Method in class org.h2.jdbc.JdbcResultSet
INTERNAL
getUrl() - Method in class org.h2.jdbcx.JdbcDataSource
Get the current URL.
getURL() - Method in class org.h2.engine.ConnectionInfo
Get the database URL.
getURL() - Method in class org.h2.jdbc.JdbcConnection
 
getURL() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the database URL for this connection.
getURL() - Method in class org.h2.jdbcx.JdbcDataSource
Get the current URL.
getURL() - Method in class org.h2.server.pg.PgServer
 
getURL() - Method in interface org.h2.server.Service
Get the URL of this service in a human readable form
getURL() - Method in class org.h2.server.TcpServer
 
getURL() - Method in class org.h2.server.web.WebServer
 
getURL() - Method in class org.h2.tools.Server
Gets the URL of this server.
getURL(int) - Method in class org.h2.jdbc.JdbcCallableStatement
[Not supported]
getURL(int) - Method in class org.h2.jdbc.JdbcResultSet
[Not supported]
getURL(int) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
getURL(String) - Method in class org.h2.jdbc.JdbcCallableStatement
[Not supported]
getURL(String) - Method in class org.h2.jdbc.JdbcResultSet
[Not supported]
getURL(String) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
getUsedMemory() - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Get the currently used memory.
getUser() - Method in class org.h2.engine.SessionLocal
 
getUser() - Method in class org.h2.jdbc.JdbcConnection
 
getUser() - Method in class org.h2.jdbcx.JdbcDataSource
Get the current user name.
getUser(String) - Method in class org.h2.engine.Database
Get user with the given name.
getUserbyid(SessionLocal, int) - Static method in class org.h2.mode.FunctionsPostgreSQL
 
getUserName() - Method in class org.h2.engine.ConnectionInfo
Get the name of the user.
getUserName() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the user name as passed to DriverManager.getConnection(url, user, password).
getUserName() - Method in class org.h2.security.auth.AuthenticationInfo
 
getUserPasswordHash() - Method in class org.h2.engine.ConnectionInfo
Get the user password hash.
getUserToRolesMappers() - Method in class org.h2.security.auth.DefaultAuthenticator
UserToRoleMappers assign roles to authenticated users
getUserToRolesMappers() - Method in class org.h2.security.auth.H2AuthConfig
Gets configuration of the mappers external users to database roles.
getUuid() - Method in class org.h2.value.ValueUuid
Returns the UUID.
getValidatorClass() - Method in class org.h2.security.auth.RealmConfig
Gets validator class name.
getValMemory(T) - Method in class org.h2.mvstore.tx.VersionedValueType
 
getValue() - Method in class org.h2.expression.analysis.WindowFrameBound
Returns the value.
getValue() - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS.Entry
 
getValue() - Method in class org.h2.mvstore.Cursor
Get the last read value if there was one.
getValue() - Method in class org.h2.schema.Constant
 
getValue() - Method in class org.h2.security.auth.PropertyConfig
 
getValue(int) - Method in class org.h2.mvstore.Page
Get the value at the given index.
getValue(int) - Method in class org.h2.mvstore.Page.Leaf
 
getValue(int) - Method in class org.h2.mvstore.Page.NonLeaf
 
getValue(int) - Method in class org.h2.result.DefaultRow
 
getValue(int) - Method in class org.h2.result.SearchRow
Get the value for the column
getValue(int) - Method in class org.h2.result.SimpleRowValue
 
getValue(int) - Method in class org.h2.result.Sparse
 
getValue(int, CastDataProvider) - Method in class org.h2.value.ExtTypeInfoEnum
Get ValueEnum instance for an ordinal.
getValue(String, CastDataProvider) - Method in class org.h2.value.ExtTypeInfoEnum
Get ValueEnum instance for a label string.
getValue(SessionLocal) - Method in class org.h2.expression.aggregate.Aggregate
 
getValue(SessionLocal) - Method in class org.h2.expression.aggregate.AggregateData
Get the aggregate result.
getValue(SessionLocal) - Method in class org.h2.expression.aggregate.AggregateDataAvg
 
getValue(SessionLocal) - Method in class org.h2.expression.aggregate.AggregateDataCollecting
 
getValue(SessionLocal) - Method in class org.h2.expression.aggregate.AggregateDataCorr
 
getValue(SessionLocal) - Method in class org.h2.expression.aggregate.AggregateDataCount
 
getValue(SessionLocal) - Method in class org.h2.expression.aggregate.AggregateDataCovar
 
getValue(SessionLocal) - Method in class org.h2.expression.aggregate.AggregateDataDefault
 
getValue(SessionLocal) - Method in class org.h2.expression.aggregate.AggregateDataDistinctWithCounts
 
getValue(SessionLocal) - Method in class org.h2.expression.aggregate.AggregateDataEnvelope
 
getValue(SessionLocal) - Method in class org.h2.expression.aggregate.AggregateDataStdVar
 
getValue(SessionLocal) - Method in class org.h2.expression.Alias
 
getValue(SessionLocal) - Method in class org.h2.expression.analysis.DataAnalysisOperation
 
getValue(SessionLocal) - Method in class org.h2.expression.ArrayConstructorByQuery
 
getValue(SessionLocal) - Method in class org.h2.expression.ArrayElementReference
 
getValue(SessionLocal) - Method in class org.h2.expression.BinaryOperation
 
getValue(SessionLocal) - Method in class org.h2.expression.CompatibilityDatePlusTimeOperation
 
getValue(SessionLocal) - Method in class org.h2.expression.ConcatenationOperation
 
getValue(SessionLocal) - Method in class org.h2.expression.condition.BetweenPredicate
 
getValue(SessionLocal) - Method in class org.h2.expression.condition.BooleanTest
 
getValue(SessionLocal) - Method in class org.h2.expression.condition.CompareLike
 
getValue(SessionLocal) - Method in class org.h2.expression.condition.Comparison
 
getValue(SessionLocal) - Method in class org.h2.expression.condition.ConditionAndOr
 
getValue(SessionLocal) - Method in class org.h2.expression.condition.ConditionAndOrN
 
getValue(SessionLocal) - Method in class org.h2.expression.condition.ConditionIn
 
getValue(SessionLocal) - Method in class org.h2.expression.condition.ConditionInConstantSet
 
getValue(SessionLocal) - Method in class org.h2.expression.condition.ConditionInParameter
 
getValue(SessionLocal) - Method in class org.h2.expression.condition.ConditionInQuery
 
getValue(SessionLocal) - Method in class org.h2.expression.condition.ConditionLocalAndGlobal
 
getValue(SessionLocal) - Method in class org.h2.expression.condition.ConditionNot
 
getValue(SessionLocal) - Method in class org.h2.expression.condition.ExistsPredicate
 
getValue(SessionLocal) - Method in class org.h2.expression.condition.IsJsonPredicate
 
getValue(SessionLocal) - Method in class org.h2.expression.condition.NullPredicate
 
getValue(SessionLocal) - Method in class org.h2.expression.condition.TypePredicate
 
getValue(SessionLocal) - Method in class org.h2.expression.condition.UniquePredicate
 
getValue(SessionLocal) - Method in class org.h2.expression.DomainValueExpression
 
getValue(SessionLocal) - Method in class org.h2.expression.Expression
Return the resulting value for the current row.
getValue(SessionLocal) - Method in class org.h2.expression.ExpressionColumn
 
getValue(SessionLocal) - Method in class org.h2.expression.ExpressionList
 
getValue(SessionLocal) - Method in class org.h2.expression.FieldReference
 
getValue(SessionLocal) - Method in class org.h2.expression.Format
 
getValue(SessionLocal) - Method in class org.h2.expression.function.ArrayFunction
 
getValue(SessionLocal) - Method in class org.h2.expression.function.CardinalityExpression
 
getValue(SessionLocal) - Method in class org.h2.expression.function.CastSpecification
 
getValue(SessionLocal) - Method in class org.h2.expression.function.CoalesceFunction
 
getValue(SessionLocal) - Method in class org.h2.expression.function.ConcatFunction
 
getValue(SessionLocal) - Method in class org.h2.expression.function.CSVWriteFunction
 
getValue(SessionLocal) - Method in class org.h2.expression.function.CurrentDateTimeValueFunction
 
getValue(SessionLocal) - Method in class org.h2.expression.function.CurrentGeneralValueSpecification
 
getValue(SessionLocal) - Method in class org.h2.expression.function.DayMonthNameFunction
 
getValue(SessionLocal) - Method in class org.h2.expression.function.FileFunction
 
getValue(SessionLocal) - Method in class org.h2.expression.function.Function1_2
 
getValue(SessionLocal) - Method in class org.h2.expression.function.Function2
 
getValue(SessionLocal) - Method in class org.h2.expression.function.FunctionN
 
getValue(SessionLocal) - Method in class org.h2.expression.function.JavaFunction
 
getValue(SessionLocal) - Method in class org.h2.expression.function.JsonConstructorFunction
 
getValue(SessionLocal) - Method in class org.h2.expression.function.LengthFunction
 
getValue(SessionLocal) - Method in class org.h2.expression.function.MathFunction1
 
getValue(SessionLocal) - Method in class org.h2.expression.function.NullIfFunction
 
getValue(SessionLocal) - Method in class org.h2.expression.function.RandFunction
 
getValue(SessionLocal) - Method in class org.h2.expression.function.RegexpFunction
 
getValue(SessionLocal) - Method in class org.h2.expression.function.SessionControlFunction
 
getValue(SessionLocal) - Method in class org.h2.expression.function.SetFunction
 
getValue(SessionLocal) - Method in class org.h2.expression.function.StringFunction
 
getValue(SessionLocal) - Method in class org.h2.expression.function.StringFunction1
 
getValue(SessionLocal) - Method in class org.h2.expression.function.SysInfoFunction
 
getValue(SessionLocal) - Method in class org.h2.expression.function.table.ArrayTableFunction
 
getValue(SessionLocal) - Method in class org.h2.expression.function.table.CSVReadFunction
 
getValue(SessionLocal) - Method in class org.h2.expression.function.table.JavaTableFunction
 
getValue(SessionLocal) - Method in class org.h2.expression.function.table.LinkSchemaFunction
 
getValue(SessionLocal) - Method in class org.h2.expression.function.table.TableFunction
Get a result with.
getValue(SessionLocal) - Method in class org.h2.expression.function.XMLFunction
 
getValue(SessionLocal) - Method in class org.h2.expression.IntervalOperation
 
getValue(SessionLocal) - Method in class org.h2.expression.Parameter
 
getValue(SessionLocal) - Method in class org.h2.expression.Rownum
 
getValue(SessionLocal) - Method in class org.h2.expression.SearchedCase
 
getValue(SessionLocal) - Method in class org.h2.expression.SequenceValue
 
getValue(SessionLocal) - Method in class org.h2.expression.SimpleCase
 
getValue(SessionLocal) - Method in class org.h2.expression.Subquery
 
getValue(SessionLocal) - Method in class org.h2.expression.TimeZoneOperation
 
getValue(SessionLocal) - Method in class org.h2.expression.UnaryOperation
 
getValue(SessionLocal) - Method in class org.h2.expression.ValueExpression
 
getValue(SessionLocal) - Method in class org.h2.expression.Variable
 
getValue(SessionLocal) - Method in class org.h2.expression.Wildcard
 
getValue(SessionLocal) - Method in class org.h2.mode.FunctionsDB2Derby
 
getValue(SessionLocal) - Method in class org.h2.mode.FunctionsLegacy
 
getValue(SessionLocal) - Method in class org.h2.mode.FunctionsMSSQLServer
 
getValue(SessionLocal) - Method in class org.h2.mode.FunctionsMySQL
 
getValue(SessionLocal) - Method in class org.h2.mode.FunctionsOracle
 
getValue(SessionLocal) - Method in class org.h2.mode.FunctionsPostgreSQL
 
getValue(SessionLocal) - Method in class org.h2.mode.OnDuplicateKeyValues
 
getValue(SessionLocal) - Method in class org.h2.mode.Regclass
 
getValue(SessionLocal, int) - Method in class org.h2.expression.ConcatenationOperation
 
getValue(SessionLocal, int) - Method in class org.h2.expression.function.CSVWriteFunction
 
getValue(SessionLocal, int) - Method in class org.h2.expression.function.table.CSVReadFunction
 
getValue(SessionLocal, int) - Method in class org.h2.expression.function.table.LinkSchemaFunction
 
getValue(SessionLocal, Expression[], boolean) - Method in class org.h2.schema.FunctionAlias.JavaMethod
Call the user-defined function and return the value.
getValue(SessionLocal, Expression[], int) - Static method in class org.h2.expression.function.table.CSVReadFunction
 
getValue(SessionLocal, Value) - Method in class org.h2.expression.condition.CompareLike
 
getValue(SessionLocal, Value) - Method in class org.h2.expression.condition.ConditionIn
 
getValue(SessionLocal, Value) - Method in class org.h2.expression.condition.ConditionInQuery
 
getValue(SessionLocal, Value[], int, ArrayList<QueryOrderBy>, BigDecimal, boolean) - Static method in class org.h2.expression.aggregate.Percentile
Get the result from the array of values.
getValue(SessionLocal, Value, boolean, Value) - Static method in class org.h2.expression.condition.ConditionInParameter
Gets evaluated condition value.
getValue(SessionLocal, Value, Value) - Method in class org.h2.expression.ConcatenationOperation
 
getValue(SessionLocal, Value, Value) - Method in class org.h2.expression.function.BitFunction
 
getValue(SessionLocal, Value, Value) - Method in class org.h2.expression.function.CompatibilitySequenceValueFunction
 
getValue(SessionLocal, Value, Value) - Method in class org.h2.expression.function.CompressFunction
 
getValue(SessionLocal, Value, Value) - Method in class org.h2.expression.function.DateTimeFunction
 
getValue(SessionLocal, Value, Value) - Method in class org.h2.expression.function.Function1_2
Returns the value of this function.
getValue(SessionLocal, Value, Value) - Method in class org.h2.expression.function.Function2
Returns the value of this function.
getValue(SessionLocal, Value, Value) - Method in class org.h2.expression.function.MathFunction
 
getValue(SessionLocal, Value, Value) - Method in class org.h2.expression.function.MathFunction2
 
getValue(SessionLocal, Value, Value) - Method in class org.h2.expression.function.SignalFunction
 
getValue(SessionLocal, Value, Value) - Method in class org.h2.expression.function.SoundexFunction
 
getValue(SessionLocal, Value, Value) - Method in class org.h2.expression.function.StringFunction2
 
getValue(SessionLocal, Value, Value) - Method in class org.h2.expression.function.TableInfoFunction
 
getValue(SessionLocal, Value, Value) - Method in class org.h2.expression.function.TrimFunction
 
getValue(SessionLocal, Value, Value, Value) - Method in class org.h2.expression.condition.BetweenPredicate
 
getValue(SessionLocal, Value, Value, Value) - Method in class org.h2.expression.function.CryptFunction
 
getValue(SessionLocal, Value, Value, Value) - Method in class org.h2.expression.function.DataTypeSQLFunction
 
getValue(SessionLocal, Value, Value, Value) - Method in class org.h2.expression.function.DateTimeFormatFunction
 
getValue(SessionLocal, Value, Value, Value) - Method in class org.h2.expression.function.DBObjectFunction
 
getValue(SessionLocal, Value, Value, Value) - Method in class org.h2.expression.function.FunctionN
Returns the value of this function.
getValue(SessionLocal, Value, Value, Value) - Method in class org.h2.expression.function.HashFunction
 
getValue(SessionLocal, Value, Value, Value) - Method in class org.h2.expression.function.SubstringFunction
 
getValue(SessionLocal, Value, Value, Value) - Method in class org.h2.expression.function.ToCharFunction
 
getValue(SessionLocal, Value, Value, Value) - Method in class org.h2.expression.function.TruncateValueFunction
 
getValue(SessionLocal, Value, Value, Value) - Method in class org.h2.expression.function.XMLFunction
 
getValue(Column) - Method in class org.h2.command.query.SelectListColumnResolver
 
getValue(Column) - Method in class org.h2.command.query.TableValueConstructor.TableValueColumnResolver
 
getValue(Column) - Method in class org.h2.constraint.DomainColumnResolver
 
getValue(Column) - Method in interface org.h2.table.ColumnResolver
Get the value for the given column.
getValue(Column) - Method in class org.h2.table.GeneratedColumnResolver
 
getValue(Column) - Method in class org.h2.table.TableFilter
 
getValue(Value) - Method in class org.h2.expression.condition.BooleanTest
 
getValue(Value) - Method in class org.h2.expression.condition.IsJsonPredicate
 
getValue(Value) - Method in class org.h2.expression.condition.NullPredicate
 
getValue(Value) - Method in class org.h2.expression.Format
Returns the value with applied format.
getValue(Value[]) - Method in class org.h2.mvstore.db.MVSortedTempResult
Reorder values back if required.
getValue(Value, SessionLocal) - Method in class org.h2.expression.condition.ConditionInConstantSet
 
getValueInSnapshot() - Method in class org.h2.mvstore.tx.TxDecisionMaker.PutIfAbsentDecisionMaker
 
getValueList() - Method in class org.h2.result.DefaultRow
 
getValueList() - Method in class org.h2.result.Row
Get values.
getValueOffset(WindowFrameBound, Value[], SessionLocal) - Static method in class org.h2.expression.analysis.WindowFrame
 
getValueOrNull(String, CastDataProvider) - Method in class org.h2.value.ExtTypeInfoEnum
 
getValueQuick(SessionLocal) - Method in class org.h2.expression.aggregate.Aggregate
 
getValues() - Method in class org.h2.expression.aggregate.AggregateDataDistinctWithCounts
Returns map with values and their counts.
getValueSlow(SessionLocal, ResultInterface, Value) - Method in class org.h2.expression.condition.ConditionInQuery
 
getValuesSQL(StringBuilder, int, ArrayList<ArrayList<Expression>>) - Static method in class org.h2.command.query.TableValueConstructor
Appends the SQL of the values to the specified string builder..
getValueTemplate(SessionLocal) - Method in class org.h2.expression.function.table.ArrayTableFunction
 
getValueTemplate(SessionLocal) - Method in class org.h2.expression.function.table.CSVReadFunction
 
getValueTemplate(SessionLocal) - Method in class org.h2.expression.function.table.JavaTableFunction
 
getValueTemplate(SessionLocal) - Method in class org.h2.expression.function.table.LinkSchemaFunction
 
getValueTemplate(SessionLocal) - Method in class org.h2.expression.function.table.TableFunction
Get an empty result with the column names set.
getValueTooLongException(String, String, long) - Static method in exception org.h2.message.DbException
Gets a SQL exception meaning this value is too long.
getValueTooLongException(TypeInfo, Object) - Method in class org.h2.value.Value
 
getValueType() - Method in class org.h2.constraint.DomainColumnResolver
Return the type of the column.
getValueType() - Method in class org.h2.mvstore.db.SpatialKey
 
getValueType() - Method in class org.h2.mvstore.MVMap.BasicBuilder
 
getValueType() - Method in class org.h2.mvstore.MVMap
Get the value type.
getValueType() - Method in interface org.h2.mvstore.MVMap.MapBuilder
 
getValueType() - Method in class org.h2.result.SearchRow
 
getValueType() - Method in class org.h2.value.TypeInfo
Returns the value type.
getValueType() - Method in class org.h2.value.Value
Get the value type.
getValueType() - Method in class org.h2.value.ValueArray
 
getValueType() - Method in class org.h2.value.ValueBigint
 
getValueType() - Method in class org.h2.value.ValueBinary
 
getValueType() - Method in class org.h2.value.ValueBlob
 
getValueType() - Method in class org.h2.value.ValueBoolean
 
getValueType() - Method in class org.h2.value.ValueChar
 
getValueType() - Method in class org.h2.value.ValueClob
 
getValueType() - Method in class org.h2.value.ValueDate
 
getValueType() - Method in class org.h2.value.ValueDecfloat
 
getValueType() - Method in class org.h2.value.ValueDouble
 
getValueType() - Method in class org.h2.value.ValueEnumBase
 
getValueType() - Method in class org.h2.value.ValueGeometry
 
getValueType() - Method in class org.h2.value.ValueInteger
 
getValueType() - Method in class org.h2.value.ValueInterval
 
getValueType() - Method in class org.h2.value.ValueJavaObject
 
getValueType() - Method in class org.h2.value.ValueJson
 
getValueType() - Method in class org.h2.value.ValueNull
 
getValueType() - Method in class org.h2.value.ValueNumeric
 
getValueType() - Method in class org.h2.value.ValueReal
 
getValueType() - Method in class org.h2.value.ValueRow
 
getValueType() - Method in class org.h2.value.ValueSmallint
 
getValueType() - Method in class org.h2.value.ValueTime
 
getValueType() - Method in class org.h2.value.ValueTimestamp
 
getValueType() - Method in class org.h2.value.ValueTimestampTimeZone
 
getValueType() - Method in class org.h2.value.ValueTimeTimeZone
 
getValueType() - Method in class org.h2.value.ValueTinyint
 
getValueType() - Method in class org.h2.value.ValueUuid
 
getValueType() - Method in class org.h2.value.ValueVarbinary
 
getValueType() - Method in class org.h2.value.ValueVarchar
 
getValueType() - Method in class org.h2.value.ValueVarcharIgnoreCase
 
getValueTypeFromResultSet(ResultSetMetaData, int) - Static method in class org.h2.value.DataType
Get the SQL type from the result set meta data for the given column.
getVariable(String) - Method in class org.h2.engine.SessionLocal
Get the value of the specified user defined variable.
getVariableIntLength(int) - Static method in class org.h2.tools.CompressTool
Get a variable size integer length using Rice coding.
getVariableNames() - Method in class org.h2.engine.SessionLocal
Get the list of variable names that are set for this session.
getVarIntLen(int) - Static method in class org.h2.mvstore.DataUtils
Get the length of the variable size int.
getVarLongLen(long) - Static method in class org.h2.mvstore.DataUtils
Get the length of the variable size long.
getVendor() - Method in class org.h2.api.H2Type
 
getVendorTypeNumber() - Method in class org.h2.api.H2Type
Returns the vendor specific type number for the data type.
getVersion() - Method in class org.h2.jmx.DatabaseInfo
 
getVersion() - Method in interface org.h2.jmx.DatabaseInfoMBean
The database version.
getVersion() - Method in class org.h2.mvstore.MVMap
Get version of the map, which is the version of the store, at the moment when map was modified last time.
getVersion() - Method in class org.h2.mvstore.RootReference
 
getVersion() - Method in class org.h2.mvstore.tx.VersionedBitSet
 
getVersion() - Method in class org.h2.value.Transfer
 
getVersionColumns(String, String, String) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Get the list of columns that are update when any value is updated.
getVersionColumns(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMeta
INTERNAL
getVersionColumns(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaLocalBase
 
getVersionColumns(String, String, String) - Method in class org.h2.jdbc.meta.DatabaseMetaRemote
 
getVersionsToKeep() - Method in class org.h2.mvstore.MVStore
Get the oldest version to retain in memory (for in-memory stores).
getViewIndexCache(boolean) - Method in class org.h2.engine.SessionLocal
Get the view cache for this session.
getVisible() - Method in class org.h2.table.Column
 
getVisibleColumnCount() - Method in class org.h2.command.query.Select.LazyResultSelect
 
getVisibleColumnCount() - Method in class org.h2.command.query.SelectUnion.LazyResultUnion
 
getVisibleColumnCount() - Method in class org.h2.result.LocalResult
 
getVisibleColumnCount() - Method in interface org.h2.result.ResultInterface
Get the number of visible columns.
getVisibleColumnCount() - Method in class org.h2.result.ResultRemote
 
getVisibleColumnCount() - Method in class org.h2.result.ResultWithPaddedStrings
 
getVisibleColumnCount() - Method in class org.h2.result.SimpleResult
 
getVisibleResult(SessionLocal, ResultTarget, Column[], ArrayList<ArrayList<Expression>>) - Static method in class org.h2.command.query.TableValueConstructor
Appends visible columns of all rows to the specified result.
getWaitForLock() - Method in class org.h2.engine.SessionLocal
 
getWaitForLockThread() - Method in class org.h2.engine.SessionLocal
 
getWarnings() - Method in class org.h2.jdbc.JdbcConnection
Gets the first warning reported by calls on this object.
getWarnings() - Method in class org.h2.jdbc.JdbcResultSet
Gets the first warning reported by calls on this object.
getWarnings() - Method in class org.h2.jdbc.JdbcStatement
Gets the first warning reported by calls on this object.
getWarnings() - Method in class org.h2.tools.SimpleResultSet
Returns null.
getWeekFields() - Static method in class org.h2.expression.function.DateTimeFunction
 
getWeekOfYear(long, int, int) - Static method in class org.h2.util.DateTimeUtils
Returns number of week in year.
getWeekYear(long, int, int) - Static method in class org.h2.util.DateTimeUtils
Returns week year.
getWeekYearAbsoluteStart(int, int, int) - Static method in class org.h2.util.DateTimeUtils
Get absolute day of the first day in the week year.
getWhen() - Method in class org.h2.command.dml.MergeUsing
 
getWhenSQL(StringBuilder, int) - Method in class org.h2.expression.condition.BetweenPredicate
 
getWhenSQL(StringBuilder, int) - Method in class org.h2.expression.condition.BooleanTest
 
getWhenSQL(StringBuilder, int) - Method in class org.h2.expression.condition.CompareLike
 
getWhenSQL(StringBuilder, int) - Method in class org.h2.expression.condition.Comparison
 
getWhenSQL(StringBuilder, int) - Method in class org.h2.expression.condition.ConditionIn
 
getWhenSQL(StringBuilder, int) - Method in class org.h2.expression.condition.ConditionInConstantSet
 
getWhenSQL(StringBuilder, int) - Method in class org.h2.expression.condition.ConditionInParameter
 
getWhenSQL(StringBuilder, int) - Method in class org.h2.expression.condition.ConditionInQuery
 
getWhenSQL(StringBuilder, int) - Method in class org.h2.expression.condition.IsJsonPredicate
 
getWhenSQL(StringBuilder, int) - Method in class org.h2.expression.condition.NullPredicate
 
getWhenSQL(StringBuilder, int) - Method in class org.h2.expression.condition.TypePredicate
 
getWhenSQL(StringBuilder, int) - Method in class org.h2.expression.Expression
Appends the SQL statement of this when operand to the specified builder.
getWhenValue(SessionLocal, Value) - Method in class org.h2.expression.condition.BetweenPredicate
 
getWhenValue(SessionLocal, Value) - Method in class org.h2.expression.condition.BooleanTest
 
getWhenValue(SessionLocal, Value) - Method in class org.h2.expression.condition.CompareLike
 
getWhenValue(SessionLocal, Value) - Method in class org.h2.expression.condition.Comparison
 
getWhenValue(SessionLocal, Value) - Method in class org.h2.expression.condition.ConditionIn
 
getWhenValue(SessionLocal, Value) - Method in class org.h2.expression.condition.ConditionInConstantSet
 
getWhenValue(SessionLocal, Value) - Method in class org.h2.expression.condition.ConditionInParameter
 
getWhenValue(SessionLocal, Value) - Method in class org.h2.expression.condition.ConditionInQuery
 
getWhenValue(SessionLocal, Value) - Method in class org.h2.expression.condition.IsJsonPredicate
 
getWhenValue(SessionLocal, Value) - Method in class org.h2.expression.condition.NullPredicate
 
getWhenValue(SessionLocal, Value) - Method in class org.h2.expression.condition.TypePredicate
 
getWhenValue(SessionLocal, Value) - Method in class org.h2.expression.Expression
Return the resulting value of when operand for the current row.
getWhitespaceChars() - Method in class org.h2.fulltext.FullTextSettings
 
getWindow(String) - Method in class org.h2.command.query.Select
Returns a window with specified name, or null.
getWindowData(SessionLocal, SelectGroups, boolean) - Method in class org.h2.expression.analysis.DataAnalysisOperation
Get the aggregate data for a window clause.
getWindowExprData(DataAnalysisOperation, Value) - Method in class org.h2.command.query.SelectGroups
Get the window data for the specified expression.
getWindowFrame() - Method in class org.h2.expression.analysis.Window
Returns window frame, or null.
getWindowResult(SessionLocal, SelectGroups) - Method in class org.h2.expression.analysis.DataAnalysisOperation
Returns result of this window function or window aggregate.
getWordId(String) - Method in class org.h2.fulltext.FullTextSettings
Get id for a searchable word
getWordIds(Connection, Object[]) - Method in class org.h2.fulltext.FullText.FullTextTrigger
 
getWriteBuffer() - Method in class org.h2.mvstore.MVStore
Get a buffer for writing.
getWriteBytes() - Method in class org.h2.mvstore.FileStore
Get the number of written bytes since this store was opened.
getWriteColumnHeader() - Method in class org.h2.tools.Csv
Whether the column header is written.
getWriteCount() - Method in class org.h2.mvstore.FileStore
Get the number of write operations since this store was opened.
getWriter(String, String) - Method in class org.h2.tools.Recover
 
getXAConnection() - Method in class org.h2.jdbcx.JdbcDataSource
Open a new XA connection using the current URL, user name and password.
getXAConnection(String, String) - Method in class org.h2.jdbcx.JdbcDataSource
Open a new XA connection using the current URL and the specified user name and password.
getXAResource() - Method in class org.h2.jdbcx.JdbcXAConnection
Get the XAResource object.
getYears() - Method in class org.h2.api.Interval
Returns years value, if any.
getZoneId(String) - Static method in class org.h2.expression.function.DateTimeFormatFunction
 
GF_128_FEEDBACK - Static variable in class org.h2.store.fs.encrypt.XTS
Galois field feedback.
global - Variable in class org.h2.expression.condition.ConditionLocalAndGlobal
 
globalTemporary - Variable in class org.h2.command.ddl.CreateLinkedTable
 
globalTemporary - Variable in class org.h2.command.ddl.CreateTableData
Whether the table is global temporary.
globalTemporary - Variable in class org.h2.table.TableBase
 
globalTemporary - Variable in class org.h2.table.TableLink
 
globalTransactionId - Variable in class org.h2.jdbcx.JdbcXid
 
GRANT - Static variable in interface org.h2.command.CommandInterface
The type of a GRANT statement.
grantedObject - Variable in class org.h2.engine.Right
The object.
grantedRight - Variable in class org.h2.engine.Right
The granted right.
grantedRights - Variable in class org.h2.engine.RightOwner
The map of granted rights.
grantedRole - Variable in class org.h2.engine.Right
The granted role, or null if a right was granted.
grantedRoles - Variable in class org.h2.engine.RightOwner
The map of granted roles.
grantee - Variable in class org.h2.command.ddl.GrantRevoke
 
grantee - Variable in class org.h2.engine.Right
To whom the right is granted.
GrantRevoke - Class in org.h2.command.ddl
This class represents the statements GRANT RIGHT, GRANT ROLE, REVOKE RIGHT, REVOKE ROLE
GrantRevoke(SessionLocal) - Constructor for class org.h2.command.ddl.GrantRevoke
 
grantRight() - Method in class org.h2.command.ddl.GrantRevoke
 
grantRight(DbObject) - Method in class org.h2.command.ddl.GrantRevoke
 
grantRight(DbObject, Right) - Method in class org.h2.engine.RightOwner
Grant a right for the given table.
grantRole(Role) - Method in class org.h2.command.ddl.GrantRevoke
 
grantRole(Role, Right) - Method in class org.h2.engine.RightOwner
Grant a role to this object.
GREATEST - Static variable in class org.h2.expression.function.CoalesceFunction
GREATEST() (non-standard).
GroovyCompiler() - Constructor for class org.h2.util.SourceCompiler.GroovyCompiler
 
group - Variable in class org.h2.command.query.Select
 
GROUP - Static variable in class org.h2.util.ParserUtil
The token "GROUP".
GROUP_BINARY_STRING - Static variable in class org.h2.value.Value
Group for binary string data types.
GROUP_BOOLEAN - Static variable in class org.h2.value.Value
Group for BINARY data type.
GROUP_BY_NOT_IN_THE_RESULT - Static variable in class org.h2.api.ErrorCode
The error with code 90157 is thrown when the integer index that is used in the GROUP BY is not in the SELECT list
GROUP_CHARACTER_STRING - Static variable in class org.h2.value.Value
Group for character string data types.
GROUP_COLLECTION - Static variable in class org.h2.value.Value
Group for collection data types (ARRAY, ROW).
GROUP_DATETIME - Static variable in class org.h2.value.Value
Group for datetime data types.
GROUP_INTERVAL_DT - Static variable in class org.h2.value.Value
Group for day-time interval data types.
GROUP_INTERVAL_YM - Static variable in class org.h2.value.Value
Group for year-month interval data types.
GROUP_NULL - Static variable in class org.h2.value.Value
Group for untyped NULL data type.
GROUP_NUMERIC - Static variable in class org.h2.value.Value
Group for numeric data types.
GROUP_OTHER - Static variable in class org.h2.value.Value
Group for other data types (JAVA_OBJECT, UUID, GEOMETRY, ENUM, JSON).
groupByColumnIndex - Variable in class org.h2.engine.Mode
Allow to use GROUP BY n, where n is column index in the SELECT list, similar to ORDER BY
groupByCopies - Variable in class org.h2.command.query.Select
 
groupByData - Variable in class org.h2.command.query.SelectGroups.Grouped
Map of group-by key to group-by expression data e.g.
groupByExpression - Variable in class org.h2.command.query.Select
Whether a column in the expression list is part of a group-by.
groupData - Variable in class org.h2.command.query.Select
Grouped data for aggregates.
Grouped(SessionLocal, ArrayList<Expression>, int[]) - Constructor for class org.h2.command.query.SelectGroups.Grouped
 
groupIndex - Variable in class org.h2.command.query.Select
The indexes of the group-by columns.
groupIndex - Variable in class org.h2.command.query.SelectGroups.Grouped
 
GROUPS - org.h2.expression.analysis.WindowFrameUnits
GROUPS unit.
GROUPS - Static variable in class org.h2.value.Value
 
grow(int) - Method in class org.h2.mvstore.WriteBuffer
 
grow(int) - Method in class org.h2.util.ByteStack
 
GUIConsole - Class in org.h2.tools
Console for environments with AWT support.
GUIConsole() - Constructor for class org.h2.tools.GUIConsole
 

H

H2_BASE_DIR - Static variable in class org.h2.engine.SysProperties
 
H2_BROWSER - Static variable in class org.h2.engine.SysProperties
INTERNAL
H2_SCRIPT_DIRECTORY - Static variable in class org.h2.engine.SysProperties
INTERNAL
H2AuthConfig - Class in org.h2.security.auth
Describe configuration of H2 DefaultAuthenticator.
H2AuthConfig() - Constructor for class org.h2.security.auth.H2AuthConfig
 
H2AuthConfigXml - Class in org.h2.security.auth
Parser of external authentication XML configuration file
H2AuthConfigXml() - Constructor for class org.h2.security.auth.H2AuthConfigXml
 
H2Type - Class in org.h2.api
Data types of H2.
H2Type(TypeInfo, String) - Constructor for class org.h2.api.H2Type
 
H2VERSION - Static variable in class org.h2.expression.function.SysInfoFunction
H2VERSION().
HALF - Static variable in class org.h2.expression.aggregate.Percentile
BigDecimal value of 0.5.
handle(Callback[]) - Method in class org.h2.security.auth.impl.JaasCredentialsValidator.AuthenticationInfoCallbackHandler
 
handleConn - Variable in class org.h2.jdbcx.JdbcXAConnection
 
handleException(Throwable) - Method in class org.h2.mvstore.MVStore
 
handleOnDuplicate(DbException, Value[]) - Method in class org.h2.command.dml.Insert
 
handler - Variable in class org.h2.mvstore.db.ValueDataType
 
handler - Variable in class org.h2.store.FileStore
The callback object is responsible to check access rights, and free up disk space if required.
handler - Variable in class org.h2.value.lob.LobDataDatabase
 
handler - Variable in class org.h2.value.lob.LobDataFetchOnDemand
 
handler - Variable in class org.h2.value.lob.LobDataFile
 
handleSyntaxError(String, int) - Static method in class org.h2.util.SourceCompiler
 
HAS_DATABASE_PRIVILEGE - Static variable in class org.h2.mode.FunctionsPostgreSQL
 
HAS_SCHEMA_PRIVILEGE - Static variable in class org.h2.mode.FunctionsPostgreSQL
 
HAS_TABLE_PRIVILEGE - Static variable in class org.h2.mode.FunctionsPostgreSQL
 
hasBounds - Variable in class org.h2.mvstore.db.MVSpatialIndex.FindBoundsCursor
 
hasChanged(Object[], Object[], int[]) - Static method in class org.h2.fulltext.FullText
Check if a the indexed columns of a row probably have changed.
hasChanges - Variable in class org.h2.mvstore.tx.TransactionMap
Indicates whether underlying map was modified from within related transaction
hasChanges() - Method in class org.h2.mvstore.tx.Transaction
Determine if any database changes were made as part of this transaction.
hasChanges(long) - Static method in class org.h2.mvstore.tx.Transaction
 
hasChangesSince(long) - Method in class org.h2.mvstore.MVMap
Does the root have changes since the specified version?
hasChangesSince(long, boolean) - Method in class org.h2.mvstore.RootReference
Does the root have changes since the specified version?
hasCharsetAndCollation - Variable in class org.h2.table.InformationSchemaTable.DataTypeInformation
 
HasConfigProperties - Interface in org.h2.security.auth
Interface for objects with configuration properties.
hasConnectionParam - Variable in class org.h2.schema.FunctionAlias.JavaMethod
 
hasConnectionParam() - Method in class org.h2.schema.FunctionAlias.JavaMethod
Check if this function requires a database connection.
hasCoordinate() - Method in class org.h2.util.geometry.EWKTUtils.EWKTSource
 
hasData() - Method in class org.h2.util.geometry.EWKTUtils.EWKTSource
 
hasData(String) - Method in class org.h2.mvstore.MVStore
Check whether a given map exists and has data.
hasDays() - Method in enum org.h2.api.IntervalQualifier
Returns whether interval with this qualifier has days.
hasDerivedColumnList() - Method in interface org.h2.table.ColumnResolver
Returns whether this column resolver has a derived column list.
hasDerivedColumnList() - Method in class org.h2.table.TableFilter
 
hasDuplicates - Variable in class org.h2.expression.condition.UniquePredicate.Target
 
hasFixedOffset() - Method in class org.h2.util.TimeZoneProvider
Returns whether this is a simple time zone provider with a fixed offset from UTC.
hasFixedOffset() - Method in class org.h2.util.TimeZoneProvider.Simple
 
hash - Variable in class org.h2.command.ddl.AlterUser
 
hash - Variable in class org.h2.command.ddl.CreateIndex
 
hash - Variable in class org.h2.command.ddl.CreateUser
 
hash - Variable in class org.h2.index.IndexType
 
hash - Variable in class org.h2.mvstore.db.LobStorageMap.BlobMeta
 
hash - Variable in class org.h2.util.IntArray
 
hash - Variable in class org.h2.value.ExtTypeInfoRow
 
hash - Variable in class org.h2.value.ValueBytesBase
The hash code.
hash - Variable in class org.h2.value.ValueCollectionBase
 
hash - Variable in class org.h2.value.ValueLob
Cache the hashCode because it can be expensive to compute.
hash - Variable in class org.h2.value.ValueVarcharIgnoreCase
The hash code.
hash(int) - Static method in class org.h2.compress.CompressLZF
Compute the address in the hash table.
HASH - Static variable in class org.h2.expression.function.HashFunction
HASH() (non-standard).
HASH_ITERATIONS - Static variable in class org.h2.store.fs.encrypt.FileEncrypt
The number of iterations.
HASH_SIZE - Static variable in class org.h2.compress.CompressLZF
The number of entries in the hash table.
hashCode - Variable in class org.h2.table.TableFilter
 
hashCode() - Method in class org.h2.api.Interval
 
hashCode() - Method in class org.h2.engine.SessionLocal
 
hashCode() - Method in class org.h2.engine.SessionLocal.SequenceAndPrepared
 
hashCode() - Method in class org.h2.expression.function.DateTimeFormatFunction.CacheKey
 
hashCode() - Method in class org.h2.mvstore.Chunk
 
hashCode() - Method in class org.h2.mvstore.db.RowDataType
 
hashCode() - Method in class org.h2.mvstore.db.SpatialKey
 
hashCode() - Method in class org.h2.mvstore.db.ValueDataType
 
hashCode() - Method in class org.h2.mvstore.MVMap
 
hashCode() - Method in class org.h2.mvstore.tx.Snapshot
 
hashCode() - Method in class org.h2.mvstore.tx.VersionedValueType
 
hashCode() - Method in class org.h2.mvstore.type.BasicDataType
 
hashCode() - Method in class org.h2.result.SearchRow
 
hashCode() - Method in class org.h2.result.SimpleResult.Column
 
hashCode() - Method in class org.h2.store.fs.mem.FileMemData.CompressItem
 
hashCode() - Method in class org.h2.store.fs.niomem.FileNioMemData.CompressItem
 
hashCode() - Method in class org.h2.table.Column
 
hashCode() - Method in class org.h2.table.TableFilter
 
hashCode() - Method in class org.h2.table.TableLinkConnection
 
hashCode() - Method in class org.h2.table.TableView.CacheKey
 
hashCode() - Method in class org.h2.util.IntArray
 
hashCode() - Method in class org.h2.util.SimpleColumnInfo
 
hashCode() - Method in class org.h2.util.TimeZoneProvider.Simple
 
hashCode() - Method in class org.h2.util.TimeZoneProvider.WithTimeZone
 
hashCode() - Method in class org.h2.value.CharsetCollator
 
hashCode() - Method in class org.h2.value.CompareMode
 
hashCode() - Method in class org.h2.value.ExtTypeInfoEnum
 
hashCode() - Method in class org.h2.value.ExtTypeInfoGeometry
 
hashCode() - Method in class org.h2.value.ExtTypeInfoRow
 
hashCode() - Method in class org.h2.value.TypeInfo
 
hashCode() - Method in class org.h2.value.Value
 
hashCode() - Method in class org.h2.value.ValueBigint
 
hashCode() - Method in class org.h2.value.ValueBoolean
 
hashCode() - Method in class org.h2.value.ValueBytesBase
 
hashCode() - Method in class org.h2.value.ValueCollectionBase
 
hashCode() - Method in class org.h2.value.ValueDate
 
hashCode() - Method in class org.h2.value.ValueDecfloat
 
hashCode() - Method in class org.h2.value.ValueDouble
 
hashCode() - Method in class org.h2.value.ValueEnumBase
 
hashCode() - Method in class org.h2.value.ValueInteger
 
hashCode() - Method in class org.h2.value.ValueInterval
 
hashCode() - Method in class org.h2.value.ValueLob
 
hashCode() - Method in class org.h2.value.ValueNull
 
hashCode() - Method in class org.h2.value.ValueNumeric
 
hashCode() - Method in class org.h2.value.ValueReal
 
hashCode() - Method in class org.h2.value.ValueSmallint
 
hashCode() - Method in class org.h2.value.ValueStringBase
 
hashCode() - Method in class org.h2.value.ValueTime
 
hashCode() - Method in class org.h2.value.ValueTimestamp
 
hashCode() - Method in class org.h2.value.ValueTimestampTimeZone
 
hashCode() - Method in class org.h2.value.ValueTimeTimeZone
 
hashCode() - Method in class org.h2.value.ValueTinyint
 
hashCode() - Method in class org.h2.value.ValueUuid
 
hashCode() - Method in class org.h2.value.ValueVarcharIgnoreCase
 
HashFunction - Class in org.h2.expression.function
A HASH or ORA_HASH function.
HashFunction(Expression, int) - Constructor for class org.h2.expression.function.HashFunction
 
HashFunction(Expression, Expression, Expression, int) - Constructor for class org.h2.expression.function.HashFunction
 
hashImpl(Value, String) - Static method in class org.h2.expression.function.HashFunction
 
hashImpl(Value, MessageDigest) - Static method in class org.h2.expression.function.HashFunction
 
hasHours() - Method in enum org.h2.api.IntervalQualifier
Returns whether interval with this qualifier has hours.
hashPassword(boolean, String, char[]) - Static method in class org.h2.engine.ConnectionInfo
 
hashWithSalt - Variable in class org.h2.security.auth.impl.StaticUserCredentialsValidator
 
hasIdentityOptions() - Method in class org.h2.table.Column
Whether the column has any identity options.
hasInComparisons() - Method in class org.h2.table.TableFilter
Are there any index conditions that involve IN(...).
hasM - Variable in class org.h2.util.geometry.GeometryUtils.DimensionSystemTarget
 
hasMap(String) - Method in class org.h2.mvstore.MVStore
Check whether a given map exists.
hasMap(String) - Method in class org.h2.mvstore.tx.TransactionStore
Check whether a given map exists.
hasMinutes() - Method in enum org.h2.api.IntervalQualifier
Returns whether interval with this qualifier has minutes.
hasMonths() - Method in enum org.h2.api.IntervalQualifier
Returns whether interval with this qualifier has months.
hasMoreCoordinates() - Method in class org.h2.util.geometry.EWKTUtils.EWKTSource
 
hasMultipleFields() - Method in enum org.h2.api.IntervalQualifier
Returns whether interval with this qualifier has multiple fields.
hasNext - Variable in class org.h2.util.Permutations
 
hasNext() - Method in class org.h2.expression.analysis.WindowFrame.PlainItr
 
hasNext() - Method in class org.h2.expression.analysis.WindowFrame.PlainReverseItr
 
hasNext() - Method in class org.h2.mvstore.Cursor
 
hasNext() - Method in class org.h2.mvstore.db.MVSecondaryIndex.Source
 
hasNext() - Method in class org.h2.mvstore.db.MVSpatialIndex.SpatialKeyIterator
 
hasNext() - Method in class org.h2.mvstore.rtree.MVRTreeMap.RTreeCursor
 
hasNext() - Method in class org.h2.mvstore.tx.TransactionMap.TMIterator
 
hasNext() - Method in class org.h2.result.LazyResult
 
hasNext() - Method in class org.h2.result.LocalResult
 
hasNext() - Method in interface org.h2.result.ResultInterface
Check if this result has more rows to fetch.
hasNext() - Method in class org.h2.result.ResultRemote
 
hasNext() - Method in class org.h2.result.ResultWithPaddedStrings
 
hasNext() - Method in class org.h2.result.SimpleResult
 
hasNull - Variable in class org.h2.expression.condition.ConditionInConstantSet
 
hasOrder() - Method in class org.h2.command.query.Query
Whether the query has an order.
hasPendingTransaction() - Method in class org.h2.engine.Session
Check whether this session has a pending transaction.
hasPendingTransaction() - Method in class org.h2.engine.SessionLocal
 
hasPendingTransaction() - Method in class org.h2.engine.SessionRemote
 
hasPreparedTransaction() - Method in class org.h2.engine.SessionLocal
Checks presence of prepared transaction in this session.
hasRollback(long) - Static method in class org.h2.mvstore.tx.Transaction
 
hasSameValues(Row) - Method in class org.h2.result.Row
Check whether values of this row are equal to values of other row.
hasSchemaRight(Schema) - Method in class org.h2.engine.User
See if this user has owner rights for the specified schema
hasSeconds() - Method in enum org.h2.api.IntervalQualifier
Returns whether interval with this qualifier has seconds.
hasSelectTrigger() - Method in class org.h2.table.Table
Check whether this table has a select trigger.
hasSharedData(Row) - Method in class org.h2.result.DefaultRow
 
hasSharedData(Row) - Method in class org.h2.result.Row
Check whether this row and the specified row share the same underlying data with values.
HasSQL - Interface in org.h2.util
An object that has an SQL representation.
hasStatementDependencies() - Method in class org.h2.mvstore.tx.Transaction
Returns whether statement dependencies are currently set.
hasTableRight(Table, int) - Method in class org.h2.engine.User
See if this user has the given rights for this database object.
hasToParseData() - Method in class org.h2.mode.ToDateParser
 
hasTotalOrdering(int) - Static method in class org.h2.value.DataType
Check if the given type has total ordering.
hasTransaction() - Method in class org.h2.engine.SessionLocal
 
hasUnsavedChanges() - Method in class org.h2.mvstore.MVStore
Check whether there are any unsaved changes.
hasYears() - Method in enum org.h2.api.IntervalQualifier
Returns whether interval with this qualifier has years.
hasZ - Variable in class org.h2.util.geometry.GeometryUtils.DimensionSystemTarget
 
haveSameOrdering(TypeInfo, TypeInfo) - Static method in class org.h2.value.TypeInfo
Determines whether two specified types have the same ordering rules.
having - Variable in class org.h2.command.query.Select
HAVING condition.
HAVING - Static variable in class org.h2.util.ParserUtil
The token "HAVING".
havingIndex - Variable in class org.h2.command.query.Select
 
HDR_BLOCK - Static variable in class org.h2.mvstore.MVStore
 
HDR_BLOCK_SIZE - Static variable in class org.h2.mvstore.MVStore
 
HDR_CHUNK - Static variable in class org.h2.mvstore.MVStore
 
HDR_CLEAN - Static variable in class org.h2.mvstore.MVStore
 
HDR_CREATED - Static variable in class org.h2.mvstore.MVStore
 
HDR_FLETCHER - Static variable in class org.h2.mvstore.MVStore
 
HDR_FORMAT - Static variable in class org.h2.mvstore.MVStore
 
HDR_FORMAT_READ - Static variable in class org.h2.mvstore.MVStore
 
HDR_H - Static variable in class org.h2.mvstore.MVStore
 
HDR_VERSION - Static variable in class org.h2.mvstore.MVStore
 
head - Variable in class org.h2.util.CacheLRU
 
HEADER - Static variable in class org.h2.store.FileStore
The magic file header.
HEADER - Static variable in class org.h2.store.fs.encrypt.FileEncrypt
 
HEADER_LENGTH - Static variable in class org.h2.store.FileStore
The size of the file header in bytes.
HEADER_LENGTH - Static variable in class org.h2.store.fs.encrypt.FileEncrypt
The length of the file header.
headerLanguage - Variable in class org.h2.server.web.WebApp
The language in the HTTP header.
Help - Class in org.h2.command.dml
This class represents the statement CALL.
Help(SessionLocal, String[]) - Constructor for class org.h2.command.dml.Help
 
HELP - Static variable in interface org.h2.command.CommandInterface
The type of a HELP statement.
HELP - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
HEX - Static variable in class org.h2.util.json.JSONStringTarget
The hex characters.
HEX - Static variable in class org.h2.util.StringUtils
 
HEX_DECODE - Static variable in class org.h2.util.StringUtils
 
HEX_START - Static variable in class org.h2.bnf.RuleFixed
 
HEX_STRING_ODD_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90003 is thrown when trying to convert a String to a binary value.
HEX_STRING_WRONG_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90004 is thrown when trying to convert a text to binary, but the expression contains a non-hexadecimal character.
hexToRaw(String, SessionLocal) - Static method in class org.h2.expression.function.StringFunction1
 
HEXTORAW - Static variable in class org.h2.expression.function.StringFunction1
HEXTORAW() (non-standard).
HH - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
HH12 - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
HH24 - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
hidden - Variable in class org.h2.command.ddl.AlterTableRename
 
HIDE_SQL - Static variable in exception org.h2.message.DbException
If the SQL statement contains this text, then it is never added to the SQL exception.
hideTable(Table, SessionLocal) - Method in class org.h2.table.MetaTable
Check whether to hide the table.
high - Variable in class org.h2.value.ValueUuid
 
HIGH - org.h2.mode.DefaultNullOrdering
NULL values are considered as larger than other values during sorting.
higherEntry(K) - Method in class org.h2.mvstore.tx.TransactionMap
Get the entry with smallest key that is larger than the given key, or null if no such key exists.
higherKey(K) - Method in class org.h2.mvstore.MVMap
Get the smallest key that is larger than the given key (next key in ascending order), or null if no such key exists.
higherKey(K) - Method in class org.h2.mvstore.tx.TransactionMap
Get the smallest key that is larger than the given key, or null if no such key exists.
higherKey(RootReference<K, V>, K) - Method in class org.h2.mvstore.MVMap
Get the smallest key that is larger than the given key, for the given root page, or null if no such key exists.
higherLowerEntry(K, boolean) - Method in class org.h2.mvstore.tx.TransactionMap
 
higherLowerKey(K, boolean) - Method in class org.h2.mvstore.tx.TransactionMap
 
HISTOGRAM - org.h2.expression.aggregate.AggregateType
The aggregate type for HISTOGRAM(expression).
history - Variable in class org.h2.tools.Shell
 
HISTORY_COUNT - Static variable in class org.h2.tools.Shell
 
hits - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
The number of cache hits.
hmac - Variable in class org.h2.store.LobStorageRemoteInputStream
 
hmac - Variable in class org.h2.value.lob.LobDataFetchOnDemand
If this is a client-side ValueLobDb object returned by a ResultSet, the hmac acts a security cookie that the client can send back to the server to ask for data related to this LOB.
HMS - Static variable in class org.h2.bnf.RuleFixed
 
holdability - Variable in class org.h2.jdbc.JdbcConnection
 
holdCount - Variable in class org.h2.mvstore.RootReference
Counter of reentrant locks.
Holder() - Constructor for class org.h2.mvstore.type.ObjectDataType.Holder
 
Holder() - Constructor for class org.h2.result.RowFactory.Holder
 
host - Variable in class org.h2.security.auth.impl.LdapCredentialsValidator
 
host - Variable in class org.h2.server.web.WebServer
 
host - Variable in class org.h2.server.web.WebThread
 
hour - Variable in class org.h2.mode.ToDateParser
 
HOUR - org.h2.api.IntervalQualifier
HOUR
HOUR - Static variable in class org.h2.expression.function.DateTimeFunction
Hour.
HOUR - Static variable in class org.h2.util.ParserUtil
The token "HOUR".
HOUR_TO_MINUTE - org.h2.api.IntervalQualifier
HOUR TO MINUTE
HOUR_TO_SECOND - org.h2.api.IntervalQualifier
HOUR TO SECOND
hour12 - Variable in class org.h2.mode.ToDateParser
 
hour12Valid - Variable in class org.h2.mode.ToDateParser
 
HOURS_PER_DAY_BI - Static variable in class org.h2.util.IntervalUtils
 
hoursFromInterval(IntervalQualifier, boolean, long, long) - Static method in class org.h2.util.IntervalUtils
Returns hours value of interval, if any.
HSQLDB - org.h2.engine.Mode.ModeEnum
 

I

ICU4J - Static variable in class org.h2.value.CompareMode
This constant means ICU4J should be used (this will fail if it is not in the classpath).
id - Variable in class org.h2.command.CommandRemote
 
id - Variable in class org.h2.command.ddl.CreateSynonymData
The object id.
id - Variable in class org.h2.command.ddl.CreateTableData
The object id.
id - Variable in class org.h2.engine.DbObject
 
id - Variable in class org.h2.engine.MetaRecord
 
id - Variable in class org.h2.engine.SessionLocal
 
id - Variable in class org.h2.fulltext.IndexInfo
The index id.
id - Variable in class org.h2.message.TraceObject
 
id - Variable in class org.h2.mvstore.Chunk
The chunk id.
id - Variable in class org.h2.mvstore.db.SpatialKey
 
id - Variable in class org.h2.mvstore.MVMap
 
id - Variable in class org.h2.mvstore.rtree.DefaultSpatial
 
id - Variable in class org.h2.result.ResultRemote
 
id - Variable in class org.h2.schema.FunctionAlias.JavaMethod
 
id - Variable in class org.h2.store.fs.mem.FileMemData
 
id - Variable in class org.h2.util.TimeZoneProvider.Simple
 
ID - Static variable in class org.h2.message.TraceObject
 
idBuffer - Variable in class org.h2.mvstore.StreamStore.Stream
 
IDENTICAL_EXPRESSIONS_SHOULD_BE_USED - Static variable in class org.h2.api.ErrorCode
The error with code 42131 is thrown when identical expressions should be used, but different expressions were found.
identifier - Variable in class org.h2.command.Token.IdentifierToken
 
identifier - Variable in class org.h2.command.Token.KeywordOrIdentifierToken
 
identifier(String) - Method in class org.h2.table.MetaTable
If needed, convert the identifier to lower case.
IDENTIFIER - Static variable in class org.h2.util.ParserUtil
An identifier (table name, column name,...).
identifiersToLower - Variable in class org.h2.command.Parser
 
identifiersToLower - Variable in class org.h2.command.Tokenizer
 
identifiersToUpper - Variable in class org.h2.command.Parser
 
identifiersToUpper - Variable in class org.h2.command.Tokenizer
 
IdentifierToken(int, String, boolean, boolean) - Constructor for class org.h2.command.Token.IdentifierToken
 
identity - Variable in class org.h2.result.ResultColumn
True if this is an identity column.
IDENTITY - Static variable in class org.h2.mode.FunctionsLegacy
 
IDENTITY_VAL_LOCAL - Static variable in class org.h2.mode.FunctionsDB2Derby
 
IDENTITY_VAL_LOCAL_TYPE - Static variable in class org.h2.mode.FunctionsDB2Derby
 
identityClause - Variable in class org.h2.engine.Mode
Whether SQL Server-style IDENTITY clause is supported.
identityColumnsHaveDefaultOnNull - Variable in class org.h2.engine.Mode
If true, identity columns have DEFAULT ON NULL clause.
identityDataType - Variable in class org.h2.engine.Mode
Whether IDENTITY pseudo data type is supported.
identityOptions - Variable in class org.h2.table.Column
 
idsToRelease - Variable in class org.h2.engine.SessionLocal
Set of database object ids to be released at the end of transaction
IF - Static variable in class org.h2.util.ParserUtil
The token "IF".
IF_ABSENT - Static variable in class org.h2.mvstore.MVMap.DecisionMaker
Decision maker for putIfAbsent() key/value.
IF_PRESENT - Static variable in class org.h2.mvstore.MVMap.DecisionMaker
Decision maker for replace().
ifAbsentDecisionMaker - Variable in class org.h2.mvstore.tx.TransactionMap
 
ifConstraintExists - Variable in class org.h2.command.ddl.AlterDomainDropConstraint
 
ifDomainExists - Variable in class org.h2.command.ddl.AlterDomain
 
ifExists - Variable in class org.h2.command.ddl.AlterIndexRename
 
ifExists - Variable in class org.h2.command.ddl.AlterSequence
 
ifExists - Variable in class org.h2.command.ddl.AlterTableDropConstraint
 
ifExists - Variable in class org.h2.command.ddl.AlterTableRenameColumn
 
ifExists - Variable in class org.h2.command.ddl.AlterView
 
ifExists - Variable in class org.h2.command.ddl.DropAggregate
 
ifExists - Variable in class org.h2.command.ddl.DropConstant
 
ifExists - Variable in class org.h2.command.ddl.DropFunctionAlias
 
ifExists - Variable in class org.h2.command.ddl.DropIndex
 
ifExists - Variable in class org.h2.command.ddl.DropRole
 
ifExists - Variable in class org.h2.command.ddl.DropSchema
 
ifExists - Variable in class org.h2.command.ddl.DropSequence
 
ifExists - Variable in class org.h2.command.ddl.DropSynonym
 
ifExists - Variable in class org.h2.command.ddl.DropTable
 
ifExists - Variable in class org.h2.command.ddl.DropTrigger
 
ifExists - Variable in class org.h2.command.ddl.DropUser
 
ifExists - Variable in class org.h2.command.ddl.DropView
 
ifExists - Variable in class org.h2.server.pg.PgServer
 
ifExists - Variable in class org.h2.server.TcpServer
 
ifExists - Variable in class org.h2.server.web.WebServer
 
ifModifiedSince - Variable in class org.h2.server.web.WebThread
 
ifNotExists - Variable in class org.h2.command.ddl.AlterDomainAddConstraint
 
ifNotExists - Variable in class org.h2.command.ddl.AlterTableAddConstraint
 
ifNotExists - Variable in class org.h2.command.ddl.AlterTableAlterColumn
 
ifNotExists - Variable in class org.h2.command.ddl.CreateAggregate
 
ifNotExists - Variable in class org.h2.command.ddl.CreateConstant
 
ifNotExists - Variable in class org.h2.command.ddl.CreateDomain
 
ifNotExists - Variable in class org.h2.command.ddl.CreateFunctionAlias
 
ifNotExists - Variable in class org.h2.command.ddl.CreateIndex
 
ifNotExists - Variable in class org.h2.command.ddl.CreateLinkedTable
 
ifNotExists - Variable in class org.h2.command.ddl.CreateRole
 
ifNotExists - Variable in class org.h2.command.ddl.CreateSchema
 
ifNotExists - Variable in class org.h2.command.ddl.CreateSequence
 
ifNotExists - Variable in class org.h2.command.ddl.CreateSynonym
 
ifNotExists - Variable in class org.h2.command.ddl.CreateTable
 
ifNotExists - Variable in class org.h2.command.ddl.CreateTrigger
 
ifNotExists - Variable in class org.h2.command.ddl.CreateUser
 
ifNotExists - Variable in class org.h2.command.ddl.CreateView
 
ifTableExists - Variable in class org.h2.command.ddl.AlterTable
 
ifTableExists - Variable in class org.h2.command.ddl.AlterTableAlterColumn
 
ifTableExists - Variable in class org.h2.command.ddl.CreateIndex
 
ifTableExists - Variable in class org.h2.command.dml.AlterTableSet
 
ignore - Variable in class org.h2.command.dml.Insert
For MySQL-style INSERT IGNORE and PostgreSQL-style ON CONFLICT DO NOTHING.
IGNORE_CATALOGS - Static variable in class org.h2.command.dml.SetTypes
The type of a SET IGNORE_CATALOGS statement.
ignoreCase - Variable in class org.h2.engine.Database
 
ignoreCase - Variable in class org.h2.expression.condition.CompareLike
 
IGNORECASE - Static variable in class org.h2.command.dml.SetTypes
The type of a SET IGNORECASE statement.
ignoreCatalogs - Variable in class org.h2.engine.Database
 
ignoreCatalogs - Variable in class org.h2.engine.DbSettings
Database setting IGNORE_CATALOGS (default: false).
IGNORED - org.h2.expression.aggregate.AggregateDataCollecting.NullCollectionMode
Rows with NULL value are completely ignored.
IGNORED_BY_PARSER - Static variable in class org.h2.engine.ConnectionInfo
 
ignoreLines - Variable in class org.h2.util.Profiler
 
ignoreList - Variable in class org.h2.fulltext.FullTextSettings
The set of words not to index (stop words).
ignoreNulls - Variable in class org.h2.expression.aggregate.AggregateDataDistinctWithCounts
 
ignoreNulls - Variable in class org.h2.expression.analysis.WindowFunction
 
ignorePackages - Variable in class org.h2.util.Profiler
 
ignoreThreads - Variable in class org.h2.util.Profiler
 
ILIKE - org.h2.expression.condition.CompareLike.LikeType
ILIKE (case-insensitive LIKE).
implCloseChannel() - Method in class org.h2.mvstore.cache.FilePathCache.FileCache
 
implCloseChannel() - Method in class org.h2.store.fs.async.FileAsync
 
implCloseChannel() - Method in class org.h2.store.fs.encrypt.FileEncrypt
 
implCloseChannel() - Method in class org.h2.store.fs.FakeFileChannel
 
implCloseChannel() - Method in class org.h2.store.fs.FileBase
 
implCloseChannel() - Method in class org.h2.store.fs.mem.FileMem
 
implCloseChannel() - Method in class org.h2.store.fs.niomapped.FileNioMapped
 
implCloseChannel() - Method in class org.h2.store.fs.niomem.FileNioMem
 
implCloseChannel() - Method in class org.h2.store.fs.rec.FileRec
 
implCloseChannel() - Method in class org.h2.store.fs.retry.FileRetryOnInterrupt
 
implCloseChannel() - Method in class org.h2.store.fs.split.FileSplit
 
implCloseChannel() - Method in class org.h2.store.fs.zip.FileZip
 
implTruncate(long) - Method in class org.h2.store.fs.async.FileAsync
 
implTruncate(long) - Method in class org.h2.store.fs.encrypt.FileEncrypt
 
implTruncate(long) - Method in class org.h2.store.fs.FileBaseDefault
The truncate implementation.
implTruncate(long) - Method in class org.h2.store.fs.mem.FileMem
 
implTruncate(long) - Method in class org.h2.store.fs.niomapped.FileNioMapped
 
implTruncate(long) - Method in class org.h2.store.fs.niomem.FileNioMem
 
implTruncate(long) - Method in class org.h2.store.fs.split.FileSplit
 
IMPORTED_KEY_CASCADE - Static variable in class org.h2.jdbc.meta.DatabaseMetaLocal
 
IMPORTED_KEY_DEFAULT - Static variable in class org.h2.jdbc.meta.DatabaseMetaLocal
 
IMPORTED_KEY_NOT_DEFERRABLE - Static variable in class org.h2.jdbc.meta.DatabaseMetaLocal
 
IMPORTED_KEY_RESTRICT - Static variable in class org.h2.jdbc.meta.DatabaseMetaLocal
 
IMPORTED_KEY_SET_NULL - Static variable in class org.h2.jdbc.meta.DatabaseMetaLocal
 
in - Variable in class org.h2.compress.LZFInputStream
 
in - Variable in class org.h2.store.DataReader
 
in - Variable in class org.h2.store.fs.zip.FileZip
 
in - Variable in class org.h2.tools.Shell
 
in - Variable in class org.h2.util.Permutations
 
in - Variable in class org.h2.value.Transfer
 
IN - Static variable in class org.h2.util.ParserUtil
The token "IN".
IN_DOUBT - Static variable in interface org.h2.store.InDoubtTransaction
The transaction state meaning this transaction is not committed yet, but also not rolled back (in-doubt).
IN_DOUBT - Static variable in class org.h2.table.InformationSchemaTable
 
IN_DOUBT - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
IN_LIST - Static variable in class org.h2.expression.condition.Comparison
This is a pseudo comparison type that is only used for index conditions.
IN_MEMORY - Static variable in class org.h2.mvstore.Page
Marker value for memory field, meaning that memory accounting is replaced by key count.
IN_MEMORY_PREFIX - Static variable in class org.h2.fulltext.FullTextLucene
The prefix for a in-memory path.
IN_QUERY - Static variable in class org.h2.expression.condition.Comparison
This is a pseudo comparison type that is only used for index conditions.
IN_RESULT_SETS - org.h2.engine.Mode.CharPadding
Spaces are trimmed from the right side of CHAR values, but CHAR values in result sets are right-padded with spaces to the declared length
inBuffer - Variable in class org.h2.compress.LZFInputStream
 
includes(JSONItemType) - Method in enum org.h2.util.json.JSONItemType
Checks whether this item type includes the specified item type.
includeUncommitted - Variable in class org.h2.mvstore.db.MVSpatialIndex.SpatialKeyIterator
 
inColumn - Variable in class org.h2.index.IndexCursor
 
IncompleteNonLeaf(MVMap<K, V>, Page.NonLeaf<K, V>) - Constructor for class org.h2.mvstore.Page.IncompleteNonLeaf
 
increaseBounds(Object, Object) - Method in class org.h2.mvstore.rtree.SpatialDataType
Increase the bounds in the given spatial object.
increaseMaxInnerBounds(Object, Object) - Method in class org.h2.mvstore.rtree.SpatialDataType
 
increment - Variable in class org.h2.command.ddl.SequenceOptions
 
increment - Variable in class org.h2.schema.Sequence
 
increment(long, long) - Method in class org.h2.schema.Sequence
 
increment(HashMap<String, Integer>, String, int) - Static method in class org.h2.util.Profiler
 
incrementAndGet() - Method in class org.h2.mvstore.MVStore.TxCounter
Increment and get the counter value.
incrementDateValue(long) - Static method in class org.h2.util.DateTimeUtils
Return the next date value.
incrementQueryLevel(int) - Method in class org.h2.expression.ExpressionVisitor
Increment or decrement the query level.
indent(StringBuilder, String, int, boolean) - Static method in class org.h2.util.StringUtils
Indents a string with spaces and appends it to a specified builder.
INDENT - Static variable in class org.h2.util.ThreadDeadlockDetector
 
INDEPENDENT - Static variable in class org.h2.expression.ExpressionVisitor
Is the value independent on unset parameters or on columns of a higher level query, or sequence values (that means can it be evaluated right now)?
INDEPENDENT_VISITOR - Static variable in class org.h2.expression.ExpressionVisitor
The visitor singleton for the type INDEPENDENT.
INDEPENDENT_VISITORS - Static variable in class org.h2.expression.ExpressionVisitor
INDEPENDENT listeners with query level 0, 1, ...
index - Variable in class org.h2.bnf.Bnf
 
index - Variable in class org.h2.command.ddl.AlterTableAddConstraint
 
index - Variable in class org.h2.command.Token.ParameterToken
 
index - Variable in class org.h2.constraint.ConstraintReferential
 
index - Variable in class org.h2.constraint.ConstraintUnique
 
index - Variable in class org.h2.expression.Parameter
 
index - Variable in class org.h2.expression.ParameterRemote
 
index - Variable in class org.h2.fulltext.FullText.FullTextTrigger
 
index - Variable in class org.h2.index.IndexCursor
 
index - Variable in class org.h2.index.MetaCursor
 
index - Variable in class org.h2.index.ViewCursor
 
index - Variable in class org.h2.index.VirtualTableCursor
 
index - Variable in class org.h2.mvstore.CursorPos
Index of the key (within page above) used to go down to a lower level in case of intermediate nodes, or index of the target key for leaf a node.
index - Variable in class org.h2.mvstore.db.MVSortedTempResult
Optional index.
index - Variable in class org.h2.result.SimpleRowValue
 
index - Variable in class org.h2.table.PlanItem
 
index - Variable in class org.h2.table.RangeTable
 
index - Variable in class org.h2.table.TableFilter
 
index - Variable in class org.h2.table.TableView
 
index - Variable in class org.h2.util.json.JSONBytesSource
 
index - Variable in class org.h2.util.json.JSONStringSource
 
index - Variable in class org.h2.util.Permutations
 
index() - Method in class org.h2.command.Token.ParameterToken
 
index() - Method in class org.h2.server.web.WebApp
 
Index - Class in org.h2.index
An index.
Index(Table, int, String, IndexColumn[], int, IndexType) - Constructor for class org.h2.index.Index
Initialize the index.
INDEX - Static variable in class org.h2.engine.DbObject
This object is an index.
INDEX - Static variable in class org.h2.message.Trace
The trace module id for indexes.
INDEX_ACCESS - Static variable in class org.h2.fulltext.FullTextLucene
 
INDEX_ALREADY_EXISTS_1 - Static variable in class org.h2.api.ErrorCode
The error with code 42111 is thrown when trying to create an index if an index with the same name already exists.
INDEX_BELONGS_TO_CONSTRAINT_2 - Static variable in class org.h2.api.ErrorCode
The error with code 90085 is thrown when trying to manually drop an index that was generated by the system because of a unique or referential constraint.
INDEX_COLUMNS - Static variable in class org.h2.table.InformationSchemaTable
 
INDEX_NOT_FOUND_1 - Static variable in class org.h2.api.ErrorCode
The error with code 42112 is thrown when trying to drop or reference an index that does not exist.
indexAccess - Variable in class org.h2.fulltext.FullTextLucene.FullTextTrigger
 
IndexAccess(IndexWriter) - Constructor for class org.h2.fulltext.FullTextLucene.IndexAccess
 
indexColumn - Variable in class org.h2.table.MetaTable
The indexed column.
IndexColumn - Class in org.h2.table
This represents a column item of an index.
IndexColumn(String) - Constructor for class org.h2.table.IndexColumn
Creates a new instance with the specified name.
IndexColumn(String, int) - Constructor for class org.h2.table.IndexColumn
Creates a new instance with the specified name.
IndexColumn(Column) - Constructor for class org.h2.table.IndexColumn
Creates a new instance with the specified column.
indexColumns - Variable in class org.h2.command.ddl.AlterTableAddConstraint
 
indexColumns - Variable in class org.h2.command.ddl.CreateIndex
 
indexColumns - Variable in class org.h2.fulltext.FullTextLucene.FullTextTrigger
 
indexColumns - Variable in class org.h2.fulltext.IndexInfo
The column indexes of the index columns.
indexColumns - Variable in class org.h2.index.Index
Columns of this index.
indexColumns - Variable in class org.h2.index.IndexCursor
 
indexColumns(SessionLocal, ArrayList<Row>, String, Table, String, Index) - Method in class org.h2.table.InformationSchemaTable
 
IndexCondition - Class in org.h2.index
A index condition object is made for each condition that can potentially use an index.
IndexCondition(int, ExpressionColumn, Expression) - Constructor for class org.h2.index.IndexCondition
 
indexConditions - Variable in class org.h2.table.TableFilter
The index conditions used for direct index lookup (start or end).
IndexCursor - Class in org.h2.index
The filter used to walk through an index.
IndexCursor() - Constructor for class org.h2.index.IndexCursor
 
indexDefinitionInCreateTable - Variable in class org.h2.engine.Mode
Creating indexes in the CREATE TABLE statement is allowed using INDEX(..) or KEY(..).
indexes - Variable in class org.h2.command.CommandContainer.GeneratedKeysCollector
 
indexes - Variable in class org.h2.fulltext.FullTextSettings
The set of indexes in this database.
indexes - Variable in class org.h2.mvstore.db.MVSortedTempResult
Mapping of indexes of columns to its positions in the store, or null if columns are not reordered.
indexes - Variable in class org.h2.mvstore.db.MVTable
 
indexes - Variable in class org.h2.mvstore.db.RowDataType
 
indexes - Variable in class org.h2.result.RowFactory.DefaultRowFactory
 
indexes - Variable in class org.h2.schema.Schema
 
indexes - Variable in class org.h2.table.TableLink
 
indexes(SessionLocal, ArrayList<Row>, String, boolean, Table, String) - Method in class org.h2.table.InformationSchemaTable
 
indexes(SessionLocal, ArrayList<Row>, String, Table, String, Index) - Method in class org.h2.table.InformationSchemaTable
 
indexes(SessionLocal, Value, Value, ArrayList<Row>, String, boolean) - Method in class org.h2.table.InformationSchemaTable
 
INDEXES - Static variable in class org.h2.table.InformationSchemaTable
 
INDEXES - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
indexExistingRows(Connection, String, String) - Static method in class org.h2.fulltext.FullText
Add the existing data to the index.
indexExistingRows(Connection, String, String) - Static method in class org.h2.fulltext.FullTextLucene
Add the existing data to the index.
indexHints - Variable in class org.h2.table.TableFilter
 
IndexHints - Class in org.h2.table
Contains the hints for which index to use for a specific table.
IndexHints(LinkedHashSet<String>) - Constructor for class org.h2.table.IndexHints
 
IndexInfo - Class in org.h2.fulltext
The settings of one full text search index.
IndexInfo() - Constructor for class org.h2.fulltext.IndexInfo
 
IndexInfo() - Constructor for class org.h2.server.web.WebApp.IndexInfo
 
indexMasks - Variable in class org.h2.index.ViewIndex
 
indexName - Variable in class org.h2.command.ddl.CreateIndex
 
indexName - Variable in class org.h2.command.ddl.DropIndex
 
indexOf(byte[], byte[], int) - Static method in class org.h2.util.Utils
Calculate the index of the first occurrence of the pattern in the byte array, starting with the given index.
indexOwner - Variable in class org.h2.constraint.ConstraintReferential
 
indexOwner - Variable in class org.h2.constraint.ConstraintUnique
 
indexPath - Variable in class org.h2.fulltext.FullTextLucene.FullTextTrigger
 
indexType - Variable in class org.h2.index.Index
The index type.
IndexType - Class in org.h2.index
Represents information about the properties of an index
IndexType() - Constructor for class org.h2.index.IndexType
 
inDoubt(SessionLocal, ArrayList<Row>) - Method in class org.h2.table.InformationSchemaTable
 
InDoubtTransaction - Interface in org.h2.store
Represents an in-doubt transaction (a transaction in the prepare phase).
info - Variable in class org.h2.mode.ModeFunction
The information about this function.
info(String) - Method in class org.h2.message.Trace
Write a message with trace level INFO to the trace system.
info(String) - Static method in class org.h2.mvstore.MVStoreTool
Read the summary information of the file and write them to system out.
info(String, Writer) - Static method in class org.h2.mvstore.MVStoreTool
Read the summary information of the file and write them to system out.
info(String, Object...) - Method in class org.h2.message.Trace
Write a message with trace level INFO to the trace system.
info(Throwable, String) - Method in class org.h2.message.Trace
Write a message with trace level INFO to the trace system.
INFO - Static variable in class org.h2.message.TraceSystem
This trace level means errors and informational messages should be written.
infoCode(String) - Method in class org.h2.message.Trace
Write Java source code with trace level INFO to the trace system.
INFORMATION_SCHEMA_CATALOG_NAME - Static variable in class org.h2.table.InformationSchemaTable
 
INFORMATION_SCHEMA_ID - Static variable in class org.h2.engine.Constants
The identity of INFORMATION_SCHEMA.
InformationSchema - Class in org.h2.schema
Information schema.
InformationSchema(Database, User) - Constructor for class org.h2.schema.InformationSchema
Creates new instance of information schema.
informationSchemaCatalogName(SessionLocal, ArrayList<Row>, String) - Method in class org.h2.table.InformationSchemaTable
 
InformationSchemaTable - Class in org.h2.table
This class is responsible to build the INFORMATION_SCHEMA tables.
InformationSchemaTable(Schema, int, int) - Constructor for class org.h2.table.InformationSchemaTable
Create a new metadata table.
InformationSchemaTable.DataTypeInformation - Class in org.h2.table
Data type information.
InformationSchemaTableLegacy - Class in org.h2.table
This class is responsible to build the legacy variant of INFORMATION_SCHEMA tables.
InformationSchemaTableLegacy(Schema, int, int) - Constructor for class org.h2.table.InformationSchemaTableLegacy
Create a new metadata table.
infoSchema - Variable in class org.h2.engine.Database
 
infoSQL(String, String, long, long) - Method in class org.h2.message.Trace
Write a SQL statement with trace level INFO to the trace system.
init - Variable in class org.h2.mvstore.tx.TransactionStore
 
init() - Method in class org.h2.command.query.Query
Initialize the query.
init() - Method in class org.h2.command.query.Select
 
init() - Method in class org.h2.command.query.SelectUnion
 
init() - Method in class org.h2.command.query.TableValueConstructor
 
init() - Method in class org.h2.mvstore.tx.TransactionStore
Initialize the store without any RollbackListener.
init() - Method in class org.h2.server.web.JakartaWebServlet
 
init() - Method in class org.h2.server.web.WebServlet
 
init() - Method in class org.h2.store.FileStore
Initialize the file.
init() - Method in class org.h2.store.fs.encrypt.FileEncrypt
 
init() - Static method in class org.h2.util.ThreadDeadlockDetector
Initialize the detector.
init() - Method in class org.h2.value.Transfer
Initialize the transfer object.
init(boolean) - Method in class org.h2.schema.FunctionAlias
 
init(int) - Method in class org.h2.util.geometry.EWKBUtils.EWKBTarget
 
init(int) - Method in class org.h2.util.geometry.EWKTUtils.EWKTTarget
 
init(int) - Method in class org.h2.util.geometry.GeometryUtils.Target
Initializes top-level target.
init(int) - Method in class org.h2.util.geometry.JTSUtils.GeometryTarget
 
init(String) - Method in interface org.h2.api.DatabaseEventListener
This method is called just after creating the object.
init(String) - Static method in class org.h2.store.RecoverTester
Initialize the recover test.
init(String...) - Method in class org.h2.server.pg.PgServer
 
init(String...) - Method in interface org.h2.server.Service
Initialize the service from command line options.
init(String...) - Method in class org.h2.server.TcpServer
 
init(String...) - Method in class org.h2.server.web.WebServer
 
init(String, String) - Method in class org.h2.tools.Csv
 
init(String, ArrayList<Parameter>, Column[], SessionLocal, boolean, boolean, boolean) - Method in class org.h2.table.TableView
 
init(Connection) - Method in interface org.h2.api.Aggregate
This method is called when the aggregate function is used.
init(Connection) - Method in interface org.h2.api.AggregateFunction
This method is called when the aggregate function is used.
init(Connection) - Static method in class org.h2.fulltext.FullText
Initializes full text search functionality for this database.
init(Connection) - Static method in class org.h2.fulltext.FullTextLucene
Initializes full text search functionality for this database.
init(Connection) - Method in class org.h2.schema.UserAggregate.AggregateWrapper
 
init(Connection, String, String, String, boolean, int) - Method in interface org.h2.api.Trigger
This method is called by the database engine once when initializing the trigger.
init(Connection, String, String, String, boolean, int) - Method in class org.h2.fulltext.FullText.FullTextTrigger
INTERNAL
init(Connection, String, String, String, boolean, int) - Method in class org.h2.fulltext.FullTextLucene.FullTextTrigger
INTERNAL
init(Connection, String, String, String, boolean, int) - Method in class org.h2.tools.TriggerAdapter
This method is called by the database engine once when initializing the trigger.
init(Database) - Method in interface org.h2.security.auth.Authenticator
Initialize the authenticator.
init(Database) - Method in class org.h2.security.auth.DefaultAuthenticator
Initializes the authenticator.
init(TransactionStore.RollbackListener) - Method in class org.h2.mvstore.tx.TransactionStore
Initialize the store.
INIT - org.h2.engine.SessionLocal.State
 
INIT_BIT - Static variable in class org.h2.util.MemoryEstimator
 
INIT_BIT_SHIFT - Static variable in class org.h2.util.MemoryEstimator
 
INIT_FAIL_EXCEPTION - Static variable in class org.h2.util.SourceCompiler.GroovyCompiler
 
initCause(T, Object...) - Static method in class org.h2.mvstore.DataUtils
 
initColumnsAndTables(SessionLocal, boolean) - Method in class org.h2.table.TableView
 
initCoordinates(int) - Method in class org.h2.util.geometry.JTSUtils.GeometryTarget
 
initCrossReferenceResult() - Method in class org.h2.jdbc.meta.DatabaseMetaLocal
 
initDb() - Method in class org.h2.server.pg.PgServerThread
 
initDone - Variable in class org.h2.server.pg.PgServerThread
 
initExpression(ArrayList<String>, Expression, boolean, ArrayList<TableFilter>) - Method in class org.h2.command.query.Query
Initialize the 'ORDER BY' or 'DISTINCT' expressions.
initFactory() - Method in class org.h2.jdbcx.JdbcDataSource
 
initGroupData(int) - Method in class org.h2.command.query.Select
 
INITIAL_LOCK_TIMEOUT - Static variable in class org.h2.engine.Constants
For testing, the lock timeout is smaller than for interactive use cases.
INITIAL_VERSION - Static variable in class org.h2.mvstore.MVMap
This designates the "last stored" version for a store which was just open for the first time.
initialize(String, ArrayList<Token>, boolean) - Method in class org.h2.command.Parser
 
initialize(K, V) - Method in class org.h2.mvstore.tx.TxDecisionMaker
 
initialized - Variable in class org.h2.fulltext.FullTextSettings
Whether this instance has been initialized.
initialized - Variable in class org.h2.mvstore.rtree.MVRTreeMap.RTreeCursor
 
initialized - Variable in class org.h2.security.auth.DefaultAuthenticator
 
initializeSearcher() - Method in class org.h2.fulltext.FullTextLucene.IndexAccess
 
initializeSequence(SessionLocal, Schema, int, boolean) - Method in class org.h2.table.Column
Initialize the sequence for this column.
initializeType() - Method in class org.h2.expression.ExpressionList
 
initialPowerOffCount - Static variable in class org.h2.engine.Database
 
initJavaObjectSerializer() - Method in class org.h2.engine.Database
 
initKey(byte[]) - Method in class org.h2.security.SecureFileStore
 
initKey(byte[]) - Method in class org.h2.store.FileStore
Initialize the key using the given salt.
initMac(byte[]) - Static method in class org.h2.security.SHA256
 
initManagementDb() - Method in class org.h2.server.TcpServer
 
initMemoryAccount(int) - Method in class org.h2.mvstore.Page
 
initOrder(ArrayList<String>, boolean, ArrayList<TableFilter>) - Method in class org.h2.command.query.Query
Initialize the order by list.
initPattern(String, Character) - Method in class org.h2.expression.condition.CompareLike
Initializes the pattern.
initRead() - Method in class org.h2.tools.Csv
 
initStore() - Method in class org.h2.command.dml.ScriptBase
 
initTokens() - Static method in enum org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
initTransfer(ConnectionInfo, String, String) - Method in class org.h2.engine.SessionRemote
 
initTweak(long) - Method in class org.h2.store.fs.encrypt.XTS
 
initVariables() - Method in class org.h2.engine.SessionLocal
 
initWrite() - Method in class org.h2.tools.Csv
 
INLINE - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
INLINE_LIST - Static variable in enum org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
inlineArguments() - Method in class org.h2.expression.ConcatenationOperation
 
InlineParslet() - Constructor for class org.h2.mode.ToDateTokenizer.InlineParslet
 
inList - Variable in class org.h2.index.IndexCursor
 
inListIndex - Variable in class org.h2.index.IndexCursor
 
inMulti - Variable in class org.h2.util.geometry.EWKTUtils.EWKTTarget
 
inMulti - Variable in class org.h2.util.geometry.GeoJsonUtils.GeoJsonTarget
 
inMultiLine - Variable in class org.h2.util.geometry.GeoJsonUtils.GeoJsonTarget
 
INNER - Static variable in class org.h2.util.ParserUtil
The token "INNER".
innerCoordinates - Variable in class org.h2.util.geometry.JTSUtils.GeometryTarget
 
innerOffset - Variable in class org.h2.util.geometry.JTSUtils.GeometryTarget
 
inPos - Variable in class org.h2.store.fs.zip.FileZip
 
input - Variable in class org.h2.server.web.WebThread
 
input - Variable in class org.h2.tools.Csv
 
inputBuffer - Variable in class org.h2.tools.Csv
 
inputBufferEnd - Variable in class org.h2.tools.Csv
 
inputBufferPos - Variable in class org.h2.tools.Csv
 
inputBufferStart - Variable in class org.h2.tools.Csv
 
inputStr - Variable in class org.h2.mode.ToDateParser
 
inResult - Variable in class org.h2.index.IndexCursor
 
insert(Object[], boolean) - Method in class org.h2.fulltext.FullTextLucene.FullTextTrigger
Add a row to the index.
insert(String, int, int, String) - Static method in class org.h2.expression.function.StringFunction
 
insert(Connection, Object[]) - Method in class org.h2.fulltext.FullText.FullTextTrigger
Add a row to the index.
Insert - Class in org.h2.command.dml
This class represents the statement INSERT
Insert(SessionLocal) - Constructor for class org.h2.command.dml.Insert
 
INSERT - Static variable in interface org.h2.api.Trigger
The trigger is called for INSERT statements.
INSERT - Static variable in interface org.h2.command.CommandInterface
The type of an INSERT statement.
INSERT - Static variable in class org.h2.engine.Right
The right bit mask that means: inserting rows into a table is allowed.
INSERT - Static variable in class org.h2.expression.function.StringFunction
INSERT() (non-standard).
INSERT_MAP - Static variable in class org.h2.fulltext.FullText.FullTextTrigger
 
INSERT_ROW - Static variable in class org.h2.fulltext.FullText.FullTextTrigger
 
INSERT_WORD - Static variable in class org.h2.fulltext.FullText.FullTextTrigger
 
insertFromSelect - Variable in class org.h2.command.dml.Insert
 
insertKey(int, K) - Method in class org.h2.mvstore.Page
Insert a key into the key array
insertLeaf(int, K, V) - Method in class org.h2.mvstore.Page
Insert a key-value pair into this leaf.
insertLeaf(int, K, V) - Method in class org.h2.mvstore.Page.Leaf
 
insertLeaf(int, K, V) - Method in class org.h2.mvstore.Page.NonLeaf
 
insertNode(int, K, Page<K, V>) - Method in class org.h2.mvstore.Page
Insert a child page into this node.
insertNode(int, K, Page<K, V>) - Method in class org.h2.mvstore.Page.Leaf
 
insertNode(int, K, Page<K, V>) - Method in class org.h2.mvstore.Page.NonLeaf
 
insertOnConflict - Variable in class org.h2.engine.Mode
PostgreSQL style INSERT ...
insertRow - Variable in class org.h2.jdbc.JdbcResultSet
 
insertRow() - Method in class org.h2.jdbc.JdbcResultSet
Inserts the current row.
insertRow() - Method in class org.h2.tools.SimpleResultSet
INTERNAL
insertRow(Value[]) - Method in class org.h2.result.UpdatableRow
Insert a new row into the database.
insertRows() - Method in class org.h2.command.dml.Insert
 
insertsAreDetected(int) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether inserts are detected.
insideRemark - Variable in class org.h2.util.ScriptReader
True if we are inside a comment
instance - Static variable in class org.h2.security.auth.DefaultAuthenticator
 
instance - Static variable in class org.h2.store.RecoverTester
 
INSTANCE - Static variable in class org.h2.Driver
 
INSTANCE - Static variable in class org.h2.engine.OnExitDatabaseCloser
 
INSTANCE - Static variable in class org.h2.mvstore.cache.FilePathCache
The instance.
INSTANCE - Static variable in class org.h2.mvstore.Chunk.PositionComparator
 
INSTANCE - Static variable in class org.h2.mvstore.db.LobStorageMap.BlobMeta.Type
 
INSTANCE - Static variable in class org.h2.mvstore.db.LobStorageMap.BlobReference.Type
 
INSTANCE - Static variable in class org.h2.mvstore.db.NullValueDataType
Dummy data type instance.
INSTANCE - Static variable in class org.h2.mvstore.MVStoreTool.GenericDataType
 
INSTANCE - Static variable in class org.h2.mvstore.type.ByteArrayDataType
 
INSTANCE - Static variable in class org.h2.mvstore.type.LongDataType
 
INSTANCE - Static variable in class org.h2.mvstore.type.ObjectDataType.BigDecimalType
The only instance of this type.
INSTANCE - Static variable in class org.h2.mvstore.type.ObjectDataType.BigIntegerType
The only instance of this type.
INSTANCE - Static variable in class org.h2.mvstore.type.ObjectDataType.BooleanType
The only instance of this type.
INSTANCE - Static variable in class org.h2.mvstore.type.ObjectDataType.ByteType
The only instance of this type.
INSTANCE - Static variable in class org.h2.mvstore.type.ObjectDataType.CharacterType
The only instance of this type.
INSTANCE - Static variable in class org.h2.mvstore.type.ObjectDataType.DateType
The only instance of this type.
INSTANCE - Static variable in class org.h2.mvstore.type.ObjectDataType.DoubleType
The only instance of this type.
INSTANCE - Static variable in class org.h2.mvstore.type.ObjectDataType.FloatType
The only instance of this type.
INSTANCE - Static variable in class org.h2.mvstore.type.ObjectDataType.IntegerType
The only instance of this type.
INSTANCE - Static variable in class org.h2.mvstore.type.ObjectDataType.LongType
The only instance of this type.
INSTANCE - Static variable in class org.h2.mvstore.type.ObjectDataType.NullType
The only instance of this type.
INSTANCE - Static variable in class org.h2.mvstore.type.ObjectDataType.ShortType
The only instance of this type.
INSTANCE - Static variable in class org.h2.mvstore.type.ObjectDataType.StringType
The only instance of this type.
INSTANCE - Static variable in class org.h2.mvstore.type.ObjectDataType.UUIDType
The only instance of this type.
INSTANCE - Static variable in class org.h2.mvstore.type.StringDataType
 
INSTANCE - Static variable in class org.h2.result.RowFactory.DefaultRowFactory
 
INSTANCE - Static variable in class org.h2.store.fs.FakeFileChannel
No need to allocate these, they have no state
INSTANCE - Static variable in class org.h2.store.fs.rec.FilePathRec
 
INSTANCE - Static variable in class org.h2.tools.MultiDimension
 
INSTANCE - Static variable in class org.h2.value.ValueNull
The main NULL instance.
instantToValue(Instant) - Static method in class org.h2.util.JSR310Utils
Converts a Instant to a Value.
insteadOf - Variable in class org.h2.command.ddl.CreateTrigger
 
insteadOf - Variable in class org.h2.schema.TriggerObject
 
instrumentation - Static variable in class org.h2.util.Profiler
 
INT_0_15 - Static variable in class org.h2.mvstore.db.ValueDataType
 
INT_NEG - Static variable in class org.h2.mvstore.db.ValueDataType
 
IntArray - Class in org.h2.util
An array with integer element.
IntArray() - Constructor for class org.h2.util.IntArray
Create an int array with the default initial capacity.
IntArray(int) - Constructor for class org.h2.util.IntArray
Create an int array with specified initial capacity.
IntArray(int[]) - Constructor for class org.h2.util.IntArray
Create an int array with the given values and size.
INTEGER - Static variable in class org.h2.api.H2Type
The INTEGER data type.
INTEGER - Static variable in class org.h2.mvstore.db.ValueDataType
 
INTEGER - Static variable in class org.h2.value.Transfer
 
INTEGER - Static variable in class org.h2.value.Value
The value type for INTEGER values.
INTEGER_DATE_TYPES - Static variable in class org.h2.server.pg.PgServerThread
 
IntegerToken(int, int) - Constructor for class org.h2.command.Token.IntegerToken
 
IntegerType() - Constructor for class org.h2.mvstore.type.ObjectDataType.IntegerType
 
integerValue - Variable in class org.h2.expression.aggregate.AggregateDataAvg
 
interfaceName - Variable in class org.h2.jmx.DocumentedMBean
 
interleave(int...) - Method in class org.h2.tools.MultiDimension
Convert the multi-dimensional value into a one-dimensional (scalar) value.
interleave(int, int) - Method in class org.h2.tools.MultiDimension
Convert the two-dimensional value into a one-dimensional (scalar) value.
interpolate(Value, Value, BigDecimal, int, SessionLocal, CompareMode) - Static method in class org.h2.expression.aggregate.Percentile
 
interpolateDecimal(BigDecimal, BigDecimal, BigDecimal) - Static method in class org.h2.expression.aggregate.Percentile
 
INTERSECT - org.h2.command.query.SelectUnion.UnionType
The type of an INTERSECT statement.
INTERSECT - Static variable in class org.h2.util.ParserUtil
The token "INTERSECT".
intersects - Variable in class org.h2.index.IndexCursor
 
intersects(double[], double[]) - Static method in class org.h2.util.geometry.GeometryUtils
Checks whether two envelopes intersect with each other.
intersectsBoundingBox(ValueGeometry) - Method in class org.h2.value.ValueGeometry
Test if this geometry envelope intersects with the other geometry envelope.
IntersectsRTreeCursor(Page<Spatial, V>, Spatial, SpatialDataType) - Constructor for class org.h2.mvstore.rtree.MVRTreeMap.IntersectsRTreeCursor
 
interval - Variable in class org.h2.util.Profiler
 
Interval - Class in org.h2.api
INTERVAL representation for result sets.
Interval(IntervalQualifier, boolean, long, long) - Constructor for class org.h2.api.Interval
Creates a new interval.
INTERVAL - Static variable in class org.h2.mvstore.db.ValueDataType
 
INTERVAL - Static variable in class org.h2.util.ParserUtil
The token "INTERVAL".
INTERVAL - Static variable in class org.h2.value.Transfer
 
INTERVAL_DAY - Static variable in class org.h2.api.H2Type
The INTERVAL DAY data type.
INTERVAL_DAY - Static variable in class org.h2.value.Value
The value type for INTERVAL DAY values.
INTERVAL_DAY_DIGITS - Static variable in class org.h2.expression.IntervalOperation
Number of digits enough to hold INTERVAL '999999999999999999' DAY / INTERVAL '0.000000001' SECOND.
INTERVAL_DAY_TO_HOUR - Static variable in class org.h2.api.H2Type
The INTERVAL DAY TO HOUR data type.
INTERVAL_DAY_TO_HOUR - Static variable in class org.h2.value.Value
The value type for INTERVAL DAY TO HOUR values.
INTERVAL_DAY_TO_MINUTE - Static variable in class org.h2.api.H2Type
The INTERVAL DAY TO MINUTE data type.
INTERVAL_DAY_TO_MINUTE - Static variable in class org.h2.value.Value
The value type for INTERVAL DAY TO MINUTE values.
INTERVAL_DAY_TO_SECOND - Static variable in class org.h2.api.H2Type
The INTERVAL DAY TO SECOND data type.
INTERVAL_DAY_TO_SECOND - Static variable in class org.h2.value.Value
The value type for INTERVAL DAY TO SECOND values.
INTERVAL_DIVIDE_INTERVAL - org.h2.expression.IntervalOperation.IntervalOpType
Interval divided by interval (non-standard).
INTERVAL_DIVIDE_INTERVAL_DAY_TYPE - Static variable in class org.h2.expression.IntervalOperation
 
INTERVAL_DIVIDE_INTERVAL_YEAR_TYPE - Static variable in class org.h2.expression.IntervalOperation
 
INTERVAL_DIVIDE_NUMERIC - org.h2.expression.IntervalOperation.IntervalOpType
Interval divided by numeric.
INTERVAL_HOUR - Static variable in class org.h2.api.H2Type
The INTERVAL HOUR data type.
INTERVAL_HOUR - Static variable in class org.h2.value.Value
The value type for INTERVAL HOUR values.
INTERVAL_HOUR_TO_MINUTE - Static variable in class org.h2.api.H2Type
The INTERVAL HOUR TO MINUTE data type.
INTERVAL_HOUR_TO_MINUTE - Static variable in class org.h2.value.Value
The value type for INTERVAL HOUR TO MINUTE values.
INTERVAL_HOUR_TO_SECOND - Static variable in class org.h2.api.H2Type
The INTERVAL HOUR TO SECOND data type.
INTERVAL_HOUR_TO_SECOND - Static variable in class org.h2.value.Value
The value type for INTERVAL HOUR TO SECOND values.
INTERVAL_MINUS_INTERVAL - org.h2.expression.IntervalOperation.IntervalOpType
Interval minus interval.
INTERVAL_MINUTE - Static variable in class org.h2.api.H2Type
The INTERVAL MINUTE data type.
INTERVAL_MINUTE - Static variable in class org.h2.value.Value
The value type for INTERVAL MINUTE values.
INTERVAL_MINUTE_TO_SECOND - Static variable in class org.h2.api.H2Type
The INTERVAL MINUTE TO SECOND data type.
INTERVAL_MINUTE_TO_SECOND - Static variable in class org.h2.value.Value
The value type for INTERVAL MINUTE TO SECOND values.
INTERVAL_MONTH - Static variable in class org.h2.api.H2Type
The INTERVAL MONTH data type.
INTERVAL_MONTH - Static variable in class org.h2.value.Value
The value type for INTERVAL MONTH values.
INTERVAL_MULTIPLY_NUMERIC - org.h2.expression.IntervalOperation.IntervalOpType
Interval multiplied by numeric.
INTERVAL_PLUS_INTERVAL - org.h2.expression.IntervalOperation.IntervalOpType
Interval plus interval.
INTERVAL_SECOND - Static variable in class org.h2.api.H2Type
The INTERVAL SECOND data type.
INTERVAL_SECOND - Static variable in class org.h2.value.Value
The value type for INTERVAL SECOND values.
INTERVAL_YEAR - Static variable in class org.h2.api.H2Type
The INTERVAL YEAR data type.
INTERVAL_YEAR - Static variable in class org.h2.value.Value
The value type for INTERVAL YEAR values.
INTERVAL_YEAR_DIGITS - Static variable in class org.h2.expression.IntervalOperation
Number of digits enough to hold INTERVAL '999999999999999999' YEAR / INTERVAL '1' MONTH.
INTERVAL_YEAR_TO_MONTH - Static variable in class org.h2.api.H2Type
The INTERVAL YEAR TO MONTH data type.
INTERVAL_YEAR_TO_MONTH - Static variable in class org.h2.value.Value
The value type for INTERVAL YEAR TO MONTH values.
intervalDayError() - Method in class org.h2.command.Parser
 
intervalFromAbsolute(IntervalQualifier, BigInteger) - Static method in class org.h2.util.IntervalUtils
Converts absolute value to an interval value.
intervalFromAbsolute(IntervalQualifier, BigInteger, BigInteger) - Static method in class org.h2.util.IntervalUtils
 
intervalHourError() - Method in class org.h2.command.Parser
 
IntervalOperation - Class in org.h2.expression
A mathematical operation with intervals.
IntervalOperation(IntervalOperation.IntervalOpType, Expression, Expression) - Constructor for class org.h2.expression.IntervalOperation
 
IntervalOperation(IntervalOperation.IntervalOpType, Expression, Expression, TypeInfo) - Constructor for class org.h2.expression.IntervalOperation
 
IntervalOperation.IntervalOpType - Enum in org.h2.expression
 
IntervalOpType() - Constructor for enum org.h2.expression.IntervalOperation.IntervalOpType
 
intervalPrecision - Variable in class org.h2.table.InformationSchemaTable.DataTypeInformation
INTERVAL_PRECISION.
IntervalQualifier - Enum in org.h2.api
Interval qualifier.
IntervalQualifier() - Constructor for enum org.h2.api.IntervalQualifier
 
intervalQualifierError() - Method in class org.h2.command.Parser
 
intervalToAbsolute(ValueInterval) - Static method in class org.h2.util.IntervalUtils
Converts interval value to an absolute value.
intervalToAbsolute(ValueInterval, BigInteger) - Static method in class org.h2.util.IntervalUtils
 
intervalToAbsolute(ValueInterval, BigInteger, BigInteger) - Static method in class org.h2.util.IntervalUtils
 
intervalType - Variable in class org.h2.table.InformationSchemaTable.DataTypeInformation
INTERVAL_TYPE.
IntervalUtils - Class in org.h2.util
This utility class contains interval conversion functions.
IntervalUtils() - Constructor for class org.h2.util.IntervalUtils
 
intValue - Variable in class org.h2.engine.Setting
 
IntValueHolder() - Constructor for class org.h2.mvstore.MVMap.IntValueHolder
 
INVALID_CLASS_2 - Static variable in class org.h2.api.ErrorCode
The error with code 90125 is thrown when PreparedStatement.setBigDecimal is called with object that extends the class BigDecimal, and the system property h2.allowBigDecimalExtensions is not set.
INVALID_DATABASE_NAME_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90138 is thrown when trying to open a persistent database using an incorrect database name.
INVALID_DATETIME_CONSTANT_2 - Static variable in class org.h2.api.ErrorCode
The error with code 22007 is thrown when a text can not be converted to a date, time, or timestamp constant.
INVALID_NAME_1 - Static variable in class org.h2.api.ErrorCode
The error with code 42602 is thrown when invalid name of identifier is used.
INVALID_PARAMETER_COUNT_2 - Static variable in class org.h2.api.ErrorCode
The error with code 7001 is thrown when trying to call a function with the wrong number of parameters.
INVALID_PRECEDING_OR_FOLLOWING_1 - Static variable in class org.h2.api.ErrorCode
The error with code 22013 is thrown when preceding or following size in a window function is null or negative.
INVALID_TO_CHAR_FORMAT - Static variable in class org.h2.api.ErrorCode
The error with code 90010 is thrown when trying to format a timestamp or number using TO_CHAR with an invalid format.
INVALID_TO_DATE_FORMAT - Static variable in class org.h2.api.ErrorCode
The error with code 90056 is thrown when trying to format a timestamp using TO_DATE and TO_TIMESTAMP with an invalid format.
INVALID_TRIGGER_FLAGS_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90005 is thrown when trying to create a trigger with invalid combination of flags.
INVALID_USE_OF_AGGREGATE_FUNCTION_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90054 is thrown when an aggregate function is used where it is not allowed.
INVALID_VALUE_2 - Static variable in class org.h2.api.ErrorCode
The error with code 90008 is thrown when trying to use a value that is not valid for the given operation.
INVALID_VALUE_PRECISION - Static variable in class org.h2.api.ErrorCode
The error with code 90150 is thrown when trying to use an invalid precision.
INVALID_VALUE_SCALE - Static variable in class org.h2.api.ErrorCode
The error with code 90151 is thrown when trying to use an invalid scale or fractional seconds precision.
invalidate() - Method in class org.h2.engine.DbObject
Set the main attributes to null to make sure the object is no longer used.
invalidate() - Method in class org.h2.mvstore.db.MVTable
 
invalidPattern - Variable in class org.h2.expression.condition.CompareLike
 
INVOKE_CLEANER - Static variable in class org.h2.util.MemoryUnmapper
 
IO_BUFFER_SIZE - Static variable in class org.h2.engine.Constants
The block size for I/O operations.
IO_BUFFER_SIZE_COMPRESS - Static variable in class org.h2.engine.Constants
The block size used to compress data in the LZFOutputStream.
IO_EXCEPTION_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90028 is thrown when an input / output error occurred.
IO_EXCEPTION_2 - Static variable in class org.h2.api.ErrorCode
The error with code 90031 is thrown when an input / output error occurred.
IOUtils - Class in org.h2.util
This utility class contains input/output functions.
IOUtils() - Constructor for class org.h2.util.IOUtils
 
ipToShortForm(StringBuilder, byte[], boolean) - Static method in class org.h2.util.NetUtils
Appends short representation of the specified IP address to the string builder.
IS - Static variable in class org.h2.util.ParserUtil
The token "IS".
isAbsolute() - Method in class org.h2.store.fs.disk.FilePathDisk
 
isAbsolute() - Method in class org.h2.store.fs.FilePath
Check if the file name includes a path.
isAbsolute() - Method in class org.h2.store.fs.FilePathWrapper
 
isAbsolute() - Method in class org.h2.store.fs.mem.FilePathMem
 
isAbsolute() - Method in class org.h2.store.fs.niomem.FilePathNioMem
 
isAbsolute() - Method in class org.h2.store.fs.zip.FilePathZip
 
isAbsolute(String) - Static method in class org.h2.store.fs.FileUtils
Check if the file name includes a path.
isActive(int) - Static method in class org.h2.mvstore.tx.Transaction
 
isAdmin() - Method in class org.h2.engine.User
 
isAfterLast() - Method in class org.h2.jdbc.JdbcResultSet
Checks if the current position is after the last row, that means next() was called and returned false, and there was at least one row.
isAfterLast() - Method in class org.h2.result.FetchedResult
 
isAfterLast() - Method in class org.h2.result.LocalResult
 
isAfterLast() - Method in interface org.h2.result.ResultInterface
Check if the current position is after last row.
isAfterLast() - Method in class org.h2.result.ResultWithPaddedStrings
 
isAfterLast() - Method in class org.h2.result.SimpleResult
 
isAfterLast() - Method in class org.h2.tools.SimpleResultSet
INTERNAL
isAggregate() - Method in class org.h2.expression.aggregate.AbstractAggregate
 
isAggregate() - Method in class org.h2.expression.analysis.DataAnalysisOperation
Checks whether this expression is an aggregate function.
isAggregate() - Method in class org.h2.expression.analysis.WindowFunction
 
isAllowBuiltinAliasOverride() - Method in class org.h2.engine.Database
 
isAllowUserRegistration() - Method in class org.h2.security.auth.DefaultAuthenticator
If set create external users in the database if not present.
isAllowUserRegistration() - Method in class org.h2.security.auth.H2AuthConfig
Allow user registration flag.
isAlwaysFalse() - Method in class org.h2.index.IndexCondition
Check if the result is always false.
isAlwaysFalse() - Method in class org.h2.index.IndexCursor
Check if the result is empty for sure.
isAM - Variable in class org.h2.mode.ToDateParser
 
isAnyDistinct() - Method in class org.h2.command.query.Query
 
isAnyDistinct() - Method in class org.h2.command.query.Select
 
isAnyDistinct() - Method in class org.h2.result.LocalResult
 
isArray - Variable in class org.h2.expression.ExpressionList
 
isArray() - Method in class org.h2.expression.ExpressionList
 
isArray(Object) - Static method in class org.h2.mvstore.type.ObjectDataType
Check whether this object is an array.
isAutoIncrement(int) - Method in class org.h2.jdbc.JdbcResultSetMetaData
Checks if this an autoincrement column.
isAutoIncrement(int) - Method in class org.h2.tools.SimpleResultSet
Returns false.
isBackgroundThread() - Method in class org.h2.mvstore.MVStore
 
isBefore() - Method in class org.h2.constraint.Constraint
Check if this constraint needs to be checked before updating the data.
isBefore() - Method in class org.h2.constraint.ConstraintCheck
 
isBefore() - Method in class org.h2.constraint.ConstraintDomain
 
isBefore() - Method in class org.h2.constraint.ConstraintReferential
 
isBefore() - Method in class org.h2.constraint.ConstraintUnique
 
isBefore() - Method in class org.h2.schema.TriggerObject
Check if this is a before trigger.
isBeforeFirst() - Method in class org.h2.jdbc.JdbcResultSet
Checks if the current position is before the first row, that means next() was not called yet, and there is at least one row.
isBeforeFirst() - Method in class org.h2.tools.SimpleResultSet
INTERNAL
isBigDecimal(Object) - Static method in class org.h2.mvstore.type.ObjectDataType
Check whether this object is a BigDecimal.
isBigInteger(Object) - Static method in class org.h2.mvstore.type.ObjectDataType
Check whether this object is a BigInteger.
isBinaryColumn(ResultSetMetaData, int) - Static method in class org.h2.value.DataType
Check whether the specified column needs the binary representation.
isBinaryStringOrSpecialBinaryType(int) - Static method in class org.h2.value.DataType
Check if the given value type is a binary string type or a compatible special data type such as Java object, UUID, geometry object, or JSON.
isBinaryStringType(int) - Static method in class org.h2.value.DataType
Check if the given value type is a binary string type.
isBlockRemark() - Method in class org.h2.util.ScriptReader
If currently inside a remark, this method tells if it is a block comment (true) or single line comment (false)
isBuiltIn(String, String) - Static method in class org.h2.util.JdbcUtils
Check is the SQL string starts with a prefix (case insensitive).
isBuiltinFunction(Database, String) - Static method in class org.h2.expression.function.BuiltinFunctions
Returns whether specified function is a non-keyword built-in function.
isCacheable() - Method in class org.h2.command.Command
 
isCacheable() - Method in class org.h2.command.CommandContainer
 
isCacheable() - Method in class org.h2.command.dml.Call
 
isCacheable() - Method in class org.h2.command.dml.DataChangeStatement
 
isCacheable() - Method in class org.h2.command.dml.Help
 
isCacheable() - Method in class org.h2.command.dml.Insert
 
isCacheable() - Method in class org.h2.command.dml.TransactionCommand
 
isCacheable() - Method in class org.h2.command.Prepared
 
isCacheable() - Method in class org.h2.command.query.Select
 
isCancelled() - Method in class org.h2.jdbc.JdbcStatement
Check whether the statement was cancelled.
isCaseSensitive(int) - Method in class org.h2.jdbc.JdbcResultSetMetaData
Checks if this column is case sensitive.
isCaseSensitive(int) - Method in class org.h2.tools.SimpleResultSet
Returns true.
isCatalogAtStart() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether the catalog is at the beginning.
isChanged() - Method in class org.h2.util.CacheObject
Check if this cache object has been changed and thus needs to be written back to the storage.
isCharacterStringType(int) - Static method in class org.h2.value.DataType
Check if the given value type is a character string type.
isClosed - Variable in class org.h2.jdbcx.JdbcXAConnection.PooledJdbcConnection
 
isClosed() - Method in class org.h2.engine.Session
Check if close was called.
isClosed() - Method in class org.h2.engine.SessionLocal
 
isClosed() - Method in class org.h2.engine.SessionRemote
 
isClosed() - Method in class org.h2.jdbc.JdbcConnection
Returns true if this connection has been closed.
isClosed() - Method in class org.h2.jdbc.JdbcResultSet
Returns whether this result set is closed.
isClosed() - Method in class org.h2.jdbc.JdbcStatement
Returns whether this statement is closed.
isClosed() - Method in class org.h2.jdbcx.JdbcXAConnection.PooledJdbcConnection
 
isClosed() - Method in class org.h2.mvstore.MVMap
 
isClosed() - Method in class org.h2.mvstore.MVStore
Determine that store is open, or wait for it to be closed (by other thread)
isClosed() - Method in class org.h2.mvstore.tx.TransactionMap
Check whether this map is closed.
isClosed() - Method in class org.h2.result.LazyResult
 
isClosed() - Method in class org.h2.result.LocalResult
Check if this result set is closed.
isClosed() - Method in interface org.h2.result.ResultInterface
Check if this result set is closed.
isClosed() - Method in class org.h2.result.ResultRemote
 
isClosed() - Method in class org.h2.result.ResultWithPaddedStrings
 
isClosed() - Method in class org.h2.result.SimpleResult
 
isClosed() - Method in class org.h2.tools.SimpleResultSet
Returns whether this result set has been closed.
isClosed() - Method in class org.h2.value.Transfer
 
isCloseOnCompletion() - Method in class org.h2.jdbc.JdbcStatement
Returns whether this statement will be closed when its dependent result set is closed.
isClosing() - Method in class org.h2.engine.Database
Check if the database is in the process of closing.
isClustered() - Method in class org.h2.engine.SessionRemote
Returns true if the connection was opened in cluster mode.
isCommandHistoryAllowed() - Method in class org.h2.server.web.WebServer
 
isCommitted() - Method in class org.h2.mvstore.tx.VersionedValueUncommitted
 
isCommitted() - Method in class org.h2.value.VersionedValue
 
isCommitted(int) - Method in class org.h2.mvstore.tx.TxDecisionMaker
Determine whether specified id corresponds to a logically committed transaction.
isCommon(int) - Static method in class org.h2.api.ErrorCode
INTERNAL
isCommonJoinColumnToExclude(Column) - Method in class org.h2.table.TableFilter
Check if the given column is an excluded common join column.
isComplete() - Method in class org.h2.mvstore.Page.IncompleteNonLeaf
 
isComplete() - Method in class org.h2.mvstore.Page
 
isConditionMet() - Method in class org.h2.command.query.Select
 
isConditionMetForUpdate() - Method in class org.h2.command.query.Select
 
isConstant() - Method in class org.h2.expression.Expression
Check if this expression will always return the same value.
isConstant() - Method in class org.h2.expression.ExpressionList
 
isConstant() - Method in class org.h2.expression.function.CastSpecification
 
isConstant() - Method in class org.h2.expression.Subquery
 
isConstant() - Method in class org.h2.expression.ValueExpression
 
isConstantQuery() - Method in class org.h2.command.query.Query
Check if this query will always return the same value and has no side effects.
isConstantQuery() - Method in class org.h2.command.query.Select
 
isConstantQuery() - Method in class org.h2.command.query.SelectUnion
 
isConstantQuery() - Method in class org.h2.command.query.TableValueConstructor
 
isCreateMissingRoles() - Method in class org.h2.security.auth.DefaultAuthenticator
When set create roles not found in the database.
isCreateMissingRoles() - Method in class org.h2.security.auth.H2AuthConfig
When set create roles not found in the database.
isCurrency(int) - Method in class org.h2.jdbc.JdbcResultSetMetaData
Checks if this is a currency column.
isCurrency(int) - Method in class org.h2.tools.SimpleResultSet
Returns false.
isCurrentCommandADefineCommand() - Method in class org.h2.command.Command
Is the command we just tried to execute a DefineCommand (i.e.
isCurrentCommandADefineCommand() - Method in class org.h2.command.CommandContainer
 
isCurrentCommandADefineCommand() - Method in class org.h2.command.CommandList
 
isCurrentGroup() - Method in class org.h2.command.query.SelectGroups
Is there currently a group-by active.
isCycle() - Method in enum org.h2.schema.Sequence.Cycle
Return whether sequence is cycled.
isDaemon - Variable in class org.h2.server.pg.PgServer
 
isDaemon - Variable in class org.h2.server.TcpServer
 
isDaemon - Variable in class org.h2.server.web.WebServer
 
isDaemon() - Method in class org.h2.server.pg.PgServer
 
isDaemon() - Method in interface org.h2.server.Service
Check if a daemon thread should be used.
isDaemon() - Method in class org.h2.server.TcpServer
 
isDaemon() - Method in class org.h2.server.web.WebServer
 
isDate(Object) - Static method in class org.h2.mvstore.type.ObjectDataType
Check whether this object is a date.
isDateTimeType(int) - Static method in class org.h2.value.DataType
Check if the given value type is a date-time type (TIME, DATE, TIMESTAMP, TIMESTAMP_TZ).
isDayTime() - Method in enum org.h2.api.IntervalQualifier
Returns whether interval with this qualifier is a day-time interval.
isDB2 - Variable in class org.h2.bnf.context.DbContents
 
isDB2() - Method in class org.h2.bnf.context.DbContents
 
isDeadlocked(Transaction) - Method in class org.h2.mvstore.tx.Transaction
 
isDebugEnabled() - Method in class org.h2.message.Trace
Check if the trace level is equal or higher than DEBUG.
isDebugEnabled() - Method in class org.h2.message.TraceObject
Check if the debug trace level is enabled.
isDefault - Variable in class org.h2.bnf.context.DbSchema
True if this is the default schema for this database.
isDefaultOnNull() - Method in class org.h2.table.Column
 
isDefinitelyWritable(int) - Method in class org.h2.jdbc.JdbcResultSetMetaData
Checks whether a write on this column will definitely succeed.
isDefinitelyWritable(int) - Method in class org.h2.tools.SimpleResultSet
Returns false.
isDeletedByCurrentTransaction(K) - Method in class org.h2.mvstore.tx.TransactionMap
Check if the row was deleted by this transaction.
isDerby - Variable in class org.h2.bnf.context.DbContents
 
isDerby() - Method in class org.h2.bnf.context.DbContents
 
isDerivedTable() - Method in class org.h2.command.Parser
 
isDeterministic() - Method in class org.h2.expression.function.table.ArrayTableFunction
 
isDeterministic() - Method in class org.h2.expression.function.table.CSVReadFunction
 
isDeterministic() - Method in class org.h2.expression.function.table.JavaTableFunction
 
isDeterministic() - Method in class org.h2.expression.function.table.LinkSchemaFunction
 
isDeterministic() - Method in class org.h2.expression.function.table.TableFunction
Whether the function always returns the same result for the same parameters.
isDeterministic() - Method in class org.h2.mvstore.db.MVTable
 
isDeterministic() - Method in class org.h2.schema.FunctionAlias
 
isDeterministic() - Method in class org.h2.table.DataChangeDeltaTable
 
isDeterministic() - Method in class org.h2.table.DualTable
 
isDeterministic() - Method in class org.h2.table.FunctionTable
 
isDeterministic() - Method in class org.h2.table.MetaTable
 
isDeterministic() - Method in class org.h2.table.RangeTable
 
isDeterministic() - Method in class org.h2.table.Table
Check if the table is deterministic.
isDeterministic() - Method in class org.h2.table.TableLink
 
isDeterministic() - Method in class org.h2.table.TableValueConstructorTable
 
isDeterministic() - Method in class org.h2.table.TableView
 
isDirectory() - Method in class org.h2.store.fs.disk.FilePathDisk
 
isDirectory() - Method in class org.h2.store.fs.FilePath
Check if it is a file or a directory.
isDirectory() - Method in class org.h2.store.fs.FilePathWrapper
 
isDirectory() - Method in class org.h2.store.fs.mem.FilePathMem
 
isDirectory() - Method in class org.h2.store.fs.niomem.FilePathNioMem
 
isDirectory() - Method in class org.h2.store.fs.zip.FilePathZip
 
isDirectory(String) - Static method in class org.h2.store.fs.FileUtils
Check if it is a file or a directory.
isDirectQuery(int) - Method in class org.h2.command.Parser
 
isDisposed - Variable in class org.h2.jdbcx.JdbcConnectionPool
 
isDistinct() - Method in class org.h2.expression.aggregate.Aggregate
Returns if distinct is used.
isDistinctQuery - Variable in class org.h2.command.query.Select
 
isDualTable(String) - Method in class org.h2.command.Parser
Is this the Oracle DUAL table or the IBM/DB2 SYSIBM table?
isEmpty() - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Check whether the cache is empty.
isEmpty() - Method in class org.h2.mvstore.MVMap
 
isEmpty() - Method in class org.h2.schema.MetaSchema
 
isEmpty() - Method in class org.h2.schema.Schema
Return whether is this schema is empty (does not contain any objects).
isEmpty() - Method in class org.h2.util.ByteStack
Returns true if this stack is empty.
isEmpty(Value) - Static method in class org.h2.expression.ConcatenationOperation
 
isEnabled(int) - Method in class org.h2.message.Trace
 
isEnabled(int) - Method in class org.h2.message.TraceSystem
 
isEnabled(int) - Method in interface org.h2.message.TraceWriter
Check the given trace / log level is enabled.
isEnabled(int) - Method in class org.h2.message.TraceWriterAdapter
 
isEncrypted() - Method in class org.h2.command.dml.ScriptBase
 
isEnd() - Method in class org.h2.index.IndexCondition
Check if this index condition is of the type column smaller or equal to value.
isEqual(Row, Row) - Method in class org.h2.constraint.ConstraintReferential
 
isEvacuatable() - Method in class org.h2.mvstore.Chunk
 
isEvaluatable() - Method in class org.h2.index.IndexCondition
Check if the expression can be evaluated.
isEvaluatable() - Method in class org.h2.table.TableFilter
 
isEverything(ExpressionVisitor) - Method in class org.h2.command.dml.SetClauseList
Check if this expression and all sub-expressions can fulfill a criteria.
isEverything(ExpressionVisitor) - Method in class org.h2.command.dml.SetClauseList.RowExpression
 
isEverything(ExpressionVisitor) - Method in class org.h2.command.dml.SetClauseList.SetMultiple
 
isEverything(ExpressionVisitor) - Method in class org.h2.command.dml.SetClauseList.SetSimple
 
isEverything(ExpressionVisitor) - Method in class org.h2.command.dml.SetClauseList.UpdateAction
 
isEverything(ExpressionVisitor) - Method in class org.h2.command.query.Query
Check if this expression and all sub-expressions can fulfill a criteria.
isEverything(ExpressionVisitor) - Method in class org.h2.command.query.Select
 
isEverything(ExpressionVisitor) - Method in class org.h2.command.query.SelectUnion
 
isEverything(ExpressionVisitor) - Method in class org.h2.command.query.TableValueConstructor
 
isEverything(ExpressionVisitor) - Method in class org.h2.constraint.Constraint
Visit all elements in the constraint.
isEverything(ExpressionVisitor) - Method in class org.h2.constraint.ConstraintCheck
 
isEverything(ExpressionVisitor) - Method in class org.h2.constraint.ConstraintDomain
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.aggregate.Aggregate
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.aggregate.JavaAggregate
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.Alias
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.analysis.DataAnalysisOperation
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.ArrayConstructorByQuery
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.condition.BetweenPredicate
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.condition.CompareLike
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.condition.Comparison
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.condition.ConditionAndOr
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.condition.ConditionAndOrN
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.condition.ConditionIn
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.condition.ConditionInConstantSet
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.condition.ConditionInParameter
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.condition.ConditionInQuery
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.condition.ConditionLocalAndGlobal
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.condition.ConditionNot
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.condition.IsJsonPredicate
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.condition.PredicateWithSubquery
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.condition.SimplePredicate
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.DomainValueExpression
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.Expression
Check if this expression and all sub-expressions can fulfill a criteria.
isEverything(ExpressionVisitor) - Method in class org.h2.expression.ExpressionColumn
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.ExpressionList
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.function.CompatibilitySequenceValueFunction
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.function.CSVWriteFunction
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.function.CurrentDateTimeValueFunction
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.function.CurrentGeneralValueSpecification
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.function.DataTypeSQLFunction
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.function.DBObjectFunction
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.function.FileFunction
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.function.Function0_1
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.function.JavaFunction
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.function.RandFunction
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.function.SessionControlFunction
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.function.SetFunction
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.function.SysInfoFunction
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.function.TableInfoFunction
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.Operation1_2
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.Operation1
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.Operation2
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.OperationN
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.Parameter
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.Rownum
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.SequenceValue
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.SimpleCase
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.Subquery
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.ValueExpression
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.Variable
 
isEverything(ExpressionVisitor) - Method in class org.h2.expression.Wildcard
 
isEverything(ExpressionVisitor) - Method in class org.h2.mode.ModeFunction
 
isEverything(ExpressionVisitor) - Method in class org.h2.mode.OnDuplicateKeyValues
 
isEverything(ExpressionVisitor) - Method in class org.h2.table.Column
Visit the default expression, the check constraint, and the sequence (if any).
isExclusive() - Method in class org.h2.jmx.DatabaseInfo
 
isExclusive() - Method in interface org.h2.jmx.DatabaseInfoMBean
Is the database open in exclusive mode?
isExpired() - Method in class org.h2.index.ViewIndex
 
isExplicitTable - Variable in class org.h2.command.query.Select
Whether this SELECT is an explicit table (TABLE tableName).
isFalse() - Method in class org.h2.value.Value
Returns whether this value IS FALSE.
isFetchPercent() - Method in class org.h2.command.query.Query
 
isFindUsingFullTableScan() - Method in class org.h2.index.Index
Returns true if find() implementation performs scan over all index, false if find() performs the fast lookup.
isFindUsingFullTableScan() - Method in class org.h2.index.VirtualConstructedTableIndex
 
isFinished() - Method in class org.h2.util.Task
Whether the call method has returned (with or without exception).
isFinite() - Method in class org.h2.value.ValueDecfloat
Returns true, if this value is finite.
isFirebird - Variable in class org.h2.bnf.context.DbContents
 
isFirebird() - Method in class org.h2.bnf.context.DbContents
 
isFirst() - Method in class org.h2.jdbc.JdbcResultSet
Checks if the current position is row 1, that means next() was called once and returned true.
isFirst() - Method in class org.h2.tools.SimpleResultSet
INTERNAL
isFirstColumn(Column) - Method in class org.h2.index.Index
Check if the given column is the first for this index
isFirstColumn(Column) - Method in class org.h2.index.MetaIndex
 
isFirstColumn(Column) - Method in class org.h2.mvstore.db.MVDelegateIndex
 
isFirstColumn(Column) - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
isForUpdate - Variable in class org.h2.command.query.Select
 
isForUpdate - Variable in class org.h2.command.query.SelectUnion
 
isFragmented() - Method in class org.h2.mvstore.FileStore
 
isFragmented() - Method in class org.h2.mvstore.FreeSpaceBitSet
 
isFree() - Method in class org.h2.mvstore.RootReference
 
isFree(long, int) - Method in class org.h2.mvstore.FreeSpaceBitSet
Check whether one of the blocks is free.
isFullMatch() - Method in class org.h2.expression.condition.CompareLike
 
isGenerated() - Method in class org.h2.table.Column
Returns whether this column is a generated column.
isGeneratedAlways - Variable in class org.h2.table.Column
 
isGeneratedAlways() - Method in class org.h2.table.Column
Returns whether this column is a generated column or always generated identity column.
isGlobalTemporary() - Method in class org.h2.table.Table
 
isGlobalTemporary() - Method in class org.h2.table.TableBase
 
isGroovySource(String) - Static method in class org.h2.util.SourceCompiler
 
isGroupOrNoOthers() - Method in enum org.h2.expression.analysis.WindowFrameExclusion
Returns true if this exclusion clause excludes or includes the whole group.
isGroupQuery - Variable in class org.h2.command.query.Select
This flag is set when SELECT statement contains (non-window) aggregate functions, GROUP BY clause or HAVING clause.
isGroupQuery() - Method in class org.h2.command.query.Select
Checks if this query is a group query.
isGroupSortedIndex(TableFilter, Index) - Method in class org.h2.command.query.Select
 
isGroupSortedQuery - Variable in class org.h2.command.query.Select
 
isGroupWindowStage2 - Variable in class org.h2.command.query.Select
 
isGroupWindowStage2() - Method in class org.h2.command.query.Select
Checks if window stage of group window query is performed.
isH2 - Variable in class org.h2.bnf.context.DbContents
 
isH2() - Method in class org.h2.bnf.context.DbContents
 
isHash() - Method in class org.h2.index.IndexType
Is this a hash index?
isHavingNullOrFalse(Value[]) - Method in class org.h2.command.query.Select
 
isHidden - Variable in class org.h2.command.ddl.CreateTableData
The table is hidden.
isHidden - Variable in class org.h2.table.Table
Protected tables are not listed in the meta data and are excluded when using the SCRIPT command.
isHidden() - Method in class org.h2.constraint.Constraint
 
isHidden() - Method in class org.h2.index.Index
 
isHidden() - Method in class org.h2.schema.SchemaObject
Check whether this is a hidden object that doesn't appear in the meta data and in the script, and is not dropped on DROP ALL OBJECTS.
isHidden() - Method in class org.h2.table.Table
 
isHot() - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS.Entry
Whether this entry is hot.
isIdentifier() - Method in class org.h2.command.Parser
 
isIdentity() - Method in class org.h2.expression.Alias
 
isIdentity() - Method in class org.h2.expression.Expression
Check if this is an identity column.
isIdentity() - Method in class org.h2.expression.ExpressionColumn
 
isIdentity() - Method in class org.h2.expression.Format
 
isIdentity() - Method in class org.h2.table.Column
Returns whether this column is an identity column.
isIdentity(int) - Method in class org.h2.result.LazyResult
 
isIdentity(int) - Method in class org.h2.result.LocalResult
 
isIdentity(int) - Method in interface org.h2.result.ResultInterface
Check if this is an identity column.
isIdentity(int) - Method in class org.h2.result.ResultRemote
 
isIdentity(int) - Method in class org.h2.result.ResultWithPaddedStrings
 
isIdentity(int) - Method in class org.h2.result.SimpleResult
 
isIdle() - Method in class org.h2.mvstore.MVStore
 
isIgnoredByParser(String) - Static method in class org.h2.engine.ConnectionInfo
Returns whether setting with the specified name should be ignored by parser.
isIndexable(TypeInfo) - Static method in class org.h2.value.DataType
Returns whether columns with the specified data type may have an index.
isIndexExcludedByHints(IndexHints, Index) - Static method in class org.h2.table.Table
 
isIndexUsable(ArrayList<String>) - Method in class org.h2.result.UpdatableRow
 
isInfoEnabled() - Method in class org.h2.message.Trace
Check if the trace level is equal or higher than INFO.
isInfoEnabled() - Method in class org.h2.message.TraceObject
Check if info trace level is enabled.
isInit - Variable in class org.h2.expression.condition.CompareLike
 
isInitialized() - Method in class org.h2.fulltext.FullTextSettings
Get the initialized flag.
isInPlace(byte[]) - Method in class org.h2.mvstore.StreamStore
Check whether the id itself contains all the data.
isInsertable() - Method in class org.h2.table.MetaTable
 
isInsertable() - Method in class org.h2.table.Table
Returns whether this table is insertable.
isInsertable() - Method in class org.h2.table.TableLink
 
isInsertable() - Method in class org.h2.table.TableView
 
isInsertable() - Method in class org.h2.table.VirtualTable
 
isInside(Object, Object) - Method in class org.h2.mvstore.rtree.SpatialDataType
Check whether a is completely inside b and does not touch the given bound.
isInsideRemark() - Method in class org.h2.util.ScriptReader
Check if this is the last statement, and if the single line or block comment is not finished yet.
isInsteadOf() - Method in class org.h2.schema.TriggerObject
 
isInternalProperty(String) - Static method in class org.h2.jdbc.JdbcConnection
 
isIntervalType(int) - Static method in class org.h2.value.DataType
Check if the given value type is an interval type.
isInvalid() - Method in class org.h2.table.TableSynonym
 
isInvalid() - Method in class org.h2.table.TableView
Check if this view is currently invalid.
isIrrelevant(long, VersionedValue<?>, BitSet) - Method in class org.h2.mvstore.tx.TransactionMap
 
isJavascriptSource(String) - Static method in class org.h2.util.SourceCompiler
 
isJavaxScriptSource(String) - Static method in class org.h2.util.SourceCompiler
Whether the passed source can be compiled using ScriptEngineManager.
isJoinOuter() - Method in class org.h2.table.TableFilter
Whether this is an outer joined table.
isJoinOuterIndirect() - Method in class org.h2.table.TableFilter
Whether this is indirectly an outer joined table (nested within an inner join).
IsJsonPredicate - Class in org.h2.expression.condition
IS JSON predicate.
IsJsonPredicate(Expression, boolean, boolean, boolean, JSONItemType) - Constructor for class org.h2.expression.condition.IsJsonPredicate
 
isKeyword(int) - Static method in class org.h2.command.Parser
 
isKeyword(String) - Method in class org.h2.command.Parser
 
isKeyword(String, boolean) - Static method in class org.h2.util.ParserUtil
Checks if this string is a SQL keyword.
isKnownSetting(String) - Static method in class org.h2.engine.ConnectionInfo
 
isKnownVersion(long) - Method in class org.h2.mvstore.MVStore
Check whether all data can be read from this version.
isLargeObject(int) - Static method in class org.h2.value.DataType
Check if the given value type is a large object (BLOB or CLOB).
isLast() - Method in class org.h2.jdbc.JdbcResultSet
Checks if the current position is the last row, that means next() was called and did not yet returned false, but will in the next call.
isLast() - Method in class org.h2.tools.SimpleResultSet
INTERNAL
isLazy() - Method in class org.h2.result.LazyResult
 
isLazy() - Method in class org.h2.result.LocalResult
 
isLazy() - Method in interface org.h2.result.ResultInterface
Check if this a lazy execution result.
isLazy() - Method in class org.h2.result.ResultRemote
 
isLazy() - Method in class org.h2.result.ResultWithPaddedStrings
 
isLazy() - Method in class org.h2.result.SimpleResult
 
isLazyQueryExecution() - Method in class org.h2.engine.SessionLocal
 
isLeaf() - Method in class org.h2.mvstore.Page
Check whether this is a leaf page.
isLeafPosition(long) - Static method in class org.h2.mvstore.DataUtils
Determines whether specified file position corresponds to a leaf page
isLinkedToTable() - Method in class org.h2.value.lob.LobData
 
isLinkedToTable() - Method in class org.h2.value.lob.LobDataDatabase
Check if this value is linked to a specific table.
isLinkedToTable() - Method in class org.h2.value.lob.LobDataFetchOnDemand
Check if this value is linked to a specific table.
isLinkedToTable() - Method in class org.h2.value.ValueLob
Check if this value is linked to a specific table.
isLive() - Method in class org.h2.mvstore.Chunk
 
isLobTable(String) - Static method in class org.h2.tools.Recover
 
isLocalAddress(Socket) - Static method in class org.h2.util.NetUtils
Check if a socket is connected to a local address.
isLocked() - Method in class org.h2.mvstore.RootReference
 
isLockedByCurrentThread() - Method in class org.h2.mvstore.RootReference
 
isLockedExclusive - Variable in class org.h2.store.fs.mem.FileMemData
 
isLockedExclusive - Variable in class org.h2.store.fs.niomem.FileNioMemData
 
isLockedExclusively() - Method in class org.h2.mvstore.db.MVTable
 
isLockedExclusively() - Method in class org.h2.table.Table
Check if this table is locked exclusively.
isLockedExclusivelyBy(SessionLocal) - Method in class org.h2.mvstore.db.MVTable
 
isLockedExclusivelyBy(SessionLocal) - Method in class org.h2.table.Table
Check if the table is exclusively locked by this session.
isMemoryEstimationAllowed() - Method in class org.h2.mvstore.db.NullValueDataType
 
isMemoryEstimationAllowed() - Method in class org.h2.mvstore.MVMap
 
isMemoryEstimationAllowed() - Method in class org.h2.mvstore.MVStoreTool.GenericDataType
 
isMemoryEstimationAllowed() - Method in class org.h2.mvstore.type.BasicDataType
 
isMemoryEstimationAllowed() - Method in interface org.h2.mvstore.type.DataType
Whether memory estimation based on previously seen values is allowed/desirable
isMSSQLServer - Variable in class org.h2.bnf.context.DbContents
 
isMSSQLServer() - Method in class org.h2.bnf.context.DbContents
 
isMySQL - Variable in class org.h2.bnf.context.DbContents
 
isMySQL() - Method in class org.h2.bnf.context.DbContents
 
isMySqlUrl(String) - Static method in class org.h2.table.TableLink
 
isNegative() - Method in class org.h2.api.Interval
Returns where the interval is negative.
isNegative() - Method in class org.h2.value.ValueInterval
Returns where the interval is negative.
isNeverLazy() - Method in class org.h2.command.query.Query
 
isNoFromClause() - Method in class org.h2.command.query.Select
 
isNoFromClauseFilter() - Method in class org.h2.table.TableFilter
Returns whether this is a table filter with implicit DUAL table for a SELECT without a FROM clause.
isNoWait() - Method in class org.h2.schema.TriggerObject
 
isNull() - Method in class org.h2.mvstore.db.SpatialKey
 
isNull() - Method in class org.h2.mvstore.rtree.DefaultSpatial
 
isNull() - Method in interface org.h2.mvstore.rtree.Spatial
Test whether this object has no value
isNull(int) - Method in class org.h2.result.SearchRow
Determine if specified column contains NULL
isNull(int) - Method in class org.h2.result.SimpleRowValue
 
isNull(Value) - Method in class org.h2.expression.aggregate.AggregateDataCollecting
 
isNull(Value) - Static method in class org.h2.index.LinkedIndex
 
ISNULL - Static variable in class org.h2.mode.FunctionsMSSQLServer
 
isNullable() - Method in class org.h2.table.Column
 
isNullable(int) - Method in class org.h2.jdbc.JdbcParameterMetaData
Checks if this is nullable parameter.
isNullable(int) - Method in class org.h2.jdbc.JdbcResultSetMetaData
Checks if this is nullable column.
isNullable(int) - Method in class org.h2.tools.SimpleResultSet
Returns ResultSetMetaData.columnNullableUnknown.
isNullConstant() - Method in class org.h2.expression.Expression
Check if this expression will always return the NULL value.
isNullConstant() - Method in class org.h2.expression.TypedValueExpression
 
isNullConstant() - Method in class org.h2.expression.ValueExpression
 
isNullOrEmpty(String) - Static method in class org.h2.util.StringUtils
Check if a String is null or empty (the length is null).
isNullRow() - Method in class org.h2.table.TableFilter
 
isNullsLast(DefaultNullOrdering, Index) - Static method in class org.h2.expression.aggregate.Percentile
 
isNumber(String) - Static method in class org.h2.util.StringUtils
Check if this string is a decimal number.
isNumberPart(char) - Static method in class org.h2.util.geometry.EWKTUtils.EWKTSource
 
isNumberStart(char) - Static method in class org.h2.util.geometry.EWKTUtils.EWKTSource
 
isNumericType(int) - Static method in class org.h2.value.DataType
Check if the given value type is a numeric type.
ISO_DAY_OF_WEEK - Static variable in class org.h2.expression.function.DateTimeFunction
ISO day of week.
ISO_WEEK - Static variable in class org.h2.expression.function.DateTimeFunction
ISO week.
ISO_WEEK_YEAR - Static variable in class org.h2.expression.function.DateTimeFunction
ISO week-based year.
isOk(Expression) - Method in class org.h2.table.TableFilter
Whether the current value of the condition is true, or there is no condition.
isolationLevel - Variable in class org.h2.command.dml.SetSessionCharacteristics
 
isolationLevel - Variable in class org.h2.engine.SessionLocal
Isolation level.
isolationLevel - Variable in class org.h2.mvstore.tx.Transaction
The current isolation level.
IsolationLevel - Enum in org.h2.engine
Level of isolation.
IsolationLevel(int, int) - Constructor for enum org.h2.engine.IsolationLevel
 
isolationLevelInSelectOrInsertStatement - Variable in class org.h2.engine.Mode
can set the isolation level using WITH {RR|RS|CS|UR}
isOldInformationSchema() - Method in class org.h2.engine.Session
Returns whether INFORMATION_SCHEMA contains old-style tables.
isOldInformationSchema() - Method in class org.h2.engine.SessionLocal
 
isOldInformationSchema() - Method in class org.h2.engine.SessionRemote
 
isOnRollback() - Method in class org.h2.schema.TriggerObject
 
isOnValidRow() - Method in class org.h2.jdbc.JdbcResultSet
 
isOpen() - Method in class org.h2.engine.SessionLocal
 
isOpen() - Method in class org.h2.mvstore.MVStore
 
isOpenOrStopping() - Method in class org.h2.mvstore.MVStore
 
isOption(String, String) - Static method in class org.h2.util.Tool
Check if the argument matches the option.
isOracle - Variable in class org.h2.bnf.context.DbContents
 
isOracle() - Method in class org.h2.bnf.context.DbContents
 
isOracle() - Method in class org.h2.table.TableLink
 
isOrdered() - Method in class org.h2.expression.analysis.Window
Returns true if window ordering clause is specified or ROWS unit is used.
isOrdinaryGroupingSet() - Method in class org.h2.command.Parser
Checks whether current opening parenthesis can be a start of ordinary grouping set.
isOverlap(Spatial, Spatial) - Method in class org.h2.mvstore.rtree.SpatialDataType
Check whether the two objects overlap.
isPageRemoved(long) - Static method in class org.h2.mvstore.DataUtils
Find out if page was removed.
isPageSaved(long) - Static method in class org.h2.mvstore.DataUtils
Find out if page was saved.
isParam(String, String...) - Static method in class org.h2.tools.Csv
 
isParameterized() - Method in class org.h2.expression.analysis.WindowFrameBound
Returns whether bound is defined as n PRECEDING or n FOLLOWING.
isParsingCreateView() - Method in class org.h2.engine.SessionLocal
 
isPersistData() - Method in class org.h2.table.Table
 
isPersistent() - Method in class org.h2.engine.ConnectionInfo
Check if the referenced database is persistent.
isPersistent() - Method in class org.h2.engine.Database
Check if this database is disk-based.
isPersistent() - Method in class org.h2.index.IndexType
Is this index persistent?
isPersistent() - Method in class org.h2.mvstore.MVMap
 
isPersistent() - Method in class org.h2.mvstore.Page
 
isPersistIndexes() - Method in class org.h2.table.Table
 
isPersistUsers() - Method in class org.h2.security.auth.DefaultAuthenticator
If set save users externals defined during the authentication.
isPinned() - Method in class org.h2.mvstore.MVStore.RemovedPageInfo
Find out if removed page was pinned (can not be evacuated to a new chunk).
isPoolable() - Method in class org.h2.jdbc.JdbcStatement
Returns whether this object is poolable.
isPostgreSQL - Variable in class org.h2.bnf.context.DbContents
 
isPostgreSQL() - Method in class org.h2.bnf.context.DbContents
 
isPrepared - Variable in class org.h2.command.query.Query
 
isPrimaryKey() - Method in class org.h2.index.IndexType
Does this index belong to a primary key constraint?
isPrimaryKey() - Method in class org.h2.table.Column
 
isPropertyExpected() - Method in class org.h2.util.json.JSONByteArrayTarget
 
isPropertyExpected() - Method in class org.h2.util.json.JSONStringTarget
 
isPropertyExpected() - Method in class org.h2.util.json.JSONTarget
Returns whether member's name or the end of the current object is expected.
isPropertyExpected() - Method in class org.h2.util.json.JSONValidationTargetWithoutUniqueKeys
 
isPropertyExpected() - Method in class org.h2.util.json.JSONValidationTargetWithUniqueKeys
 
isPropertyExpected() - Method in class org.h2.util.json.JSONValueTarget
 
isQuadraticSplit() - Method in class org.h2.mvstore.rtree.MVRTreeMap
 
isQuery - Variable in class org.h2.command.CommandRemote
 
isQuery() - Method in class org.h2.command.Command
Check if this command is a query.
isQuery() - Method in class org.h2.command.CommandContainer
 
isQuery() - Method in interface org.h2.command.CommandInterface
Check if this is a query.
isQuery() - Method in class org.h2.command.CommandList
 
isQuery() - Method in class org.h2.command.CommandRemote
 
isQuery() - Method in class org.h2.command.dml.Call
 
isQuery() - Method in class org.h2.command.dml.ExecuteProcedure
 
isQuery() - Method in class org.h2.command.dml.Explain
 
isQuery() - Method in class org.h2.command.dml.Help
 
isQuery() - Method in class org.h2.command.dml.ScriptCommand
 
isQuery() - Method in class org.h2.command.Parser
 
isQuery() - Method in class org.h2.command.Prepared
Check if this object is a query.
isQuery() - Method in class org.h2.command.query.Query
 
isQueryComparable() - Method in class org.h2.table.Table
Check whether the table (or view) contains no columns that prevent index conditions to be used.
isQueryComparable() - Method in class org.h2.table.TableView
 
isQueryQuick() - Method in class org.h2.command.Parser
 
isQuickAggregateQuery - Variable in class org.h2.command.query.Select
 
isQuickAggregateQuery() - Method in class org.h2.command.query.Select
Check if this is an aggregate query with direct lookup, for example a query of the type SELECT COUNT(*) FROM TEST or SELECT MAX(ID) FROM TEST.
isQuirksMode() - Method in class org.h2.engine.SessionLocal
Returns whether quirks mode is enabled explicitly or implicitly.
isQuoted() - Method in class org.h2.command.Token.IdentifierToken
 
isQuoted() - Method in class org.h2.command.Token
 
isRandomAccessResult() - Method in class org.h2.command.query.Query
Returns whether results support random access.
isReadCommitted() - Method in class org.h2.mvstore.tx.Transaction
 
isReadOnly - Variable in class org.h2.store.fs.mem.FileMemData
 
isReadOnly - Variable in class org.h2.store.fs.niomem.FileNioMemData
 
isReadOnly() - Method in class org.h2.command.Command
Check if this command is read only.
isReadOnly() - Method in class org.h2.command.CommandContainer
 
isReadOnly() - Method in class org.h2.command.CommandList
 
isReadOnly() - Method in class org.h2.command.ddl.DefineCommand
 
isReadOnly() - Method in class org.h2.command.dml.Call
 
isReadOnly() - Method in class org.h2.command.dml.Explain
 
isReadOnly() - Method in class org.h2.command.dml.Help
 
isReadOnly() - Method in class org.h2.command.dml.NoOperation
 
isReadOnly() - Method in class org.h2.command.Prepared
Check if this command is read only.
isReadOnly() - Method in class org.h2.command.query.Query
 
isReadOnly() - Method in class org.h2.engine.Database
 
isReadOnly() - Method in class org.h2.jdbc.JdbcConnection
Returns true if the database is read-only.
isReadOnly() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns the same as Connection.isReadOnly().
isReadOnly() - Method in class org.h2.jmx.DatabaseInfo
 
isReadOnly() - Method in interface org.h2.jmx.DatabaseInfoMBean
Is the database read-only?
isReadOnly() - Method in class org.h2.mvstore.db.LobStorageMap
 
isReadOnly() - Method in class org.h2.mvstore.FileStore
 
isReadOnly() - Method in class org.h2.mvstore.MVMap
 
isReadOnly() - Method in class org.h2.mvstore.MVStore
Whether the store is read-only.
isReadOnly() - Method in class org.h2.store.LobStorageFrontend
 
isReadOnly() - Method in interface org.h2.store.LobStorageInterface
Whether the storage is read-only
isReadOnly(int) - Method in class org.h2.jdbc.JdbcResultSetMetaData
Checks if this column is read only.
isReadOnly(int) - Method in class org.h2.tools.SimpleResultSet
Returns true.
isRecoveryReference - Variable in class org.h2.value.lob.LobDataDatabase
Fix for recovery tool.
isRecoveryReference() - Method in class org.h2.value.lob.LobDataDatabase
 
isRecursive() - Method in class org.h2.index.ViewIndex
 
isRecursive() - Method in class org.h2.table.TableView
 
isRecursiveQueryDetected - Variable in class org.h2.table.TableView
 
isRecursiveQueryDetected() - Method in class org.h2.table.TableView
Was query recursion detected during compiling.
isRecursiveQueryExceptionDetected(DbException) - Method in class org.h2.table.TableView
Does exception indicate query recursion?
isRemote() - Method in class org.h2.engine.ConnectionInfo
Check if this is a remote connection.
isRemote() - Method in class org.h2.engine.Session
Check if this session is remote or embedded.
isRemote() - Method in class org.h2.engine.SessionLocal
 
isRemote() - Method in class org.h2.engine.SessionRemote
 
isRemoved() - Method in class org.h2.mvstore.Page
 
isRepeatedOperation(long) - Method in class org.h2.mvstore.tx.TxDecisionMaker
Store operation id provided, but before that, compare it against last stored one.
isReplace - Variable in class org.h2.command.dml.Merge
 
isReservedFunctionName(String) - Method in class org.h2.command.Parser
 
isReturnsResult() - Method in class org.h2.bnf.context.DbProcedure
 
isRewritable() - Method in class org.h2.mvstore.Chunk
 
isRewritable(Chunk, long) - Method in class org.h2.mvstore.MVStore
 
isRoleGranted(Role) - Method in class org.h2.engine.RightOwner
Check if a role has been granted for this right owner.
isRoot() - Method in class org.h2.store.fs.mem.FilePathMem
 
isRoot() - Method in class org.h2.store.fs.niomem.FilePathNioMem
 
isRoot() - Method in class org.h2.store.fs.niomem.FilePathNioMemLZF
 
isRowBased() - Method in class org.h2.schema.TriggerObject
 
isRowId() - Method in class org.h2.table.Column
Returns whether this column is a row identity column.
isRowIdIndex() - Method in class org.h2.index.Index
Does this index support lookup by row id?
isRowIdIndex() - Method in class org.h2.mvstore.db.MVDelegateIndex
 
isRowIdIndex() - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
isRowLockable() - Method in class org.h2.mvstore.db.MVTable
 
isRowLockable() - Method in class org.h2.table.Table
Views, function tables, links, etc.
isRubySource(String) - Static method in class org.h2.util.SourceCompiler
 
isRunning(boolean) - Method in class org.h2.server.pg.PgServer
 
isRunning(boolean) - Method in interface org.h2.server.Service
Check if the service is running.
isRunning(boolean) - Method in class org.h2.server.TcpServer
 
isRunning(boolean) - Method in class org.h2.server.web.WebServer
 
isRunning(boolean) - Method in class org.h2.tools.Server
Checks if the server is running.
isSameRM(XAResource) - Method in class org.h2.jdbcx.JdbcXAConnection
Checks if this is the same XAResource.
isSameTransaction(K) - Method in class org.h2.mvstore.tx.TransactionMap
Whether the entry for this key was added or removed from this session.
isSaved() - Method in class org.h2.mvstore.Chunk
 
isSaved() - Method in class org.h2.mvstore.Page
 
isSaveNeeded() - Method in class org.h2.mvstore.MVStore
 
isScan() - Method in class org.h2.index.IndexType
Is this a table scan pseudo-index?
isSchemaObjectTypeDelayed(MetaRecord) - Static method in class org.h2.tools.Recover
 
isSchemaRightGrantedRecursive(Schema) - Method in class org.h2.engine.RightOwner
Checks if a schema owner right is already granted to this object or to objects that were granted to this object.
isSearchable(int) - Method in class org.h2.jdbc.JdbcResultSetMetaData
Checks if this column is searchable.
isSearchable(int) - Method in class org.h2.tools.SimpleResultSet
Returns true.
isSeasonedChunk(Chunk, long) - Method in class org.h2.mvstore.MVStore
 
isSelectTrigger() - Method in class org.h2.schema.TriggerObject
Check whether this is a select trigger.
isSigned(int) - Method in class org.h2.jdbc.JdbcParameterMetaData
Checks if this parameter is signed.
isSigned(int) - Method in class org.h2.jdbc.JdbcResultSetMetaData
Checks if this column is signed.
isSigned(int) - Method in class org.h2.tools.SimpleResultSet
Returns true.
isSimpleColumnName(String) - Static method in class org.h2.tools.Csv
 
isSimpleIdentifier(String) - Method in class org.h2.jdbc.JdbcStatement
 
isSimpleIdentifier(String) - Method in interface org.h2.jdbc.JdbcStatementBackwardsCompat
Checks if specified identifier may be used without quotes.
isSimpleIdentifier(String, boolean, boolean) - Static method in class org.h2.util.ParserUtil
Is this a simple identifier (in the JDBC specification sense).
isSingleWriter() - Method in class org.h2.mvstore.MVMap
 
isSpatial() - Method in class org.h2.index.IndexType
Is this a spatial index?
isSpatialIntersects() - Method in class org.h2.index.IndexCondition
Check if this index condition is of the type spatial column intersects value.
isSQLite - Variable in class org.h2.bnf.context.DbContents
 
isSQLite() - Method in class org.h2.bnf.context.DbContents
 
isSSL() - Method in class org.h2.engine.ConnectionInfo
Check if this is a remote connection with SSL enabled.
isStandardDistinct() - Method in class org.h2.command.query.Query
 
isStart() - Method in class org.h2.index.IndexCondition
Check if this index condition is of the type column larger or equal to value.
isStarting() - Method in class org.h2.engine.Database
Check if the database is currently opening.
isStopped() - Method in class org.h2.server.web.WebServer
 
isStoreKeys() - Method in class org.h2.mvstore.db.RowDataType
 
isStream() - Method in class org.h2.util.CacheObject
 
isStringType(int) - Static method in class org.h2.value.DataType
Check if the given value type is a String (VARCHAR,...).
isSysTableLocked() - Method in class org.h2.engine.Database
Checks if the system table (containing the catalog) is locked.
isSysTableLockedBy(SessionLocal) - Method in class org.h2.engine.Database
Checks if the system table (containing the catalog) is locked by the given session.
isSystem - Variable in class org.h2.bnf.context.DbSchema
True if this is a system schema (for example the INFORMATION_SCHEMA).
isTableExpression - Variable in class org.h2.command.ddl.CreateView
 
isTableExpression - Variable in class org.h2.table.TableView
 
isTableExpression() - Method in class org.h2.table.Table
 
isTableRightGrantedRecursive(Table, int) - Method in class org.h2.engine.RightOwner
Checks if a right is already granted to this object or to objects that were granted to this object.
isTemporary() - Method in class org.h2.engine.DbObject
Check if this object is temporary (for example, a temporary table).
isTemporaryLob(int) - Static method in class org.h2.mvstore.db.LobStorageMap
 
isThisTransaction(int) - Method in class org.h2.mvstore.tx.TxDecisionMaker
Check whether specified transaction id belongs to "current" transaction (transaction we are acting within).
isToken(int) - Method in class org.h2.command.Parser
 
isToken(String) - Method in class org.h2.command.Parser
 
isTrace() - Method in class org.h2.store.fs.rec.FilePathRec
 
isTransactional() - Method in class org.h2.command.Command
Check if this command is transactional.
isTransactional() - Method in class org.h2.command.CommandContainer
 
isTransactional() - Method in class org.h2.command.CommandList
 
isTransactional() - Method in class org.h2.command.ddl.AlterSequence
 
isTransactional() - Method in class org.h2.command.ddl.DefineCommand
 
isTransactional() - Method in class org.h2.command.ddl.DropUser
 
isTransactional() - Method in class org.h2.command.ddl.GrantRevoke
 
isTransactional() - Method in class org.h2.command.dml.AlterTableSet
 
isTransactional() - Method in class org.h2.command.dml.BackupCommand
 
isTransactional() - Method in class org.h2.command.dml.Call
 
isTransactional() - Method in class org.h2.command.dml.DataChangeStatement
 
isTransactional() - Method in class org.h2.command.dml.ExecuteImmediate
 
isTransactional() - Method in class org.h2.command.dml.ExecuteProcedure
 
isTransactional() - Method in class org.h2.command.dml.Explain
 
isTransactional() - Method in class org.h2.command.dml.Help
 
isTransactional() - Method in class org.h2.command.dml.NoOperation
 
isTransactional() - Method in class org.h2.command.dml.ScriptBase
 
isTransactional() - Method in class org.h2.command.dml.Set
 
isTransactional() - Method in class org.h2.command.dml.SetSessionCharacteristics
 
isTransactional() - Method in class org.h2.command.dml.TransactionCommand
 
isTransactional() - Method in class org.h2.command.Prepared
Check if this command is transactional.
isTransactional() - Method in class org.h2.command.query.Query
 
isTrue() - Method in class org.h2.value.Value
Returns whether this value IS TRUE.
isTruncateLargeLength() - Method in class org.h2.engine.SessionLocal
Returns parsing mode of data types with too large length.
isUndoEmpty() - Method in class org.h2.mvstore.tx.TransactionStore
 
isUnion() - Method in class org.h2.command.query.Query
Check if this is a UNION query.
isUnion() - Method in class org.h2.command.query.Select
 
isUnion() - Method in class org.h2.command.query.SelectUnion
 
isUnion() - Method in class org.h2.command.query.TableValueConstructor
 
isUnique() - Method in class org.h2.index.IndexType
Is this a unique index?
isUnnamedInMemory() - Method in class org.h2.engine.ConnectionInfo
Check if the referenced database is an unnamed in-memory database.
isUpdatable - Variable in class org.h2.result.UpdatableRow
 
isUpdatable() - Method in class org.h2.result.UpdatableRow
Check if this result set is updatable.
isUpperSysIdentifier(String) - Static method in class org.h2.engine.Database
 
isUsed() - Method in class org.h2.table.TableFilter
 
isUsed(long, int) - Method in class org.h2.mvstore.FreeSpaceBitSet
Check whether one of the blocks is in use.
isUserSession(SessionLocal) - Method in class org.h2.engine.Database
 
isValid() - Method in class org.h2.engine.DbObject
 
isValid() - Method in class org.h2.expression.analysis.WindowFrame
Checks validity of this frame.
isValid() - Method in class org.h2.store.fs.retry.FileRetryOnInterrupt.FileLockRetry
 
isValid(int) - Method in class org.h2.jdbc.JdbcConnection
Returns true if this connection is still valid.
isValidDate(int, int, int) - Static method in class org.h2.util.DateTimeUtils
Verify if the specified date is valid.
isValueSeparatorExpected() - Method in class org.h2.util.json.JSONByteArrayTarget
 
isValueSeparatorExpected() - Method in class org.h2.util.json.JSONStringTarget
 
isValueSeparatorExpected() - Method in class org.h2.util.json.JSONTarget
Returns whether value separator expected before the next member or value.
isValueSeparatorExpected() - Method in class org.h2.util.json.JSONValidationTargetWithoutUniqueKeys
 
isValueSeparatorExpected() - Method in class org.h2.util.json.JSONValidationTargetWithUniqueKeys
 
isValueSeparatorExpected() - Method in class org.h2.util.json.JSONValueTarget
 
isValueSet() - Method in class org.h2.expression.DomainValueExpression
 
isValueSet() - Method in class org.h2.expression.Expression
Is the value of a parameter set.
isValueSet() - Method in class org.h2.expression.Parameter
 
isValueSet() - Method in interface org.h2.expression.ParameterInterface
Is the value of a parameter set.
isValueSet() - Method in class org.h2.expression.ParameterRemote
 
isValueSet() - Method in class org.h2.expression.ValueExpression
 
isVarArgs() - Method in class org.h2.schema.FunctionAlias.JavaMethod
 
isVariable - Variable in class org.h2.expression.analysis.WindowFrameBound
 
isVariable() - Method in class org.h2.expression.analysis.WindowFrameBound
Returns whether bound is defined with a variable.
isVariableBinary() - Method in class org.h2.engine.SessionLocal
Returns BINARY data type parsing mode.
isVariableBounds() - Method in class org.h2.expression.analysis.WindowFrame
Check if bounds of this frame has variable expressions.
isView - Variable in class org.h2.bnf.context.DbTableOrView
True if this represents a view.
isView - Variable in class org.h2.table.InformationSchemaTable
 
isView() - Method in class org.h2.bnf.context.DbTableOrView
 
isView() - Method in class org.h2.table.InformationSchemaTable
 
isView() - Method in class org.h2.table.Table
 
isView() - Method in class org.h2.table.TableView
 
isVolatile - Variable in class org.h2.mvstore.MVMap
 
isVolatile() - Method in class org.h2.mvstore.MVMap
Whether this is volatile map, meaning that changes are not persisted.
isWhenConditionOperand() - Method in class org.h2.expression.condition.BetweenPredicate
 
isWhenConditionOperand() - Method in class org.h2.expression.condition.CompareLike
 
isWhenConditionOperand() - Method in class org.h2.expression.condition.Comparison
 
isWhenConditionOperand() - Method in class org.h2.expression.condition.ConditionIn
 
isWhenConditionOperand() - Method in class org.h2.expression.condition.ConditionInConstantSet
 
isWhenConditionOperand() - Method in class org.h2.expression.condition.ConditionInParameter
 
isWhenConditionOperand() - Method in class org.h2.expression.condition.ConditionInQuery
 
isWhenConditionOperand() - Method in class org.h2.expression.condition.IsJsonPredicate
 
isWhenConditionOperand() - Method in class org.h2.expression.condition.SimplePredicate
 
isWhenConditionOperand() - Method in class org.h2.expression.Expression
Returns whether this expression is a right side of condition in a when operand.
isWhitespaceOrEmpty(String) - Static method in class org.h2.util.StringUtils
Check if the specified string is empty or contains only whitespace.
isWideningConversion(Column) - Method in class org.h2.table.Column
Check whether the new column is of the same type and not more restricted than this column.
isWindowQuery - Variable in class org.h2.command.query.Select
 
isWindowQuery() - Method in class org.h2.command.query.Select
Checks if this query contains window functions.
isWindows - Variable in class org.h2.tools.Console
 
isWithoutCount() - Method in class org.h2.expression.aggregate.ListaggArguments
Returns the LISTAGG count indication.
isWithTies() - Method in class org.h2.command.query.Query
 
isWrapperFor(Class<?>) - Method in class org.h2.jdbc.JdbcConnection
Checks if unwrap can return an object of this class.
isWrapperFor(Class<?>) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Checks if unwrap can return an object of this class.
isWrapperFor(Class<?>) - Method in class org.h2.jdbc.JdbcParameterMetaData
Checks if unwrap can return an object of this class.
isWrapperFor(Class<?>) - Method in class org.h2.jdbc.JdbcResultSet
Checks if unwrap can return an object of this class.
isWrapperFor(Class<?>) - Method in class org.h2.jdbc.JdbcResultSetMetaData
Checks if unwrap can return an object of this class.
isWrapperFor(Class<?>) - Method in class org.h2.jdbc.JdbcStatement
Checks if unwrap can return an object of this class.
isWrapperFor(Class<?>) - Method in class org.h2.jdbcx.JdbcConnectionPool
Checks if unwrap can return an object of this class.
isWrapperFor(Class<?>) - Method in class org.h2.jdbcx.JdbcDataSource
Checks if unwrap can return an object of this class.
isWrapperFor(Class<?>) - Method in class org.h2.tools.SimpleResultSet
Checks if unwrap can return an object of this class.
isWritable(int) - Method in class org.h2.jdbc.JdbcResultSetMetaData
Checks whether it is possible for a write on this column to succeed.
isWritable(int) - Method in class org.h2.tools.SimpleResultSet
Returns false.
isWriteStoreHeader(Chunk, boolean) - Method in class org.h2.mvstore.MVStore
 
isYearMonth() - Method in enum org.h2.api.IntervalQualifier
Returns whether interval with this qualifier is a year-month interval.
isYearMonthIntervalType(int) - Static method in class org.h2.value.DataType
Check if the given value type is a year-month interval type.
it - Variable in class org.h2.mvstore.db.MVPrimaryIndex.MVStoreCursor
 
it - Variable in class org.h2.mvstore.db.MVSecondaryIndex.MVStoreCursor
 
it - Variable in class org.h2.mvstore.db.MVSpatialIndex.MVStoreCursor
 
itemType - Variable in class org.h2.expression.condition.IsJsonPredicate
 
iterator - Variable in class org.h2.mvstore.db.MVSecondaryIndex.Source
 
iterator - Variable in class org.h2.mvstore.db.MVSpatialIndex.SpatialKeyIterator
 
iterator() - Method in class org.h2.expression.aggregate.AggregateDataCollecting
 
iterator(SessionLocal, ArrayList<Value[]>, SortOrder, int, boolean) - Method in class org.h2.expression.analysis.WindowFrame
Returns iterator.
iterator(Window, SessionLocal, ArrayList<Value[]>, SortOrder, int, boolean) - Static method in class org.h2.expression.analysis.WindowFrame
Returns iterator for the specified frame, or default iterator if frame is null.
Itr(ArrayList<Value[]>) - Constructor for class org.h2.expression.analysis.WindowFrame.Itr
 

J

J - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
JaasCredentialsValidator - Class in org.h2.security.auth.impl
Validate credentials by using standard Java Authentication and Authorization Service
JaasCredentialsValidator() - Constructor for class org.h2.security.auth.impl.JaasCredentialsValidator
 
JaasCredentialsValidator(String) - Constructor for class org.h2.security.auth.impl.JaasCredentialsValidator
Create the validator with the given name of JAAS configuration
JaasCredentialsValidator.AuthenticationInfoCallbackHandler - Class in org.h2.security.auth.impl
 
JakartaDbStarter - Class in org.h2.server.web
This class can be used to start the H2 TCP server (or other H2 servers, for example the PG server) inside a Jakarta web application container such as Tomcat or Jetty.
JakartaDbStarter() - Constructor for class org.h2.server.web.JakartaDbStarter
 
JakartaWebServlet - Class in org.h2.server.web
This servlet lets the H2 Console be used in a Jakarta servlet container such as Tomcat or Jetty.
JakartaWebServlet() - Constructor for class org.h2.server.web.JakartaWebServlet
 
JAVA_COMPILER - Static variable in class org.h2.util.SourceCompiler
The "com.sun.tools.javac.Main" (if available).
JAVA_OBJECT - Static variable in class org.h2.api.H2Type
The JAVA_OBJECT data type.
JAVA_OBJECT - Static variable in class org.h2.mvstore.db.ValueDataType
 
JAVA_OBJECT - Static variable in class org.h2.value.Transfer
 
JAVA_OBJECT - Static variable in class org.h2.value.Value
The value type for JAVA_OBJECT values.
JAVA_OBJECT_SERIALIZER - Static variable in class org.h2.command.dml.SetTypes
The type of a SET JAVA_OBJECT_SERIALIZER statement.
JAVA_OBJECT_SERIALIZER - Static variable in class org.h2.engine.SysProperties
System property h2.javaObjectSerializer (default: null).
JAVA_OBJECT_SERIALIZER_CHANGE_WITH_DATA_TABLE - Static variable in class org.h2.api.ErrorCode
The error with code 90141 is thrown when trying to change the java object serializer while there was already data in the database.
JAVA_SYSTEM_COMPILER - Static variable in class org.h2.engine.SysProperties
System property h2.javaSystemCompiler (default: true).
JavaAggregate - Class in org.h2.expression.aggregate
This class wraps a user-defined aggregate.
JavaAggregate(UserAggregate, Expression[], Select, boolean) - Constructor for class org.h2.expression.aggregate.JavaAggregate
 
JAVAC_SUN - Static variable in class org.h2.util.SourceCompiler
 
javacCompile(String, String, String) - Method in class org.h2.util.SourceCompiler
Compile the given class.
javaClass - Variable in class org.h2.schema.UserAggregate
 
javaClassMethod - Variable in class org.h2.command.ddl.CreateAggregate
 
javaClassMethod - Variable in class org.h2.command.ddl.CreateFunctionAlias
 
JavaClassObject(String, JavaFileObject.Kind) - Constructor for class org.h2.util.SourceCompiler.JavaClassObject
 
javacProcess(Path) - Static method in class org.h2.util.SourceCompiler
 
javacSun(Path) - Static method in class org.h2.util.SourceCompiler
 
javaDecode(String) - Static method in class org.h2.util.StringUtils
Decode a text that is encoded as a Java string literal.
javaEncode(String) - Static method in class org.h2.util.StringUtils
Convert a string to a Java literal using the correct escape sequences.
javaEncode(String, StringBuilder, boolean) - Static method in class org.h2.util.StringUtils
Convert a string to a Java literal using the correct escape sequences.
JavaFunction - Class in org.h2.expression.function
This class wraps a user-defined function.
JavaFunction(FunctionAlias, Expression[]) - Constructor for class org.h2.expression.function.JavaFunction
 
javaMethod - Variable in class org.h2.expression.function.JavaFunction
 
javaMethod - Variable in class org.h2.expression.function.table.JavaTableFunction
 
JavaMethod(Method, int) - Constructor for class org.h2.schema.FunctionAlias.JavaMethod
 
javaMethods - Variable in class org.h2.schema.FunctionAlias
 
javaObjectSerializer - Variable in class org.h2.engine.Database
 
javaObjectSerializer - Variable in class org.h2.engine.SessionRemote
 
JavaObjectSerializer - Interface in org.h2.api
Custom serialization mechanism for java objects being stored in column of type OTHER.
javaObjectSerializerInitialized - Variable in class org.h2.engine.Database
 
javaObjectSerializerName - Variable in class org.h2.engine.Database
 
JavaTableFunction - Class in org.h2.expression.function.table
This class wraps a user-defined function.
JavaTableFunction(FunctionAlias, Expression[]) - Constructor for class org.h2.expression.function.table.JavaTableFunction
 
javaxToolsJavac(String, String, String) - Method in class org.h2.util.SourceCompiler
Compile using the standard java compiler.
jdbc - Variable in enum org.h2.engine.IsolationLevel
 
JDBC - Static variable in class org.h2.message.Trace
The trace module id for the JDBC API.
JdbcArray - Class in org.h2.jdbc
Represents an ARRAY value.
JdbcArray(JdbcConnection, Value, int) - Constructor for class org.h2.jdbc.JdbcArray
INTERNAL
JdbcBatchUpdateException - Exception in org.h2.jdbc
Represents a batch update database exception.
JdbcBatchUpdateException(SQLException, int[]) - Constructor for exception org.h2.jdbc.JdbcBatchUpdateException
INTERNAL
JdbcBatchUpdateException(SQLException, long[]) - Constructor for exception org.h2.jdbc.JdbcBatchUpdateException
INTERNAL
JdbcBlob - Class in org.h2.jdbc
Represents a BLOB value.
JdbcBlob(JdbcConnection, Value, JdbcLob.State, int) - Constructor for class org.h2.jdbc.JdbcBlob
INTERNAL
JdbcCallableStatement - Class in org.h2.jdbc
Represents a callable statement.
JdbcCallableStatement(JdbcConnection, String, int, int, int) - Constructor for class org.h2.jdbc.JdbcCallableStatement
 
JdbcClob - Class in org.h2.jdbc
Represents a CLOB value.
JdbcClob(JdbcConnection, Value, JdbcLob.State, int) - Constructor for class org.h2.jdbc.JdbcClob
INTERNAL
jdbcCompliant() - Method in class org.h2.Driver
Check if this driver is compliant to the JDBC specification.
JdbcConnection - Class in org.h2.jdbc
Represents a connection (session) to a database.
JdbcConnection(String, Properties, String, Object, boolean) - Constructor for class org.h2.jdbc.JdbcConnection
INTERNAL the session closable object does not leak as Eclipse warns - due to the CloseWatcher.
JdbcConnection(Session, String, String) - Constructor for class org.h2.jdbc.JdbcConnection
INTERNAL
JdbcConnection(JdbcConnection) - Constructor for class org.h2.jdbc.JdbcConnection
INTERNAL
JdbcConnectionBackwardsCompat - Interface in org.h2.jdbc
Allows us to compile on older platforms, while still implementing the methods from the newer JDBC API.
JdbcConnectionPool - Class in org.h2.jdbcx
A simple standalone JDBC connection pool.
JdbcConnectionPool(ConnectionPoolDataSource) - Constructor for class org.h2.jdbcx.JdbcConnectionPool
 
JdbcConnectionPoolBackwardsCompat - Interface in org.h2.jdbcx
Allows us to compile on older platforms, while still implementing the methods from the newer JDBC API.
JdbcDatabaseMetaData - Class in org.h2.jdbc
Represents the meta data for a database.
JdbcDatabaseMetaData(JdbcConnection, Trace, int) - Constructor for class org.h2.jdbc.JdbcDatabaseMetaData
 
JdbcDatabaseMetaDataBackwardsCompat - Interface in org.h2.jdbc
Allows us to compile on older platforms, while still implementing the methods from the newer JDBC API.
JdbcDataSource - Class in org.h2.jdbcx
A data source for H2 database connections.
JdbcDataSource() - Constructor for class org.h2.jdbcx.JdbcDataSource
The public constructor.
JdbcDataSourceBackwardsCompat - Interface in org.h2.jdbcx
Allows us to compile on older platforms, while still implementing the methods from the newer JDBC API.
JdbcDataSourceFactory - Class in org.h2.jdbcx
This class is used to create new DataSource objects.
JdbcDataSourceFactory() - Constructor for class org.h2.jdbcx.JdbcDataSourceFactory
The public constructor to create new factory objects.
JdbcDriverBackwardsCompat - Interface in org.h2
Allows us to compile on older platforms, while still implementing the methods from the newer JDBC API.
JdbcException - Interface in org.h2.jdbc
This interface contains additional methods for database exceptions.
JdbcLob - Class in org.h2.jdbc
Represents a large object value.
JdbcLob(JdbcConnection, Value, JdbcLob.State, int, int) - Constructor for class org.h2.jdbc.JdbcLob
 
JdbcLob.LobPipedOutputStream - Class in org.h2.jdbc
 
JdbcLob.State - Enum in org.h2.jdbc
State of the object.
JdbcParameterMetaData - Class in org.h2.jdbc
Information about the parameters of a prepared statement.
JdbcParameterMetaData(Trace, JdbcPreparedStatement, CommandInterface, int) - Constructor for class org.h2.jdbc.JdbcParameterMetaData
 
JdbcPreparedStatement - Class in org.h2.jdbc
Represents a prepared statement.
JdbcPreparedStatement(JdbcConnection, String, int, int, int, Object) - Constructor for class org.h2.jdbc.JdbcPreparedStatement
 
JdbcResultSet - Class in org.h2.jdbc
Represents a result set.
JdbcResultSet(JdbcConnection, JdbcPreparedStatement, CommandInterface, ResultInterface, int, boolean, boolean, HashMap<String, Integer>) - Constructor for class org.h2.jdbc.JdbcResultSet
 
JdbcResultSet(JdbcConnection, JdbcStatement, CommandInterface, ResultInterface, int, boolean, boolean, boolean) - Constructor for class org.h2.jdbc.JdbcResultSet
 
JdbcResultSetMetaData - Class in org.h2.jdbc
Represents the meta data for a ResultSet.
JdbcResultSetMetaData(JdbcResultSet, JdbcPreparedStatement, ResultInterface, String, Trace, int) - Constructor for class org.h2.jdbc.JdbcResultSetMetaData
 
JdbcSavepoint - Class in org.h2.jdbc
A savepoint is a point inside a transaction to where a transaction can be rolled back.
JdbcSavepoint(JdbcConnection, int, String, Trace, int) - Constructor for class org.h2.jdbc.JdbcSavepoint
 
JdbcSQLDataException - Exception in org.h2.jdbc
Represents a database exception.
JdbcSQLDataException(String, String, String, int, Throwable, String) - Constructor for exception org.h2.jdbc.JdbcSQLDataException
Creates a SQLDataException.
JdbcSQLException - Exception in org.h2.jdbc
Represents a database exception.
JdbcSQLException(String, String, String, int, Throwable, String) - Constructor for exception org.h2.jdbc.JdbcSQLException
Creates a SQLException.
JdbcSQLFeatureNotSupportedException - Exception in org.h2.jdbc
Represents a database exception.
JdbcSQLFeatureNotSupportedException(String, String, String, int, Throwable, String) - Constructor for exception org.h2.jdbc.JdbcSQLFeatureNotSupportedException
Creates a SQLFeatureNotSupportedException.
JdbcSQLIntegrityConstraintViolationException - Exception in org.h2.jdbc
Represents a database exception.
JdbcSQLIntegrityConstraintViolationException(String, String, String, int, Throwable, String) - Constructor for exception org.h2.jdbc.JdbcSQLIntegrityConstraintViolationException
Creates a SQLIntegrityConstraintViolationException.
JdbcSQLInvalidAuthorizationSpecException - Exception in org.h2.jdbc
Represents a database exception.
JdbcSQLInvalidAuthorizationSpecException(String, String, String, int, Throwable, String) - Constructor for exception org.h2.jdbc.JdbcSQLInvalidAuthorizationSpecException
Creates a SQLInvalidAuthorizationSpecException.
JdbcSQLNonTransientConnectionException - Exception in org.h2.jdbc
Represents a database exception.
JdbcSQLNonTransientConnectionException(String, String, String, int, Throwable, String) - Constructor for exception org.h2.jdbc.JdbcSQLNonTransientConnectionException
Creates a SQLNonTransientConnectionException.
JdbcSQLNonTransientException - Exception in org.h2.jdbc
Represents a database exception.
JdbcSQLNonTransientException(String, String, String, int, Throwable, String) - Constructor for exception org.h2.jdbc.JdbcSQLNonTransientException
Creates a SQLNonTransientException.
JdbcSQLSyntaxErrorException - Exception in org.h2.jdbc
Represents a database exception.
JdbcSQLSyntaxErrorException(String, String, String, int, Throwable, String) - Constructor for exception org.h2.jdbc.JdbcSQLSyntaxErrorException
Creates a SQLSyntaxErrorException.
JdbcSQLTimeoutException - Exception in org.h2.jdbc
Represents a database exception.
JdbcSQLTimeoutException(String, String, String, int, Throwable, String) - Constructor for exception org.h2.jdbc.JdbcSQLTimeoutException
Creates a SQLTimeoutException.
JdbcSQLTransactionRollbackException - Exception in org.h2.jdbc
Represents a database exception.
JdbcSQLTransactionRollbackException(String, String, String, int, Throwable, String) - Constructor for exception org.h2.jdbc.JdbcSQLTransactionRollbackException
Creates a SQLTransactionRollbackException.
JdbcSQLTransientException - Exception in org.h2.jdbc
Represents a database exception.
JdbcSQLTransientException(String, String, String, int, Throwable, String) - Constructor for exception org.h2.jdbc.JdbcSQLTransientException
Creates a SQLTransientException.
JdbcSQLXML - Class in org.h2.jdbc
Represents a SQLXML value.
JdbcSQLXML(JdbcConnection, Value, JdbcLob.State, int) - Constructor for class org.h2.jdbc.JdbcSQLXML
INTERNAL
JdbcStatement - Class in org.h2.jdbc
Represents a statement.
JdbcStatement(JdbcConnection, int, int, int) - Constructor for class org.h2.jdbc.JdbcStatement
 
JdbcStatementBackwardsCompat - Interface in org.h2.jdbc
Allows us to compile on older platforms, while still implementing the methods from the newer JDBC API.
JdbcUtils - Class in org.h2.util
This is a utility class with JDBC helper functions.
JdbcUtils() - Constructor for class org.h2.util.JdbcUtils
 
JDBCX - Static variable in class org.h2.message.Trace
The trace module id for the JDBCX API
JdbcXAConnection - Class in org.h2.jdbcx
This class provides support for distributed transactions.
JdbcXAConnection(JdbcDataSourceFactory, int, JdbcConnection) - Constructor for class org.h2.jdbcx.JdbcXAConnection
 
JdbcXAConnection.PooledJdbcConnection - Class in org.h2.jdbcx
A pooled connection.
JdbcXid - Class in org.h2.jdbcx
An object of this class represents a transaction id.
JdbcXid(JdbcDataSourceFactory, int, String) - Constructor for class org.h2.jdbcx.JdbcXid
 
JMX - Static variable in class org.h2.engine.Engine
 
JOI_VISITOR - Static variable in class org.h2.table.TableFilter
A visitor that sets joinOuterIndirect to true.
join - Variable in class org.h2.table.TableFilter
The joined table (if there is one).
join() - Method in class org.h2.util.Task
Stop the thread and wait until it is no longer running.
join(int) - Method in class org.h2.server.web.WebThread
Wait until the thread is stopped.
JOIN - Static variable in class org.h2.util.ParserUtil
The token "JOIN".
joinCondition - Variable in class org.h2.table.TableFilter
The complete join condition.
joinOuter - Variable in class org.h2.table.TableFilter
Whether this is an outer join.
joinOuterIndirect - Variable in class org.h2.table.TableFilter
Whether this is a direct or indirect (nested) outer join
joinPlan - Variable in class org.h2.table.PlanItem
 
JSON - org.h2.expression.Format.FormatEnum
JSON.
JSON - Static variable in class org.h2.api.H2Type
The JSON data type.
JSON - Static variable in class org.h2.mvstore.db.ValueDataType
 
JSON - Static variable in class org.h2.value.Transfer
 
JSON - Static variable in class org.h2.value.Value
The value type for JSON values.
JSON_ABSENT_ON_NULL - Static variable in class org.h2.util.json.JsonConstructorUtils
The ABSENT ON NULL flag.
JSON_ARRAYAGG - org.h2.expression.aggregate.AggregateType
The aggregate type for JSON_ARRAYAGG(expression).
JSON_OBJECTAGG - org.h2.expression.aggregate.AggregateType
The aggregate type for JSON_OBJECTAGG(expression: expression).
JSON_TEXT - Static variable in class org.h2.bnf.RuleFixed
 
JSON_WITH_UNIQUE_KEYS - Static variable in class org.h2.util.json.JsonConstructorUtils
The WITH UNIQUE KEYS flag.
jsonArray(SessionLocal, Expression[]) - Method in class org.h2.expression.function.JsonConstructorFunction
 
JSONArray - Class in org.h2.util.json
JSON array.
JSONArray() - Constructor for class org.h2.util.json.JSONArray
 
jsonArrayAppend(ByteArrayOutputStream, Value, int) - Static method in class org.h2.util.json.JsonConstructorUtils
Appends a value to a JSON array in the specified output stream.
JSONBoolean - Class in org.h2.util.json
JSON boolean.
JSONBoolean(boolean) - Constructor for class org.h2.util.json.JSONBoolean
 
JSONByteArrayTarget - Class in org.h2.util.json
JSON byte array target.
JSONByteArrayTarget() - Constructor for class org.h2.util.json.JSONByteArrayTarget
Creates new instance of JSON byte array target.
JSONBytesSource - Class in org.h2.util.json
JSON byte array source.
JSONBytesSource(byte[], JSONTarget<?>) - Constructor for class org.h2.util.json.JSONBytesSource
 
JsonConstructorFunction - Class in org.h2.expression.function
JSON constructor function.
JsonConstructorFunction(boolean) - Constructor for class org.h2.expression.function.JsonConstructorFunction
Creates a new instance of JSON constructor function.
JsonConstructorUtils - Class in org.h2.util.json
Utilities for JSON constructors.
JsonConstructorUtils() - Constructor for class org.h2.util.json.JsonConstructorUtils
 
JSONItemType - Enum in org.h2.util.json
JSON item type.
JSONItemType() - Constructor for enum org.h2.util.json.JSONItemType
 
JSONNull - Class in org.h2.util.json
JSON null.
JSONNull() - Constructor for class org.h2.util.json.JSONNull
 
JSONNumber - Class in org.h2.util.json
JSON number.
JSONNumber(BigDecimal) - Constructor for class org.h2.util.json.JSONNumber
 
jsonObject(SessionLocal, Expression[]) - Method in class org.h2.expression.function.JsonConstructorFunction
 
JSONObject - Class in org.h2.util.json
JSON object.
JSONObject() - Constructor for class org.h2.util.json.JSONObject
 
jsonObjectAppend(ByteArrayOutputStream, String, Value) - Static method in class org.h2.util.json.JsonConstructorUtils
Appends a value to a JSON object in the specified string builder.
jsonObjectFinish(ByteArrayOutputStream, int) - Static method in class org.h2.util.json.JsonConstructorUtils
Appends trailing closing brace to the specified string builder with a JSON object, validates it, and converts to a JSON value.
JSONString - Class in org.h2.util.json
JSON string.
JSONString(String) - Constructor for class org.h2.util.json.JSONString
 
JSONStringSource - Class in org.h2.util.json
JSON string source.
JSONStringSource(String, JSONTarget<?>) - Constructor for class org.h2.util.json.JSONStringSource
 
JSONStringTarget - Class in org.h2.util.json
JSON String target.
JSONStringTarget() - Constructor for class org.h2.util.json.JSONStringTarget
Creates new instance of JSON String target.
JSONStringTarget(boolean) - Constructor for class org.h2.util.json.JSONStringTarget
Creates new instance of JSON String target.
JSONTarget<R> - Class in org.h2.util.json
Abstract JSON output target.
JSONTarget() - Constructor for class org.h2.util.json.JSONTarget
 
JSONTextSource - Class in org.h2.util.json
JSON text source.
JSONTextSource(JSONTarget<?>) - Constructor for class org.h2.util.json.JSONTextSource
 
JSONValidationTarget - Class in org.h2.util.json
JSON validation target.
JSONValidationTarget() - Constructor for class org.h2.util.json.JSONValidationTarget
 
JSONValidationTargetWithoutUniqueKeys - Class in org.h2.util.json
JSON validation target without unique keys.
JSONValidationTargetWithoutUniqueKeys() - Constructor for class org.h2.util.json.JSONValidationTargetWithoutUniqueKeys
Creates new instance of JSON validation target without unique keys.
JSONValidationTargetWithUniqueKeys - Class in org.h2.util.json
JSON validation target with unique keys.
JSONValidationTargetWithUniqueKeys() - Constructor for class org.h2.util.json.JSONValidationTargetWithUniqueKeys
Creates new instance of JSON validation target with unique keys.
JSONValue - Class in org.h2.util.json
JSON value.
JSONValue() - Constructor for class org.h2.util.json.JSONValue
 
JSONValueTarget - Class in org.h2.util.json
JSON value target.
JSONValueTarget() - Constructor for class org.h2.util.json.JSONValueTarget
Creates new instance of JSON value target.
JSR310Utils - Class in org.h2.util
This utility class provides access to JSR 310 classes.
JSR310Utils() - Constructor for class org.h2.util.JSR310Utils
 
JTSUtils - Class in org.h2.util.geometry
Utilities for Geometry data type from JTS library.
JTSUtils() - Constructor for class org.h2.util.geometry.JTSUtils
 
JTSUtils.GeometryTarget - Class in org.h2.util.geometry
Converter output target that creates a JTS Geometry.
JULIAN_EPOCH - Static variable in class org.h2.expression.function.ToCharFunction
The beginning of the Julian calendar.

K

k0 - Variable in class org.h2.security.XTEA
 
k1 - Variable in class org.h2.security.XTEA
 
k10 - Variable in class org.h2.security.XTEA
 
k11 - Variable in class org.h2.security.XTEA
 
k12 - Variable in class org.h2.security.XTEA
 
k13 - Variable in class org.h2.security.XTEA
 
k14 - Variable in class org.h2.security.XTEA
 
k15 - Variable in class org.h2.security.XTEA
 
k16 - Variable in class org.h2.security.XTEA
 
k17 - Variable in class org.h2.security.XTEA
 
k18 - Variable in class org.h2.security.XTEA
 
k19 - Variable in class org.h2.security.XTEA
 
k2 - Variable in class org.h2.security.XTEA
 
k20 - Variable in class org.h2.security.XTEA
 
k21 - Variable in class org.h2.security.XTEA
 
k22 - Variable in class org.h2.security.XTEA
 
k23 - Variable in class org.h2.security.XTEA
 
k24 - Variable in class org.h2.security.XTEA
 
k25 - Variable in class org.h2.security.XTEA
 
k26 - Variable in class org.h2.security.XTEA
 
k27 - Variable in class org.h2.security.XTEA
 
k28 - Variable in class org.h2.security.XTEA
 
k29 - Variable in class org.h2.security.XTEA
 
k3 - Variable in class org.h2.security.XTEA
 
k30 - Variable in class org.h2.security.XTEA
 
k31 - Variable in class org.h2.security.XTEA
 
k4 - Variable in class org.h2.security.XTEA
 
k5 - Variable in class org.h2.security.XTEA
 
k6 - Variable in class org.h2.security.XTEA
 
k7 - Variable in class org.h2.security.XTEA
 
k8 - Variable in class org.h2.security.XTEA
 
k9 - Variable in class org.h2.security.XTEA
 
keeper - Variable in class org.h2.mvstore.Cursor
 
keepOpenStackTrace - Static variable in class org.h2.jdbc.JdbcConnection
 
key - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Entry
The key.
key - Variable in class org.h2.mvstore.tx.Record
Key of the changed map entry key
key - Variable in class org.h2.mvstore.tx.TransactionStore.Change
The key.
key - Variable in class org.h2.mvstore.tx.TxDecisionMaker
Key for the map entry to decide upon
key - Variable in class org.h2.result.SearchRow
The row key.
key - Variable in class org.h2.result.UpdatableRow
 
key - Variable in class org.h2.security.Fog
 
key - Variable in class org.h2.security.SecureFileStore
 
key - Variable in class org.h2.server.pg.PgServer
 
key - Variable in class org.h2.server.TcpServer
 
key - Variable in class org.h2.server.web.WebServer
 
key - Variable in class org.h2.util.SoftValuesHashMap.SoftValue
 
KEY - Static variable in class org.h2.util.ParserUtil
The token "KEY".
KEY_COLUMN_USAGE - Static variable in class org.h2.table.InformationSchemaTable
 
KEY_COLUMN_USAGE - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
keyColumnUsage(SessionLocal, ArrayList<Row>, String, Constraint, Constraint.Type, IndexColumn[], Table, String) - Method in class org.h2.table.InformationSchemaTable
 
keyColumnUsage(SessionLocal, Value, Value, ArrayList<Row>, String) - Method in class org.h2.table.InformationSchemaTable
 
keyDatabase - Variable in class org.h2.server.pg.PgServer
 
keyDatabase - Variable in class org.h2.server.TcpServer
 
keyIterations - Variable in class org.h2.security.SecureFileStore
 
keyIterator(K) - Method in class org.h2.mvstore.MVMap
Iterate over a number of keys.
keyIterator(K) - Method in class org.h2.mvstore.tx.TransactionMap
Iterate over keys.
keyIterator(K, boolean) - Method in class org.h2.mvstore.tx.TransactionMap
Iterate over keys in the specified order.
keyIterator(K, K) - Method in class org.h2.mvstore.tx.TransactionMap
Iterate over keys.
keyIteratorReverse(K) - Method in class org.h2.mvstore.MVMap
Iterate over a number of keys in reverse order
keyIteratorUncommitted(K, K) - Method in class org.h2.mvstore.tx.TransactionMap
Iterate over keys, including keys from uncommitted entries.
keyList() - Method in class org.h2.mvstore.MVMap
Get the key list.
keys - Variable in class org.h2.command.dml.Merge
 
keys - Variable in class org.h2.fulltext.FullTextLucene.FullTextTrigger
 
keys - Variable in class org.h2.fulltext.IndexInfo
The column indexes of the key columns.
keys - Variable in class org.h2.mvstore.Page
The keys.
keys() - Method in class org.h2.util.SortedProperties
 
keys(boolean, boolean) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Get the list of keys.
keys(boolean, boolean) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
Get the list of keys.
keysBuffer - Variable in class org.h2.mvstore.MVMap
 
keySet() - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Get the set of keys for resident entries.
keySet() - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
Get the set of keys for resident entries.
keySet() - Method in class org.h2.mvstore.MVMap
 
keysPerPage - Variable in class org.h2.mvstore.MVMap
 
keysPerPage - Variable in class org.h2.mvstore.MVStore
 
keysPerPage(int) - Method in class org.h2.mvstore.MVStore.Builder
Set the number of keys per page.
KEYSTORE - Static variable in class org.h2.security.CipherFactory
 
KEYSTORE_KEY - Static variable in class org.h2.security.CipherFactory
 
KEYSTORE_PASSWORD - Static variable in class org.h2.security.CipherFactory
The default password to use for the .h2.keystore file
KEYSTORE_PASSWORD_KEY - Static variable in class org.h2.security.CipherFactory
 
keyType - Variable in class org.h2.mvstore.MVMap.BasicBuilder
 
keyType - Variable in class org.h2.mvstore.MVMap
 
keyType - Variable in class org.h2.mvstore.rtree.MVRTreeMap.ContainsRTreeCursor
 
keyType - Variable in class org.h2.mvstore.rtree.MVRTreeMap.IntersectsRTreeCursor
 
keyType - Variable in class org.h2.mvstore.rtree.MVRTreeMap
The spatial key type.
keyType - Variable in class org.h2.mvstore.tx.TransactionMap.RepeatableIterator
 
keyType(DataType<? super K>) - Method in class org.h2.mvstore.MVMap.BasicBuilder
Set the key data type.
keyType(DataType<? super K>) - Method in class org.h2.mvstore.MVMap.Builder
 
keyword - Variable in class org.h2.bnf.RuleElement
 
KEYWORD - Static variable in class org.h2.bnf.Sentence
The token type for a keyword.
KEYWORD - Static variable in class org.h2.util.ParserUtil
A keyword.
KeywordOrIdentifierToken(int, int, String) - Constructor for class org.h2.command.Token.KeywordOrIdentifierToken
 
KEYWORDS - Static variable in class org.h2.util.ParserUtil
 
KeywordToken(int, int) - Constructor for class org.h2.command.Token.KeywordToken
 
KNOWN_DEADLOCKS - Static variable in class org.h2.util.AbbaDetector
 
KNOWN_SETTINGS - Static variable in class org.h2.engine.ConnectionInfo
 
knownDeadlocks - Variable in class org.h2.util.AbbaLockingDetector
 
knownErrors - Variable in class org.h2.store.RecoverTester
 

L

l - Variable in class org.h2.command.query.SelectUnion.LazyResultUnion
 
label - Variable in class org.h2.value.ValueEnumBase
 
LAG - org.h2.expression.analysis.WindowFunctionType
The type for LAG() window function.
languages - Variable in class org.h2.server.web.WebServer
 
LANGUAGES - Static variable in class org.h2.server.web.WebServer
 
last - Variable in class org.h2.command.dml.SetClauseList.SetMultiple
 
last - Variable in class org.h2.index.ViewCursor
 
last - Variable in class org.h2.index.VirtualTableCursor
 
last - Variable in class org.h2.mvstore.Cursor
 
last - Variable in class org.h2.mvstore.type.ObjectDataType
 
last() - Method in class org.h2.jdbc.JdbcResultSet
Moves the current position to the last row.
last() - Method in class org.h2.tools.SimpleResultSet
INTERNAL
LAST - org.h2.mode.DefaultNullOrdering
NULL values are sorted after other values, no matter if ascending or descending order is used.
LAST - Static variable in class org.h2.message.TraceObject
 
LAST_INSERT_ID - Static variable in class org.h2.mode.FunctionsMySQL
 
LAST_KEYWORD - Static variable in class org.h2.util.ParserUtil
The ordinal number of the last keyword.
LAST_VALUE - org.h2.expression.analysis.WindowFunctionType
The type for LAST_VALUE() window function.
lastAccess - Variable in class org.h2.server.web.ConnectionInfo
The last time this connection was used.
lastAccess - Variable in class org.h2.server.web.WebSession
The last time this client sent a request.
lastChunk - Variable in class org.h2.mvstore.MVStore
The newest chunk.
lastChunkId - Variable in class org.h2.mvstore.MVStore
 
lastChunkVersion() - Method in class org.h2.mvstore.MVStore
 
lastCommitTime - Variable in class org.h2.mvstore.MVStore
 
lastConfigProperties - Variable in class org.h2.security.auth.H2AuthConfigXml
 
lastEntry() - Method in class org.h2.mvstore.tx.TransactionMap
Get the last entry.
lastEvaluated - Variable in class org.h2.command.query.Query
 
lastExists - Variable in class org.h2.command.query.Query
 
lastGroupRowId - Variable in class org.h2.expression.analysis.DataAnalysisOperation
 
lastId - Variable in class org.h2.util.SmallMap
 
lastIdentity - Variable in class org.h2.engine.SessionLocal
 
lastKey - Variable in class org.h2.mvstore.db.MVPrimaryIndex
 
lastKey() - Method in class org.h2.mvstore.MVMap
Get the last key, or null if the map is empty.
lastKey() - Method in class org.h2.mvstore.tx.TransactionMap
Get the last key.
lastLimit - Variable in class org.h2.command.query.Query
 
lastMapId - Variable in class org.h2.mvstore.MVStore
 
lastMatchedSchema - Variable in class org.h2.bnf.Sentence
 
lastMatchedTable - Variable in class org.h2.bnf.Sentence
 
lastModificationCheck - Variable in class org.h2.table.TableView
 
lastModificationId - Variable in class org.h2.mvstore.db.MVTable
 
lastModified - Variable in class org.h2.store.fs.mem.FileMemData
 
lastModified - Variable in class org.h2.store.fs.niomem.FileNioMemData
 
lastModified() - Method in class org.h2.store.fs.disk.FilePathDisk
 
lastModified() - Method in class org.h2.store.fs.FilePath
Get the last modified date of a file
lastModified() - Method in class org.h2.store.fs.FilePathWrapper
 
lastModified() - Method in class org.h2.store.fs.mem.FilePathMem
 
lastModified() - Method in class org.h2.store.fs.niomem.FilePathNioMem
 
lastModified() - Method in class org.h2.store.fs.split.FilePathSplit
 
lastModified() - Method in class org.h2.store.fs.zip.FilePathZip
 
lastModified(String) - Static method in class org.h2.store.fs.FileUtils
Get the last modified date of a file.
lastOpenNs - Variable in class org.h2.tools.GUIConsole
 
lastOperationId - Variable in class org.h2.mvstore.tx.TxDecisionMaker
Id of the last operation, we decided to MVMap.Decision.REPEAT.
lastPage - Variable in class org.h2.mvstore.Cursor
 
lastParameters - Variable in class org.h2.command.query.Query
 
lastReconnect - Variable in class org.h2.engine.SessionRemote
 
lastRemoteSettingsId - Variable in class org.h2.server.TcpServerThread
 
lastRepeat - Variable in class org.h2.bnf.Bnf
 
lastResult - Variable in class org.h2.command.query.Query
 
lastTable - Variable in class org.h2.bnf.Sentence
 
lastThrottleNs - Variable in class org.h2.engine.SessionLocal
 
lastTimeAbsolute - Variable in class org.h2.mvstore.MVStore
 
lastTimeoutCheck - Variable in class org.h2.server.web.WebServer
 
lastUpdateTime - Variable in class org.h2.engine.QueryStatisticsData.QueryEntry
The last time the statistics for this entry were updated, in milliseconds since 1970.
lastUsed - Variable in class org.h2.util.CacheTQ
 
lastUsed - Static variable in class org.h2.value.CompareMode
 
LASTVAL - Static variable in class org.h2.mode.FunctionsPostgreSQL
 
lastValue - Variable in class org.h2.expression.Variable
 
lastValue - Variable in class org.h2.mvstore.Cursor
 
lastValue - Variable in class org.h2.mvstore.tx.TxDecisionMaker
 
lastWrite - Variable in class org.h2.store.FileLock
The last time the lock file was written.
layout - Variable in class org.h2.mvstore.MVStore
The layout map.
layoutRootPos - Variable in class org.h2.mvstore.Chunk
The position of the root of layout map.
LAZY_QUERY_EXECUTION - Static variable in class org.h2.command.dml.SetTypes
The type of SET LAZY_QUERY_EXECUTION statement.
lazyQueryExecution - Variable in class org.h2.engine.SessionLocal
 
LazyResult - Class in org.h2.result
Lazy execution support for queries.
LazyResult(SessionLocal, Expression[]) - Constructor for class org.h2.result.LazyResult
 
LazyResultGroupSorted(Expression[], int) - Constructor for class org.h2.command.query.Select.LazyResultGroupSorted
 
LazyResultQueryFlat(Expression[], int, boolean) - Constructor for class org.h2.command.query.Select.LazyResultQueryFlat
 
LazyResultSelect(Expression[], int) - Constructor for class org.h2.command.query.Select.LazyResultSelect
 
LazyResultUnion(Expression[], int) - Constructor for class org.h2.command.query.SelectUnion.LazyResultUnion
 
LdapCredentialsValidator - Class in org.h2.security.auth.impl
Validate credentials by performing an LDAP bind
LdapCredentialsValidator() - Constructor for class org.h2.security.auth.impl.LdapCredentialsValidator
 
LEAD - org.h2.expression.analysis.WindowFunctionType
The type for LEAD() window function.
leading - Variable in class org.h2.api.Interval
Non-negative long with value of leading field.
leading - Variable in class org.h2.value.ValueInterval
 
LEADING - Static variable in class org.h2.expression.function.TrimFunction
The LEADING flag.
LEADING_MAX - Static variable in class org.h2.util.IntervalUtils
 
LEADING_MIN - Static variable in class org.h2.util.IntervalUtils
 
leadingExact(BigInteger) - Static method in class org.h2.util.IntervalUtils
 
Leaf(MVMap<K, V>) - Constructor for class org.h2.mvstore.Page.Leaf
 
Leaf(MVMap<K, V>, K[], V[]) - Constructor for class org.h2.mvstore.Page.Leaf
 
Leaf(MVMap<K, V>, Page.Leaf<K, V>) - Constructor for class org.h2.mvstore.Page.Leaf
 
leafCount - Variable in class org.h2.mvstore.MVStore
 
LEAST - Static variable in class org.h2.expression.function.CoalesceFunction
LEAST() (non-standard).
left - Variable in class org.h2.command.query.SelectUnion
The left hand side of the union (the first subquery).
left - Variable in class org.h2.expression.condition.BetweenPredicate
 
left - Variable in class org.h2.expression.condition.CompareLike
 
left - Variable in class org.h2.expression.condition.Comparison
 
left - Variable in class org.h2.expression.condition.ConditionAndOr
 
left - Variable in class org.h2.expression.condition.ConditionIn
 
left - Variable in class org.h2.expression.condition.ConditionInConstantSet
 
left - Variable in class org.h2.expression.condition.ConditionInParameter
 
left - Variable in class org.h2.expression.condition.ConditionInQuery
 
left - Variable in class org.h2.expression.condition.IsJsonPredicate
 
left - Variable in class org.h2.expression.condition.SimplePredicate
The left hand side of the expression.
left - Variable in class org.h2.expression.Operation1_2
The left part of the operation (the first argument).
left - Variable in class org.h2.expression.Operation2
The left part of the operation (the first argument).
LEFT - Static variable in class org.h2.expression.function.StringFunction2
LEFT() (non-standard).
LEFT - Static variable in class org.h2.util.ParserUtil
The token "LEFT".
leftDone - Variable in class org.h2.command.query.SelectUnion.LazyResultUnion
 
LEGACY - org.h2.engine.Mode.ModeEnum
 
LEGACY_ALGORITHMS_SECURITY_KEY - Static variable in class org.h2.security.CipherFactory
The security property which can prevent anonymous TLS connections.
legacyClassToType(Class<?>) - Static method in class org.h2.util.LegacyDateTimeUtils
Get the type information for the given legacy Java class.
LegacyDateTimeUtils - Class in org.h2.util
Date and time utilities for Date, Time, and Timestamp classes.
LegacyDateTimeUtils() - Constructor for class org.h2.util.LegacyDateTimeUtils
 
legacyObjectToValue(CastDataProvider, Object) - Static method in class org.h2.util.LegacyDateTimeUtils
Convert a legacy Java object to a value.
len - Variable in class org.h2.mvstore.Chunk
The length in number of blocks.
len - Variable in class org.h2.server.web.PageParser
 
len - Variable in class org.h2.util.CacheLRU
The number of cache buckets.
LEN - Static variable in class org.h2.mode.FunctionsMSSQLServer
 
length - Variable in class org.h2.mvstore.StreamStore.Stream
 
length - Variable in class org.h2.store.CountingReaderInputStream
 
length - Variable in class org.h2.store.fs.mem.FileMemData
 
length - Variable in class org.h2.store.fs.niomem.FileNioMemData
 
length - Variable in class org.h2.store.fs.split.FileSplit
 
length - Variable in class org.h2.store.fs.zip.FileZip
 
length - Variable in class org.h2.util.json.JSONBytesSource
 
length - Variable in class org.h2.util.json.JSONStringSource
 
length() - Method in class org.h2.jdbc.JdbcBlob
Returns the length.
length() - Method in class org.h2.jdbc.JdbcClob
Returns the length.
length() - Method in class org.h2.store.Data
Get the current write position of this buffer, which is the current length.
length() - Method in class org.h2.store.FileStore
Get the file size in bytes.
length() - Method in class org.h2.store.fs.mem.FileMemData
Get the file length.
length() - Method in class org.h2.store.fs.niomem.FileNioMemData
Get the file length.
length(byte[]) - Method in class org.h2.mvstore.StreamStore
Calculate the number of data bytes for the given id.
LengthFunction - Class in org.h2.expression.function
CHAR_LENGTH(), or OCTET_LENGTH() function.
LengthFunction(Expression, int) - Constructor for class org.h2.expression.function.LengthFunction
 
level - Variable in class org.h2.compress.CompressDeflate
 
levelFile - Variable in class org.h2.message.TraceSystem
 
levelMax - Variable in class org.h2.message.TraceSystem
 
levelSystemOut - Variable in class org.h2.message.TraceSystem
 
LIKE - org.h2.expression.condition.CompareLike.LikeType
LIKE.
LIKE - Static variable in class org.h2.util.ParserUtil
The token "LIKE".
LIKE_ESCAPE_ERROR_1 - Static variable in class org.h2.api.ErrorCode
The error with code 22025 is thrown when using an invalid escape character sequence for LIKE or REGEXP.
likeType - Variable in class org.h2.expression.condition.CompareLike
 
LikeType() - Constructor for enum org.h2.expression.condition.CompareLike.LikeType
 
limit - Variable in class org.h2.engine.Mode
Whether LIMIT / OFFSET clauses are supported.
limit - Variable in class org.h2.result.LazyResult
 
limit - Variable in class org.h2.result.LocalResult
 
limit - Variable in class org.h2.store.RangeInputStream
 
limit - Variable in class org.h2.store.RangeReader
 
limit() - Method in class org.h2.mvstore.WriteBuffer
Get the limit.
limit(int) - Method in class org.h2.mvstore.WriteBuffer
Set the limit, possibly growing the buffer.
LIMIT - Static variable in class org.h2.util.ParserUtil
The token "LIMIT".
limitsWereApplied - Variable in class org.h2.result.LocalResult
 
limitsWereApplied() - Method in class org.h2.command.CommandContainer.GeneratedKeysCollector
 
limitsWereApplied() - Method in class org.h2.command.dml.Insert
 
limitsWereApplied() - Method in class org.h2.expression.condition.UniquePredicate.Target
 
limitsWereApplied() - Method in class org.h2.result.LocalResult
 
limitsWereApplied() - Method in interface org.h2.result.ResultTarget
A hint that sorting, offset and limit may be ignored by this result because they were applied during the query.
limitsWereApplied() - Method in class org.h2.result.SimpleResult
 
LINE_SEPARATOR - Static variable in class org.h2.util.Profiler
 
LINE_STRING - Static variable in class org.h2.util.geometry.GeometryUtils
LINESTRING geometry type.
lineComment - Variable in class org.h2.tools.Csv
 
lineSeparator - Variable in class org.h2.command.dml.ScriptCommand
 
lineSeparator - Variable in class org.h2.message.Trace
 
lineSeparator - Variable in class org.h2.tools.Csv
 
lineSeparatorString - Variable in class org.h2.command.dml.ScriptCommand
 
link - Variable in class org.h2.bnf.RuleElement
 
link - Variable in class org.h2.index.LinkedIndex
 
linkConnections - Variable in class org.h2.engine.Database
 
LinkedCursor - Class in org.h2.index
The cursor implementation for the linked index.
LinkedCursor(TableLink, ResultSet, SessionLocal, String, PreparedStatement) - Constructor for class org.h2.index.LinkedCursor
 
linkedIndex - Variable in class org.h2.table.TableLink
 
LinkedIndex - Class in org.h2.index
A linked index is a index for a linked (remote) table.
LinkedIndex(TableLink, int, IndexColumn[], int, IndexType) - Constructor for class org.h2.index.LinkedIndex
 
LinkSchemaFunction - Class in org.h2.expression.function.table
A LINK_SCHEMA function.
LinkSchemaFunction() - Constructor for class org.h2.expression.function.table.LinkSchemaFunction
 
linkStatements() - Method in class org.h2.bnf.Bnf
Cross-link all statements with each other.
linkToSource(String) - Static method in class org.h2.server.web.WebApp
 
list - Variable in class org.h2.bnf.RuleList
 
list - Variable in class org.h2.expression.ExpressionList
 
list - Variable in class org.h2.store.fs.split.FileSplit
 
LISTAGG - org.h2.expression.aggregate.AggregateType
The aggregate type for LISTAGG(...).
ListaggArguments - Class in org.h2.expression.aggregate
Additional arguments of LISTAGG aggregate function.
ListaggArguments() - Constructor for class org.h2.expression.aggregate.ListaggArguments
Creates a new instance of additional arguments of LISTAGG aggregate function.
listen() - Method in class org.h2.server.pg.PgServer
 
listen() - Method in interface org.h2.server.Service
Listen for incoming connections.
listen() - Method in class org.h2.server.TcpServer
 
listen() - Method in class org.h2.server.web.WebServer
 
listener - Variable in class org.h2.mvstore.tx.RollbackDecisionMaker
 
listener - Variable in class org.h2.mvstore.tx.Transaction
Listener for this transaction's rollback changes.
listeners - Variable in class org.h2.jdbcx.JdbcXAConnection
 
listenerThread - Variable in class org.h2.server.TcpServer
 
listenerThread - Variable in class org.h2.server.web.WebServer
 
listMode - Variable in class org.h2.tools.Shell
 
listSessions() - Method in class org.h2.jmx.DatabaseInfo
 
listSessions() - Method in interface org.h2.jmx.DatabaseInfoMBean
List sessions, including the queries that are in progress, and locked tables.
listSettings() - Method in class org.h2.jmx.DatabaseInfo
 
listSettings() - Method in interface org.h2.jmx.DatabaseInfoMBean
List the database settings.
LITERAL - Static variable in class org.h2.command.Token
Token with literal.
LITERALS_ARE_NOT_ALLOWED - Static variable in class org.h2.api.ErrorCode
The error with code 90116 is thrown when trying use a literal in a SQL statement if literals are disabled.
literalsChecked - Variable in class org.h2.command.Parser
 
LiteralToken(int) - Constructor for class org.h2.command.Token.LiteralToken
 
LN - Static variable in class org.h2.expression.function.MathFunction1
LN().
load() - Static method in class org.h2.Driver
INTERNAL
load() - Method in class org.h2.schema.FunctionAlias
 
load() - Method in class org.h2.schema.TriggerObject
 
load() - Method in class org.h2.store.FileLock
Load the properties file.
load(String) - Static method in class org.h2.util.JdbcUtils
Load the driver class for the given URL, if the database URL is known.
loadBnf() - Method in class org.h2.server.web.WebSession
Load the SQL grammar BNF.
loadClass() - Method in class org.h2.schema.FunctionAlias
 
loadClass(String) - Method in interface org.h2.util.Utils.ClassFactory
Load the class.
LOADER - Static variable in class org.h2.util.SourceCompiler.GroovyCompiler
 
loadFont() - Method in class org.h2.tools.GUIConsole
 
loadFromSource() - Method in class org.h2.schema.FunctionAlias
 
loadFromSource() - Method in class org.h2.schema.TriggerObject
 
loadH2(int) - Static method in class org.h2.tools.Upgrade
Loads the specified version of H2 in a separate class loader.
loadImage(String) - Static method in class org.h2.tools.GUIConsole
 
loadProperties() - Method in class org.h2.server.web.WebServer
 
loadProperties(String) - Static method in class org.h2.util.SortedProperties
Load a properties object from a file.
loadResource(String) - Static method in class org.h2.util.Utils
 
loadRow(ResultSet, int, ArrayList<String[]>) - Method in class org.h2.tools.Shell
 
loadUserClass(String) - Static method in class org.h2.util.JdbcUtils
Load a class, but check if it is allowed to load this class first.
LOB_CLIENT_MAX_SIZE_MEMORY - Static variable in class org.h2.engine.SysProperties
System property h2.lobClientMaxSizeMemory (default: 1048576).
LOB_CLOSED_ON_TIMEOUT_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90039 is thrown when trying to access a CLOB or BLOB object that timed out.
LOB_MAC_SALT_LENGTH - Static variable in class org.h2.value.Transfer
 
LOB_MAGIC - Static variable in class org.h2.value.Transfer
 
LOB_READ - Static variable in class org.h2.engine.SessionRemote
 
lobBlockSize - Variable in class org.h2.command.dml.ScriptCommand
 
lobCloseBetweenReads - Static variable in class org.h2.engine.SysProperties
System property h2.lobCloseBetweenReads (default: false).
lobData - Variable in class org.h2.value.ValueLob
 
LobData - Class in org.h2.value.lob
LOB data.
LobData() - Constructor for class org.h2.value.lob.LobData
 
LobDataDatabase - Class in org.h2.value.lob
LOB data stored in database.
LobDataDatabase(DataHandler, int, long) - Constructor for class org.h2.value.lob.LobDataDatabase
 
LobDataFetchOnDemand - Class in org.h2.value.lob
A implementation of the LOB data used on the client side of a remote H2 connection.
LobDataFetchOnDemand(DataHandler, int, long, byte[]) - Constructor for class org.h2.value.lob.LobDataFetchOnDemand
 
LobDataFile - Class in org.h2.value.lob
LOB data stored in a temporary file.
LobDataFile(DataHandler, String, FileStore) - Constructor for class org.h2.value.lob.LobDataFile
 
LobDataInMemory - Class in org.h2.value.lob
LOB data stored in memory.
LobDataInMemory(byte[]) - Constructor for class org.h2.value.lob.LobDataInMemory
 
lobFileListCache - Variable in class org.h2.engine.Database
 
lobId - Variable in class org.h2.mvstore.db.LobStorageMap.BlobReference
 
lobId - Variable in class org.h2.store.LobStorageRemoteInputStream
The lob id.
lobId - Variable in class org.h2.value.lob.LobDataDatabase
 
lobId - Variable in class org.h2.value.lob.LobDataFetchOnDemand
 
LobInputStream(InputStream) - Constructor for class org.h2.mvstore.db.LobStorageMap.LobInputStream
 
lobMacSalt - Variable in class org.h2.value.Transfer
 
lobMap - Variable in class org.h2.mvstore.db.LobStorageMap
The lob metadata map.
lobMaps - Variable in class org.h2.tools.Recover
 
LobPipedOutputStream(PipedInputStream, Task) - Constructor for class org.h2.jdbc.JdbcLob.LobPipedOutputStream
 
lobs - Variable in class org.h2.server.TcpServerThread
 
lobSession - Variable in class org.h2.engine.Database
 
lobStorage - Variable in class org.h2.engine.Database
 
lobStorage - Variable in class org.h2.engine.SessionRemote
 
LobStorageFrontend - Class in org.h2.store
This factory creates in-memory objects and temporary files.
LobStorageFrontend(SessionRemote) - Constructor for class org.h2.store.LobStorageFrontend
 
LobStorageInterface - Interface in org.h2.store
A mechanism to store and retrieve lob data.
LobStorageMap - Class in org.h2.mvstore.db
This class stores LOB objects in the database, in maps.
LobStorageMap(Database) - Constructor for class org.h2.mvstore.db.LobStorageMap
 
LobStorageMap.BlobMeta - Class in org.h2.mvstore.db
 
LobStorageMap.BlobMeta.Type - Class in org.h2.mvstore.db
 
LobStorageMap.BlobReference - Class in org.h2.mvstore.db
 
LobStorageMap.BlobReference.Type - Class in org.h2.mvstore.db
 
LobStorageMap.LobInputStream - Class in org.h2.mvstore.db
 
LobStorageRemoteInputStream - Class in org.h2.store
An input stream used by the client side of a tcp connection to fetch LOB data on demand from the server.
LobStorageRemoteInputStream(SessionRemote, long, byte[]) - Constructor for class org.h2.store.LobStorageRemoteInputStream
 
lobSyncObject - Variable in class org.h2.engine.Database
 
lobSyncObject - Variable in class org.h2.engine.SessionRemote
 
lobTimeout - Variable in class org.h2.engine.DbSettings
Database setting LOB_TIMEOUT (default: 300000, which means 5 minutes).
local - Variable in class org.h2.expression.condition.ConditionLocalAndGlobal
 
LOCAL - Static variable in class org.h2.util.DateTimeUtils
 
localDateTimeFromDateNanos(long, long) - Static method in class org.h2.util.JSR310Utils
 
localDateTimeToValue(LocalDateTime) - Static method in class org.h2.util.JSR310Utils
Converts a LocalDateTime to a Value.
localDateToValue(LocalDate) - Static method in class org.h2.util.JSR310Utils
Converts a LocalDate to a Value.
locale - Variable in class org.h2.expression.function.DateTimeFormatFunction.CacheKey
 
locale - Variable in class org.h2.server.web.WebSession
The current locale.
LOCALES - Static variable in class org.h2.value.CompareMode
 
LocalResult - Class in org.h2.result
A local result set contains all row data of a result set.
LocalResult() - Constructor for class org.h2.result.LocalResult
Construct a local result object.
LocalResult(SessionLocal) - Constructor for class org.h2.result.LocalResult
 
LocalResult(SessionLocal, Expression[], int, int) - Constructor for class org.h2.result.LocalResult
Construct a local result object.
localTempTableConstraints - Variable in class org.h2.engine.SessionLocal
 
localTempTableIndexes - Variable in class org.h2.engine.SessionLocal
 
localTempTables - Variable in class org.h2.engine.SessionLocal
 
LOCALTIME - Static variable in class org.h2.expression.function.CurrentDateTimeValueFunction
The function "LOCALTIME"
LOCALTIME - Static variable in class org.h2.util.ParserUtil
The token "LOCALTIME".
LOCALTIMESTAMP - Static variable in class org.h2.expression.function.CurrentDateTimeValueFunction
The function "LOCALTIMESTAMP"
LOCALTIMESTAMP - Static variable in class org.h2.util.ParserUtil
The token "LOCALTIMESTAMP".
localTimeToValue(LocalTime) - Static method in class org.h2.util.JSR310Utils
Converts a LocalTime to a Value.
locate(String, String, int) - Static method in class org.h2.expression.function.StringFunction
 
LOCATE - Static variable in class org.h2.expression.function.StringFunction
LOCATE() (non-standard).
locatorsUpdateCopy() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Does the database make a copy before updating.
lock - Variable in class org.h2.engine.Database
 
lock - Variable in class org.h2.mvstore.MVMap
 
lock - Variable in class org.h2.store.FileStore
 
lock - Variable in class org.h2.store.fs.retry.FileRetryOnInterrupt
 
lock(long, long, boolean) - Method in class org.h2.store.fs.FakeFileChannel
 
lock(long, long, boolean) - Method in class org.h2.store.fs.FileBase
 
lock(K) - Method in class org.h2.mvstore.tx.TransactionMap
Lock row for the given key.
lock(SessionLocal) - Method in class org.h2.table.TableFilter
Lock the table.
lock(SessionLocal, int) - Method in class org.h2.mvstore.db.MVTable
 
lock(SessionLocal, int) - Method in class org.h2.table.Table
Lock the table for the given session.
lock(FileLockMethod) - Method in class org.h2.store.FileLock
Lock the file if possible.
LOCK - Static variable in class org.h2.message.Trace
The trace module id for locks.
LOCK_MODE - Static variable in class org.h2.command.dml.SetTypes
The type of a SET LOCK_MODE statement.
LOCK_MODE - Static variable in class org.h2.expression.function.SysInfoFunction
LOCK_MODE().
LOCK_MODE_OFF - Static variable in class org.h2.engine.Constants
The lock mode that means no locking is used at all.
LOCK_MODE_READ_COMMITTED - Static variable in class org.h2.engine.Constants
The lock mode that means read locks are acquired, but they are released immediately after the statement is executed.
LOCK_MODE_TABLE - Static variable in class org.h2.engine.Constants
The lock mode that means table level locking is used for reads and writes.
LOCK_MODE_TABLE_GC - Static variable in class org.h2.engine.Constants
The lock mode that means table level locking is used for reads and writes.
LOCK_ORDERING - Static variable in class org.h2.util.AbbaDetector
Map of (object A) -> ( map of (object locked before object A) -> (stack trace where locked) )
LOCK_SLEEP - Static variable in class org.h2.engine.Constants
The number of milliseconds to wait between checking the .lock.db file still exists once a database is locked.
LOCK_TIMEOUT - Static variable in class org.h2.command.dml.SetTypes
The type of a SET LOCK_TIMEOUT statement.
LOCK_TIMEOUT - Static variable in class org.h2.expression.function.SysInfoFunction
LOCK_TIMEOUT().
LOCK_TIMEOUT_1 - Static variable in class org.h2.api.ErrorCode
The error with code 50200 is thrown when another connection locked an object longer than the lock timeout set for this connection, or when a deadlock occurred.
lockDecisionMaker - Variable in class org.h2.mvstore.tx.TransactionMap
 
LockDecisionMaker(int, Transaction) - Constructor for class org.h2.mvstore.tx.TxDecisionMaker.LockDecisionMaker
 
locked - Variable in class org.h2.store.FileLock
Whether the file is locked.
lockExclusive() - Method in class org.h2.store.fs.mem.FileMemData
Lock the file in exclusive mode if possible.
lockExclusive() - Method in class org.h2.store.fs.niomem.FileNioMemData
Lock the file in exclusive mode if possible.
lockExclusiveSession - Variable in class org.h2.mvstore.db.MVTable
The session (if any) that has exclusively locked this table.
lockFile() - Method in class org.h2.store.FileLock
 
lockMeta(SessionLocal) - Method in class org.h2.engine.Database
Lock the metadata table for updates.
lockMetaAssertion(SessionLocal) - Method in class org.h2.engine.Database
 
lockMode - Variable in class org.h2.engine.Database
 
lockMode - Variable in enum org.h2.engine.IsolationLevel
 
lockOrdering - Variable in class org.h2.util.AbbaLockingDetector
Map of (object A) -> ( map of (object locked before object A) -> (stack trace where locked) )
lockRoot(RootReference<K, V>, int) - Method in class org.h2.mvstore.MVMap
 
lockRow(SessionLocal, Row) - Method in class org.h2.mvstore.db.MVPrimaryIndex
Lock a single row.
lockRow(SessionLocal, Row) - Method in class org.h2.mvstore.db.MVTable
 
lockRow(SessionLocal, Row) - Method in class org.h2.table.Table
Locks row, preventing any updated to it, except from the session specified.
lockRow(TransactionMap<Long, SearchRow>, long) - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
locks - Variable in class org.h2.engine.SessionLocal
 
locks(SessionLocal, ArrayList<Row>) - Method in class org.h2.table.InformationSchemaTable
 
locks(SessionLocal, ArrayList<Row>, SessionLocal) - Method in class org.h2.table.InformationSchemaTable
 
LOCKS - Static variable in class org.h2.table.InformationSchemaTable
 
LOCKS - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
lockShared() - Method in class org.h2.store.fs.mem.FileMemData
Lock the file in shared mode if possible.
lockShared() - Method in class org.h2.store.fs.niomem.FileNioMemData
Lock the file in shared mode if possible.
lockSharedSessions - Variable in class org.h2.mvstore.db.MVTable
The set of sessions (if any) that have a shared lock on the table.
lockSocket() - Method in class org.h2.store.FileLock
 
lockTimeout - Variable in class org.h2.engine.SessionLocal
 
lockTypeToString(int) - Static method in class org.h2.mvstore.db.MVTable
 
log(int, String) - Method in class org.h2.store.fs.rec.FilePathRec
Log the operation.
log(int, String, byte[], long) - Method in class org.h2.store.fs.rec.FilePathRec
Log the operation.
log(int, String, byte[], long) - Method in interface org.h2.store.fs.Recorder
Record the method.
log(int, String, byte[], long) - Method in class org.h2.store.RecoverTester
 
log(Record<?, ?>) - Method in class org.h2.mvstore.tx.Transaction
Add a log entry.
LOG - Static variable in class org.h2.expression.function.MathFunction2
LOG().
LOG_ID_BITS - Static variable in class org.h2.mvstore.tx.Transaction
How many bits of the "operation id" we store in the transaction belong to the log id (the rest belong to the transaction id).
LOG_ID_BITS - Static variable in class org.h2.mvstore.tx.TransactionStore
 
LOG_ID_BITS1 - Static variable in class org.h2.mvstore.tx.Transaction
 
LOG_ID_LIMIT - Static variable in class org.h2.mvstore.tx.Transaction
 
LOG_ID_MASK - Static variable in class org.h2.mvstore.tx.Transaction
 
LOG_ID_MASK - Static variable in class org.h2.mvstore.tx.TransactionStore
 
LOG10 - Static variable in class org.h2.expression.function.MathFunction1
LOG10().
logAndConvert(Throwable) - Method in class org.h2.message.TraceObject
Log an exception and convert it to a SQL exception if required.
logAndDecideToPut(VersionedValue<V>, V) - Method in class org.h2.mvstore.tx.TxDecisionMaker
Create undo log entry and record for future references MVMap.Decision.PUT decision along with last known committed value
logAndDecideToPut(VersionedValue<V>, V) - Method in class org.h2.mvstore.tx.TxDecisionMaker.RepeatableReadLockDecisionMaker
 
logger - Variable in class org.h2.message.TraceWriterAdapter
 
login(NetworkConnectionInfo) - Method in class org.h2.server.web.WebApp
 
logIndex - Variable in class org.h2.engine.SessionLocal.Savepoint
The undo log index.
loginTimeout - Variable in class org.h2.jdbcx.JdbcDataSource
 
logIsLogBase10 - Variable in class org.h2.engine.Mode
The single-argument function LOG() uses base 10 instead of E.
logout() - Method in class org.h2.server.web.WebApp
 
logUndo() - Method in class org.h2.mvstore.tx.Transaction
Remove the last log entry.
logWriter - Variable in class org.h2.jdbcx.JdbcConnectionPool
 
logWriter - Variable in class org.h2.jdbcx.JdbcDataSource
 
logWritingError(Exception) - Method in class org.h2.message.TraceSystem
 
LongDataCounter - Class in org.h2.expression.aggregate
Counter.
LongDataCounter() - Constructor for class org.h2.expression.aggregate.LongDataCounter
 
LongDataType - Class in org.h2.mvstore.type
Class LongDataType.
LongDataType() - Constructor for class org.h2.mvstore.type.LongDataType
 
LongType() - Constructor for class org.h2.mvstore.type.ObjectDataType.LongType
 
low - Variable in class org.h2.value.ValueUuid
 
LOW - org.h2.mode.DefaultNullOrdering
NULL values are considered as smaller than other values during sorting.
LOWER - Static variable in class org.h2.expression.function.StringFunction1
LOWER().
LOWERCASE - org.h2.expression.function.ToCharFunction.Capitalization
All letters are lowercased.
lowerEntry(K) - Method in class org.h2.mvstore.tx.TransactionMap
Get the entry with largest key that is smaller than the given key, or null if no such key exists.
lowerKey(K) - Method in class org.h2.mvstore.MVMap
Get the largest key that is smaller than the given key, or null if no such key exists.
lowerKey(K) - Method in class org.h2.mvstore.tx.TransactionMap
Get the largest key that is smaller than the given key, or null if no such key exists.
lowerKey(RootReference<K, V>, K) - Method in class org.h2.mvstore.MVMap
Get the largest key that is smaller than the given key, for the given root page, or null if no such key exists.
LPAD - Static variable in class org.h2.expression.function.StringFunction
LPAD() (non-standard).
lru - Variable in class org.h2.util.CacheTQ
 
LSHIFT - Static variable in class org.h2.expression.function.BitFunction
LSHIFT() (non-standard).
LUCENE_FIELD_COLUMN_PREFIX - Static variable in class org.h2.fulltext.FullTextLucene
 
LUCENE_FIELD_DATA - Static variable in class org.h2.fulltext.FullTextLucene
 
LUCENE_FIELD_MODIFIED - Static variable in class org.h2.fulltext.FullTextLucene
 
LUCENE_FIELD_QUERY - Static variable in class org.h2.fulltext.FullTextLucene
 
LZF - Static variable in interface org.h2.compress.Compressor
The LZF compression algorithm is used
LZF - Static variable in class org.h2.store.fs.mem.FileMemData
 
LZF_THREAD_LOCAL - Static variable in class org.h2.store.fs.niomem.FileNioMemData
 
LZFInputStream - Class in org.h2.compress
An input stream to read from an LZF stream.
LZFInputStream(InputStream) - Constructor for class org.h2.compress.LZFInputStream
 
LZFOutputStream - Class in org.h2.compress
An output stream to write an LZF stream.
LZFOutputStream(OutputStream) - Constructor for class org.h2.compress.LZFOutputStream
 

M

m - Variable in class org.h2.util.Permutations
 
M - Static variable in class org.h2.util.geometry.GeometryUtils
Number of M coordinate.
m2 - Variable in class org.h2.expression.aggregate.AggregateDataStdVar
 
m2x - Variable in class org.h2.expression.aggregate.AggregateDataCorr
 
m2y - Variable in class org.h2.expression.aggregate.AggregateDataCorr
 
MAGIC - Static variable in class org.h2.compress.LZFOutputStream
The file header of a LZF file.
MAGIC - Static variable in class org.h2.store.FileLock
 
MAGNITUDE_LIMIT - Static variable in class org.h2.util.MemoryEstimator
 
main(String...) - Static method in class org.h2.mvstore.MVStoreTool
Runs this tool.
main(String...) - Static method in class org.h2.tools.Backup
Options are case sensitive.
main(String...) - Static method in class org.h2.tools.ChangeFileEncryption
Options are case sensitive.
main(String...) - Static method in class org.h2.tools.Console
When running without options, -tcp, -web, -browser and -pg are started.
main(String...) - Static method in class org.h2.tools.ConvertTraceFile
Options are case sensitive.
main(String...) - Static method in class org.h2.tools.CreateCluster
Options are case sensitive.
main(String...) - Static method in class org.h2.tools.DeleteDbFiles
Options are case sensitive.
main(String...) - Static method in class org.h2.tools.Recover
Options are case sensitive.
main(String...) - Static method in class org.h2.tools.Restore
Options are case sensitive.
main(String...) - Static method in class org.h2.tools.RunScript
Options are case sensitive.
main(String...) - Static method in class org.h2.tools.Script
Options are case sensitive.
main(String...) - Static method in class org.h2.tools.Server
When running without options, -tcp, -web, -browser and -pg are started.
main(String...) - Static method in class org.h2.tools.Shell
Options are case sensitive.
main(String...) - Static method in class org.h2.util.Profiler
Run the command line version of the profiler.
MAIN_SCHEMA_ID - Static variable in class org.h2.engine.Constants
The identity of PUBLIC schema.
mainIndex - Variable in class org.h2.mvstore.db.MVDelegateIndex
 
mainIndexColumn - Variable in class org.h2.mvstore.db.MVPrimaryIndex
 
mainSchema - Variable in class org.h2.engine.Database
 
makeColumnNamesUnique() - Method in class org.h2.tools.Csv
 
makeRegexpFlags(String, boolean) - Static method in class org.h2.expression.function.RegexpFunction
 
MANAGEMENT_DB_PREFIX - Static variable in class org.h2.server.TcpServer
The name of the in-memory management database used by the TCP server to keep the active sessions.
managementDb - Variable in class org.h2.server.TcpServer
 
managementDbAdd - Variable in class org.h2.server.TcpServer
 
managementDbRemove - Variable in class org.h2.server.TcpServer
 
managementPassword - Variable in class org.h2.server.TcpServer
 
map - Variable in class org.h2.command.query.AllColumnsForPlan
 
map - Variable in class org.h2.engine.QueryStatisticsData
 
map - Variable in class org.h2.mvstore.db.MVPlainTempResult
Map with identities of rows as keys rows as values.
map - Variable in class org.h2.mvstore.db.MVSortedTempResult
Map with rows as keys and counts of duplicate rows as values.
map - Variable in class org.h2.mvstore.db.MVSpatialIndex.FindBoundsCursor
 
map - Variable in class org.h2.mvstore.db.MVSpatialIndex.SpatialKeyIterator
 
map - Variable in class org.h2.mvstore.Page
Map this page belongs to
map - Variable in class org.h2.mvstore.StreamStore
 
map - Variable in class org.h2.mvstore.tx.TransactionMap
The map used for writing (the latest version).
map - Variable in class org.h2.result.RowFactory.DefaultRowFactory
 
map - Variable in class org.h2.result.Sparse
 
map - Variable in class org.h2.server.web.WebSession
The session attribute map.
map - Variable in class org.h2.table.TableLinkConnection
The map where the link is kept.
map - Variable in class org.h2.util.CacheSecondLevel
 
map - Variable in class org.h2.util.DebuggingThreadLocal
 
map - Variable in class org.h2.util.SmallMap
 
map - Variable in class org.h2.util.SoftValuesHashMap
 
map(FileChannel.MapMode, long, long) - Method in class org.h2.store.fs.FakeFileChannel
 
map(FileChannel.MapMode, long, long) - Method in class org.h2.store.fs.FileBase
 
MAP_IN_AGGREGATE - Static variable in class org.h2.expression.Expression
State for expressions inside an aggregate for Expression.mapColumns(ColumnResolver, int, int).
MAP_IN_WINDOW - Static variable in class org.h2.expression.Expression
State for expressions inside a window function for Expression.mapColumns(ColumnResolver, int, int).
MAP_INITIAL - Static variable in class org.h2.expression.Expression
mapAndAddFilter(Expression) - Method in class org.h2.table.TableFilter
Map the columns and add the join condition.
mapAndOptimize(SessionLocal, ColumnResolver, ColumnResolver) - Method in class org.h2.command.dml.SetClauseList
Map the columns and optimize expressions.
mapAndOptimize(SessionLocal, ColumnResolver, ColumnResolver) - Method in class org.h2.command.dml.SetClauseList.RowExpression
 
mapAndOptimize(SessionLocal, ColumnResolver, ColumnResolver) - Method in class org.h2.command.dml.SetClauseList.SetMultiple
 
mapAndOptimize(SessionLocal, ColumnResolver, ColumnResolver) - Method in class org.h2.command.dml.SetClauseList.SetSimple
 
mapAndOptimize(SessionLocal, ColumnResolver, ColumnResolver) - Method in class org.h2.command.dml.SetClauseList.UpdateAction
 
mapColumn(ColumnResolver, Column, int) - Method in class org.h2.expression.ExpressionColumn
 
mapColumns(ColumnResolver, int) - Method in class org.h2.command.query.Query
Map the columns to the given column resolver.
mapColumns(ColumnResolver, int) - Method in class org.h2.command.query.Select
 
mapColumns(ColumnResolver, int) - Method in class org.h2.command.query.SelectUnion
 
mapColumns(ColumnResolver, int) - Method in class org.h2.command.query.TableValueConstructor
 
mapColumns(ColumnResolver, int) - Method in class org.h2.expression.analysis.Window
Map the columns of the resolver to expression columns.
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.Alias
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.analysis.DataAnalysisOperation
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.analysis.WindowFrame
Map the columns of the resolver to expression columns.
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.analysis.WindowFrameBound
Map the columns of the resolver to expression columns.
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.ArrayConstructorByQuery
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.condition.BetweenPredicate
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.condition.CompareLike
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.condition.Comparison
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.condition.ConditionAndOr
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.condition.ConditionAndOrN
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.condition.ConditionIn
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.condition.ConditionInConstantSet
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.condition.ConditionInParameter
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.condition.ConditionInQuery
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.condition.ConditionLocalAndGlobal
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.condition.ConditionNot
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.condition.IsJsonPredicate
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.condition.PredicateWithSubquery
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.condition.SimplePredicate
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.DomainValueExpression
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.Expression
Map the columns of the resolver to expression columns.
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.ExpressionColumn
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.ExpressionList
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.function.Function0_1
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.function.JavaFunction
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.Operation0
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.Operation1_2
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.Operation1
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.Operation2
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.OperationN
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.SimpleCase
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.Subquery
 
mapColumns(ColumnResolver, int, int) - Method in class org.h2.expression.Wildcard
 
mapColumns(IndexColumn[], Table) - Static method in class org.h2.table.IndexColumn
Map the columns using the column names and the specified table.
mapColumnsAnalysis(ColumnResolver, int, int) - Method in class org.h2.expression.aggregate.AbstractAggregate
 
mapColumnsAnalysis(ColumnResolver, int, int) - Method in class org.h2.expression.aggregate.Aggregate
 
mapColumnsAnalysis(ColumnResolver, int, int) - Method in class org.h2.expression.analysis.DataAnalysisOperation
Map the columns of the resolver to expression columns.
mapColumnsAnalysis(ColumnResolver, int, int) - Method in class org.h2.expression.analysis.WindowFunction
 
MapColumnsVisitor(Expression) - Constructor for class org.h2.table.TableFilter.MapColumnsVisitor
 
mapCondition(int) - Method in class org.h2.command.query.Select
 
mapExceptColumns() - Method in class org.h2.expression.Wildcard
Returns map of excluded table columns to expression columns and validates that all columns are resolved and not duplicated.
mapId - Variable in class org.h2.mvstore.Chunk
The last used map id.
mapId - Variable in class org.h2.mvstore.tx.Record
Map id for this change is related to
mapId - Variable in class org.h2.mvstore.tx.TxDecisionMaker
Map to decide upon
mapName - Variable in class org.h2.mvstore.db.MVPrimaryIndex
 
mapName - Variable in class org.h2.mvstore.tx.TransactionStore.Change
The name of the map where the change occurred.
mapNext - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Entry
The next entry in the map (the chained entry).
mapped - Variable in class org.h2.store.fs.niomapped.FileNioMapped
 
maps - Variable in class org.h2.mvstore.MVStore
 
mapSet - Variable in class org.h2.bnf.RuleExtension
 
mapSet - Variable in class org.h2.bnf.RuleList
 
mapSet - Variable in class org.h2.bnf.RuleOptional
 
mapSize - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
The number of (hot, cold, and non-resident) entries in the map.
mapUserToRoles(AuthenticationInfo) - Method in interface org.h2.api.UserToRolesMapper
Map user identified by authentication info to a set of granted roles.
mapUserToRoles(AuthenticationInfo) - Method in class org.h2.security.auth.impl.AssignRealmNameRole
 
mapUserToRoles(AuthenticationInfo) - Method in class org.h2.security.auth.impl.StaticRolesMapper
 
margin - Variable in class org.h2.schema.Sequence
 
MariaDB - org.h2.engine.Mode.ModeEnum
 
mark(int) - Method in class org.h2.store.RangeInputStream
 
mark(int) - Method in class org.h2.store.RangeReader
 
markAsRemoved() - Method in class org.h2.mvstore.Page
Mark this page as removed "in memory".
markHigher(Object, Deque<Object>) - Static method in class org.h2.util.AbbaDetector
 
markHigher(List<String>, ThreadInfo) - Method in class org.h2.util.AbbaLockingDetector
 
markMetaChanged() - Method in class org.h2.mvstore.MVStore
 
markStatementEnd() - Method in class org.h2.mvstore.tx.Transaction
Mark an exit from SQL statement execution within this transaction.
markStatementStart(HashSet<MVMap<Object, VersionedValue<Object>>>) - Method in class org.h2.mvstore.tx.Transaction
Mark an entry into a new SQL statement execution within this transaction.
markSupported() - Method in class org.h2.store.RangeInputStream
 
markSupported() - Method in class org.h2.store.RangeReader
 
markTableForAnalyze(Table) - Method in class org.h2.engine.SessionLocal
Mark that the given table needs to be analyzed on commit.
markTransactionEnd() - Method in class org.h2.mvstore.tx.Transaction
 
markUndoLogAsCommitted(int) - Method in class org.h2.mvstore.tx.TransactionStore
 
markUsed(long, int) - Method in class org.h2.mvstore.FileStore
Mark the space as in use.
markUsed(long, int) - Method in class org.h2.mvstore.FreeSpaceBitSet
Mark the space as in use.
markUsedTablesAsUpdated() - Method in class org.h2.engine.SessionLocal
 
mask - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
The bit mask that is applied to the key hash code to get the index in the map array.
mask - Variable in class org.h2.util.CacheLRU
 
masks - Variable in class org.h2.table.PlanItem
 
masks - Variable in class org.h2.table.TableFilter
 
masks - Variable in class org.h2.table.TableView.CacheKey
 
match(Class<?>[], Object[]) - Static method in class org.h2.util.Utils
 
match(String) - Method in interface org.h2.util.Utils.ClassFactory
Check whether the factory can return the named class.
match(String, int) - Method in class org.h2.util.geometry.EWKTUtils.EWKTSource
 
MATCH - Static variable in class org.h2.expression.condition.CompareLike
 
MATCH_ALL_ROW_KEY - Static variable in class org.h2.result.SearchRow
If the key is this value, then the key is considered equal to all other keys, when comparing.
matchStringOrThrow(Pattern, ToDateParser, Enum<?>) - Static method in class org.h2.mode.ToDateTokenizer
Match the pattern, or if not possible throw an exception.
MathFunction - Class in org.h2.expression.function
A math function.
MathFunction(Expression, Expression, int) - Constructor for class org.h2.expression.function.MathFunction
 
MathFunction1 - Class in org.h2.expression.function
A math function with one argument and DOUBLE PRECISION result.
MathFunction1(Expression, int) - Constructor for class org.h2.expression.function.MathFunction1
 
MathFunction2 - Class in org.h2.expression.function
A math function with two arguments and DOUBLE PRECISION result.
MathFunction2(Expression, Expression, int) - Constructor for class org.h2.expression.function.MathFunction2
 
MathUtils - Class in org.h2.util
This is a utility class with mathematical helper functions.
MathUtils() - Constructor for class org.h2.util.MathUtils
 
max - Variable in class org.h2.expression.function.CardinalityExpression
 
max - Variable in class org.h2.table.RangeTable
 
max(int) - Method in class org.h2.mvstore.db.SpatialKey
 
max(int) - Method in class org.h2.mvstore.rtree.DefaultSpatial
 
max(int) - Method in interface org.h2.mvstore.rtree.Spatial
Get the maximum value for the given dimension.
MAX - org.h2.expression.aggregate.AggregateType
The aggregate type for MAX(expression).
MAX - Static variable in class org.h2.value.ValueBigint
The largest ValueLong value.
MAX_AGE_NANOS - Static variable in class org.h2.index.ViewIndex
 
MAX_ARRAY_CARDINALITY - Static variable in class org.h2.engine.Constants
The maximum allowed cardinality of array.
MAX_ARRAY_SIZE - Static variable in class org.h2.util.ByteStack
 
MAX_BI - Static variable in class org.h2.value.ValueBigint
The largest Long value, as a BigInteger.
MAX_BRUTE_FORCE - Static variable in class org.h2.command.query.Optimizer
 
MAX_BRUTE_FORCE_FILTERS - Static variable in class org.h2.command.query.Optimizer
 
MAX_BUFFER_SIZE - Static variable in class org.h2.tools.CompressTool
 
MAX_COLUMNS - Static variable in class org.h2.engine.Constants
The maximum number of columns in a table, select statement or row value.
MAX_DATE_VALUE - Static variable in class org.h2.util.DateTimeUtils
Maximum possible date value.
MAX_DATE_VALUE - Static variable in class org.h2.util.JSR310Utils
 
MAX_ELEMENTS - Static variable in class org.h2.util.Profiler
 
MAX_FILE_RETRY - Static variable in class org.h2.engine.SysProperties
System property h2.maxFileRetry (default: 16).
MAX_GENETIC - Static variable in class org.h2.command.query.Optimizer
 
MAX_GROUP_SCALE - Static variable in class org.h2.server.pg.PgServerThread
 
MAX_GROUP_SIZE - Static variable in class org.h2.server.pg.PgServerThread
 
MAX_HEADER_LENGTH - Static variable in class org.h2.mvstore.Chunk
The maximum length of a chunk header, in bytes.
MAX_HISTORY - Static variable in class org.h2.server.web.WebSession
 
MAX_ID - Static variable in class org.h2.mvstore.Chunk
The maximum chunk id.
MAX_IDENTIFIER_LENGTH - Static variable in class org.h2.engine.Constants
The maximum allowed length of identifiers.
MAX_INSTANT_SECOND - Static variable in class org.h2.util.JSR310Utils
 
MAX_LENGTH_INPLACE_LOB - Static variable in class org.h2.command.dml.SetTypes
The type of a SET MAX_LENGTH_INPLACE_LOB statement.
MAX_LITERAL - Static variable in class org.h2.compress.CompressLZF
The maximum number of literals in a chunk (32).
MAX_LOG_SIZE - Static variable in class org.h2.command.dml.SetTypes
The type of a SET MAX_LOG_SIZE statement.
MAX_LONG_DECIMAL - Static variable in class org.h2.value.Value
 
MAX_MEMORY_ROWS - Static variable in class org.h2.command.dml.SetTypes
The type of a SET MAX_MEMORY_ROWS statement.
MAX_MEMORY_ROWS - Static variable in class org.h2.engine.SysProperties
System property h2.maxMemoryRows (default: 40000 per GB of available RAM).
MAX_MEMORY_UNDO - Static variable in class org.h2.command.dml.SetTypes
The type of a SET MAX_MEMORY_UNDO statement.
MAX_NUMERIC_PRECISION - Static variable in class org.h2.engine.Constants
The maximum allowed precision of numeric data types.
MAX_OFF - Static variable in class org.h2.compress.CompressLZF
The maximum offset allowed for a back-reference (8192).
MAX_OPEN_TRANSACTIONS - Static variable in class org.h2.mvstore.tx.TransactionStore
Hard limit on the number of concurrently opened transactions
MAX_OPERATION_MEMORY - Static variable in class org.h2.command.dml.SetTypes
The type of a SET MAX_OPERATION_MEMORY statement.
MAX_PARAMETER_INDEX - Static variable in class org.h2.engine.Constants
The highest possible parameter index.
MAX_PROCESSING_TIME - Static variable in class org.h2.bnf.Sentence
 
MAX_RECONNECT - Static variable in class org.h2.engine.SysProperties
System property h2.maxReconnect (default: 3).
MAX_REF - Static variable in class org.h2.compress.CompressLZF
The maximum back-reference length (264).
MAX_RETRY - Static variable in class org.h2.table.TableLink
 
MAX_REUSE_CAPACITY - Static variable in class org.h2.mvstore.WriteBuffer
The maximum size of the buffer in order to be re-used after a clear operation.
MAX_ROW_BUFFER - Static variable in class org.h2.tools.Shell
 
MAX_STRING_LENGTH - Static variable in class org.h2.engine.Constants
The maximum allowed length for character string, binary string, and other data types based on them; excluding LOB data types.
MAX_TRACE_DATA_LENGTH - Static variable in class org.h2.engine.SysProperties
System property h2.maxTraceDataLength (default: 65535).
MAX_VAR_INT_LEN - Static variable in class org.h2.mvstore.DataUtils
The maximum length of a variable size int.
MAX_VAR_LONG_LEN - Static variable in class org.h2.mvstore.DataUtils
The maximum length of a variable size long.
MAX_X - Static variable in class org.h2.util.geometry.GeometryUtils
Maximum X coordinate index.
MAX_Y - Static variable in class org.h2.util.geometry.GeometryUtils
Maximum Y coordinate index.
maxBlockSize - Variable in class org.h2.mvstore.StreamStore
 
maxColumnSize - Variable in class org.h2.tools.Shell
 
maxCompactTime - Variable in class org.h2.engine.DbSettings
Database setting MAX_COMPACT_TIME (default: 200).
maxConnections - Variable in class org.h2.jdbcx.JdbcConnectionPool
 
maxDataModificationId - Variable in class org.h2.expression.ExpressionVisitor
 
maxDataModificationId - Variable in class org.h2.table.TableView
 
maxDistinctCount - Variable in class org.h2.expression.aggregate.AggregateDataDistinctWithCounts
 
maxElements - Variable in class org.h2.util.SmallMap
 
maxFileSize - Variable in class org.h2.message.TraceSystem
 
maxFileSize - Variable in class org.h2.store.RecoverTester
 
MAXIMUM_PRECISION - Static variable in class org.h2.value.ValueInterval
The maximum leading field precision for intervals.
MAXIMUM_PRECISION - Static variable in class org.h2.value.ValueTime
The maximum precision and display size of the textual representation of a time.
MAXIMUM_PRECISION - Static variable in class org.h2.value.ValueTimestamp
The maximum precision and display size of the textual representation of a timestamp.
MAXIMUM_PRECISION - Static variable in class org.h2.value.ValueTimestampTimeZone
The maximum precision and display size of the textual representation of a timestamp.
MAXIMUM_PRECISION - Static variable in class org.h2.value.ValueTimeTimeZone
The maximum precision and display size of the textual representation of a time.
MAXIMUM_SCALE - Static variable in class org.h2.value.ValueInterval
The maximum scale for intervals with seconds.
MAXIMUM_SCALE - Static variable in class org.h2.value.ValueNumeric
The maximum scale.
MAXIMUM_SCALE - Static variable in class org.h2.value.ValueTime
The maximum scale for time.
MAXIMUM_SCALE - Static variable in class org.h2.value.ValueTimestamp
The maximum scale for timestamps.
maximumCardinality - Variable in class org.h2.table.InformationSchemaTable.DataTypeInformation
MAXIMUM_CARDINALITY.
maxLen - Variable in class org.h2.mvstore.Chunk
The sum of the max length of all pages.
maxLength - Variable in class org.h2.store.fs.split.FileSplit
 
maxLengthInplaceLob - Variable in class org.h2.engine.Database
 
maxLenLive - Variable in class org.h2.mvstore.Chunk
The sum of the length of all pages that are still alive.
maxMemory - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Config
The maximum memory to use (1 or larger).
maxMemory - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS
The maximum memory this cache should use.
maxMemory - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
The maximum memory this cache should use in bytes.
maxMemory - Variable in class org.h2.util.CacheLRU
The maximum memory, in words (4 bytes each).
maxMemory - Variable in class org.h2.util.CacheTQ
 
maxMemoryRows - Variable in class org.h2.engine.Database
 
maxMemoryRows - Variable in class org.h2.result.LocalResult
 
maxOperationMemory - Variable in class org.h2.engine.Database
 
maxOutParameters - Variable in class org.h2.jdbc.JdbcCallableStatement
 
maxPrecision - Variable in class org.h2.value.DataType
The maximum supported precision.
maxQueryEntries - Variable in class org.h2.engine.QueryStatisticsData
 
maxQueryTimeout - Variable in class org.h2.engine.DbSettings
Database setting MAX_QUERY_TIMEOUT (default: 0).
maxRows - Variable in class org.h2.jdbc.JdbcStatement
 
maxScale - Variable in class org.h2.value.DataType
The highest possible scale.
maxSize - Variable in class org.h2.command.ddl.Analyze.SelectivityData
 
maxTransactionId - Variable in class org.h2.mvstore.tx.TransactionStore
Soft limit on the number of concurrently opened transactions.
maxValue - Variable in class org.h2.command.ddl.SequenceOptions
 
maxValue - Variable in class org.h2.schema.Sequence
 
maxX - Variable in class org.h2.util.geometry.GeometryUtils.EnvelopeTarget
 
maxY - Variable in class org.h2.util.geometry.GeometryUtils.EnvelopeTarget
 
mayHaveNullDuplicates(SearchRow) - Method in class org.h2.index.Index
Check if this row may have duplicates with the same indexed values in the current compatibility mode.
mayHaveStandardViews - Variable in class org.h2.bnf.context.DbContents
 
mayHaveStandardViews() - Method in class org.h2.bnf.context.DbContents
Returns whether standard INFORMATION_SCHEMA.VIEWS may be supported.
MBEANS - Static variable in class org.h2.jmx.DatabaseInfo
 
mean - Variable in class org.h2.expression.aggregate.AggregateDataStdVar
 
meanX - Variable in class org.h2.expression.aggregate.AggregateDataCorr
 
meanY - Variable in class org.h2.expression.aggregate.AggregateDataCorr
 
measureFileLengthInUse() - Method in class org.h2.mvstore.MVStore
 
MEDIAN - org.h2.expression.aggregate.AggregateType
The aggregate type for MEDIAN(expression).
member(String) - Method in class org.h2.util.json.JSONByteArrayTarget
 
member(String) - Method in class org.h2.util.json.JSONStringTarget
 
member(String) - Method in class org.h2.util.json.JSONTarget
Name of a member.
member(String) - Method in class org.h2.util.json.JSONValidationTargetWithoutUniqueKeys
 
member(String) - Method in class org.h2.util.json.JSONValidationTargetWithUniqueKeys
 
member(String) - Method in class org.h2.util.json.JSONValueTarget
 
memberName - Variable in class org.h2.util.json.JSONValidationTargetWithUniqueKeys
 
memberName - Variable in class org.h2.util.json.JSONValueTarget
 
members - Variable in class org.h2.util.json.JSONObject
 
memory - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Entry
The estimated memory used.
memory - Variable in class org.h2.mvstore.OffHeapStore
 
memory - Variable in class org.h2.mvstore.Page
The estimated memory used in persistent case, IN_MEMORY marker value otherwise.
memory - Variable in class org.h2.result.DefaultRow
 
memory - Variable in class org.h2.util.CacheLRU
The current memory used in this cache, in words (4 bytes each).
MEMORY_ARRAY - Static variable in class org.h2.engine.Constants
The memory needed by an array.
MEMORY_CALCULATE - Static variable in class org.h2.result.DefaultRow
The constant that means "memory usage is unknown and needs to be calculated first".
MEMORY_CALCULATE - Static variable in class org.h2.result.SearchRow
The constant that means "memory usage is unknown and needs to be calculated first".
MEMORY_FILES - Static variable in class org.h2.store.fs.mem.FilePathMem
 
MEMORY_FILES - Static variable in class org.h2.store.fs.niomem.FilePathNioMem
 
MEMORY_FREE - Static variable in class org.h2.expression.function.SysInfoFunction
MEMORY_FREE().
MEMORY_OBJECT - Static variable in class org.h2.engine.Constants
The memory needed by a regular object with at least one field.
MEMORY_POINTER - Static variable in class org.h2.engine.Constants
The memory needed by a pointer.
MEMORY_ROW - Static variable in class org.h2.engine.Constants
The memory needed by a Row.
MEMORY_USED - Static variable in class org.h2.expression.function.SysInfoFunction
MEMORY_USED().
MemoryEstimator - Class in org.h2.util
Class MemoryEstimator.
MemoryEstimator() - Constructor for class org.h2.util.MemoryEstimator
 
MemoryUnmapper - Class in org.h2.util
Unsafe memory unmapper.
MemoryUnmapper() - Constructor for class org.h2.util.MemoryUnmapper
 
merge(boolean, ResultTarget, DataChangeDeltaTable.ResultOption) - Method in class org.h2.command.dml.MergeUsing
 
merge(SessionLocal, ResultTarget, DataChangeDeltaTable.ResultOption) - Method in class org.h2.command.dml.MergeUsing.When
Merges rows.
merge(SessionLocal, ResultTarget, DataChangeDeltaTable.ResultOption) - Method in class org.h2.command.dml.MergeUsing.WhenMatchedThenDelete
 
merge(SessionLocal, ResultTarget, DataChangeDeltaTable.ResultOption) - Method in class org.h2.command.dml.MergeUsing.WhenMatchedThenUpdate
 
merge(SessionLocal, ResultTarget, DataChangeDeltaTable.ResultOption) - Method in class org.h2.command.dml.MergeUsing.WhenNotMatched
 
merge(Row, Expression[], ResultTarget, DataChangeDeltaTable.ResultOption) - Method in class org.h2.command.dml.Merge
Updates an existing row or inserts a new one.
Merge - Class in org.h2.command.dml
This class represents the statement MERGE or the MySQL compatibility statement REPLACE
Merge(SessionLocal, boolean) - Constructor for class org.h2.command.dml.Merge
 
MERGE - Static variable in interface org.h2.command.CommandInterface
The type of a MERGE statement.
MergedResult - Class in org.h2.result
Merged result.
MergedResult() - Constructor for class org.h2.result.MergedResult
 
mergeGroupByExpressions(Database, int, ArrayList<String>, boolean) - Method in class org.h2.command.query.Select
 
MergeUsing - Class in org.h2.command.dml
This class represents the statement syntax MERGE INTO table alias USING...
MergeUsing(SessionLocal, TableFilter) - Constructor for class org.h2.command.dml.MergeUsing
 
MergeUsing.When - Class in org.h2.command.dml
Abstract WHEN command of the MERGE statement.
MergeUsing.WhenMatchedThenDelete - Class in org.h2.command.dml
 
MergeUsing.WhenMatchedThenUpdate - Class in org.h2.command.dml
 
MergeUsing.WhenNotMatched - Class in org.h2.command.dml
 
mergeWhere - Variable in class org.h2.engine.Mode
If true, merge when matched clause may have WHERE clause.
message - Variable in exception org.h2.jdbc.JdbcSQLDataException
 
message - Variable in exception org.h2.jdbc.JdbcSQLException
 
message - Variable in exception org.h2.jdbc.JdbcSQLFeatureNotSupportedException
 
message - Variable in exception org.h2.jdbc.JdbcSQLIntegrityConstraintViolationException
 
message - Variable in exception org.h2.jdbc.JdbcSQLInvalidAuthorizationSpecException
 
message - Variable in exception org.h2.jdbc.JdbcSQLNonTransientConnectionException
 
message - Variable in exception org.h2.jdbc.JdbcSQLNonTransientException
 
message - Variable in exception org.h2.jdbc.JdbcSQLSyntaxErrorException
 
message - Variable in exception org.h2.jdbc.JdbcSQLTimeoutException
 
message - Variable in exception org.h2.jdbc.JdbcSQLTransactionRollbackException
 
message - Variable in exception org.h2.jdbc.JdbcSQLTransientException
 
MESSAGES - Static variable in exception org.h2.message.DbException
 
messageType - Variable in class org.h2.server.pg.PgServerThread
 
meta - Variable in class org.h2.engine.Database
 
meta - Variable in class org.h2.index.MetaIndex
 
meta - Variable in class org.h2.jdbc.JdbcDatabaseMetaData
 
meta - Variable in class org.h2.mvstore.MVStore
The metadata map.
meta - Variable in class org.h2.server.web.WebSession
 
META_CHUNK - Static variable in class org.h2.mvstore.DataUtils
The prefix for chunks ("chunk.").
META_ID_KEY - Static variable in class org.h2.mvstore.MVStore
The key for the entry within "layout" map, which contains id of "meta" map.
META_LOCK_DEBUGGING - Static variable in class org.h2.engine.Database
 
META_LOCK_DEBUGGING_DB - Static variable in class org.h2.engine.Database
 
META_LOCK_DEBUGGING_STACK - Static variable in class org.h2.engine.Database
 
META_MAP - Static variable in class org.h2.mvstore.DataUtils
The prefix for maps ("map.").
META_NAME - Static variable in class org.h2.mvstore.DataUtils
The prefix for names ("name.").
META_ROOT - Static variable in class org.h2.mvstore.DataUtils
The prefix for root positions of maps ("root.").
META_TABLE_TYPE_COUNT - Static variable in class org.h2.mode.PgCatalogTable
The number of meta table types.
META_TABLE_TYPE_COUNT - Static variable in class org.h2.table.InformationSchemaTable
The number of meta table types.
META_TABLE_TYPE_COUNT - Static variable in class org.h2.table.InformationSchemaTableLegacy
The number of meta table types.
metaChanged - Variable in class org.h2.mvstore.MVStore
 
MetaCursor - Class in org.h2.index
An index for a meta data table.
MetaCursor(ArrayList<Row>) - Constructor for class org.h2.index.MetaCursor
 
metaIdIndex - Variable in class org.h2.engine.Database
 
metaIndex - Variable in class org.h2.table.MetaTable
The index for this table.
MetaIndex - Class in org.h2.index
The index implementation for meta data tables.
MetaIndex(MetaTable, IndexColumn[], boolean) - Constructor for class org.h2.index.MetaIndex
 
MetaRecord - Class in org.h2.engine
A record in the system table of the database.
MetaRecord(SearchRow) - Constructor for class org.h2.engine.MetaRecord
 
MetaSchema - Class in org.h2.schema
Meta data schema.
MetaSchema(Database, int, String, User) - Constructor for class org.h2.schema.MetaSchema
Creates a new instance of meta data schema.
MetaTable - Class in org.h2.table
This class is responsible to build the database meta data pseudo tables.
MetaTable(Schema, int, int) - Constructor for class org.h2.table.MetaTable
Create a new metadata table.
MetaType<D> - Class in org.h2.mvstore.type
Class DBMetaType is a type for values in the type registry map.
MetaType(D, Thread.UncaughtExceptionHandler) - Constructor for class org.h2.mvstore.type.MetaType
 
method - Variable in class org.h2.schema.FunctionAlias.JavaMethod
 
method - Variable in class org.h2.store.FileLock
 
METHOD_DISABLED_ON_AUTOCOMMIT_TRUE - Static variable in class org.h2.api.ErrorCode
The error with code 90147 is thrown when trying to execute a statement which closes the transaction (such as commit and rollback) and autocommit mode is on.
METHOD_NOT_ALLOWED_FOR_PREPARED_STATEMENT - Static variable in class org.h2.api.ErrorCode
The error with code 90130 is thrown when an execute method of PreparedStatement was called with a SQL statement.
METHOD_NOT_ALLOWED_FOR_QUERY - Static variable in class org.h2.api.ErrorCode
The error with code 90001 is thrown when Statement.executeUpdate() was called for a SELECT statement.
METHOD_NOT_FOUND_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90087 is thrown when a method with matching number of arguments was not found in the class.
METHOD_ONLY_ALLOWED_FOR_QUERY - Static variable in class org.h2.api.ErrorCode
The error with code 90002 is thrown when Statement.executeQuery() was called for a statement that does not return a result set (for example, an UPDATE statement).
methodName - Variable in class org.h2.schema.FunctionAlias
 
METHODS_MUST_HAVE_DIFFERENT_PARAMETER_COUNTS_2 - Static variable in class org.h2.api.ErrorCode
The error with code 90073 is thrown when trying to create an alias for a Java method, if two methods exists in this class that have this name and the same number of parameters.
MI - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
MICROSECOND - Static variable in class org.h2.expression.function.DateTimeFunction
Microsecond.
millennium(int) - Static method in class org.h2.expression.function.DateTimeFunction
 
MILLENNIUM - Static variable in class org.h2.expression.function.DateTimeFunction
Millennium.
MILLIS_PER_DAY - Static variable in class org.h2.util.DateTimeUtils
The number of milliseconds per day.
MILLISECOND - Static variable in class org.h2.expression.function.DateTimeFunction
Millisecond.
mimeType - Variable in class org.h2.server.web.WebApp
The mime type of the current response.
min - Variable in class org.h2.table.RangeTable
 
min(int) - Method in class org.h2.mvstore.db.SpatialKey
 
min(int) - Method in class org.h2.mvstore.rtree.DefaultSpatial
 
min(int) - Method in interface org.h2.mvstore.rtree.Spatial
Get the minimum value for the given dimension.
MIN - org.h2.expression.aggregate.AggregateType
The aggregate type for MIN(expression).
MIN - Static variable in class org.h2.value.ValueBigint
The smallest ValueLong value.
MIN_DATE_VALUE - Static variable in class org.h2.util.DateTimeUtils
Minimum possible date value.
MIN_DATE_VALUE - Static variable in class org.h2.util.JSR310Utils
 
MIN_GROW - Static variable in class org.h2.mvstore.WriteBuffer
The minimum number of bytes to grow a buffer at a time.
MIN_INSTANT_SECOND - Static variable in class org.h2.util.JSR310Utils
 
MIN_LONG_DECIMAL - Static variable in class org.h2.value.Value
The smallest Long value, as a BigDecimal.
MIN_X - Static variable in class org.h2.util.geometry.GeometryUtils
Minimum X coordinate index.
MIN_Y - Static variable in class org.h2.util.geometry.GeometryUtils
Minimum Y coordinate index.
minBlockSize - Variable in class org.h2.mvstore.StreamStore
 
minCount - Variable in class org.h2.util.Profiler
 
minMax - Variable in class org.h2.mvstore.db.SpatialKey
 
minMax - Variable in class org.h2.mvstore.rtree.DefaultSpatial
 
minPrecision - Variable in class org.h2.value.DataType
The minimum supported precision.
minScale - Variable in class org.h2.value.DataType
The lowest possible scale.
MINUS - org.h2.expression.BinaryOperation.OpType
This operation represents a subtraction as in 2 - 1.
MINUS - Static variable in class org.h2.util.ParserUtil
The token "MINUS".
MINUS_SIGN - Static variable in class org.h2.command.Token
The token "-".
minusIsExcept - Variable in class org.h2.engine.Mode
Whether MINUS can be used as EXCEPT.
minute - Variable in class org.h2.mode.ToDateParser
 
MINUTE - org.h2.api.IntervalQualifier
MINUTE
MINUTE - Static variable in class org.h2.expression.function.DateTimeFunction
Minute.
MINUTE - Static variable in class org.h2.util.ParserUtil
The token "MINUTE".
MINUTE_TO_SECOND - org.h2.api.IntervalQualifier
MINUTE TO SECOND
MINUTES_PER_DAY_BI - Static variable in class org.h2.util.IntervalUtils
 
MINUTES_PER_HOUR_BI - Static variable in class org.h2.util.IntervalUtils
 
minutesFromInterval(IntervalQualifier, boolean, long, long) - Static method in class org.h2.util.IntervalUtils
Returns minutes value of interval, if any.
minValue - Variable in class org.h2.command.ddl.SequenceOptions
 
minValue - Variable in class org.h2.schema.Sequence
 
minX - Variable in class org.h2.util.geometry.GeometryUtils.EnvelopeTarget
 
minY - Variable in class org.h2.util.geometry.GeometryUtils.EnvelopeTarget
 
misses - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
The number of cache misses.
MM - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
MOD - Static variable in class org.h2.expression.function.MathFunction
MOD().
mode - Variable in class org.h2.engine.Database
 
mode - Variable in class org.h2.engine.Session.DynamicSettings
The database mode.
mode - Variable in class org.h2.store.FileStore
 
mode - Variable in class org.h2.store.fs.niomapped.FileNioMapped
 
mode - Variable in class org.h2.store.fs.retry.FileRetryOnInterrupt
 
mode - Variable in class org.h2.store.fs.split.FileSplit
 
Mode - Class in org.h2.engine
The compatibility modes.
Mode(Mode.ModeEnum) - Constructor for class org.h2.engine.Mode
 
MODE - org.h2.expression.aggregate.AggregateType
The aggregate type for MODE(expression).
MODE - Static variable in class org.h2.command.dml.SetTypes
The type of a SET MODE statement.
Mode.CharPadding - Enum in org.h2.engine
When CHAR values are right-padded with spaces.
Mode.ExpressionNames - Enum in org.h2.engine
Generation of column names for expressions.
Mode.ModeEnum - Enum in org.h2.engine
 
Mode.UniqueIndexNullsHandling - Enum in org.h2.engine
Determines how rows with NULL values in indexed columns are handled in unique indexes.
Mode.ViewExpressionNames - Enum in org.h2.engine
Generation of column names for expressions to be used in a view.
modeEnum - Variable in class org.h2.engine.Mode
 
ModeEnum() - Constructor for enum org.h2.engine.Mode.ModeEnum
 
ModeFunction - Class in org.h2.mode
Base class for mode-specific functions.
ModeFunction(FunctionInfo) - Constructor for class org.h2.mode.ModeFunction
Creates a new instance of function.
MODES - Static variable in class org.h2.engine.Mode
 
modeToOptions(String) - Static method in class org.h2.store.fs.FileUtils
Convert the string representation to a set.
modificationDataId - Variable in class org.h2.engine.Database
 
modificationId - Variable in class org.h2.engine.DbObject
 
modificationId - Variable in class org.h2.engine.SessionLocal
 
modificationMetaId - Variable in class org.h2.command.Prepared
 
modificationMetaId - Variable in class org.h2.engine.Database
 
modificationMetaID - Variable in class org.h2.engine.SessionLocal
 
modify(Long, Long, Long, Long, Long, Sequence.Cycle, Long) - Method in class org.h2.schema.Sequence
Allows the base value, start value, min value, max value, increment and cache size to be updated atomically, including atomic validation.
module - Variable in class org.h2.message.Trace
 
MODULE_NAMES - Static variable in class org.h2.message.Trace
Module names by their ids as array indexes.
modulus(Value) - Method in class org.h2.value.Value
Take the modulus with a value and return the result.
modulus(Value) - Method in class org.h2.value.ValueBigint
 
modulus(Value) - Method in class org.h2.value.ValueDecfloat
 
modulus(Value) - Method in class org.h2.value.ValueDouble
 
modulus(Value) - Method in class org.h2.value.ValueEnumBase
 
modulus(Value) - Method in class org.h2.value.ValueInteger
 
modulus(Value) - Method in class org.h2.value.ValueNumeric
 
modulus(Value) - Method in class org.h2.value.ValueReal
 
modulus(Value) - Method in class org.h2.value.ValueSmallint
 
modulus(Value) - Method in class org.h2.value.ValueTinyint
 
MON - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
month - Variable in class org.h2.mode.ToDateParser
 
MONTH - org.h2.api.IntervalQualifier
MONTH
MONTH - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
MONTH - Static variable in class org.h2.expression.function.DateTimeFunction
Month.
MONTH - Static variable in class org.h2.util.ParserUtil
The token "MONTH".
monthFromDateValue(long) - Static method in class org.h2.util.DateTimeUtils
Get the month from a date value.
MONTHNAME - Static variable in class org.h2.expression.function.DayMonthNameFunction
MONTHNAME() (non-standard).
MonthParslet() - Constructor for class org.h2.mode.ToDateTokenizer.MonthParslet
 
MONTHS - Static variable in class org.h2.expression.function.ToCharFunction
The month field.
MONTHS_AND_WEEKS - Static variable in class org.h2.expression.function.DayMonthNameFunction
English names of months and week days.
MONTHS_PER_YEAR_BI - Static variable in class org.h2.util.IntervalUtils
 
monthsFromInterval(IntervalQualifier, boolean, long, long) - Static method in class org.h2.util.IntervalUtils
Returns months value of interval, if any.
mouseClicked(MouseEvent) - Method in class org.h2.tools.GUIConsole
INTERNAL
mouseEntered(MouseEvent) - Method in class org.h2.tools.GUIConsole
INTERNAL
mouseExited(MouseEvent) - Method in class org.h2.tools.GUIConsole
INTERNAL
mousePressed(MouseEvent) - Method in class org.h2.tools.GUIConsole
INTERNAL
mouseReleased(MouseEvent) - Method in class org.h2.tools.GUIConsole
INTERNAL
move(String, String) - Static method in class org.h2.store.fs.FileUtils
Rename a file if this is allowed.
move(Page<Spatial, V>, Page<Spatial, V>, int) - Static method in class org.h2.mvstore.rtree.MVRTreeMap
 
moveAtomicReplace(String, String) - Static method in class org.h2.store.fs.FileUtils
Rename a file if this is allowed, and try to atomically replace an existing file.
moveChunk(Chunk, long, long) - Method in class org.h2.mvstore.MVStore
Move specified chunk into free area of the file.
moveChunkInside(Chunk, long) - Method in class org.h2.mvstore.MVStore
 
moveIndex() - Method in class org.h2.util.Permutations
Move the index forward a notch.
moveTo(FilePath, boolean) - Method in class org.h2.store.fs.disk.FilePathDisk
 
moveTo(FilePath, boolean) - Method in class org.h2.store.fs.FilePath
Rename a file if this is allowed.
moveTo(FilePath, boolean) - Method in class org.h2.store.fs.FilePathWrapper
 
moveTo(FilePath, boolean) - Method in class org.h2.store.fs.mem.FilePathMem
 
moveTo(FilePath, boolean) - Method in class org.h2.store.fs.niomem.FilePathNioMem
 
moveTo(FilePath, boolean) - Method in class org.h2.store.fs.rec.FilePathRec
 
moveTo(FilePath, boolean) - Method in class org.h2.store.fs.split.FilePathSplit
 
moveTo(FilePath, boolean) - Method in class org.h2.store.fs.zip.FilePathZip
 
moveToCurrentRow() - Method in class org.h2.jdbc.JdbcResultSet
Moves the current position to the current row.
moveToCurrentRow() - Method in class org.h2.tools.SimpleResultSet
INTERNAL
moveToInsertRow() - Method in class org.h2.jdbc.JdbcResultSet
Moves the current position to the insert row.
moveToInsertRow() - Method in class org.h2.tools.SimpleResultSet
INTERNAL
MSSQLServer - org.h2.engine.Mode.ModeEnum
 
mul(int[], int[], int, int) - Static method in class org.h2.security.AES
 
MULTI_LINE_STRING - Static variable in class org.h2.util.geometry.GeometryUtils
MULTILINESTRING geometry type.
MULTI_POINT - Static variable in class org.h2.util.geometry.GeometryUtils
MULTIPOINT geometry type.
MULTI_POLYGON - Static variable in class org.h2.util.geometry.GeometryUtils
MULTIPOLYGON geometry type.
MultiDimension - Class in org.h2.tools
A tool to help an application execute multi-dimensional range queries.
MultiDimension() - Constructor for class org.h2.tools.MultiDimension
 
MULTIPLIERS - Static variable in class org.h2.value.ValueInterval
 
multiply(Value) - Method in class org.h2.value.Value
Multiply with a value and return the result.
multiply(Value) - Method in class org.h2.value.ValueBigint
 
multiply(Value) - Method in class org.h2.value.ValueDecfloat
 
multiply(Value) - Method in class org.h2.value.ValueDouble
 
multiply(Value) - Method in class org.h2.value.ValueEnumBase
 
multiply(Value) - Method in class org.h2.value.ValueInteger
 
multiply(Value) - Method in class org.h2.value.ValueNumeric
 
multiply(Value) - Method in class org.h2.value.ValueReal
 
multiply(Value) - Method in class org.h2.value.ValueSmallint
 
multiply(Value) - Method in class org.h2.value.ValueTime
 
multiply(Value) - Method in class org.h2.value.ValueTinyint
 
MULTIPLY - org.h2.expression.BinaryOperation.OpType
This operation represents a multiplication as in 2 * 3.
MUST_GROUP_BY_COLUMN_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90016 is thrown when a column was used in the expression list or the order by clause of a group or aggregate query, and that column is not in the GROUP BY clause.
MVDelegateIndex - Class in org.h2.mvstore.db
An index that delegates indexing to another index.
MVDelegateIndex(MVTable, int, String, MVPrimaryIndex, IndexType) - Constructor for class org.h2.mvstore.db.MVDelegateIndex
 
MVIndex<K,​V> - Class in org.h2.mvstore.db
An index that stores the data in an MVStore.
MVIndex(Table, int, String, IndexColumn[], int, IndexType) - Constructor for class org.h2.mvstore.db.MVIndex
 
MVInDoubtTransaction - Class in org.h2.mvstore.db
An in-doubt transaction.
MVInDoubtTransaction(MVStore, Transaction) - Constructor for class org.h2.mvstore.db.MVInDoubtTransaction
 
MVMap<K,​V> - Class in org.h2.mvstore
A stored map.
MVMap(Map<String, Object>, DataType<K>, DataType<V>) - Constructor for class org.h2.mvstore.MVMap
 
MVMap(MVMap<K, V>) - Constructor for class org.h2.mvstore.MVMap
 
MVMap(MVStore, int, DataType<K>, DataType<V>) - Constructor for class org.h2.mvstore.MVMap
 
MVMap(MVStore, DataType<K>, DataType<V>, int, long, AtomicReference<RootReference<K, V>>, int, boolean) - Constructor for class org.h2.mvstore.MVMap
 
MVMap.BasicBuilder<M extends MVMap<K,​V>,​K,​V> - Class in org.h2.mvstore
A builder for this class.
MVMap.Builder<K,​V> - Class in org.h2.mvstore
A builder for this class.
MVMap.Decision - Enum in org.h2.mvstore
The decision on what to do on an update.
MVMap.DecisionMaker<V> - Class in org.h2.mvstore
Class DecisionMaker provides callback interface (and should become a such in Java 8) for MVMap.operate method.
MVMap.EqualsDecisionMaker<V> - Class in org.h2.mvstore
 
MVMap.IntValueHolder - Class in org.h2.mvstore
 
MVMap.MapBuilder<M extends MVMap<K,​V>,​K,​V> - Interface in org.h2.mvstore
A builder for maps.
MVMap.RewriteDecisionMaker<V> - Class in org.h2.mvstore
 
MVPlainTempResult - Class in org.h2.mvstore.db
Plain temporary result.
MVPlainTempResult(Database, Expression[], int, int) - Constructor for class org.h2.mvstore.db.MVPlainTempResult
Creates a new plain temporary result.
MVPlainTempResult(MVPlainTempResult) - Constructor for class org.h2.mvstore.db.MVPlainTempResult
Creates a shallow copy of the result.
MVPrimaryIndex - Class in org.h2.mvstore.db
A table stored in a MVStore.
MVPrimaryIndex(Database, MVTable, int, IndexColumn[], IndexType) - Constructor for class org.h2.mvstore.db.MVPrimaryIndex
 
MVPrimaryIndex.MVStoreCursor - Class in org.h2.mvstore.db
A cursor.
MVRTreeMap<V> - Class in org.h2.mvstore.rtree
An r-tree implementation.
MVRTreeMap(Map<String, Object>, SpatialDataType, DataType<V>) - Constructor for class org.h2.mvstore.rtree.MVRTreeMap
 
MVRTreeMap(MVRTreeMap<V>) - Constructor for class org.h2.mvstore.rtree.MVRTreeMap
 
MVRTreeMap.Builder<V> - Class in org.h2.mvstore.rtree
A builder for this class.
MVRTreeMap.ContainsRTreeCursor<V> - Class in org.h2.mvstore.rtree
 
MVRTreeMap.IntersectsRTreeCursor<V> - Class in org.h2.mvstore.rtree
 
MVRTreeMap.RTreeCursor<V> - Class in org.h2.mvstore.rtree
A cursor to iterate over a subset of the keys.
MVSecondaryIndex - Class in org.h2.mvstore.db
An index stored in a MVStore.
MVSecondaryIndex(Database, MVTable, int, String, IndexColumn[], int, IndexType) - Constructor for class org.h2.mvstore.db.MVSecondaryIndex
 
MVSecondaryIndex.MVStoreCursor - Class in org.h2.mvstore.db
A cursor.
MVSecondaryIndex.Source - Class in org.h2.mvstore.db
 
MVSecondaryIndex.Source.Comparator - Class in org.h2.mvstore.db
 
MVSortedTempResult - Class in org.h2.mvstore.db
Sorted temporary result.
MVSortedTempResult(Database, Expression[], boolean, int[], int, int, SortOrder) - Constructor for class org.h2.mvstore.db.MVSortedTempResult
Creates a new sorted temporary result.
MVSortedTempResult(MVSortedTempResult) - Constructor for class org.h2.mvstore.db.MVSortedTempResult
Creates a shallow copy of the result.
MVSpatialIndex - Class in org.h2.mvstore.db
This is an index based on a MVRTreeMap.
MVSpatialIndex(Database, MVTable, int, String, IndexColumn[], int, IndexType) - Constructor for class org.h2.mvstore.db.MVSpatialIndex
Constructor.
MVSpatialIndex.FindBoundsCursor - Class in org.h2.mvstore.db
A cursor for getBounds() method.
MVSpatialIndex.MVStoreCursor - Class in org.h2.mvstore.db
A cursor.
MVSpatialIndex.SpatialKeyIterator - Class in org.h2.mvstore.db
 
mvStore - Variable in class org.h2.engine.DbSettings
Database setting MV_STORE (default: true).
mvStore - Variable in class org.h2.mvstore.db.LobStorageMap
 
mvStore - Variable in class org.h2.mvstore.db.Store
The store.
MVStore - Class in org.h2.mvstore
A persistent storage for maps.
MVStore(Map<String, Object>) - Constructor for class org.h2.mvstore.MVStore
Create and open the store.
MVStore.BackgroundWriterThread - Class in org.h2.mvstore
A background writer thread to automatically store changes from time to time.
MVStore.Builder - Class in org.h2.mvstore
A builder for an MVStore.
MVStore.RemovedPageInfo - Class in org.h2.mvstore
 
MVStore.TxCounter - Class in org.h2.mvstore
Class TxCounter is a simple data structure to hold version of the store along with the counter of open transactions, which are still operating on this version.
MVStoreCursor(SessionLocal, Iterator<Spatial>, MVTable) - Constructor for class org.h2.mvstore.db.MVSpatialIndex.MVStoreCursor
 
MVStoreCursor(SessionLocal, TransactionMap.TMIterator<SearchRow, Value, SearchRow>, MVTable) - Constructor for class org.h2.mvstore.db.MVSecondaryIndex.MVStoreCursor
 
MVStoreCursor(TransactionMap.TMIterator<Long, SearchRow, Map.Entry<Long, SearchRow>>) - Constructor for class org.h2.mvstore.db.MVPrimaryIndex.MVStoreCursor
 
MVStoreException - Exception in org.h2.mvstore
Various kinds of MVStore problems, along with associated error code.
MVStoreException(int, String) - Constructor for exception org.h2.mvstore.MVStoreException
 
MVStoreTool - Class in org.h2.mvstore
Utility methods used in combination with the MVStore.
MVStoreTool() - Constructor for class org.h2.mvstore.MVStoreTool
 
MVStoreTool.GenericDataType - Class in org.h2.mvstore
A data type that can read any data that is persisted, and converts it to a byte array.
mvTable - Variable in class org.h2.mvstore.db.MVPrimaryIndex
 
mvTable - Variable in class org.h2.mvstore.db.MVSecondaryIndex.MVStoreCursor
 
mvTable - Variable in class org.h2.mvstore.db.MVSecondaryIndex
The multi-value table.
mvTable - Variable in class org.h2.mvstore.db.MVSpatialIndex.MVStoreCursor
 
mvTable - Variable in class org.h2.mvstore.db.MVSpatialIndex
The multi-value table.
MVTable - Class in org.h2.mvstore.db
A table stored in a MVStore.
MVTable(CreateTableData, Store) - Constructor for class org.h2.mvstore.db.MVTable
 
MVTable.TraceLockEvent - Enum in org.h2.mvstore.db
The type of trace lock events
MVTempResult - Class in org.h2.mvstore.db
Temporary result.
MVTempResult(Database, Expression[], int, int) - Constructor for class org.h2.mvstore.db.MVTempResult
Creates a new temporary result.
MVTempResult(MVTempResult) - Constructor for class org.h2.mvstore.db.MVTempResult
Creates a shallow copy of the result.
MVTempResult.CloseImpl - Class in org.h2.mvstore.db
 
MySQL - org.h2.engine.Mode.ModeEnum
 
MYSQL_STYLE - org.h2.engine.Mode.ViewExpressionNames
Use both specified and generated names as is, but replace too long generated names with Name_exp_###.

N

n - Variable in class org.h2.util.Permutations
 
name - Variable in class org.h2.bnf.context.DbColumn
 
name - Variable in class org.h2.bnf.context.DbProcedure
 
name - Variable in class org.h2.bnf.context.DbSchema
The schema name.
name - Variable in class org.h2.bnf.context.DbTableOrView
The table name.
name - Variable in class org.h2.bnf.RuleElement
 
name - Variable in class org.h2.command.ddl.CreateAggregate
 
name - Variable in class org.h2.command.ddl.DropAggregate
 
name - Variable in class org.h2.constraint.DomainColumnResolver
 
name - Variable in class org.h2.engine.ConnectionInfo
The database name
name - Variable in class org.h2.engine.Mode
 
name - Variable in class org.h2.engine.Procedure
 
name - Variable in class org.h2.expression.Variable
 
name - Variable in class org.h2.jdbc.JdbcSavepoint
 
name - Variable in class org.h2.message.TraceWriterAdapter
 
name - Variable in class org.h2.mode.FunctionInfo
The name of the function.
name - Variable in class org.h2.mvstore.tx.Transaction
Transaction name.
name - Variable in class org.h2.security.auth.PropertyConfig
 
name - Variable in class org.h2.security.auth.RealmConfig
 
name - Variable in class org.h2.server.pg.PgServerThread.Portal
The portal name.
name - Variable in class org.h2.server.pg.PgServerThread.Prepared
The object name.
name - Variable in class org.h2.server.web.ConnectionInfo
The connection display name.
name - Variable in class org.h2.server.web.WebApp.IndexInfo
The index name.
name - Variable in class org.h2.store.FileStore
The file name.
name - Variable in class org.h2.store.fs.async.FileAsync
 
name - Variable in class org.h2.store.fs.encrypt.FileEncrypt
 
name - Variable in class org.h2.store.fs.FilePath
The complete path (which may be absolute or relative, depending on the file system).
name - Variable in class org.h2.store.fs.mem.FileMemData
 
name - Variable in class org.h2.store.fs.niomapped.FileNioMapped
 
name - Variable in class org.h2.store.fs.niomem.FileNioMemData
 
name - Variable in class org.h2.store.fs.rec.FileRec
 
name - Variable in class org.h2.table.Column
 
name - Variable in class org.h2.util.SimpleColumnInfo
Name of the column.
name - Variable in class org.h2.value.CompareMode
 
NAME - Static variable in class org.h2.table.DualTable
The name of the range table.
NAME - Static variable in class org.h2.table.RangeTable
The name of the range table.
NAME_TOO_LONG_2 - Static variable in class org.h2.api.ErrorCode
The error with code 42622 is thrown when name of identifier is too long.
NamedExpression - Interface in org.h2.expression.function
A function-like expression with a name.
namedParameters - Variable in class org.h2.jdbc.JdbcCallableStatement
 
nameHashCode - Variable in class org.h2.store.fs.niomem.FileNioMemData
The hash code of the name.
nameNormalized - Variable in class org.h2.engine.ConnectionInfo
 
names - Variable in class org.h2.util.json.JSONValidationTargetWithUniqueKeys
 
names - Variable in class org.h2.util.json.JSONValueTarget
 
NAMES - Static variable in class org.h2.expression.function.ArrayFunction
 
NAMES - Static variable in class org.h2.expression.function.BitFunction
 
NAMES - Static variable in class org.h2.expression.function.CoalesceFunction
 
NAMES - Static variable in class org.h2.expression.function.CompressFunction
 
NAMES - Static variable in class org.h2.expression.function.ConcatFunction
 
NAMES - Static variable in class org.h2.expression.function.CryptFunction
 
NAMES - Static variable in class org.h2.expression.function.CurrentDateTimeValueFunction
 
NAMES - Static variable in class org.h2.expression.function.CurrentGeneralValueSpecification
 
NAMES - Static variable in class org.h2.expression.function.DateTimeFormatFunction
 
NAMES - Static variable in class org.h2.expression.function.DateTimeFunction
 
NAMES - Static variable in class org.h2.expression.function.DayMonthNameFunction
 
NAMES - Static variable in class org.h2.expression.function.DBObjectFunction
 
NAMES - Static variable in class org.h2.expression.function.FileFunction
 
NAMES - Static variable in class org.h2.expression.function.HashFunction
 
NAMES - Static variable in class org.h2.expression.function.LengthFunction
 
NAMES - Static variable in class org.h2.expression.function.MathFunction
 
NAMES - Static variable in class org.h2.expression.function.MathFunction1
 
NAMES - Static variable in class org.h2.expression.function.MathFunction2
 
NAMES - Static variable in class org.h2.expression.function.RandFunction
 
NAMES - Static variable in class org.h2.expression.function.RegexpFunction
 
NAMES - Static variable in class org.h2.expression.function.SessionControlFunction
 
NAMES - Static variable in class org.h2.expression.function.SoundexFunction
 
NAMES - Static variable in class org.h2.expression.function.StringFunction
 
NAMES - Static variable in class org.h2.expression.function.StringFunction1
 
NAMES - Static variable in class org.h2.expression.function.StringFunction2
 
NAMES - Static variable in class org.h2.expression.function.SysInfoFunction
 
NAMES - Static variable in class org.h2.expression.function.table.ArrayTableFunction
 
NAMES - Static variable in class org.h2.expression.function.TableInfoFunction
 
NAMES - Static variable in class org.h2.expression.function.ToCharFunction
 
NAMES - Static variable in class org.h2.expression.function.XMLFunction
 
NAMES - Static variable in class org.h2.value.Value
 
nameSeparatorsToNative(String) - Static method in class org.h2.util.IOUtils
Converts / and \ name separators in path to native separators.
NAN - Static variable in class org.h2.value.ValueDecfloat
The not a number value.
NAN - Static variable in class org.h2.value.ValueDouble
 
NAN - Static variable in class org.h2.value.ValueReal
 
nanos - Variable in class org.h2.mode.ToDateParser
 
nanos - Variable in class org.h2.value.ValueTime
Nanoseconds since midnight
nanos - Variable in class org.h2.value.ValueTimeTimeZone
Nanoseconds since midnight
NANOS - Static variable in class org.h2.bnf.RuleFixed
 
NANOS_PER_DAY - Static variable in class org.h2.util.DateTimeUtils
The number of nanoseconds per day.
NANOS_PER_DAY_BI - Static variable in class org.h2.util.IntervalUtils
The number of nanoseconds per day as BigInteger.
NANOS_PER_HOUR - Static variable in class org.h2.util.DateTimeUtils
The number of nanoseconds per hour.
NANOS_PER_HOUR_BI - Static variable in class org.h2.util.IntervalUtils
 
NANOS_PER_MINUTE - Static variable in class org.h2.util.DateTimeUtils
The number of nanoseconds per minute.
NANOS_PER_MINUTE_BI - Static variable in class org.h2.util.IntervalUtils
 
NANOS_PER_SECOND - Static variable in class org.h2.util.DateTimeUtils
The number of nanoseconds per second.
NANOS_PER_SECOND_BI - Static variable in class org.h2.util.IntervalUtils
 
NANOSECOND - Static variable in class org.h2.expression.function.DateTimeFunction
Nanosecond.
nanosFromInterval(IntervalQualifier, boolean, long, long) - Static method in class org.h2.util.IntervalUtils
Returns nanoseconds value of interval, if any.
nanosFromLocalMillis(long) - Static method in class org.h2.util.LegacyDateTimeUtils
Convert a time in milliseconds in local time to the nanoseconds since midnight.
nanosFromLocalSeconds(long) - Static method in class org.h2.util.DateTimeUtils
Convert a time in seconds in local time to the nanoseconds since midnight.
nanosFromValue(SessionLocal, Value) - Static method in class org.h2.expression.IntervalOperation
 
nanoTimePlusMillis(long, int) - Static method in class org.h2.util.Utils
Returns the current value of the high-resolution time source plus the specified offset.
nativeSQL(String) - Method in class org.h2.jdbc.JdbcConnection
Translates a SQL statement into the database grammar.
NATURAL - Static variable in class org.h2.util.ParserUtil
The token "NATURAL".
needFlush() - Method in class org.h2.mvstore.RootReference
Whether flushing is needed.
needParentheses() - Method in class org.h2.expression.BinaryOperation
 
needParentheses() - Method in class org.h2.expression.CompatibilityDatePlusTimeOperation
 
needParentheses() - Method in class org.h2.expression.ConcatenationOperation
 
needParentheses() - Method in class org.h2.expression.condition.BetweenPredicate
 
needParentheses() - Method in class org.h2.expression.condition.CompareLike
 
needParentheses() - Method in class org.h2.expression.condition.Comparison
 
needParentheses() - Method in class org.h2.expression.condition.ConditionAndOr
 
needParentheses() - Method in class org.h2.expression.condition.ConditionAndOrN
 
needParentheses() - Method in class org.h2.expression.condition.ConditionIn
 
needParentheses() - Method in class org.h2.expression.condition.ConditionInConstantSet
 
needParentheses() - Method in class org.h2.expression.condition.ConditionInParameter
 
needParentheses() - Method in class org.h2.expression.condition.ConditionInQuery
 
needParentheses() - Method in class org.h2.expression.condition.ConditionLocalAndGlobal
 
needParentheses() - Method in class org.h2.expression.condition.ConditionNot
 
needParentheses() - Method in class org.h2.expression.condition.IsJsonPredicate
 
needParentheses() - Method in class org.h2.expression.condition.SimplePredicate
 
needParentheses() - Method in class org.h2.expression.Expression
Returns whether this expressions needs to be wrapped in parentheses when it is used as an argument of other expressions.
needParentheses() - Method in class org.h2.expression.IntervalOperation
 
needParentheses() - Method in class org.h2.expression.UnaryOperation
 
needRebuild() - Method in class org.h2.index.Index
Check if the index needs to be rebuilt.
needRebuild() - Method in class org.h2.index.LinkedIndex
 
needRebuild() - Method in class org.h2.index.MetaIndex
 
needRebuild() - Method in class org.h2.index.ViewIndex
 
needRebuild() - Method in class org.h2.index.VirtualTableIndex
 
needRebuild() - Method in class org.h2.mvstore.db.MVDelegateIndex
 
needRebuild() - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
needRebuild() - Method in class org.h2.mvstore.db.MVSecondaryIndex
 
needRebuild() - Method in class org.h2.mvstore.db.MVSpatialIndex
 
needRecompile() - Method in class org.h2.command.dml.BackupCommand
 
needRecompile() - Method in class org.h2.command.dml.NoOperation
 
needRecompile() - Method in class org.h2.command.dml.ScriptBase
 
needRecompile() - Method in class org.h2.command.dml.Set
 
needRecompile() - Method in class org.h2.command.dml.SetSessionCharacteristics
 
needRecompile() - Method in class org.h2.command.dml.TransactionCommand
 
needRecompile() - Method in class org.h2.command.Prepared
Check if the statement needs to be re-compiled.
needSeparator - Variable in class org.h2.util.json.JSONByteArrayTarget
 
needSeparator - Variable in class org.h2.util.json.JSONStringTarget
 
needSeparator - Variable in class org.h2.util.json.JSONValidationTargetWithoutUniqueKeys
 
needSeparator - Variable in class org.h2.util.json.JSONValidationTargetWithUniqueKeys
 
needSeparator - Variable in class org.h2.util.json.JSONValueTarget
 
needStore() - Method in class org.h2.mvstore.MVStore
 
needsUnicodeConversion() - Method in class org.h2.command.Token.CharacterStringToken
 
needsUnicodeConversion() - Method in class org.h2.command.Token.IdentifierToken
 
needsUnicodeConversion() - Method in class org.h2.command.Token
 
needToClose() - Method in class org.h2.result.FetchedResult
 
needToClose() - Method in class org.h2.result.LocalResult
 
needToClose() - Method in interface org.h2.result.ResultInterface
Check if this result set should be closed, for example because it is buffered using a temporary file.
needToClose() - Method in class org.h2.result.ResultWithPaddedStrings
 
needToClose() - Method in class org.h2.result.SimpleResult
 
negate() - Method in class org.h2.value.Value
Return -value if this value support arithmetic operations.
negate() - Method in class org.h2.value.ValueBigint
 
negate() - Method in class org.h2.value.ValueBoolean
 
negate() - Method in class org.h2.value.ValueDecfloat
 
negate() - Method in class org.h2.value.ValueDouble
 
negate() - Method in class org.h2.value.ValueInteger
 
negate() - Method in class org.h2.value.ValueInterval
 
negate() - Method in class org.h2.value.ValueNumeric
 
negate() - Method in class org.h2.value.ValueReal
 
negate() - Method in class org.h2.value.ValueSmallint
 
negate() - Method in class org.h2.value.ValueTinyint
 
negative - Variable in class org.h2.api.Interval
false for zero or positive intervals, true for negative intervals.
negative - Variable in class org.h2.value.ValueInterval
 
NEGATIVE_INFINITY - Static variable in class org.h2.value.ValueDecfloat
The negative infinity value.
nestedIdentity - Variable in class org.h2.security.auth.AuthenticationInfo
Can be used by authenticator to hold information.
nestedJoin - Variable in class org.h2.table.TableFilter
The nested joined table (if there is one).
nestedJoinPlan - Variable in class org.h2.table.PlanItem
 
NetUtils - Class in org.h2.util
This utility class contains socket helper functions.
NetUtils() - Constructor for class org.h2.util.NetUtils
 
networkConnectionInfo - Variable in class org.h2.engine.ConnectionInfo
 
networkConnectionInfo - Variable in class org.h2.engine.SessionLocal
 
NetworkConnectionInfo - Class in org.h2.util
Network connection information.
NetworkConnectionInfo(String, byte[], int, String) - Constructor for class org.h2.util.NetworkConnectionInfo
Creates new instance of network connection information.
NetworkConnectionInfo(String, String, int) - Constructor for class org.h2.util.NetworkConnectionInfo
Creates new instance of network connection information.
NEVER - org.h2.engine.Mode.CharPadding
Spaces are trimmed from the right side of CHAR values.
neverLazy - Variable in class org.h2.command.query.Query
 
NEW - org.h2.jdbc.JdbcLob.State
New object without a value.
NEW - org.h2.table.DataChangeDeltaTable.ResultOption
NEW row with evaluated default expressions, but before triggers.
NEW_TABLE_ALIAS - Static variable in class org.h2.bnf.context.DbContextRule
 
newBufferedReader(String, Charset) - Static method in class org.h2.store.fs.FileUtils
Create a buffered reader to read from the file.
newBytes(int) - Static method in class org.h2.util.Utils
Create an array of bytes with the given size.
newColumn - Variable in class org.h2.command.ddl.AlterTableAlterColumn
 
newConcurrentStringMap() - Method in class org.h2.engine.Database
Create a new hash map.
newConstraintName - Variable in class org.h2.command.ddl.AlterDomainRenameConstraint
 
newConstraintName - Variable in class org.h2.command.ddl.AlterTableRenameConstraint
 
newDirectoryStream() - Method in class org.h2.store.fs.disk.FilePathDisk
 
newDirectoryStream() - Method in class org.h2.store.fs.FilePath
List the files and directories in the given directory.
newDirectoryStream() - Method in class org.h2.store.fs.FilePathWrapper
 
newDirectoryStream() - Method in class org.h2.store.fs.mem.FilePathMem
 
newDirectoryStream() - Method in class org.h2.store.fs.niomem.FilePathNioMem
 
newDirectoryStream() - Method in class org.h2.store.fs.split.FilePathSplit
 
newDirectoryStream() - Method in class org.h2.store.fs.zip.FilePathZip
 
newDirectoryStream(String) - Static method in class org.h2.store.fs.FileUtils
List the files and directories in the given directory.
newDomainName - Variable in class org.h2.command.ddl.AlterDomainRename
 
newFileChannelOutputStream(FileChannel, boolean) - Static method in class org.h2.store.fs.FilePath
Create a new output stream from the channel.
NEWID - Static variable in class org.h2.mode.FunctionsMSSQLServer
 
newIllegalArgumentException(String, Object...) - Static method in class org.h2.mvstore.DataUtils
Create a new IllegalArgumentException.
newIndexName - Variable in class org.h2.command.ddl.AlterIndexRename
 
newInputStream() - Method in class org.h2.store.fs.disk.FilePathDisk
 
newInputStream() - Method in class org.h2.store.fs.encrypt.FilePathEncrypt
 
newInputStream() - Method in class org.h2.store.fs.FilePath
Create an input stream to read from the file.
newInputStream() - Method in class org.h2.store.fs.FilePathWrapper
 
newInputStream() - Method in class org.h2.store.fs.split.FilePathSplit
 
newInputStream(String) - Static method in class org.h2.store.fs.FileUtils
Create an input stream to read from the file.
newInstance(int) - Static method in class org.h2.util.SmallLRUCache
Create a new object with all elements of the given collection.
newInstance(String, Object...) - Static method in class org.h2.util.Utils
Creates a new instance.
newInstance(Schema, int, String, String, boolean) - Static method in class org.h2.schema.FunctionAlias
Create a new alias based on a method name.
newInstanceFromSource(Schema, int, String, String, boolean) - Static method in class org.h2.schema.FunctionAlias
Create a new alias based on source code.
newMVStoreException(int, String, Object...) - Static method in class org.h2.mvstore.DataUtils
Create a new MVStoreException.
newName - Variable in class org.h2.command.ddl.AlterTableRenameColumn
 
newName - Variable in class org.h2.command.ddl.AlterUser
 
newOutputStream(boolean) - Method in class org.h2.store.fs.disk.FilePathDisk
 
newOutputStream(boolean) - Method in class org.h2.store.fs.encrypt.FilePathEncrypt
 
newOutputStream(boolean) - Method in class org.h2.store.fs.FilePath
Create an output stream to write into the file.
newOutputStream(boolean) - Method in class org.h2.store.fs.FilePathWrapper
 
newOutputStream(boolean) - Method in class org.h2.store.fs.rec.FilePathRec
 
newOutputStream(boolean) - Method in class org.h2.store.fs.split.FilePathSplit
 
newOutputStream(boolean) - Method in class org.h2.store.fs.zip.FilePathZip
 
newOutputStream(String, boolean) - Static method in class org.h2.store.fs.FileUtils
Create an output stream to write into the file.
newPage(boolean) - Method in class org.h2.mvstore.rtree.MVRTreeMap
 
newPrimaryKeyConstraintCommand(SessionLocal, Schema, String, Column) - Static method in class org.h2.command.Parser
Create a new alter table command.
newSchemaName - Variable in class org.h2.command.ddl.AlterSchemaRename
 
newSelectivity - Variable in class org.h2.command.ddl.AlterTableAlterColumn
 
newSmallArrayList() - Static method in class org.h2.util.Utils
Create a new ArrayList with an initial capacity of 4.
newStringMap() - Method in class org.h2.engine.Database
Create a new hash map.
newStringMap(int) - Method in class org.h2.engine.Database
Create a new hash map.
newTableName - Variable in class org.h2.command.ddl.AlterTableRename
 
newTables - Variable in class org.h2.schema.InformationSchema
 
newType(int) - Method in class org.h2.mvstore.type.ObjectDataType
 
newUnsupportedOperationException(String) - Static method in class org.h2.mvstore.DataUtils
Create a new UnsupportedOperationException.
next - Variable in class org.h2.bnf.Sentence
The map of next tokens in the form type#tokenName token.
next - Variable in class org.h2.expression.SimpleCase.SimpleWhen
 
next - Variable in class org.h2.mvstore.Chunk
The predicted position of the next chunk.
next() - Method in class org.h2.command.query.SelectGroups.Grouped
 
next() - Method in class org.h2.command.query.SelectGroups
Returns the key of the next group.
next() - Method in class org.h2.command.query.SelectGroups.Plain
 
next() - Method in class org.h2.expression.analysis.WindowFrame.BiItr
 
next() - Method in class org.h2.expression.analysis.WindowFrame.BiReverseItr
 
next() - Method in class org.h2.expression.analysis.WindowFrame.PlainItr
 
next() - Method in class org.h2.expression.analysis.WindowFrame.PlainReverseItr
 
next() - Method in class org.h2.expression.analysis.WindowFrame.TriItr
 
next() - Method in class org.h2.expression.analysis.WindowFrame.TriReverseItr
 
next() - Method in interface org.h2.index.Cursor
Skip to the next row if one is available.
next() - Method in class org.h2.index.DualCursor
 
next() - Method in class org.h2.index.IndexCursor
 
next() - Method in class org.h2.index.LinkedCursor
 
next() - Method in class org.h2.index.MetaCursor
 
next() - Method in class org.h2.index.RangeCursor
 
next() - Method in class org.h2.index.SingleRowCursor
 
next() - Method in class org.h2.index.ViewCursor
 
next() - Method in class org.h2.index.VirtualTableCursor
 
next() - Method in class org.h2.jdbc.JdbcResultSet
Moves the cursor to the next row of the result set.
next() - Method in class org.h2.mvstore.Cursor
 
next() - Method in class org.h2.mvstore.db.MVPlainTempResult
 
next() - Method in class org.h2.mvstore.db.MVPrimaryIndex.MVStoreCursor
 
next() - Method in class org.h2.mvstore.db.MVSecondaryIndex.MVStoreCursor
 
next() - Method in class org.h2.mvstore.db.MVSecondaryIndex.Source
 
next() - Method in class org.h2.mvstore.db.MVSortedTempResult
 
next() - Method in class org.h2.mvstore.db.MVSpatialIndex.MVStoreCursor
 
next() - Method in class org.h2.mvstore.db.MVSpatialIndex.SpatialKeyIterator
 
next() - Method in class org.h2.mvstore.rtree.MVRTreeMap.RTreeCursor
 
next() - Method in class org.h2.mvstore.tx.TransactionMap.TMIterator
 
next() - Method in class org.h2.result.FetchedResult
 
next() - Method in class org.h2.result.LocalResult
 
next() - Method in interface org.h2.result.ResultExternal
Get the next row from the result.
next() - Method in interface org.h2.result.ResultInterface
Go to the next row.
next() - Method in class org.h2.result.ResultWithPaddedStrings
 
next() - Method in class org.h2.result.SimpleResult
 
next() - Method in class org.h2.table.TableFilter
Check if there are more rows to read.
next() - Method in class org.h2.tools.SimpleResultSet
Moves the cursor to the next row of the result set.
next() - Method in class org.h2.util.Permutations
Go to the next lineup, and if available, fill the target array.
next(int, byte[], int) - Static method in class org.h2.compress.CompressLZF
Shift the value 1 byte left, and add the byte at index inPos+2.
next(int, ByteBuffer, int) - Static method in class org.h2.compress.CompressLZF
Shift the value 1 byte left, and add the byte at index inPos+2.
nextAnalyze - Variable in class org.h2.mvstore.db.MVTable
 
nextBuffer - Variable in class org.h2.mvstore.StreamStore
 
nextBuffer() - Method in class org.h2.mvstore.StreamStore.Stream
 
nextChar() - Method in class org.h2.util.json.JSONBytesSource
 
nextChar() - Method in class org.h2.util.json.JSONStringSource
 
nextChar() - Method in class org.h2.util.json.JSONTextSource
Read the next character.
nextCharAfterWhitespace() - Method in class org.h2.util.json.JSONBytesSource
 
nextCharAfterWhitespace() - Method in class org.h2.util.json.JSONStringSource
 
nextCharAfterWhitespace() - Method in class org.h2.util.json.JSONTextSource
Skip all whitespace characters, and get the next character.
nextCursor() - Method in class org.h2.index.IndexCursor
 
nextId - Variable in class org.h2.engine.SessionRemote
 
nextImpl() - Method in class org.h2.index.VirtualTableCursor
Skip to the next row if one is available.
nextKey - Variable in class org.h2.mvstore.StreamStore
 
nextLazyGroup() - Method in class org.h2.command.query.SelectGroups
Moves group data to the next group in lazy mode.
nextLazyRow() - Method in class org.h2.command.query.SelectGroups
Moves group data to the next row in lazy mode.
nextLazyRow() - Method in class org.h2.jdbc.JdbcResultSet
 
nextLobId - Variable in class org.h2.command.dml.ScriptCommand
 
nextLobId - Variable in class org.h2.mvstore.db.LobStorageMap
 
nextObjectId() - Method in class org.h2.engine.SessionLocal
Get the next object id.
nextPowerOf2(int) - Static method in class org.h2.util.MathUtils
Get the value that is equal to or higher than this value, and that is a power of two.
nextRow - Variable in class org.h2.result.FetchedResult
 
nextRow() - Method in class org.h2.jdbc.JdbcResultSet
 
nextRow(long, long) - Method in class org.h2.command.dml.FilteredDataChangeStatement
 
nextSerialId - Static variable in class org.h2.engine.SessionLocal
 
nextSessionId - Variable in class org.h2.engine.Database
 
nextSource() - Method in class org.h2.command.query.SelectGroups.Grouped
 
nextSource() - Method in class org.h2.command.query.SelectGroups
Invoked for each source row to evaluate group key and setup all necessary data for aggregates.
nextSource() - Method in class org.h2.command.query.SelectGroups.Plain
 
nextTemporaryMapName() - Method in class org.h2.mvstore.db.Store
Get the name of the next available temporary map.
nextTempTableId - Variable in class org.h2.engine.Database
 
nextThreadId - Variable in class org.h2.server.TcpServer
 
nextvalAndCurrvalPseudoColumns - Variable in class org.h2.engine.Mode
If true, sequence.NEXTVAL and sequence.CURRVAL pseudo columns are supported.
nextValue - Variable in class org.h2.engine.SessionLocal.RowNumberAndValue
 
nextValueFor - Variable in class org.h2.engine.SessionLocal
 
nextValueReturnsDifferentValues - Variable in class org.h2.engine.Mode
If true, the next value expression returns different values when invoked multiple times within a row.
NIO_CLEANER_HACK - Static variable in class org.h2.engine.SysProperties
System property h2.nioCleanerHack (default: false).
NIO_LOAD_MAPPED - Static variable in class org.h2.engine.SysProperties
System property h2.nioLoadMapped (default: false).
NO - org.h2.store.FileLockMethod
This locking method means no locking is used at all.
NO - Static variable in interface org.h2.compress.Compressor
No compression is used.
NO - Static variable in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
NO - Static variable in class org.h2.jdbc.meta.DatabaseMetaLocal
 
NO_ATTRIBUTES - Static variable in class org.h2.store.fs.FileUtils
No file attributes.
NO_CASTS - Static variable in interface org.h2.util.HasSQL
Don't add casts around literals.
NO_CYCLE - org.h2.schema.Sequence.Cycle
Sequence is not cycled and isn't exhausted yet.
NO_DATA_AVAILABLE - Static variable in class org.h2.api.ErrorCode
The error with code 2000 is thrown when the result set is positioned before the first or after the last row, or not on a valid row for the given operation.
NO_DEFAULT_SET_1 - Static variable in class org.h2.api.ErrorCode
The error with code 23507 is thrown when updating or deleting from a table with a foreign key constraint that should set the default value, but there is no default value defined.
NO_EXTRA_INFO - Static variable in class org.h2.mvstore.db.MVTable
 
NO_NULL_CONSTRAINT_FOUND - org.h2.command.Parser.NullConstraintType
 
NO_OPERATION - Static variable in interface org.h2.command.CommandInterface
The type of a no operation statement.
NO_USAGE_RESTRICTIONS - Static variable in class org.h2.jdbc.meta.DatabaseMetaLocal
 
noCache - Variable in class org.h2.command.query.Query
 
NON_KEYWORDS - Static variable in class org.h2.command.dml.SetTypes
The type of a SET NON_KEYWORDS statement.
NONE - Static variable in class org.h2.engine.GeneratedKeysMode
Generated keys are not needed.
nonKeywords - Variable in class org.h2.command.Parser
 
nonKeywords - Variable in class org.h2.command.Tokenizer
 
nonKeywords - Variable in class org.h2.engine.SessionLocal
 
NonLeaf(MVMap<K, V>) - Constructor for class org.h2.mvstore.Page.NonLeaf
 
NonLeaf(MVMap<K, V>, K[], Page.PageReference<K, V>[], long) - Constructor for class org.h2.mvstore.Page.NonLeaf
 
NonLeaf(MVMap<K, V>, Page.NonLeaf<K, V>, Page.PageReference<K, V>[], long) - Constructor for class org.h2.mvstore.Page.NonLeaf
 
nonLeafCount - Variable in class org.h2.mvstore.MVStore
 
nonResidentQueueSize - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Config
Low water mark for the number of entries in the non-resident queue, as a factor of the number of all other entries in the map.
nonResidentQueueSize - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS
 
nonResidentQueueSize - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
Low watermark for the number of entries in the non-resident queue, as a factor of the number of entries in the map.
nonResidentQueueSizeHigh - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Config
High watermark for the number of entries in the non-resident queue, as a factor of the number of all other entries in the map
nonResidentQueueSizeHigh - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS
 
nonResidentQueueSizeHigh - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
High watermark for the number of entries in the non-resident queue, as a factor of the number of entries in the map.
NOOP_ENTITY_RESOLVER - Static variable in class org.h2.jdbc.JdbcSQLXML
 
NOOP_URI_RESOLVER - Static variable in class org.h2.jdbc.JdbcSQLXML
 
NoOperation - Class in org.h2.command.dml
Represents an empty statement or a statement that has no effect.
NoOperation(SessionLocal) - Constructor for class org.h2.command.dml.NoOperation
 
NORMAL_DAYS_PER_MONTH - Static variable in class org.h2.util.DateTimeUtils
 
normalize(byte[]) - Static method in class org.h2.util.json.JSONBytesSource
Converts bytes into normalized JSON representation.
normalize(int, double, double, double) - Method in class org.h2.tools.MultiDimension
Normalize a value so that it is between the minimum and maximum for the given number of dimensions.
normalize(String) - Static method in class org.h2.util.json.JSONStringSource
Normalizes textual JSON representation.
normalizeNanosOfDay(long) - Static method in class org.h2.util.DateTimeUtils
Calculate the normalized nanos of day.
normalizeWord(String) - Static method in class org.h2.fulltext.FullTextSettings
 
not - Variable in class org.h2.expression.condition.BetweenPredicate
 
not - Variable in class org.h2.expression.condition.CompareLike
 
not - Variable in class org.h2.expression.condition.ConditionIn
 
not - Variable in class org.h2.expression.condition.ConditionInConstantSet
 
not - Variable in class org.h2.expression.condition.ConditionInParameter
 
not - Variable in class org.h2.expression.condition.ConditionInQuery
 
not - Variable in class org.h2.expression.condition.IsJsonPredicate
 
not - Variable in class org.h2.expression.condition.SimplePredicate
Whether it is a "not" condition (e.g.
NOT - Static variable in class org.h2.util.ParserUtil
The token "NOT".
NOT_ENOUGH_RIGHTS_FOR_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90096 is thrown when trying to perform an operation with a non-admin user if the user does not have enough rights.
NOT_EQUAL - Static variable in class org.h2.command.Token
The token "<>" or "!=".
NOT_EQUAL - Static variable in class org.h2.expression.condition.Comparison
The comparison type meaning <> as in ID<>1.
NOT_EQUAL_NULL_SAFE - Static variable in class org.h2.expression.condition.Comparison
The comparison type meaning ID IS DISTINCT FROM 1.
NOT_FROM_RESOLVER - Static variable in class org.h2.expression.ExpressionVisitor
Does an expression have no relation to the given table filter (getResolver)?
NOT_NULLABLE - Static variable in class org.h2.table.Column
This column is not nullable.
NOT_ON_UPDATABLE_ROW - Static variable in class org.h2.api.ErrorCode
The error with code 90029 is thrown when calling ResultSet.deleteRow(), insertRow(), or updateRow() when the current row is not updatable.
NOT_TILDE - Static variable in class org.h2.command.Token
The token "!~".
notificationRequested - Variable in class org.h2.mvstore.MVMap
 
notificationRequested - Variable in class org.h2.mvstore.tx.Transaction
Whether other transaction(s) are waiting for this to close.
notifyAllWaitingTransactions() - Method in class org.h2.mvstore.tx.Transaction
 
notifyWaiters() - Method in class org.h2.mvstore.MVMap
 
noWait - Variable in class org.h2.command.ddl.CreateTrigger
 
noWait - Variable in class org.h2.schema.TriggerObject
 
NTH_VALUE - org.h2.expression.analysis.WindowFunctionType
The type for NTH_VALUE() window function.
NTILE - org.h2.expression.analysis.WindowFunctionType
The type for NTILE() window function.
NULL - Static variable in class org.h2.expression.ValueExpression
The expression represents ValueNull.INSTANCE.
NULL - Static variable in class org.h2.mvstore.db.ValueDataType
 
NULL - Static variable in class org.h2.table.InformationSchemaTable.DataTypeInformation
 
NULL - Static variable in class org.h2.util.json.JSONNull
null value.
NULL - Static variable in class org.h2.util.ParserUtil
The token "NULL".
NULL - Static variable in class org.h2.value.Transfer
 
NULL - Static variable in class org.h2.value.Value
The value type for NULL.
NULL - Static variable in class org.h2.value.ValueJson
null JSON value.
NULL_BYTES - Static variable in class org.h2.util.json.JSONByteArrayTarget
 
NULL_BYTES - Static variable in class org.h2.value.ValueJson
 
NULL_IS_ALLOWED - org.h2.command.Parser.NullConstraintType
 
NULL_IS_NOT_ALLOWED - org.h2.command.Parser.NullConstraintType
 
NULL_NOT_ALLOWED - Static variable in class org.h2.api.ErrorCode
The error with code 23502 is thrown when trying to insert NULL into a column that does not allow NULL.
NULL_ROW - Static variable in class org.h2.table.TableFilter
 
nullable - Variable in class org.h2.expression.ParameterRemote
 
nullable - Variable in class org.h2.result.ResultColumn
True if this column is nullable.
nullable - Variable in class org.h2.table.Column
 
NULLABLE - Static variable in class org.h2.table.Column
This column is nullable.
NULLABLE_UNKNOWN - Static variable in class org.h2.table.Column
It is not know whether this column is nullable.
nullAsc - Variable in enum org.h2.mode.DefaultNullOrdering
 
nullCollectionMode - Variable in class org.h2.expression.aggregate.AggregateDataCollecting
 
NullCollectionMode() - Constructor for enum org.h2.expression.aggregate.AggregateDataCollecting.NullCollectionMode
 
NullConstraintType() - Constructor for enum org.h2.command.Parser.NullConstraintType
 
nullDesc - Variable in enum org.h2.mode.DefaultNullOrdering
 
NullIfFunction - Class in org.h2.expression.function
A NULLIF function.
NullIfFunction(Expression, Expression) - Constructor for class org.h2.expression.function.NullIfFunction
 
nullIfParameterIsNull - Variable in class org.h2.mode.FunctionInfo
If the result of the function is NULL if any of the parameters is NULL.
nullPlusNonNullIsNull() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether NULL+1 is NULL or not.
NullPredicate - Class in org.h2.expression.condition
Null predicate (IS [NOT] NULL).
NullPredicate(Expression, boolean, boolean) - Constructor for class org.h2.expression.condition.NullPredicate
 
nullRow - Variable in class org.h2.table.Table
 
NULLS_FIRST - Static variable in class org.h2.result.SortOrder
This bit mask means NULLs should be sorted before other data, no matter if ascending or descending order is used.
NULLS_LAST - Static variable in class org.h2.result.SortOrder
This bit mask means NULLs should be sorted after other data, no matter if ascending or descending order is used.
nullsAreSortedAtEnd() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Checks if NULL values are sorted at the end (no matter if ASC or DESC is used).
nullsAreSortedAtStart() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Checks if NULL values are sorted at the beginning (no matter if ASC or DESC is used).
nullsAreSortedHigh() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Checks if NULL values are sorted high (bigger than anything that is not null).
nullsAreSortedLow() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Checks if NULL values are sorted low (smaller than anything that is not null).
nullString - Variable in class org.h2.tools.Csv
 
NullType() - Constructor for class org.h2.mvstore.type.ObjectDataType.NullType
 
nullValue - Variable in class org.h2.expression.Subquery
 
NullValueDataType - Class in org.h2.mvstore.db
Dummy data type used when no value is required.
NullValueDataType() - Constructor for class org.h2.mvstore.db.NullValueDataType
 
NUM_SERVERS - Static variable in class org.h2.jdbc.JdbcConnection
 
number - Variable in class org.h2.command.Token.BigintToken
 
number - Variable in class org.h2.command.Token.IntegerToken
 
NUMBER - org.h2.engine.Mode.ExpressionNames
Use ordinal number of a column.
NUMERIC - Static variable in class org.h2.api.H2Type
The NUMERIC data type.
NUMERIC - Static variable in class org.h2.mvstore.db.ValueDataType
 
NUMERIC - Static variable in class org.h2.value.Transfer
 
NUMERIC - Static variable in class org.h2.value.Value
The value type for NUMERIC values.
NUMERIC_0_1 - Static variable in class org.h2.mvstore.db.ValueDataType
 
NUMERIC_SMALL - Static variable in class org.h2.mvstore.db.ValueDataType
 
NUMERIC_SMALL_0 - Static variable in class org.h2.mvstore.db.ValueDataType
 
NUMERIC_VALUE_OUT_OF_RANGE_1 - Static variable in class org.h2.api.ErrorCode
The error with code 22003 is thrown when a value is out of range when converting to another data type.
NUMERIC_VALUE_OUT_OF_RANGE_2 - Static variable in class org.h2.api.ErrorCode
The error with code 22004 is thrown when a value is out of range when converting to another column's data type.
numericPrecision - Variable in class org.h2.table.InformationSchemaTable.DataTypeInformation
NUMERIC_PRECISION.
numericPrecisionRadix - Variable in class org.h2.table.InformationSchemaTable.DataTypeInformation
NUMERIC_PRECISION_RADIX.
numericScale - Variable in class org.h2.table.InformationSchemaTable.DataTypeInformation
NUMERIC_SCALE.
numericWithBooleanComparison - Variable in class org.h2.engine.Mode
Allow to compare numeric with BOOLEAN.
numFrameExpressions - Variable in class org.h2.expression.analysis.DataAnalysisOperation
 

O

OBJ_DESCRIPTION - Static variable in class org.h2.mode.FunctionsPostgreSQL
 
OBJECT - org.h2.util.json.JSONItemType
JSON object.
OBJECT - Static variable in class org.h2.util.json.JSONStringTarget
A JSON object.
OBJECT - Static variable in class org.h2.util.json.JSONValidationTargetWithoutUniqueKeys
 
OBJECT_CACHE - Static variable in class org.h2.engine.SysProperties
System property h2.objectCache (default: true).
OBJECT_CACHE_MAX_PER_ELEMENT_SIZE - Static variable in class org.h2.engine.SysProperties
System property h2.objectCacheMaxPerElementSize (default: 4096).
OBJECT_CACHE_SIZE - Static variable in class org.h2.engine.SysProperties
System property h2.objectCacheSize (default: 1024).
OBJECT_CLOSED - Static variable in class org.h2.api.ErrorCode
The error with code 90007 is thrown when trying to call a JDBC method on an object that has been closed.
ObjectArrayType() - Constructor for class org.h2.mvstore.type.ObjectDataType.ObjectArrayType
 
ObjectDataType - Class in org.h2.mvstore.type
A data type implementation for the most common data types, including serializable objects.
ObjectDataType() - Constructor for class org.h2.mvstore.type.ObjectDataType
 
ObjectDataType.AutoDetectDataType<T> - Class in org.h2.mvstore.type
The base class for auto-detect data types.
ObjectDataType.BigDecimalType - Class in org.h2.mvstore.type
The type for BigDecimal objects.
ObjectDataType.BigIntegerType - Class in org.h2.mvstore.type
The type for BigInteger objects.
ObjectDataType.BooleanType - Class in org.h2.mvstore.type
The type for boolean true and false.
ObjectDataType.ByteType - Class in org.h2.mvstore.type
The type for byte objects.
ObjectDataType.CharacterType - Class in org.h2.mvstore.type
The type for character objects.
ObjectDataType.DateType - Class in org.h2.mvstore.type
The type for java.util.Date objects.
ObjectDataType.DoubleType - Class in org.h2.mvstore.type
The type for double objects.
ObjectDataType.FloatType - Class in org.h2.mvstore.type
The type for float objects.
ObjectDataType.Holder - Class in org.h2.mvstore.type
 
ObjectDataType.IntegerType - Class in org.h2.mvstore.type
The type for integer objects.
ObjectDataType.LongType - Class in org.h2.mvstore.type
The type for long objects.
ObjectDataType.NullType - Class in org.h2.mvstore.type
The type for the null value
ObjectDataType.ObjectArrayType - Class in org.h2.mvstore.type
The type for object arrays.
ObjectDataType.SerializedObjectType - Class in org.h2.mvstore.type
The type for serialized objects.
ObjectDataType.ShortType - Class in org.h2.mvstore.type
The type for short objects.
ObjectDataType.StringType - Class in org.h2.mvstore.type
The type for string objects.
ObjectDataType.UUIDType - Class in org.h2.mvstore.type
The type for UUID objects.
objectId - Variable in class org.h2.engine.SessionLocal
 
objectIds - Variable in class org.h2.engine.Database
 
objectIdSet - Variable in class org.h2.tools.Recover
 
objectName - Variable in class org.h2.command.ddl.SetComment
 
objectName - Variable in class org.h2.engine.DbObject
 
objectToValue(Session, Object, int) - Static method in class org.h2.value.ValueToObjectConverter
Convert a Java object to a value.
objectType - Variable in class org.h2.command.ddl.SetComment
 
objectType - Variable in class org.h2.engine.Comment
 
objectType - Variable in class org.h2.engine.MetaRecord
 
occupancy - Variable in class org.h2.mvstore.Chunk
Collection of "deleted" flags for all pages in the chunk.
OCTET_LENGTH - Static variable in class org.h2.expression.function.LengthFunction
OCTET_LENGTH().
octetLength - Variable in class org.h2.value.ValueLob
Length in bytes.
octetLength() - Method in class org.h2.value.Value
Returns length of this value in bytes.
octetLength() - Method in class org.h2.value.ValueBlob
 
octetLength() - Method in class org.h2.value.ValueClob
 
octetLength() - Method in class org.h2.value.ValueUuid
 
of(long) - Static method in class org.h2.result.ResultWithGeneratedKeys
Returns a result with only update count.
of(Database, Expression[], boolean, int[], int, int, SortOrder) - Static method in class org.h2.mvstore.db.MVTempResult
Creates MVStore-based temporary result.
ofDays(long) - Static method in class org.h2.api.Interval
Creates a new INTERVAL DAY.
ofDaysHours(long, int) - Static method in class org.h2.api.Interval
Creates a new INTERVAL DAY TO HOUR.
ofDaysHoursMinutes(long, int, int) - Static method in class org.h2.api.Interval
Creates a new INTERVAL DAY TO MINUTE.
ofDaysHoursMinutesNanos(long, int, int, long) - Static method in class org.h2.api.Interval
Creates a new INTERVAL DAY TO SECOND.
ofDaysHoursMinutesSeconds(long, int, int, int) - Static method in class org.h2.api.Interval
Creates a new INTERVAL DAY TO SECOND.
OFF - Static variable in class org.h2.message.TraceSystem
This trace level means nothing should be written.
OFF - Static variable in class org.h2.value.CompareMode
This constant means there is no collator set, and the default string comparison is to be used.
OffHeapStore - Class in org.h2.mvstore
A storage mechanism that "persists" data in the off-heap area of the main memory.
OffHeapStore() - Constructor for class org.h2.mvstore.OffHeapStore
 
offset - Variable in class org.h2.command.query.Query.OffsetFetch
OFFSET value.
offset - Variable in class org.h2.result.LocalResult
 
offset - Variable in class org.h2.util.geometry.EWKBUtils.EWKBSource
 
offset - Variable in class org.h2.util.geometry.EWKTUtils.EWKTSource
 
offset - Variable in class org.h2.util.TimeZoneProvider.Simple
 
OFFSET - Static variable in class org.h2.util.ParserUtil
The token "OFFSET".
offsetDateTimeToValue(OffsetDateTime) - Static method in class org.h2.util.JSR310Utils
Converts a OffsetDateTime to a Value.
offsetExpr - Variable in class org.h2.command.query.Query
The offset expression as specified in the OFFSET clause.
OffsetFetch(long, long, boolean) - Constructor for class org.h2.command.query.Query.OffsetFetch
 
offsetTimeToValue(OffsetTime) - Static method in class org.h2.util.JSR310Utils
Converts a OffsetTime to a Value.
ofHours(long) - Static method in class org.h2.api.Interval
Creates a new INTERVAL HOUR.
ofHoursMinutes(long, int) - Static method in class org.h2.api.Interval
Creates a new INTERVAL HOUR TO MINUTE.
ofHoursMinutesNanos(long, int, long) - Static method in class org.h2.api.Interval
Creates a new INTERVAL HOUR TO SECOND.
ofHoursMinutesSeconds(long, int, int) - Static method in class org.h2.api.Interval
Creates a new INTERVAL HOUR TO SECOND.
ofId(String) - Static method in class org.h2.util.TimeZoneProvider
Returns the time zone provider with the specified name.
ofMinutes(long) - Static method in class org.h2.api.Interval
Creates a new INTERVAL MINUTE.
ofMinutesNanos(long, long) - Static method in class org.h2.api.Interval
Creates a new INTERVAL MINUTE TO SECOND.
ofMinutesSeconds(long, int) - Static method in class org.h2.api.Interval
Creates a new INTERVAL MINUTE TO SECOND.
ofMonths(long) - Static method in class org.h2.api.Interval
Creates a new INTERVAL MONTH.
ofNanos(long) - Static method in class org.h2.api.Interval
Creates a new INTERVAL SECOND.
ofOffset(int) - Static method in class org.h2.util.TimeZoneProvider
Returns the time zone provider with the specified offset.
ofSeconds(long) - Static method in class org.h2.api.Interval
Creates a new INTERVAL SECOND.
ofSeconds(long, int) - Static method in class org.h2.api.Interval
Creates a new INTERVAL SECOND.
ofYears(long) - Static method in class org.h2.api.Interval
Creates a new INTERVAL YEAR.
ofYearsMonths(long, int) - Static method in class org.h2.api.Interval
Creates a new INTERVAL YEAR TO MONTH.
OLD - org.h2.table.DataChangeDeltaTable.ResultOption
OLD row.
oldColumn - Variable in class org.h2.command.ddl.AlterTableAlterColumn
 
oldestVersionToKeep - Variable in class org.h2.mvstore.MVStore
Oldest store version in use.
oldIndexName - Variable in class org.h2.command.ddl.AlterIndexRename
 
oldInformationSchema - Variable in class org.h2.engine.SessionLocal
Whether INFORMATION_SCHEMA contains old-style tables.
oldInformationSchema - Variable in class org.h2.engine.SessionRemote
 
oldName - Variable in class org.h2.command.ddl.AlterTableRenameColumn
 
oldSchema - Variable in class org.h2.command.ddl.AlterIndexRename
 
oldSchema - Variable in class org.h2.command.ddl.AlterSchemaRename
 
oldSequence - Variable in class org.h2.command.ddl.SequenceOptions
 
oldTables - Variable in class org.h2.schema.InformationSchema
 
oldValue - Variable in class org.h2.mvstore.tx.Record
Value of the entry before change.
oldValueSupplier - Variable in class org.h2.mvstore.tx.TxDecisionMaker.PutIfAbsentDecisionMaker
 
on - Variable in class org.h2.table.TableFilter.MapColumnsVisitor
 
ON - Static variable in class org.h2.util.ParserUtil
The token "ON".
ON_UPDATE - Static variable in class org.h2.command.dml.SetClauseList.UpdateAction
 
onCommitDrop - Variable in class org.h2.command.ddl.CreateTable
 
onCommitDrop - Variable in class org.h2.table.Table
 
onCommitTruncate - Variable in class org.h2.command.ddl.CreateTable
 
onCommitTruncate - Variable in class org.h2.table.Table
 
onCondition - Variable in class org.h2.command.dml.MergeUsing
ON condition expression.
onDuplicateKeyInsert - Variable in class org.h2.command.dml.Update
 
onDuplicateKeyRow - Variable in class org.h2.command.dml.Insert
 
onDuplicateKeyUpdate - Variable in class org.h2.engine.Mode
MySQL style INSERT ...
OnDuplicateKeyValues - Class in org.h2.mode
VALUES(column) function for ON DUPLICATE KEY UPDATE clause.
OnDuplicateKeyValues(Column, Update) - Constructor for class org.h2.mode.OnDuplicateKeyValues
 
ONE - Static variable in class org.h2.expression.condition.CompareLike
 
ONE - Static variable in class org.h2.value.ValueDecfloat
The value 'one'.
ONE - Static variable in class org.h2.value.ValueDouble
The value 1.
ONE - Static variable in class org.h2.value.ValueNumeric
The value 'one'.
ONE - Static variable in class org.h2.value.ValueReal
The value 1.
oneByteBuffer - Variable in class org.h2.mvstore.StreamStore.Stream
 
OnExitDatabaseCloser - Class in org.h2.engine
This class is responsible to close a database on JVM shutdown.
OnExitDatabaseCloser() - Constructor for class org.h2.engine.OnExitDatabaseCloser
 
onLazyResultSetClose(CommandInterface, boolean) - Method in class org.h2.jdbc.JdbcStatement
Called when the result set is closed.
onOverflowTruncate - Variable in class org.h2.expression.aggregate.ListaggArguments
 
onRollback - Variable in class org.h2.command.ddl.CreateTrigger
 
onRollback - Variable in class org.h2.schema.TriggerObject
 
onRollback(MVMap<Object, VersionedValue<Object>>, Object, VersionedValue<Object>, VersionedValue<Object>) - Method in class org.h2.engine.SessionLocal
 
onRollback(MVMap<Object, VersionedValue<Object>>, Object, VersionedValue<Object>, VersionedValue<Object>) - Method in interface org.h2.mvstore.tx.TransactionStore.RollbackListener
Notified of a single map change (add/update/remove)
onShutdown() - Static method in class org.h2.engine.OnExitDatabaseCloser
 
onStore(int) - Method in class org.h2.mvstore.StreamStore
This method is called after a block of data is stored.
onUpdate - Variable in class org.h2.command.dml.SetClauseList
 
onUpdateExpression - Variable in class org.h2.command.ddl.CreateDomain
 
onUpdateExpression - Variable in class org.h2.schema.Domain
 
onUpdateExpression - Variable in class org.h2.table.Column
 
onVersionChange(long) - Method in class org.h2.mvstore.MVStore
 
OOME - Static variable in exception org.h2.message.DbException
 
open() - Method in class org.h2.mvstore.MVStore.Builder
Open the store.
open() - Method in class org.h2.store.fs.retry.FileRetryOnInterrupt
 
open() - Method in class org.h2.table.TableLinkConnection
 
open(String) - Method in class org.h2.mvstore.cache.FilePathCache
 
open(String) - Static method in class org.h2.mvstore.MVStore
Open a store in exclusive mode.
open(String) - Method in class org.h2.store.fs.async.FilePathAsync
 
open(String) - Method in class org.h2.store.fs.disk.FilePathDisk
 
open(String) - Method in class org.h2.store.fs.encrypt.FilePathEncrypt
 
open(String) - Method in class org.h2.store.fs.FilePath
Open a random access file object.
open(String) - Method in class org.h2.store.fs.FilePathWrapper
 
open(String) - Method in class org.h2.store.fs.mem.FilePathMem
 
open(String) - Method in class org.h2.store.fs.niomapped.FilePathNioMapped
 
open(String) - Method in class org.h2.store.fs.niomem.FilePathNioMem
 
open(String) - Method in class org.h2.store.fs.rec.FilePathRec
 
open(String) - Method in class org.h2.store.fs.retry.FilePathRetryOnInterrupt
 
open(String) - Method in class org.h2.store.fs.split.FilePathSplit
 
open(String) - Method in class org.h2.store.fs.zip.FilePathZip
 
open(String, boolean, char[]) - Method in class org.h2.mvstore.FileStore
Try to open the file.
open(String, boolean, char[]) - Method in class org.h2.mvstore.OffHeapStore
 
open(String, String) - Static method in class org.h2.store.fs.FileUtils
Open a random access file object.
open(HashMap<TableLinkConnection, TableLinkConnection>, String, String, String, String, boolean) - Static method in class org.h2.table.TableLinkConnection
Open a new connection.
open(DataHandler, String, String) - Static method in class org.h2.store.FileStore
Open a non encrypted file store with the given settings.
open(DataHandler, String, String, String, byte[]) - Static method in class org.h2.store.FileStore
Open an encrypted file store with the given settings.
open(DataHandler, String, String, String, byte[], int) - Static method in class org.h2.store.FileStore
Open an encrypted file store with the given settings.
OPEN_BRACE - Static variable in class org.h2.command.Token
The token "{".
OPEN_BRACKET - Static variable in class org.h2.bnf.RuleFixed
 
OPEN_BRACKET - Static variable in class org.h2.command.Token
The token "[".
OPEN_OUTPUT_STREAM - Static variable in interface org.h2.store.fs.Recorder
Open a file output stream.
OPEN_PAREN - Static variable in class org.h2.command.Token
The token "(".
openBrowser(String) - Method in class org.h2.tools.Console
Open a new browser tab or window with the given URL.
openBrowser(String) - Static method in class org.h2.tools.Server
Open a new browser tab or window with the given URL.
opened() - Method in interface org.h2.api.DatabaseEventListener
This method is called after the database has been opened.
opened() - Method in class org.h2.engine.Database
Called after the database has been opened and initialized.
openFile() - Method in class org.h2.store.FileStore
Re-open the file.
openFile(String, String, boolean) - Method in class org.h2.engine.Database
 
openFile(String, String, boolean) - Method in class org.h2.engine.SessionRemote
 
openFile(String, String, boolean) - Method in interface org.h2.store.DataHandler
Open a file at the given location.
openFile(String, String, boolean) - Method in class org.h2.tools.Recover
INTERNAL
openInput(Charset) - Method in class org.h2.command.dml.ScriptBase
Open the input stream.
openLobDataMap(TransactionStore) - Static method in class org.h2.mvstore.db.LobStorageMap
Open map used to store LOB data
openLobMap(TransactionStore) - Static method in class org.h2.mvstore.db.LobStorageMap
Open map used to store LOB metadata
openMap(int) - Method in class org.h2.mvstore.tx.TransactionStore
Open the map with the given id.
openMap(int, MVMap.MapBuilder<M, K, V>) - Method in class org.h2.mvstore.MVStore
Open an existing map with the given builder.
openMap(String) - Method in class org.h2.mvstore.db.MVSecondaryIndex
 
openMap(String) - Method in class org.h2.mvstore.MVStore
Open a map with the default settings.
openMap(String) - Method in class org.h2.mvstore.tx.Transaction
Open a data map.
openMap(String, MVMap.MapBuilder<M, K, V>) - Method in class org.h2.mvstore.MVStore
Open a map with the given builder.
openMap(String, DataType<K>, DataType<V>) - Method in class org.h2.mvstore.tx.Transaction
Open the map to store the data.
openMap(String, DataType<K>, DataType<V>) - Method in class org.h2.mvstore.tx.TransactionStore
Open the map with the given name.
openMapX(MVMap<K, VersionedValue<V>>) - Method in class org.h2.mvstore.tx.Transaction
Open the transactional version of the given map.
openMetaMap() - Method in class org.h2.mvstore.MVStore
 
openNewConnection() - Method in class org.h2.value.Transfer
Open a new connection to the same address and port as this one.
openOutput() - Method in class org.h2.command.dml.ScriptBase
Open the output stream.
openOutputStream() - Method in class org.h2.util.SourceCompiler.JavaClassObject
 
openReadOnly(long, long) - Method in class org.h2.mvstore.MVMap
Open a copy of the map in read-only mode.
openReadOnly(Page<K, V>, long) - Method in class org.h2.mvstore.MVMap
 
openSession(ConnectionInfo) - Static method in class org.h2.engine.Engine
 
openSession(ConnectionInfo, boolean, boolean, String) - Static method in class org.h2.engine.Engine
 
openStackTrace - Variable in class org.h2.util.CloseWatcher
The stack trace of when the object was created.
openTransactions - Variable in class org.h2.mvstore.tx.TransactionStore
This BitSet is used as vacancy indicator for transaction slots in transactions[].
openTypeRegistry(MVStore, MetaType<?>) - Static method in class org.h2.mvstore.tx.TransactionStore
 
openVersion(long) - Method in class org.h2.mvstore.MVMap
Open an old version for the given map.
openVersionedMap(String, DataType<K>, DataType<V>) - Method in class org.h2.mvstore.tx.TransactionStore
 
openWriter() - Method in class org.h2.message.TraceSystem
 
openZipFile() - Method in class org.h2.store.fs.zip.FilePathZip
 
operand - Variable in class org.h2.expression.SimpleCase
 
operands - Variable in class org.h2.expression.SimpleCase.SimpleWhen
 
operate(K, V, MVMap.DecisionMaker<? super V>) - Method in class org.h2.mvstore.MVMap
Add, replace or remove a key-value pair.
operate(Page<Spatial, V>, Spatial, V, MVMap.DecisionMaker<? super V>, Collection<Page<Spatial, V>>) - Method in class org.h2.mvstore.rtree.MVRTreeMap
 
operate(Spatial, V, MVMap.DecisionMaker<? super V>) - Method in class org.h2.mvstore.rtree.MVRTreeMap
 
Operation0 - Class in org.h2.expression
Operation without subexpressions.
Operation0() - Constructor for class org.h2.expression.Operation0
 
Operation1 - Class in org.h2.expression
Operation with one argument.
Operation1(Expression) - Constructor for class org.h2.expression.Operation1
 
Operation1_2 - Class in org.h2.expression
Operation with one or two arguments.
Operation1_2(Expression, Expression) - Constructor for class org.h2.expression.Operation1_2
 
Operation2 - Class in org.h2.expression
Operation with two arguments.
Operation2(Expression, Expression) - Constructor for class org.h2.expression.Operation2
 
operationId - Variable in class org.h2.mvstore.tx.VersionedValueUncommitted
 
OperationN - Class in org.h2.expression
Operation with many arguments.
OperationN(Expression[]) - Constructor for class org.h2.expression.OperationN
 
operationType - Variable in class org.h2.command.ddl.GrantRevoke
 
OPTIMIZABLE_AGGREGATE - Static variable in class org.h2.expression.ExpressionVisitor
Are all aggregates MIN(column), MAX(column), COUNT(*), MEDIAN(column), ENVELOPE(count) for the given table (getTable)?
optimize(boolean) - Method in class org.h2.command.query.Optimizer
Calculate the best query plan to use.
optimize(SessionLocal) - Method in class org.h2.expression.aggregate.AbstractAggregate
 
optimize(SessionLocal) - Method in class org.h2.expression.aggregate.Aggregate
 
optimize(SessionLocal) - Method in class org.h2.expression.aggregate.JavaAggregate
 
optimize(SessionLocal) - Method in class org.h2.expression.Alias
 
optimize(SessionLocal) - Method in class org.h2.expression.analysis.DataAnalysisOperation
 
optimize(SessionLocal) - Method in class org.h2.expression.analysis.Window
Try to optimize the window conditions.
optimize(SessionLocal) - Method in class org.h2.expression.analysis.WindowFrame
Try to optimize bound expressions.
optimize(SessionLocal) - Method in class org.h2.expression.analysis.WindowFrameBound
Try to optimize bound expression.
optimize(SessionLocal) - Method in class org.h2.expression.analysis.WindowFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.ArrayConstructorByQuery
 
optimize(SessionLocal) - Method in class org.h2.expression.ArrayElementReference
 
optimize(SessionLocal) - Method in class org.h2.expression.BinaryOperation
 
optimize(SessionLocal) - Method in class org.h2.expression.CompatibilityDatePlusTimeOperation
 
optimize(SessionLocal) - Method in class org.h2.expression.ConcatenationOperation
 
optimize(SessionLocal) - Method in class org.h2.expression.condition.BetweenPredicate
 
optimize(SessionLocal) - Method in class org.h2.expression.condition.CompareLike
 
optimize(SessionLocal) - Method in class org.h2.expression.condition.Comparison
 
optimize(SessionLocal) - Method in class org.h2.expression.condition.ConditionAndOr
 
optimize(SessionLocal) - Method in class org.h2.expression.condition.ConditionAndOrN
 
optimize(SessionLocal) - Method in class org.h2.expression.condition.ConditionIn
 
optimize(SessionLocal) - Method in class org.h2.expression.condition.ConditionInConstantSet
 
optimize(SessionLocal) - Method in class org.h2.expression.condition.ConditionInParameter
 
optimize(SessionLocal) - Method in class org.h2.expression.condition.ConditionInQuery
 
optimize(SessionLocal) - Method in class org.h2.expression.condition.ConditionLocalAndGlobal
 
optimize(SessionLocal) - Method in class org.h2.expression.condition.ConditionNot
 
optimize(SessionLocal) - Method in class org.h2.expression.condition.IsJsonPredicate
 
optimize(SessionLocal) - Method in class org.h2.expression.condition.NullPredicate
 
optimize(SessionLocal) - Method in class org.h2.expression.condition.PredicateWithSubquery
 
optimize(SessionLocal) - Method in class org.h2.expression.condition.SimplePredicate
 
optimize(SessionLocal) - Method in class org.h2.expression.condition.TypePredicate
 
optimize(SessionLocal) - Method in class org.h2.expression.condition.UniquePredicate
 
optimize(SessionLocal) - Method in class org.h2.expression.DomainValueExpression
 
optimize(SessionLocal) - Method in class org.h2.expression.Expression
Try to optimize the expression.
optimize(SessionLocal) - Method in class org.h2.expression.ExpressionColumn
 
optimize(SessionLocal) - Method in class org.h2.expression.ExpressionList
 
optimize(SessionLocal) - Method in class org.h2.expression.FieldReference
 
optimize(SessionLocal) - Method in class org.h2.expression.Format
 
optimize(SessionLocal) - Method in class org.h2.expression.function.ArrayFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.BitFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.CardinalityExpression
 
optimize(SessionLocal) - Method in class org.h2.expression.function.CastSpecification
 
optimize(SessionLocal) - Method in class org.h2.expression.function.CoalesceFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.CompatibilitySequenceValueFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.CompressFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.ConcatFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.CryptFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.CSVWriteFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.DataTypeSQLFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.DateTimeFormatFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.DateTimeFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.DayMonthNameFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.DBObjectFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.FileFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.HashFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.JavaFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.JsonConstructorFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.LengthFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.MathFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.MathFunction1
 
optimize(SessionLocal) - Method in class org.h2.expression.function.MathFunction2
 
optimize(SessionLocal) - Method in class org.h2.expression.function.NullIfFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.RandFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.RegexpFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.SessionControlFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.SetFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.SignalFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.SoundexFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.StringFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.StringFunction1
 
optimize(SessionLocal) - Method in class org.h2.expression.function.StringFunction2
 
optimize(SessionLocal) - Method in class org.h2.expression.function.SubstringFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.table.ArrayTableFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.table.CSVReadFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.table.JavaTableFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.table.LinkSchemaFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.table.TableFunction
Try to optimize this table function
optimize(SessionLocal) - Method in class org.h2.expression.function.TableInfoFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.ToCharFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.TrimFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.TruncateValueFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.function.XMLFunction
 
optimize(SessionLocal) - Method in class org.h2.expression.IntervalOperation
 
optimize(SessionLocal) - Method in class org.h2.expression.Operation0
 
optimize(SessionLocal) - Method in class org.h2.expression.Parameter
 
optimize(SessionLocal) - Method in class org.h2.expression.Rownum
 
optimize(SessionLocal) - Method in class org.h2.expression.SearchedCase
 
optimize(SessionLocal) - Method in class org.h2.expression.SimpleCase
 
optimize(SessionLocal) - Method in class org.h2.expression.Subquery
 
optimize(SessionLocal) - Method in class org.h2.expression.TimeZoneOperation
 
optimize(SessionLocal) - Method in class org.h2.expression.UnaryOperation
 
optimize(SessionLocal) - Method in class org.h2.expression.Wildcard
 
optimize(SessionLocal) - Method in class org.h2.mode.FunctionsDB2Derby
 
optimize(SessionLocal) - Method in class org.h2.mode.FunctionsLegacy
 
optimize(SessionLocal) - Method in class org.h2.mode.FunctionsMSSQLServer
 
optimize(SessionLocal) - Method in class org.h2.mode.FunctionsMySQL
 
optimize(SessionLocal) - Method in class org.h2.mode.FunctionsOracle
 
optimize(SessionLocal) - Method in class org.h2.mode.FunctionsPostgreSQL
 
optimize(SessionLocal) - Method in class org.h2.mode.Regclass
 
optimize(SessionLocal) - Method in class org.h2.table.RangeTable
 
optimize(ExpressionColumn, Column) - Method in class org.h2.command.query.SelectListColumnResolver
 
optimize(ExpressionColumn, Column) - Method in class org.h2.command.query.TableValueConstructor.TableValueColumnResolver
 
optimize(ExpressionColumn, Column) - Method in interface org.h2.table.ColumnResolver
Get the expression that represents this column.
OPTIMIZE_REUSE_RESULTS - Static variable in class org.h2.command.dml.SetTypes
The type of a SET OPTIMIZE_REUSE_RESULTS statement.
optimize2(SessionLocal, boolean, boolean, boolean, ArrayList<Expression>) - Method in class org.h2.expression.condition.ConditionIn
 
optimizeArguments(SessionLocal) - Method in class org.h2.mode.ModeFunction
Optimizes arguments.
optimizeArguments(SessionLocal, boolean) - Method in class org.h2.expression.OperationN
Optimizes arguments.
optimizeCondition(SessionLocal) - Method in class org.h2.expression.Expression
Try to optimize or remove the condition.
optimizeConditionAndOr(ConditionAndOr, ConditionAndOr) - Static method in class org.h2.expression.condition.ConditionAndOr
Optimize query according to the given condition.
optimizeConstant(SessionLocal, int, Value, Expression) - Static method in class org.h2.expression.condition.ConditionAndOr
 
optimized - Variable in class org.h2.expression.condition.NullPredicate
 
optimized - Variable in class org.h2.table.RangeTable
 
OPTIMIZED_SQL - org.h2.engine.Mode.ExpressionNames
Use optimized SQL representation of expression.
optimizeDateTime(SessionLocal, int, int) - Method in class org.h2.expression.BinaryOperation
 
optimizeDecfloat(TypeInfo, TypeInfo) - Method in class org.h2.expression.BinaryOperation
 
optimizeDistinct - Variable in class org.h2.engine.DbSettings
Database setting OPTIMIZE_DISTINCT (default: true).
optimizeEvaluatableSubqueries - Variable in class org.h2.engine.DbSettings
Database setting OPTIMIZE_EVALUATABLE_SUBQUERIES (default: true).
optimizeExpressionsAndPreserveAliases() - Method in class org.h2.command.query.Select
 
optimizeFullCondition() - Method in class org.h2.table.TableFilter
Optimize the full condition.
optimizeIfConstant(SessionLocal, int, Expression, Expression) - Static method in class org.h2.expression.condition.ConditionAndOr
Optimize the condition if at least one part is constant.
optimizeInList - Variable in class org.h2.engine.DbSettings
Database setting OPTIMIZE_IN_LIST (default: true).
optimizeInSelect - Variable in class org.h2.engine.DbSettings
Database setting OPTIMIZE_IN_SELECT (default: true).
optimizeInsertFromSelect - Variable in class org.h2.engine.DbSettings
Database setting OPTIMIZE_INSERT_FROM_SELECT (default: true).
optimizeInterval(int, int) - Method in class org.h2.expression.BinaryOperation
 
optimizeMerge(int) - Method in class org.h2.expression.condition.ConditionAndOrN
 
optimizeN(ConditionAndOr) - Static method in class org.h2.expression.condition.ConditionAndOr
 
optimizeNot(SessionLocal) - Method in class org.h2.expression.function.BitFunction
 
optimizeNumeric(TypeInfo, TypeInfo) - Method in class org.h2.expression.BinaryOperation
 
optimizeOr - Variable in class org.h2.engine.DbSettings
Database setting OPTIMIZE_OR (default: true).
optimizeOr(SessionLocal, Comparison) - Method in class org.h2.expression.condition.Comparison
Replace the OR condition with IN condition if possible.
optimizeOther() - Method in class org.h2.expression.ExpressionColumn
 
Optimizer - Class in org.h2.command.query
The optimizer is responsible to find the best execution plan for a given query.
Optimizer(TableFilter[], Expression, SessionLocal) - Constructor for class org.h2.command.query.Optimizer
 
optimizeReuseResults - Variable in class org.h2.engine.Database
 
optimizeRound(int, boolean, boolean, boolean) - Method in class org.h2.expression.function.MathFunction
Optimizes rounding and truncation functions.
optimizeRoundWithScale(SessionLocal, boolean) - Method in class org.h2.expression.function.MathFunction
 
optimizeSimpleSingleRowSubqueries - Variable in class org.h2.engine.DbSettings
Database setting OPTIMIZE_SIMPLE_SINGLE_ROW_SUBQUERIES (default: true).
optimizeTwoEquals - Variable in class org.h2.engine.DbSettings
Database setting OPTIMIZE_TWO_EQUALS (default: true).
options - Variable in class org.h2.command.ddl.AlterSequence
 
options - Variable in class org.h2.command.ddl.CreateSequence
 
opType - Variable in class org.h2.expression.BinaryOperation
 
opType - Variable in class org.h2.expression.IntervalOperation
 
OpType() - Constructor for enum org.h2.expression.BinaryOperation.OpType
 
or - Variable in class org.h2.bnf.RuleList
 
OR - Static variable in class org.h2.expression.condition.ConditionAndOr
The OR condition type as in ID=1 OR NAME='Hello'.
OR - Static variable in class org.h2.util.ParserUtil
The token "OR".
ORA_HASH - Static variable in class org.h2.expression.function.HashFunction
ORA_HASH() (non-standard).
Oracle - org.h2.engine.Mode.ModeEnum
 
oraHash(Value, long, long) - Static method in class org.h2.expression.function.HashFunction
 
ORDER - Static variable in class org.h2.util.ParserUtil
The token "ORDER".
ORDER_BY_NOT_IN_RESULT - Static variable in class org.h2.api.ErrorCode
The error with code 90068 is thrown when the given expression that is used in the ORDER BY is not in the result list.
ORDER_IN_FROM_COMPARATOR - Static variable in class org.h2.table.TableFilter
Comparator that uses order in FROM clause as a sort key.
orderBy - Variable in class org.h2.expression.analysis.Window
 
orderByList - Variable in class org.h2.expression.aggregate.Aggregate
 
orderBySort - Variable in class org.h2.expression.aggregate.Aggregate
 
orderedDistinctOnType - Variable in class org.h2.mvstore.db.MVSortedTempResult
Used for DISTINCT ON in presence of ORDER BY.
orderedResult - Variable in class org.h2.expression.analysis.PartitionData
Evaluated ordered result.
orderedRows - Variable in class org.h2.expression.analysis.WindowFrame.Itr
 
orderedWithOrder - Variable in class org.h2.expression.aggregate.AggregateDataCollecting
 
orderInFrom - Variable in class org.h2.command.Parser
 
orderInFrom - Variable in class org.h2.table.TableFilter
 
orderList - Variable in class org.h2.command.query.Query
Describes elements of the ORDER BY clause of a query.
orderList - Variable in class org.h2.result.SortOrder
The order list.
ordinal - Variable in class org.h2.expression.FieldReference
 
ordinal - Variable in class org.h2.value.ValueEnumBase
 
org.h2 - package org.h2
Implementation of the JDBC driver.
org.h2.api - package org.h2.api
Contains interfaces for user-defined extensions, such as triggers and user-defined aggregate functions.
org.h2.bnf - package org.h2.bnf
The implementation of the BNF (Backus-Naur form) parser and tool.
org.h2.bnf.context - package org.h2.bnf.context
Classes that provide context for the BNF tool, in order to provide BNF-based auto-complete.
org.h2.command - package org.h2.command
This package contains the parser and the base classes for prepared SQL statements.
org.h2.command.ddl - package org.h2.command.ddl
Contains DDL (data definition language) and related SQL statements.
org.h2.command.dml - package org.h2.command.dml
Contains DML (data manipulation language) and related SQL statements.
org.h2.command.query - package org.h2.command.query
Contains queries.
org.h2.compress - package org.h2.compress
Lossless data compression classes.
org.h2.constraint - package org.h2.constraint
Database constraints such as check constraints, unique constraints, and referential constraints.
org.h2.engine - package org.h2.engine
Contains high level classes of the database and classes that don't fit in another sub-package.
org.h2.expression - package org.h2.expression
Expressions include mathematical operations, simple values, and others.
org.h2.expression.aggregate - package org.h2.expression.aggregate
Aggregate functions.
org.h2.expression.analysis - package org.h2.expression.analysis
Base classes for data analysis operations and implementations of window functions.
org.h2.expression.condition - package org.h2.expression.condition
Condition expressions.
org.h2.expression.function - package org.h2.expression.function
Functions.
org.h2.expression.function.table - package org.h2.expression.function.table
Table value functions.
org.h2.fulltext - package org.h2.fulltext
The native full text search implementation, and the wrapper for the Lucene full text search implementation.
org.h2.index - package org.h2.index
Various table index implementations, as well as cursors to navigate in an index.
org.h2.jdbc - package org.h2.jdbc
Implementation of the JDBC API (package java.sql).
org.h2.jdbc.meta - package org.h2.jdbc.meta
Implementation of the JDBC database metadata API (package java.sql).
org.h2.jdbcx - package org.h2.jdbcx
Implementation of the extended JDBC API (package javax.sql).
org.h2.jmx - package org.h2.jmx
Implementation of the Java Management Extension (JMX) features.
org.h2.message - package org.h2.message
Trace (logging facility) and error message tool.
org.h2.mode - package org.h2.mode
Utility classes for compatibility with other database, for example MySQL.
org.h2.mvstore - package org.h2.mvstore
A persistent storage for tree maps.
org.h2.mvstore.cache - package org.h2.mvstore.cache
Classes related to caching.
org.h2.mvstore.db - package org.h2.mvstore.db
Helper classes to use the MVStore in the H2 database.
org.h2.mvstore.rtree - package org.h2.mvstore.rtree
An R-tree implementation
org.h2.mvstore.tx - package org.h2.mvstore.tx
Helper classes to use the MVStore in a transactional manner.
org.h2.mvstore.type - package org.h2.mvstore.type
Data types and serialization / deserialization
org.h2.result - package org.h2.result
Implementation of row and internal result sets.
org.h2.schema - package org.h2.schema
Schema implementation and objects that are stored in a schema (for example, sequences and constants).
org.h2.security - package org.h2.security
Security classes, such as encryption and cryptographically secure hash algorithms.
org.h2.security.auth - package org.h2.security.auth
Authentication classes.
org.h2.security.auth.impl - package org.h2.security.auth.impl
Authentication classes.
org.h2.server - package org.h2.server
A small FTP server.
org.h2.server.pg - package org.h2.server.pg
PostgreSQL server implementation of this database.
org.h2.server.web - package org.h2.server.web
The H2 Console tool.
org.h2.store - package org.h2.store
Storage abstractions, such as a file with a cache, or a class to convert values to a byte array and vice versa.
org.h2.store.fs - package org.h2.store.fs
A file system abstraction.
org.h2.store.fs.async - package org.h2.store.fs.async
This file system stores files on disk and uses java.nio.channels.AsynchronousFileChannel to access the files.
org.h2.store.fs.disk - package org.h2.store.fs.disk
This file system stores files on disk.
org.h2.store.fs.encrypt - package org.h2.store.fs.encrypt
An encrypted file system abstraction.
org.h2.store.fs.mem - package org.h2.store.fs.mem
This file system keeps files fully in memory.
org.h2.store.fs.niomapped - package org.h2.store.fs.niomapped
This file system stores files on disk and uses java.nio to access the files.
org.h2.store.fs.niomem - package org.h2.store.fs.niomem
This file system keeps files fully in off-java-heap memory.
org.h2.store.fs.rec - package org.h2.store.fs.rec
A file system that records all write operations and can re-play them.
org.h2.store.fs.retry - package org.h2.store.fs.retry
A file system that re-opens and re-tries the operation if the file was closed, because a thread was interrupted.
org.h2.store.fs.split - package org.h2.store.fs.split
A file system that may split files into multiple smaller files (required for a FAT32 because it only support files up to 2 GB).
org.h2.store.fs.zip - package org.h2.store.fs.zip
A zip-file base file system abstraction.
org.h2.table - package org.h2.table
Classes related to a table and table meta data.
org.h2.tools - package org.h2.tools
Various tools.
org.h2.util - package org.h2.util
Internal utility classes.
org.h2.util.geometry - package org.h2.util.geometry
Internal utility classes for GEOMETRY data type.
org.h2.util.json - package org.h2.util.json
Internal utility classes for JSON data type.
org.h2.value - package org.h2.value
Data type and value implementations.
org.h2.value.lob - package org.h2.value.lob
LOB data for values.
ORIGINAL_SQL - org.h2.engine.Mode.ExpressionNames
Use original SQL representation of expression.
originalMessage - Variable in exception org.h2.jdbc.JdbcSQLDataException
 
originalMessage - Variable in exception org.h2.jdbc.JdbcSQLException
 
originalMessage - Variable in exception org.h2.jdbc.JdbcSQLFeatureNotSupportedException
 
originalMessage - Variable in exception org.h2.jdbc.JdbcSQLIntegrityConstraintViolationException
 
originalMessage - Variable in exception org.h2.jdbc.JdbcSQLInvalidAuthorizationSpecException
 
originalMessage - Variable in exception org.h2.jdbc.JdbcSQLNonTransientConnectionException
 
originalMessage - Variable in exception org.h2.jdbc.JdbcSQLNonTransientException
 
originalMessage - Variable in exception org.h2.jdbc.JdbcSQLSyntaxErrorException
 
originalMessage - Variable in exception org.h2.jdbc.JdbcSQLTimeoutException
 
originalMessage - Variable in exception org.h2.jdbc.JdbcSQLTransactionRollbackException
 
originalMessage - Variable in exception org.h2.jdbc.JdbcSQLTransientException
 
originalParameters - Variable in class org.h2.index.ViewIndex
 
originalSchema - Variable in class org.h2.command.ddl.CreateLinkedTable
 
originalSchema - Variable in class org.h2.table.TableLink
 
originalTable - Variable in class org.h2.command.ddl.CreateLinkedTable
 
originalTable - Variable in class org.h2.table.TableLink
 
originalURL - Variable in class org.h2.engine.ConnectionInfo
 
orReplace - Variable in class org.h2.command.ddl.CreateSynonym
 
orReplace - Variable in class org.h2.command.ddl.CreateView
 
OsgiDataSourceFactory - Class in org.h2.util
This class implements the OSGi DataSourceFactory interface for the H2 JDBC driver.
OsgiDataSourceFactory(Driver) - Constructor for class org.h2.util.OsgiDataSourceFactory
 
othersDeletesAreVisible(int) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether other deletes are visible.
othersInsertsAreVisible(int) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether other inserts are visible.
othersUpdatesAreVisible(int) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether other updates are visible.
otherToValue(Session, Object) - Static method in class org.h2.value.ValueToObjectConverter
 
out - Variable in class org.h2.command.dml.ScriptBase
The output stream.
out - Variable in class org.h2.compress.LZFOutputStream
 
out - Variable in class org.h2.server.pg.PgServerThread
 
out - Variable in class org.h2.util.Permutations
 
out - Variable in class org.h2.util.SourceCompiler.JavaClassObject
 
out - Variable in class org.h2.util.Tool
The output stream where this tool writes to.
out - Variable in class org.h2.value.Transfer
 
OUT_OF_MEMORY - Static variable in class org.h2.api.ErrorCode
The error with code 90108 is thrown when not enough heap memory was available.
outBuffer - Variable in class org.h2.compress.LZFOutputStream
 
outBuffer - Variable in class org.h2.server.pg.PgServerThread
 
outerResolvers - Variable in class org.h2.expression.Subquery
 
outParameters - Variable in class org.h2.jdbc.JdbcCallableStatement
 
output - Variable in class org.h2.server.web.WebThread
 
output - Variable in class org.h2.tools.Csv
 
output - Variable in class org.h2.util.geometry.EWKBUtils.EWKBTarget
 
output - Variable in class org.h2.util.geometry.EWKTUtils.EWKTTarget
 
output - Variable in class org.h2.util.geometry.GeoJsonUtils.GeoJsonTarget
 
over - Variable in class org.h2.expression.analysis.DataAnalysisOperation
OVER clause
overOrderBySort - Variable in class org.h2.expression.analysis.DataAnalysisOperation
Sort order for OVER
overridingSystem - Variable in class org.h2.command.dml.Insert
 
overridingSystem - Variable in class org.h2.command.dml.MergeUsing.WhenNotMatched
 
ownDeletesAreVisible(int) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether own deletes are visible.
owner - Variable in class org.h2.schema.Schema
 
owner - Variable in class org.h2.table.TableView
 
ownerId - Variable in class org.h2.mvstore.RootReference
Lock owner thread id.
ownerId - Variable in class org.h2.mvstore.tx.Transaction
Identification of the owner of this transaction, usually the owner is a database session.
ownInsertsAreVisible(int) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether own inserts are visible.
ownUpdatesAreVisible(int) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether own updates are visible.

P

pad(String, int, String, boolean) - Static method in class org.h2.util.StringUtils
Pad a string.
padNumberLeft(long, int) - Static method in class org.h2.tools.ConvertTraceFile
 
page - Variable in class org.h2.mvstore.CursorPos
The page at the current level.
page - Variable in class org.h2.mvstore.Page.PageReference
The page, if in memory, or null.
page - Variable in class org.h2.server.web.PageParser
 
page - Variable in class org.h2.store.FileStoreInputStream
 
page - Variable in class org.h2.store.FileStoreOutputStream
 
page - Variable in class org.h2.store.fs.mem.FileMemData.CompressItem
The page to compress.
page - Variable in class org.h2.store.fs.niomem.FileNioMemData.CompressItem
The page to compress.
Page<K,​V> - Class in org.h2.mvstore
A page (a node or a leaf).
Page(MVMap<K, V>) - Constructor for class org.h2.mvstore.Page
 
Page(MVMap<K, V>, K[]) - Constructor for class org.h2.mvstore.Page
 
Page(MVMap<K, V>, Page<K, V>) - Constructor for class org.h2.mvstore.Page
 
PAGE_COMPRESSED - Static variable in class org.h2.mvstore.DataUtils
The bit mask for compressed pages (compression level fast).
PAGE_COMPRESSED_HIGH - Static variable in class org.h2.mvstore.DataUtils
The bit mask for compressed pages (compression level high).
PAGE_HAS_PAGE_NO - Static variable in class org.h2.mvstore.DataUtils
The bit mask for pages with page sequential number.
PAGE_LARGE - Static variable in class org.h2.mvstore.DataUtils
The marker size of a very large page.
PAGE_LEAF_MEMORY - Static variable in class org.h2.mvstore.Page
The estimated number of bytes used per empty leaf page.
PAGE_MEMORY - Static variable in class org.h2.mvstore.Page
The estimated number of bytes used per base page.
PAGE_MEMORY_CHILD - Static variable in class org.h2.mvstore.Page
The estimated number of bytes used per child entry.
PAGE_NODE_MEMORY - Static variable in class org.h2.mvstore.Page
The estimated number of bytes used per empty internal page object.
PAGE_TYPE_LEAF - Static variable in class org.h2.mvstore.DataUtils
The type for leaf page.
PAGE_TYPE_NODE - Static variable in class org.h2.mvstore.DataUtils
The type for node page.
Page.IncompleteNonLeaf<K,​V> - Class in org.h2.mvstore
 
Page.Leaf<K,​V> - Class in org.h2.mvstore
 
Page.NonLeaf<K,​V> - Class in org.h2.mvstore
 
Page.PageReference<K,​V> - Class in org.h2.mvstore
A pointer to a page, either in-memory or using a page position.
pageCount - Variable in class org.h2.mvstore.Chunk
The total number of pages in this chunk.
pageCountLive - Variable in class org.h2.mvstore.Chunk
The number of pages that are still alive in the latest version of the store.
pageNo - Variable in class org.h2.mvstore.Page
Sequential 0-based number of the page within containing chunk.
PageParser - Class in org.h2.server.web
A page parser can parse an HTML page and replace the tags there.
PageParser(String, Map<String, Object>, int) - Constructor for class org.h2.server.web.PageParser
 
pagePos - Variable in class org.h2.mvstore.MVMap.RewriteDecisionMaker
 
PageReference(long, long) - Constructor for class org.h2.mvstore.Page.PageReference
 
PageReference(Page<K, V>) - Constructor for class org.h2.mvstore.Page.PageReference
 
PageReference(Page<K, V>, long, long) - Constructor for class org.h2.mvstore.Page.PageReference
 
pageSize - Variable in class org.h2.engine.Database
 
pageSplitSize - Variable in class org.h2.mvstore.MVStore
 
pageSplitSize(int) - Method in class org.h2.mvstore.MVStore.Builder
Set the amount of memory a page should contain at most, in bytes, before it is split.
panic(MVStoreException) - Method in class org.h2.mvstore.MVStore
 
panicException - Variable in class org.h2.mvstore.MVStore
 
paramCount - Variable in class org.h2.jdbc.JdbcParameterMetaData
 
paramCount - Variable in class org.h2.schema.FunctionAlias.JavaMethod
 
parameter - Variable in class org.h2.expression.condition.ConditionInParameter
 
parameter - Variable in class org.h2.expression.condition.ConditionInParameter.ParameterList
 
Parameter - Class in org.h2.expression
A parameter of a prepared statement.
Parameter(int) - Constructor for class org.h2.expression.Parameter
 
PARAMETER - Static variable in class org.h2.command.Token
Token with parameter.
PARAMETER_META_DATA - Static variable in class org.h2.message.TraceObject
The trace type id for parameter meta data objects.
PARAMETER_NOT_SET_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90012 is thrown when trying to execute a statement with an parameter.
parameterCount - Variable in class org.h2.mode.FunctionInfo
The number of parameters.
ParameterInterface - Interface in org.h2.expression
The interface for client side (remote) and server side parameters.
ParameterList(Parameter) - Constructor for class org.h2.expression.condition.ConditionInParameter.ParameterList
 
ParameterRemote - Class in org.h2.expression
A client side (remote) parameter.
ParameterRemote(int) - Constructor for class org.h2.expression.ParameterRemote
 
parameters - Variable in class org.h2.bnf.context.DbProcedure
 
parameters - Variable in class org.h2.command.CommandList
 
parameters - Variable in class org.h2.command.CommandRemote
 
parameters - Variable in class org.h2.command.Parser
 
parameters - Variable in class org.h2.command.Prepared
The list of parameters.
parameters - Variable in class org.h2.jdbc.JdbcParameterMetaData
 
parameters(SessionLocal, ArrayList<Row>, String) - Method in class org.h2.table.InformationSchemaTable
 
parameters(SessionLocal, ArrayList<Row>, String, String, String, String, String, TypeInfo, int) - Method in class org.h2.table.InformationSchemaTable
 
PARAMETERS - Static variable in class org.h2.table.InformationSchemaTable
 
ParameterToken(int, int) - Constructor for class org.h2.command.Token.ParameterToken
 
params - Variable in class org.h2.value.DataType
The list of parameters used in the column definition.
paramType - Variable in class org.h2.server.pg.PgServerThread.Prepared
The list of parameter types (if set).
parent - Variable in class org.h2.expression.analysis.Window
 
parent - Variable in class org.h2.mvstore.CursorPos
Next node in the linked list, representing the position within parent level, or null, if we are at the root level already.
parent - Variable in class org.h2.mvstore.db.MVTempResult
Parent store for copies.
PARENT - Static variable in class org.h2.message.TraceSystem
The parent trace level should be used.
parentDomain - Variable in class org.h2.command.ddl.CreateDomain
 
parentSelect - Variable in class org.h2.command.query.Select
Parent select for selects in table filters.
parse() - Method in class org.h2.util.json.JSONTextSource
Parse the text and write it to the output.
parse(byte[], JSONTarget<R>) - Static method in class org.h2.util.json.JSONBytesSource
Parses source bytes to a specified target.
parse(Reader) - Method in class org.h2.bnf.Bnf
 
parse(String) - Method in class org.h2.store.fs.encrypt.FilePathEncrypt
Split the file name into algorithm, password, and base file name.
parse(String) - Method in class org.h2.store.fs.split.FilePathSplit
Split the file name into size and base file name.
parse(String) - Static method in class org.h2.value.ValueDate
Parse a string to a ValueDate.
parse(String) - Static method in class org.h2.value.ValueTime
Parse a string to a ValueTime.
parse(String) - Static method in class org.h2.value.ValueTimeTimeZone
Parse a string to a ValueTime.
parse(String, boolean) - Method in class org.h2.command.Parser
 
parse(String, ArrayList<Token>) - Method in class org.h2.command.Parser
Parse the statement, but don't prepare it for execution.
parse(String, Map<String, Object>) - Static method in class org.h2.server.web.PageParser
Replace the tags in the HTML page with the given settings.
parse(String, CastDataProvider) - Static method in class org.h2.value.ValueTimestamp
Parse a string to a ValueTimestamp, using the given CastDataProvider.
parse(String, CastDataProvider) - Static method in class org.h2.value.ValueTimestampTimeZone
Parse a string to a ValueTimestamp.
parse(String, JSONTarget<R>) - Static method in class org.h2.util.json.JSONStringSource
Parses source string to a specified target.
parse(ToDateParser) - Static method in class org.h2.mode.ToDateParser
 
parse(ToDateParser, ToDateTokenizer.FormatTokenEnum, String) - Method in class org.h2.mode.ToDateTokenizer.DayParslet
 
parse(ToDateParser, ToDateTokenizer.FormatTokenEnum, String) - Method in class org.h2.mode.ToDateTokenizer.InlineParslet
 
parse(ToDateParser, ToDateTokenizer.FormatTokenEnum, String) - Method in class org.h2.mode.ToDateTokenizer.MonthParslet
 
parse(ToDateParser, ToDateTokenizer.FormatTokenEnum, String) - Method in class org.h2.mode.ToDateTokenizer.TimeParslet
 
parse(ToDateParser, ToDateTokenizer.FormatTokenEnum, String) - Method in interface org.h2.mode.ToDateTokenizer.ToDateParslet
Parse a date part.
parse(ToDateParser, ToDateTokenizer.FormatTokenEnum, String) - Method in class org.h2.mode.ToDateTokenizer.YearParslet
 
parse(JSONObject, GeometryUtils.Target, int) - Static method in class org.h2.util.geometry.GeoJsonUtils
 
parse(JSONValue, GeometryUtils.Target) - Static method in class org.h2.util.geometry.GeoJsonUtils
 
PARSE_ERROR_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90014 is thrown when trying to parse a date with an unsupported format string, or when the date can not be parsed.
parseAction() - Method in class org.h2.command.Parser
 
parseAll() - Method in class org.h2.server.web.PageParser
 
parseAlter() - Method in class org.h2.command.Parser
 
parseAlterColumnUsingIf(AlterTableAlterColumn) - Method in class org.h2.command.Parser
 
parseAlterDomain() - Method in class org.h2.command.Parser
 
parseAlterIndex() - Method in class org.h2.command.Parser
 
parseAlterSchema() - Method in class org.h2.command.Parser
 
parseAlterSequence() - Method in class org.h2.command.Parser
 
parseAlterTable() - Method in class org.h2.command.Parser
 
parseAlterTableAddColumn(String, Schema, boolean) - Method in class org.h2.command.Parser
 
parseAlterTableAlter(Schema, String, boolean) - Method in class org.h2.command.Parser
 
parseAlterTableAlterColumnDataType(Schema, String, String, boolean, boolean) - Method in class org.h2.command.Parser
 
parseAlterTableAlterColumnIdentity(Schema, String, boolean, Column) - Method in class org.h2.command.Parser
 
parseAlterTableAlterColumnSet(Schema, String, boolean, boolean, String, Column) - Method in class org.h2.command.Parser
 
parseAlterTableAlterColumnType(Schema, String, String, boolean, boolean, boolean) - Method in class org.h2.command.Parser
 
parseAlterTableCompatibility(Schema, String, boolean, Mode) - Method in class org.h2.command.Parser
 
parseAlterTableDrop(Schema, String, boolean) - Method in class org.h2.command.Parser
 
parseAlterTableDropCompatibility(Schema, String, boolean) - Method in class org.h2.command.Parser
 
parseAlterTableRename(Schema, String, boolean) - Method in class org.h2.command.Parser
 
parseAlterTableSet(Schema, String, boolean) - Method in class org.h2.command.Parser
 
parseAlterUser() - Method in class org.h2.command.Parser
 
parseAlterView() - Method in class org.h2.command.Parser
 
parseAnalyze() - Method in class org.h2.command.Parser
 
parseArrayType(TypeInfo) - Method in class org.h2.command.Parser
 
parseAttributes(String) - Method in class org.h2.server.web.WebThread
 
parseBackup() - Method in class org.h2.command.Parser
 
parseBasicSequenceOption(SequenceOptions) - Method in class org.h2.command.Parser
 
parseBegin() - Method in class org.h2.command.Parser
 
parseBlockUntil(String) - Method in class org.h2.server.web.PageParser
 
parseBodyAttributes() - Method in class org.h2.server.web.WebThread
 
parseBoolean(String, boolean, boolean) - Static method in class org.h2.util.Utils
Parses the specified string to boolean value.
parseCall() - Method in class org.h2.command.Parser
 
parseCascadeOrRestrict() - Method in class org.h2.command.Parser
 
parseCheckpoint() - Method in class org.h2.command.Parser
 
parseChecksummedMap(byte[]) - Static method in class org.h2.mvstore.DataUtils
Parse a key-value pair list and checks its checksum.
parseClass(String, String) - Static method in class org.h2.util.SourceCompiler.GroovyCompiler
 
parseCollection(EWKTUtils.EWKTSource, GeometryUtils.Target, int, int, int) - Static method in class org.h2.util.geometry.EWKTUtils
 
parseColumn(Table) - Method in class org.h2.command.Parser
 
parseColumnForTable(String, boolean) - Method in class org.h2.command.Parser
 
parseColumnList() - Method in class org.h2.command.Parser
 
parseColumnList(String, int) - Method in class org.h2.command.Parser
Parses a list of column names or numbers in parentheses.
parseColumnList(Table) - Method in class org.h2.command.Parser
 
parseColumnWithType(String) - Method in class org.h2.command.Parser
 
parseComment() - Method in class org.h2.command.Parser
 
parseCommit() - Method in class org.h2.command.Parser
 
parseCompatibilityIdentity(Column, Mode) - Method in class org.h2.command.Parser
 
parseCompatibilityIdentityOptions(Column) - Method in class org.h2.command.Parser
 
parseCoordinate(JSONValue, GeometryUtils.Target, int, int) - Static method in class org.h2.util.geometry.GeoJsonUtils
 
parseCreate() - Method in class org.h2.command.Parser
 
parseCreateAggregate(boolean) - Method in class org.h2.command.Parser
 
parseCreateConstant() - Method in class org.h2.command.Parser
 
parseCreateDomain() - Method in class org.h2.command.Parser
 
parseCreateFunctionAlias(boolean) - Method in class org.h2.command.Parser
 
parseCreateLinkedTable(boolean, boolean, boolean) - Method in class org.h2.command.Parser
 
parseCreateRole() - Method in class org.h2.command.Parser
 
parseCreateSchema() - Method in class org.h2.command.Parser
 
parseCreateSequence() - Method in class org.h2.command.Parser
 
parseCreateSequenceOption(CreateSequence) - Method in class org.h2.command.Parser
 
parseCreateSynonym(boolean) - Method in class org.h2.command.Parser
 
parseCreateTable(boolean, boolean, boolean) - Method in class org.h2.command.Parser
 
parseCreateTableMySQLTableOptions(CreateTable) - Method in class org.h2.command.Parser
 
parseCreateTrigger(boolean) - Method in class org.h2.command.Parser
 
parseCreateUser() - Method in class org.h2.command.Parser
 
parseCreateView(boolean, boolean) - Method in class org.h2.command.Parser
 
parseDatabaseShortName() - Method in class org.h2.engine.Database
 
parseDataType() - Method in class org.h2.command.Parser
 
parseDateTime(SessionLocal, String, String, String, String) - Static method in class org.h2.expression.function.DateTimeFormatFunction
Parses a date using a format string.
PARSEDATETIME - Static variable in class org.h2.expression.function.DateTimeFormatFunction
PARSEDATETIME() (non-standard).
parseDateTimeType(boolean) - Method in class org.h2.command.Parser
 
parseDateValue(String, int, int) - Static method in class org.h2.util.DateTimeUtils
Parse a date string.
parseDB2SpecialRegisters(String) - Method in class org.h2.command.Parser
 
parseDeallocate() - Method in class org.h2.command.Parser
 
parseDecfloatType() - Method in class org.h2.command.Parser
 
parseDelete(int) - Method in class org.h2.command.Parser
 
parseDimensionSystem(String) - Static method in class org.h2.util.geometry.EWKTUtils
Parses a dimension system from the given string.
parseDomainConstraint - Variable in class org.h2.command.Parser
 
parseDomainConstraintExpression(String) - Method in class org.h2.command.Parser
Parse a SQL code snippet that represents an expression for a domain constraint.
parseDrop() - Method in class org.h2.command.Parser
 
parseDropAggregate() - Method in class org.h2.command.Parser
 
parseDropDomain() - Method in class org.h2.command.Parser
 
parseEndOfQuery(Query) - Method in class org.h2.command.Parser
 
parseEnumType() - Method in class org.h2.command.Parser
 
parseEWKB(byte[], GeometryUtils.Target) - Static method in class org.h2.util.geometry.EWKBUtils
Parses a EWKB.
parseEWKB(EWKBUtils.EWKBSource, GeometryUtils.Target, int) - Static method in class org.h2.util.geometry.EWKBUtils
Parses a EWKB.
parseEWKT(String, GeometryUtils.Target) - Static method in class org.h2.util.geometry.EWKTUtils
Parses a EWKT.
parseEWKT(EWKTUtils.EWKTSource, GeometryUtils.Target, int, int) - Static method in class org.h2.util.geometry.EWKTUtils
Parses a EWKB.
parseExecutePostgre() - Method in class org.h2.command.Parser
 
parseExecuteSQLServer() - Method in class org.h2.command.Parser
 
parseExplain() - Method in class org.h2.command.Parser
 
parseExplicitTable(int) - Method in class org.h2.command.Parser
 
parseExpression(String) - Method in class org.h2.command.Parser
Parse a SQL code snippet that represents an expression.
parseExtension(boolean) - Method in class org.h2.bnf.Bnf
 
parseFloatType() - Method in class org.h2.command.Parser
 
parseFormatStrWithToken(ToDateParser) - Method in enum org.h2.mode.ToDateTokenizer.FormatTokenEnum
Parse the format-string with passed token of ToDateTokenizer.FormatTokenEnum.
parseFormattedInterval(IntervalQualifier, String) - Static method in class org.h2.util.IntervalUtils
Parses the specified string as INTERVAL value.
parseFrom(InputStream) - Static method in class org.h2.security.auth.H2AuthConfigXml
Parse the xml.
parseFrom(URL) - Static method in class org.h2.security.auth.H2AuthConfigXml
Parse the xml.
parseGeometry(Geometry, GeometryUtils.Target) - Static method in class org.h2.util.geometry.JTSUtils
Parses a JTS Geometry object.
parseGeometry(Geometry, GeometryUtils.Target, int) - Static method in class org.h2.util.geometry.JTSUtils
Parses a JTS Geometry object.
parseGeometryCollection(JSONObject, GeometryUtils.Target) - Static method in class org.h2.util.geometry.GeoJsonUtils
 
parseGeometryType() - Method in class org.h2.command.Parser
 
parseGeometryType(String) - Static method in class org.h2.util.geometry.EWKTUtils
Parses geometry type and dimension system from the given string.
parseGrantRevoke(int) - Method in class org.h2.command.Parser
 
parseHeader() - Method in class org.h2.server.web.WebThread
 
parseHelp() - Method in class org.h2.command.Parser
 
parseHexBytes(Map<String, ?>, String) - Static method in class org.h2.mvstore.DataUtils
Parse the hex-encoded bytes of an entry in the map.
parseHexInt(String) - Static method in class org.h2.mvstore.DataUtils
Parse an unsigned, hex long.
parseHexLong(String) - Static method in class org.h2.mvstore.DataUtils
Parse an unsigned, hex long.
parseIndexColumnList() - Method in class org.h2.command.Parser
 
parseIndexHints(Table) - Method in class org.h2.command.Parser
 
parseInsert(int) - Method in class org.h2.command.Parser
 
parseInsertCompatibility(Insert, Table, Mode) - Method in class org.h2.command.Parser
 
parseInsertSet(Insert, Table, Column[]) - Method in class org.h2.command.Parser
 
parseInterval(IntervalQualifier, boolean, String) - Static method in class org.h2.util.IntervalUtils
Parses the specified string as INTERVAL value.
parseInterval(Value) - Static method in class org.h2.expression.TimeZoneOperation
Parses a daytime interval as time zone offset.
parseInterval2(IntervalQualifier, String, char, int, boolean) - Static method in class org.h2.util.IntervalUtils
 
parseIntervalLeading(String, int, int, boolean) - Static method in class org.h2.util.IntervalUtils
 
parseIntervalRemaining(String, int, int, int) - Static method in class org.h2.util.IntervalUtils
 
parseIntervalRemainingSeconds(String, int) - Static method in class org.h2.util.IntervalUtils
 
parseIsolationClause() - Method in class org.h2.command.Parser
DB2 isolation clause
parseKey(Connection, String) - Static method in class org.h2.fulltext.FullText
Parse a primary key condition into the primary key columns.
parseLineString(JSONArray, GeometryUtils.Target) - Static method in class org.h2.util.geometry.GeoJsonUtils
 
parseList() - Method in class org.h2.bnf.Bnf
 
parseMap(String) - Static method in class org.h2.mvstore.DataUtils
Parse a key-value pair list.
parseMapValue(StringBuilder, String, int, int) - Static method in class org.h2.mvstore.DataUtils
 
parseMerge(int) - Method in class org.h2.command.Parser
 
parseMergeInto(TableFilter, int) - Method in class org.h2.command.Parser
 
parseMergeUsing(TableFilter, int) - Method in class org.h2.command.Parser
 
parseMultiPointAlternative(EWKTUtils.EWKTSource, GeometryUtils.Target, int) - Static method in class org.h2.util.geometry.EWKTUtils
 
parseName() - Method in class org.h2.engine.ConnectionInfo
 
parseNanos(String, int, int) - Static method in class org.h2.util.DateTimeUtils
Parse nanoseconds.
parseNonKeywords(String[]) - Static method in class org.h2.command.Parser
Parses the specified collection of non-keywords.
parseNotNullCompatibility(Parser.NullConstraintType) - Method in class org.h2.command.Parser
 
parseNotNullConstraint() - Method in class org.h2.command.Parser
 
parseNotNullConstraint(Parser.NullConstraintType) - Method in class org.h2.command.Parser
 
parseNumber(boolean) - Method in class org.h2.util.json.JSONBytesSource
 
parseNumber(boolean) - Method in class org.h2.util.json.JSONStringSource
 
parseNumber(boolean) - Method in class org.h2.util.json.JSONTextSource
Parse a number.
parseNumericType(boolean) - Method in class org.h2.command.Parser
 
parseOr() - Method in class org.h2.bnf.Bnf
 
parseParameterIndex(String, int, int, ArrayList<Token>) - Static method in class org.h2.command.Tokenizer
 
parsePolygon(JSONArray, GeometryUtils.Target) - Static method in class org.h2.util.geometry.GeoJsonUtils
 
parsePrepare() - Method in class org.h2.command.Parser
 
parsePrepared() - Method in class org.h2.command.Parser
 
parsePrepareProcedure() - Method in class org.h2.command.Parser
 
parseQuery() - Method in class org.h2.command.Parser
 
parseQueryExpression() - Method in class org.h2.command.Parser
 
parseQueryExpressionBody() - Method in class org.h2.command.Parser
 
parseQueryExpressionBodyAndEndOfQuery() - Method in class org.h2.command.Parser
 
parseQueryPrimary() - Method in class org.h2.command.Parser
 
parseQueryTerm() - Method in class org.h2.command.Parser
 
Parser - Class in org.h2.command
The parser is used to convert a SQL statement string to an command object.
Parser() - Constructor for class org.h2.command.Parser
Creates a new instance of parser for special use cases.
Parser(SessionLocal) - Constructor for class org.h2.command.Parser
Creates a new instance of parser.
Parser.NullConstraintType - Enum in org.h2.command
Enumeration describing null constraints
parseReferences(AlterTableAddConstraint, Schema, String) - Method in class org.h2.command.Parser
 
parseReleaseSavepoint() - Method in class org.h2.command.Parser
 
parseReplace(int) - Method in class org.h2.command.Parser
MySQL compatibility.
parseRing(JSONValue[], GeometryUtils.Target) - Static method in class org.h2.util.geometry.GeoJsonUtils
 
parseRollback() - Method in class org.h2.command.Parser
 
parseRowType() - Method in class org.h2.command.Parser
 
parseRule() - Method in class org.h2.bnf.Bnf
 
parseRunScript() - Method in class org.h2.command.Parser
 
ParserUtil - Class in org.h2.util
 
ParserUtil() - Constructor for class org.h2.util.ParserUtil
 
parseSavepoint() - Method in class org.h2.command.Parser
 
parseScript() - Method in class org.h2.command.Parser
 
parseSelect(int) - Method in class org.h2.command.Parser
 
parseSelectExpressions(Select) - Method in class org.h2.command.Parser
 
parseSelectFromPart(Select) - Method in class org.h2.command.Parser
 
parseSequenceOptions(SequenceOptions, CreateSequence, boolean, boolean) - Method in class org.h2.command.Parser
 
parseSet() - Method in class org.h2.command.Parser
 
parseSetCollation() - Method in class org.h2.command.Parser
 
parseSetTransactionMode() - Method in class org.h2.command.Parser
 
parseShow() - Method in class org.h2.command.Parser
 
parseShutdown() - Method in class org.h2.command.Parser
 
parseSingleCommonTableExpression(boolean) - Method in class org.h2.command.Parser
 
parseSortSpecification() - Method in class org.h2.command.Parser
 
parseSortSpecificationList() - Method in class org.h2.command.Parser
 
parseSortType() - Method in class org.h2.command.Parser
 
parseTableColumnDefinition(CommandWithColumns, Schema, String, boolean) - Method in class org.h2.command.Parser
 
parseTableConstraintIf(String, Schema, boolean) - Method in class org.h2.command.Parser
 
parseTableName(String) - Method in class org.h2.command.Parser
Parse a SQL code snippet that represents a table name.
parseTimeNanos(String, int, int) - Static method in class org.h2.util.DateTimeUtils
Parse a time string.
parseTimestamp(String, CastDataProvider, boolean) - Static method in class org.h2.util.DateTimeUtils
Parses timestamp value from the specified string.
parseTimestampType() - Method in class org.h2.command.Parser
 
parseTimeType() - Method in class org.h2.command.Parser
 
parseTimeWithTimeZone(String, CastDataProvider) - Static method in class org.h2.util.DateTimeUtils
Parses TIME WITH TIME ZONE value from the specified string.
parseTimeZone(Value) - Static method in class org.h2.command.dml.Set
 
parseTimeZone(Value, long, long, int, boolean) - Static method in class org.h2.expression.TimeZoneOperation
 
parseToken() - Method in class org.h2.bnf.Bnf
 
parseTruncate() - Method in class org.h2.command.Parser
 
parseUInt31(String, int, int) - Static method in class org.h2.util.StringUtils
Parses an unsigned 31-bit integer.
parseUpdate(int) - Method in class org.h2.command.Parser
 
parseUse() - Method in class org.h2.command.Parser
 
parseValues() - Method in class org.h2.command.Parser
 
parseValuesForCommand(CommandWithValues) - Method in class org.h2.command.Parser
 
parseValuesRow(ArrayList<Expression>) - Method in class org.h2.command.Parser
 
parseWhenMatched(MergeUsing) - Method in class org.h2.command.Parser
 
parseWhenNotMatched(MergeUsing) - Method in class org.h2.command.Parser
 
parseWildcard(String, String) - Method in class org.h2.command.Parser
 
parseWith() - Method in class org.h2.command.Parser
 
parseWith1(List<TableView>) - Method in class org.h2.command.Parser
 
parseWithQuery() - Method in class org.h2.command.Parser
 
parseWithStatementOrQuery(int) - Method in class org.h2.command.Parser
 
PARSLET_DAY - Static variable in class org.h2.mode.ToDateTokenizer
The parslet for a day.
PARSLET_INLINE - Static variable in class org.h2.mode.ToDateTokenizer
The inline parslet.
PARSLET_MONTH - Static variable in class org.h2.mode.ToDateTokenizer
The parslet for a month.
PARSLET_TIME - Static variable in class org.h2.mode.ToDateTokenizer
The parslet for time.
PARSLET_YEAR - Static variable in class org.h2.mode.ToDateTokenizer
The parslet for a year.
PART_SUFFIX - Static variable in class org.h2.store.fs.split.FilePathSplit
 
partialQuickSort(X[], int, int, Comparator<? super X>, int, int) - Static method in class org.h2.util.Utils
Partial quick sort.
partitionBy - Variable in class org.h2.expression.analysis.Window
 
PartitionData - Class in org.h2.expression.analysis
Partition data of a window aggregate.
PartitionData(Object) - Constructor for class org.h2.expression.analysis.PartitionData
Creates new instance of partition data.
password - Variable in class org.h2.command.ddl.AlterUser
 
password - Variable in class org.h2.command.ddl.CreateLinkedTable
 
password - Variable in class org.h2.command.ddl.CreateUser
 
password - Variable in class org.h2.command.dml.ScriptBase
 
password - Variable in class org.h2.security.auth.AuthenticationInfo
 
password - Variable in class org.h2.security.auth.impl.StaticUserCredentialsValidator
 
password - Variable in class org.h2.table.TableLink
 
password - Variable in class org.h2.table.TableLinkConnection
The connection information.
passwordChars - Variable in class org.h2.jdbcx.JdbcDataSource
 
passwordConfirmationField - Variable in class org.h2.tools.GUIConsole
 
passwordField - Variable in class org.h2.tools.GUIConsole
 
passwordHash - Variable in class org.h2.engine.User
 
passwords - Variable in class org.h2.command.dml.ScriptCommand
 
patchCurrentRow(Value[]) - Method in class org.h2.jdbc.JdbcResultSet
 
patchedRows - Variable in class org.h2.jdbc.JdbcResultSet
 
pathField - Variable in class org.h2.tools.GUIConsole
 
PATTERN_AM_PM - Static variable in class org.h2.mode.ToDateTokenizer
The pattern for "am" or "pm".
PATTERN_BC_AD - Static variable in class org.h2.mode.ToDateTokenizer
The pattern for "bc" or "ad".
PATTERN_FF - Static variable in class org.h2.mode.ToDateTokenizer
The pattern for a fraction (of a second for example).
PATTERN_FOUR_DIGITS - Static variable in class org.h2.mode.ToDateTokenizer
The pattern for four digits (typically a year).
PATTERN_INLINE - Static variable in class org.h2.mode.ToDateTokenizer
The pattern for a number.
PATTERN_NUMBER - Static variable in class org.h2.mode.ToDateTokenizer
The pattern for a number.
PATTERN_ONE_DIGIT - Static variable in class org.h2.mode.ToDateTokenizer
The pattern for one digit.
PATTERN_THREE_DIGITS - Static variable in class org.h2.mode.ToDateTokenizer
The pattern for three digits.
PATTERN_TWO_DIGITS - Static variable in class org.h2.mode.ToDateTokenizer
The pattern for two digits.
PATTERN_TWO_DIGITS_OR_LESS - Static variable in class org.h2.mode.ToDateTokenizer
The pattern for one or two digits.
PATTERN_TWO_TO_FOUR_DIGITS - Static variable in class org.h2.mode.ToDateTokenizer
The pattern 2-4 digits (e.g.
patternChars - Variable in class org.h2.expression.condition.CompareLike
 
patternLength - Variable in class org.h2.expression.condition.CompareLike
 
patternRegexp - Variable in class org.h2.expression.condition.CompareLike
 
patternString - Variable in class org.h2.expression.condition.CompareLike
 
patternToUse - Variable in enum org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
patternTypes - Variable in class org.h2.expression.condition.CompareLike
one of MATCH / ONE / ANY
paused - Variable in class org.h2.util.Profiler
 
peek(int) - Method in class org.h2.util.ByteStack
Looks at the item at the top of this stack without removing it.
peek(long) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Get the value for the given key if the entry is cached.
PERCENT - Static variable in class org.h2.command.Token
The token "%".
PERCENT - Static variable in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
PERCENT_RANK - org.h2.expression.aggregate.AggregateType
The type for PERCENT_RANK() hypothetical set function.
PERCENT_RANK - org.h2.expression.analysis.WindowFunctionType
The type for PERCENT_RANK() window function.
Percentile - Class in org.h2.expression.aggregate
PERCENTILE_CONT, PERCENTILE_DISC, and MEDIAN inverse distribution functions.
Percentile() - Constructor for class org.h2.expression.aggregate.Percentile
 
PERCENTILE_CONT - org.h2.expression.aggregate.AggregateType
The aggregate type for PERCENTILE_CONT(expression).
PERCENTILE_DISC - org.h2.expression.aggregate.AggregateType
The aggregate type for PERCENTILE_DISC(expression).
performTransfer(Statement, String, String, String, String) - Static method in class org.h2.tools.CreateCluster
 
periodToValue(Period) - Static method in class org.h2.util.JSR310Utils
Converts a Period to a Value.
Permutations<T> - Class in org.h2.util
A class to iterate over all permutations of an array.
Permutations(T[], T[], int) - Constructor for class org.h2.util.Permutations
 
persistData - Variable in class org.h2.command.ddl.CreateTableData
Whether the data should be persisted.
persistData - Variable in class org.h2.table.Table
 
persistedObjectId - Variable in class org.h2.command.Prepared
Used to preserve object identities on database startup.
persistent - Variable in class org.h2.engine.ConnectionInfo
 
persistent - Variable in class org.h2.engine.Database
 
persistent - Variable in class org.h2.index.IndexType
 
persistIndexes - Variable in class org.h2.command.ddl.CreateTableData
Whether the indexes should be persisted.
persistIndexes - Variable in class org.h2.table.Table
 
persistUsers - Variable in class org.h2.security.auth.DefaultAuthenticator
 
pg - Variable in class org.h2.tools.Console
 
pg - Variable in class org.h2.tools.Server
 
PG_AM - Static variable in class org.h2.mode.PgCatalogTable
 
PG_ATTRDEF - Static variable in class org.h2.mode.PgCatalogTable
 
PG_ATTRIBUTE - Static variable in class org.h2.mode.PgCatalogTable
 
PG_AUTHID - Static variable in class org.h2.mode.PgCatalogTable
 
PG_CATALOG_SCHEMA_ID - Static variable in class org.h2.engine.Constants
The identity of pg_catalog schema.
PG_CLASS - Static variable in class org.h2.mode.PgCatalogTable
 
PG_CONSTRAINT - Static variable in class org.h2.mode.PgCatalogTable
 
PG_DATABASE - Static variable in class org.h2.mode.PgCatalogTable
 
PG_DEFAULT_CLIENT_ENCODING - Static variable in class org.h2.engine.SysProperties
System property h2.pgClientEncoding (default: UTF-8).
PG_DESCRIPTION - Static variable in class org.h2.mode.PgCatalogTable
 
PG_ENCODING_TO_CHAR - Static variable in class org.h2.mode.FunctionsPostgreSQL
 
PG_EXTRA_TYPES - Static variable in class org.h2.mode.PgCatalogTable
 
PG_GET_EXPR - Static variable in class org.h2.mode.FunctionsPostgreSQL
 
PG_GET_INDEXDEF - Static variable in class org.h2.mode.FunctionsPostgreSQL
 
PG_GET_USERBYID - Static variable in class org.h2.mode.FunctionsPostgreSQL
 
PG_GROUP - Static variable in class org.h2.mode.PgCatalogTable
 
PG_INDEX - Static variable in class org.h2.mode.PgCatalogTable
 
PG_INHERITS - Static variable in class org.h2.mode.PgCatalogTable
 
PG_NAMESPACE - Static variable in class org.h2.mode.PgCatalogTable
 
PG_POSTMASTER_START_TIME - Static variable in class org.h2.mode.FunctionsPostgreSQL
 
PG_PROC - Static variable in class org.h2.mode.PgCatalogTable
 
PG_RELATION_SIZE - Static variable in class org.h2.mode.FunctionsPostgreSQL
 
PG_ROLES - Static variable in class org.h2.mode.PgCatalogTable
 
PG_SETTINGS - Static variable in class org.h2.mode.PgCatalogTable
 
PG_STAT_GET_NUMSCANS - Static variable in class org.h2.mode.FunctionsPostgreSQL
 
PG_TABLE_IS_VISIBLE - Static variable in class org.h2.mode.FunctionsPostgreSQL
 
PG_TABLESPACE - Static variable in class org.h2.mode.PgCatalogTable
 
PG_TRIGGER - Static variable in class org.h2.mode.PgCatalogTable
 
PG_TYPE - Static variable in class org.h2.mode.PgCatalogTable
 
PG_TYPE_BOOL - Static variable in class org.h2.server.pg.PgServer
 
PG_TYPE_BPCHAR - Static variable in class org.h2.server.pg.PgServer
 
PG_TYPE_BYTEA - Static variable in class org.h2.server.pg.PgServer
 
PG_TYPE_DATE - Static variable in class org.h2.server.pg.PgServer
 
PG_TYPE_FLOAT4 - Static variable in class org.h2.server.pg.PgServer
 
PG_TYPE_FLOAT8 - Static variable in class org.h2.server.pg.PgServer
 
PG_TYPE_INT2 - Static variable in class org.h2.server.pg.PgServer
 
PG_TYPE_INT2_ARRAY - Static variable in class org.h2.server.pg.PgServer
 
PG_TYPE_INT4 - Static variable in class org.h2.server.pg.PgServer
 
PG_TYPE_INT4_ARRAY - Static variable in class org.h2.server.pg.PgServer
 
PG_TYPE_INT8 - Static variable in class org.h2.server.pg.PgServer
 
PG_TYPE_NUMERIC - Static variable in class org.h2.server.pg.PgServer
 
PG_TYPE_TEXT - Static variable in class org.h2.server.pg.PgServer
 
PG_TYPE_TIME - Static variable in class org.h2.server.pg.PgServer
 
PG_TYPE_TIMESTAMP - Static variable in class org.h2.server.pg.PgServer
 
PG_TYPE_TIMESTAMPTZ - Static variable in class org.h2.server.pg.PgServer
 
PG_TYPE_TIMETZ - Static variable in class org.h2.server.pg.PgServer
 
PG_TYPE_UNKNOWN - Static variable in class org.h2.server.pg.PgServer
 
PG_TYPE_VARCHAR - Static variable in class org.h2.server.pg.PgServer
The VARCHAR type.
PG_TYPE_VARCHAR_ARRAY - Static variable in class org.h2.server.pg.PgServer
 
PG_USER - Static variable in class org.h2.mode.PgCatalogTable
 
PG_VERSION - Static variable in class org.h2.engine.Constants
Announced version for PgServer.
pgAttribute(SessionLocal, ArrayList<Row>, Table) - Method in class org.h2.mode.PgCatalogTable
 
pgCatalogSchema - Variable in class org.h2.engine.Database
 
PgCatalogSchema - Class in org.h2.mode
pg_catalog schema.
PgCatalogSchema(Database, User) - Constructor for class org.h2.mode.PgCatalogSchema
Creates new instance of pg_catalog schema.
PgCatalogTable - Class in org.h2.mode
This class is responsible to build the pg_catalog tables.
PgCatalogTable(Schema, int, int) - Constructor for class org.h2.mode.PgCatalogTable
Create a new metadata table.
pgClass(SessionLocal, ArrayList<Row>, Table) - Method in class org.h2.mode.PgCatalogTable
 
pgConstraint(SessionLocal, ArrayList<Row>) - Method in class org.h2.mode.PgCatalogTable
 
PgServer - Class in org.h2.server.pg
This class implements a subset of the PostgreSQL protocol as described here: https://www.postgresql.org/docs/devel/protocol.html The PostgreSQL catalog is described here: https://www.postgresql.org/docs/7.4/catalogs.html
PgServer() - Constructor for class org.h2.server.pg.PgServer
 
PgServerThread - Class in org.h2.server.pg
One server thread is opened for each client.
PgServerThread(Socket, PgServer) - Constructor for class org.h2.server.pg.PgServerThread
 
PgServerThread.Portal - Class in org.h2.server.pg
Represents a PostgreSQL Portal object.
PgServerThread.Prepared - Class in org.h2.server.pg
Represents a PostgreSQL Prepared object.
pgTimeZone(String) - Static method in class org.h2.server.pg.PgServerThread
 
physicalConn - Variable in class org.h2.jdbcx.JdbcXAConnection
 
pid - Variable in class org.h2.server.pg.PgServer
 
pid - Variable in class org.h2.util.Profiler
 
pinCount - Variable in class org.h2.mvstore.Chunk
Number of live pinned pages.
PIPE_LENGTH - Static variable in class org.h2.mvstore.MVStore
 
Plain(SessionLocal, ArrayList<Expression>) - Constructor for class org.h2.command.query.SelectGroups.Plain
 
plainIterator(ArrayList<Value[]>, int, int, boolean) - Static method in class org.h2.expression.analysis.WindowFrame
 
PlainItr(ArrayList<Value[]>, int, int) - Constructor for class org.h2.expression.analysis.WindowFrame.PlainItr
 
PlainReverseItr(ArrayList<Value[]>, int, int) - Constructor for class org.h2.expression.analysis.WindowFrame.PlainReverseItr
 
Plan - Class in org.h2.table
A possible query execution plan.
Plan(TableFilter[], int, Expression) - Constructor for class org.h2.table.Plan
Create a query plan with the given order.
PlanItem - Class in org.h2.table
The plan item describes the index to be used, and the estimated cost when using it.
PlanItem() - Constructor for class org.h2.table.PlanItem
 
planItems - Variable in class org.h2.table.Plan
 
PLUS - org.h2.expression.BinaryOperation.OpType
This operation represents an addition as in 1 + 2.
PLUS_SIGN - Static variable in class org.h2.command.Token
The token "+".
POINT - Static variable in class org.h2.util.geometry.GeometryUtils
POINT geometry type.
poll(int) - Method in class org.h2.util.ByteStack
Removes the item at the top of this stack and returns that item.
pollUnclosed() - Static method in class org.h2.util.CloseWatcher
Check for an collected object.
POLYGON - Static variable in class org.h2.util.geometry.GeometryUtils
POLYGON geometry type.
PooledJdbcConnection(JdbcConnection) - Constructor for class org.h2.jdbcx.JdbcXAConnection.PooledJdbcConnection
 
pop() - Method in class org.h2.util.ByteStack
Removes the item at the top of this stack and returns that item.
populateRowFromDBObject(DbObject, SearchRow) - Static method in class org.h2.engine.MetaRecord
Copy metadata from the specified object into specified search row.
port - Variable in class org.h2.security.auth.impl.LdapCredentialsValidator
 
port - Variable in class org.h2.server.pg.PgServer
 
port - Variable in class org.h2.server.TcpServer
 
port - Variable in class org.h2.server.web.WebServer
 
Portal() - Constructor for class org.h2.server.pg.PgServerThread.Portal
 
portals - Variable in class org.h2.server.pg.PgServerThread
 
portIsSet - Variable in class org.h2.server.pg.PgServer
 
portIsSet - Variable in class org.h2.server.TcpServer
 
pos - Variable in class org.h2.compress.LZFInputStream
 
pos - Variable in class org.h2.compress.LZFOutputStream
 
pos - Variable in class org.h2.mvstore.Page.PageReference
The position, if known, or 0.
pos - Variable in class org.h2.mvstore.Page
Position of this page's saved image within a Chunk or 0 if this page has not been saved yet or 1 if this page has not been saved yet, but already removed This "removed" flag is to keep track of pages that concurrently changed while they are being stored, in which case the live bookkeeping needs to be aware of such cases.
pos - Variable in class org.h2.mvstore.rtree.MVRTreeMap.RTreeCursor
 
pos - Variable in class org.h2.mvstore.StreamStore.Stream
 
pos - Variable in class org.h2.security.SecureFileStore
 
pos - Variable in class org.h2.server.TcpServerThread.CachedInputStream
 
pos - Variable in class org.h2.server.web.PageParser
 
pos - Variable in class org.h2.store.Data
The current write or read position.
pos - Variable in class org.h2.store.fs.FileChannelInputStream
 
pos - Variable in class org.h2.store.fs.zip.FileZip
 
pos - Variable in class org.h2.store.LobStorageRemoteInputStream
The position.
pos - Variable in class org.h2.util.CacheObject
 
position - Variable in class org.h2.bnf.context.DbColumn
 
position - Variable in class org.h2.command.dml.SetClauseList.SetMultiple
 
position - Variable in class org.h2.store.fs.FileBaseDefault
 
position() - Method in class org.h2.mvstore.cache.FilePathCache.FileCache
 
position() - Method in class org.h2.mvstore.WriteBuffer
Get the current position.
position() - Method in class org.h2.store.fs.FakeFileChannel
 
position() - Method in class org.h2.store.fs.FileBaseDefault
 
position() - Method in class org.h2.store.fs.rec.FileRec
 
position() - Method in class org.h2.store.fs.retry.FileRetryOnInterrupt
 
position() - Method in class org.h2.store.fs.zip.FileZip
 
position(byte[], long) - Method in class org.h2.jdbc.JdbcBlob
[Not supported] Searches a pattern and return the position.
position(int) - Method in class org.h2.mvstore.WriteBuffer
Set the position.
position(long) - Method in class org.h2.mvstore.cache.FilePathCache.FileCache
 
position(long) - Method in class org.h2.store.fs.FakeFileChannel
 
position(long) - Method in class org.h2.store.fs.FileBaseDefault
 
position(long) - Method in class org.h2.store.fs.rec.FileRec
 
position(long) - Method in class org.h2.store.fs.retry.FileRetryOnInterrupt
 
position(long) - Method in class org.h2.store.fs.zip.FileZip
 
position(String, long) - Method in class org.h2.jdbc.JdbcClob
[Not supported] Searches a pattern and return the position.
position(Blob, long) - Method in class org.h2.jdbc.JdbcBlob
[Not supported] Searches a pattern and return the position.
position(Clob, long) - Method in class org.h2.jdbc.JdbcClob
[Not supported] Searches a pattern and return the position.
PositionComparator() - Constructor for class org.h2.mvstore.Chunk.PositionComparator
 
POSITIVE_INFINITY - Static variable in class org.h2.value.ValueDecfloat
The positive infinity value.
PostgreSQL - org.h2.engine.Mode.ModeEnum
 
POSTGRESQL_STYLE - org.h2.engine.Mode.ExpressionNames
Use function name for functions and ?column? for other expressions
posUpdater - Static variable in class org.h2.mvstore.Page
Updater for pos field, which can be updated when page is saved, but can be concurrently marked as removed
POWER - Static variable in class org.h2.expression.function.MathFunction2
POWER().
powerOffCount - Variable in class org.h2.engine.Database
 
POWERS10 - Static variable in class org.h2.server.pg.PgServerThread
 
PRECEDING - org.h2.expression.analysis.WindowFrameBoundType
PRECEDING clause.
precision - Variable in class org.h2.util.SimpleColumnInfo
Precision of the column
precision - Variable in class org.h2.value.TypeInfo
 
PRECISION - Static variable in class org.h2.value.ValueBigint
The precision in bits.
PRECISION - Static variable in class org.h2.value.ValueBoolean
The precision in digits.
PRECISION - Static variable in class org.h2.value.ValueDate
The default precision and display size of the textual representation of a date.
PRECISION - Static variable in class org.h2.value.ValueDouble
The precision in bits.
PRECISION - Static variable in class org.h2.value.ValueInteger
The precision in bits.
PRECISION - Static variable in class org.h2.value.ValueNull
The precision of NULL.
PRECISION - Static variable in class org.h2.value.ValueReal
The precision in bits.
PRECISION - Static variable in class org.h2.value.ValueSmallint
The precision in bits.
PRECISION - Static variable in class org.h2.value.ValueTinyint
The precision in bits.
PRECISION - Static variable in class org.h2.value.ValueUuid
The precision of this value in number of bytes.
PredicateWithSubquery - Class in org.h2.expression.condition
Base class for predicates with a subquery.
PredicateWithSubquery(Query) - Constructor for class org.h2.expression.condition.PredicateWithSubquery
 
predictAllocation(int, long, long) - Method in class org.h2.mvstore.FileStore
Calculate starting position of the prospective allocation.
predictAllocation(int, long, long) - Method in class org.h2.mvstore.FreeSpaceBitSet
Calculate starting position of the prospective allocation.
prefix - Variable in class org.h2.value.DataType
The prefix required for the SQL literal representation.
PREFIX - Static variable in class org.h2.jdbcx.JdbcXid
 
PREFIX - Static variable in class org.h2.message.TraceObject
 
PREFIX_INDEX - Static variable in class org.h2.engine.Constants
The name prefix used for indexes that are not explicitly named.
PREFIX_JOIN - Static variable in class org.h2.engine.Constants
The name prefix used for synthetic nested join tables.
PREFIX_PRIMARY_KEY - Static variable in class org.h2.engine.Constants
The name prefix used for primary key constraints that are not explicitly named.
PREFIX_QUERY_ALIAS - Static variable in class org.h2.engine.Constants
The name prefix used for query aliases that are not explicitly named.
PREFIX_SERVER - Static variable in class org.h2.jdbc.JdbcConnection
 
PREFIX_TEMP_FILE - Static variable in class org.h2.engine.SysProperties
System property h2.prefixTempFile (default: h2.temp).
premain(String, Instrumentation) - Static method in class org.h2.util.Profiler
This method is called when the agent is installed.
prep - Variable in class org.h2.index.LinkedCursor
 
prep - Variable in class org.h2.jdbc.JdbcParameterMetaData
 
prep - Variable in class org.h2.jdbc.JdbcResultSetMetaData
 
prep - Variable in class org.h2.server.pg.PgServerThread.Portal
The prepared object.
prep - Variable in class org.h2.server.pg.PgServerThread.Prepared
The prepared statement.
prepare() - Method in class org.h2.command.dml.Call
 
prepare() - Method in class org.h2.command.dml.Delete
 
prepare() - Method in class org.h2.command.dml.Explain
 
prepare() - Method in class org.h2.command.dml.Insert
 
prepare() - Method in class org.h2.command.dml.Merge
 
prepare() - Method in class org.h2.command.dml.MergeUsing
 
prepare() - Method in class org.h2.command.dml.Update
 
prepare() - Method in class org.h2.command.Prepared
Prepare this statement.
prepare() - Method in class org.h2.command.query.Select
 
prepare() - Method in class org.h2.command.query.SelectUnion
 
prepare() - Method in class org.h2.command.query.TableValueConstructor
 
prepare() - Method in class org.h2.mvstore.tx.Transaction
Prepare the transaction.
prepare() - Method in class org.h2.table.TableFilter
Prepare reading rows.
prepare(String) - Method in class org.h2.command.Parser
Parse the statement and prepare it for execution.
prepare(String) - Method in class org.h2.engine.SessionLocal
Parse and prepare the given SQL statement.
prepare(String, boolean, boolean) - Method in class org.h2.engine.SessionLocal
Parse and prepare the given SQL statement.
prepare(Connection, String) - Method in class org.h2.fulltext.FullTextSettings
Prepare a statement.
prepare(Xid) - Method in class org.h2.jdbcx.JdbcXAConnection
Prepare a transaction.
prepare(Database, SessionLocal, DatabaseEventListener) - Method in class org.h2.engine.MetaRecord
Prepares the meta data statement.
prepare(SessionLocal) - Method in class org.h2.command.dml.MergeUsing.When
Prepares WHEN command.
prepare(SessionLocal) - Method in class org.h2.command.dml.MergeUsing.WhenMatchedThenUpdate
 
prepare(SessionLocal) - Method in class org.h2.command.dml.MergeUsing.WhenNotMatched
 
prepare(SessionLocal, String, ArrayList<Value>) - Static method in class org.h2.command.Parser
 
prepare(SessionLocal, String, ConstraintActionType) - Method in class org.h2.constraint.ConstraintReferential
 
prepare(SessionLocal, ArrayList<IndexCondition>) - Method in class org.h2.index.IndexCursor
Prepare this index cursor to make a lookup in index.
prepare(SessionRemote, boolean) - Method in class org.h2.command.CommandRemote
 
PREPARE - Static variable in interface org.h2.command.CommandInterface
The type of a PREPARE statement.
PREPARE_COMMIT - Static variable in interface org.h2.command.CommandInterface
The type of a PREPARE COMMIT statement.
prepareAlways - Variable in class org.h2.command.Prepared
If the query should be prepared before each execution.
prepareAndExecute(Database, SessionLocal, DatabaseEventListener) - Method in class org.h2.engine.MetaRecord
Execute the meta data statement.
prepareCall(String) - Method in class org.h2.jdbc.JdbcConnection
Creates a new callable statement.
prepareCall(String, int, int) - Method in class org.h2.jdbc.JdbcConnection
Creates a callable statement with the specified result set type and concurrency.
prepareCall(String, int, int, int) - Method in class org.h2.jdbc.JdbcConnection
Creates a callable statement with the specified result set type, concurrency, and holdability.
prepareColumns(Database, IndexColumn[], IndexType) - Static method in class org.h2.mvstore.db.MVTable
Prepares columns of an index.
prepareColumnsQueryH2(Connection) - Static method in class org.h2.bnf.context.DbSchema
 
prepareCommand(String) - Method in class org.h2.command.Parser
Parse a statement or a list of statements, and prepare it for execution.
prepareCommand(String, int) - Method in class org.h2.engine.Session
Parse a command and prepare it for execution.
prepareCommand(String, int) - Method in class org.h2.engine.SessionLocal
 
prepareCommand(String, int) - Method in class org.h2.engine.SessionRemote
 
prepareCommand(String, int) - Method in class org.h2.jdbc.JdbcConnection
Prepare an command.
prepareCommand(String, CommandInterface) - Method in class org.h2.jdbc.JdbcConnection
 
prepareCommandList(CommandContainer, Prepared, String, String, ArrayList<Token>) - Method in class org.h2.command.Parser
 
prepareCommit(String) - Method in class org.h2.engine.SessionLocal
Prepare the given transaction.
prepareCommit(SessionLocal, String) - Method in class org.h2.engine.Database
Prepare a transaction.
prepareCommit(SessionLocal, String) - Method in class org.h2.mvstore.db.Store
Prepare a transaction.
prepared - Variable in class org.h2.command.CommandContainer
 
prepared - Variable in class org.h2.command.ddl.PrepareProcedure
 
prepared - Variable in class org.h2.engine.Procedure
 
prepared - Variable in class org.h2.engine.SessionLocal.SequenceAndPrepared
 
prepared - Variable in class org.h2.expression.Rownum
 
prepared - Variable in class org.h2.expression.SequenceValue
 
prepared - Variable in class org.h2.jdbcx.JdbcXAConnection
 
prepared - Variable in class org.h2.server.pg.PgServerThread
 
Prepared - Class in org.h2.command
A prepared statement.
Prepared() - Constructor for class org.h2.server.pg.PgServerThread.Prepared
 
Prepared(SessionLocal) - Constructor for class org.h2.command.Prepared
Create a new object.
PREPARED_STATEMENT - Static variable in class org.h2.message.TraceObject
The trace type id for prepared statements.
preparedMap - Variable in class org.h2.table.TableLink
 
prepareDrop() - Method in class org.h2.command.ddl.DropTable
 
preparedStatement - Variable in class org.h2.jdbc.JdbcResultSet
 
preparedTransactions - Variable in class org.h2.mvstore.tx.TransactionStore
The persisted map of prepared transactions.
prepareExpressions(SessionLocal) - Method in class org.h2.schema.Domain
 
prepareExpressions(SessionLocal) - Method in class org.h2.table.Column
 
prepareExpressions(SessionLocal) - Method in interface org.h2.table.ColumnTemplate
Prepare all expressions of this column or domain.
prepareIfRequired() - Method in class org.h2.command.CommandRemote
 
prepareLocal(String) - Method in class org.h2.engine.SessionLocal
Parse and prepare the given SQL statement.
prepareOrder(ArrayList<QueryOrderBy>, int) - Method in class org.h2.command.query.Query
Create a SortOrder object given the list of QueryOrderBy objects.
preparePlan(boolean) - Method in class org.h2.command.query.Select
 
PrepareProcedure - Class in org.h2.command.ddl
This class represents the statement PREPARE
PrepareProcedure(SessionLocal) - Constructor for class org.h2.command.ddl.PrepareProcedure
 
prepareStatement(String) - Method in class org.h2.jdbc.JdbcConnection
Creates a new prepared statement.
prepareStatement(String, int) - Method in class org.h2.jdbc.JdbcConnection
Creates a new prepared statement.
prepareStatement(String, int[]) - Method in class org.h2.jdbc.JdbcConnection
Creates a new prepared statement.
prepareStatement(String, int, int) - Method in class org.h2.jdbc.JdbcConnection
Creates a prepared statement with the specified result set type and concurrency.
prepareStatement(String, int, int, int) - Method in class org.h2.jdbc.JdbcConnection
Creates a prepared statement with the specified result set type, concurrency, and holdability.
prepareStatement(String, String[]) - Method in class org.h2.jdbc.JdbcConnection
Creates a new prepared statement.
prepareUpdate(Table, SessionLocal, ResultTarget, DataChangeDeltaTable.ResultOption, LocalResult, Row, boolean) - Method in class org.h2.command.dml.SetClauseList
 
prepareUpdateCondition(Index, Expression[]) - Method in class org.h2.command.dml.Insert
 
prepareViewDefinitionQuery(Connection, DbContents) - Static method in class org.h2.server.web.WebApp
 
preservePasswordForAuthentication(Object) - Method in class org.h2.engine.ConnectionInfo
 
preserveWhitespace - Variable in class org.h2.tools.Csv
 
previous - Variable in class org.h2.mvstore.RootReference
Reference to the previous root in the chain.
previous() - Method in interface org.h2.index.Cursor
Skip to the previous row if one is available.
previous() - Method in class org.h2.index.DualCursor
 
previous() - Method in class org.h2.index.IndexCursor
 
previous() - Method in class org.h2.index.LinkedCursor
 
previous() - Method in class org.h2.index.MetaCursor
 
previous() - Method in class org.h2.index.RangeCursor
 
previous() - Method in class org.h2.index.SingleRowCursor
 
previous() - Method in class org.h2.index.ViewCursor
 
previous() - Method in class org.h2.index.VirtualTableCursor
 
previous() - Method in class org.h2.jdbc.JdbcResultSet
Moves the cursor to the last row, or row before first row if the current position is the first row.
previous() - Method in class org.h2.mvstore.db.MVPrimaryIndex.MVStoreCursor
 
previous() - Method in class org.h2.mvstore.db.MVSecondaryIndex.MVStoreCursor
 
previous() - Method in class org.h2.mvstore.db.MVSpatialIndex.MVStoreCursor
 
previous() - Method in class org.h2.tools.SimpleResultSet
INTERNAL
previousKeyValues - Variable in class org.h2.command.query.Select.LazyResultGroupSorted
 
PRIMARY - Static variable in class org.h2.util.ParserUtil
The token "PRIMARY".
PRIMARY_KEY - org.h2.constraint.Constraint.Type
The constraint type for primary key constraints.
primaryIndex - Variable in class org.h2.mvstore.db.MVTable
 
primaryKey - Variable in class org.h2.command.ddl.CommandWithColumns
 
primaryKey - Variable in class org.h2.command.ddl.CreateIndex
 
primaryKey - Variable in class org.h2.constraint.ConstraintUnique
 
primaryKey - Variable in class org.h2.index.IndexType
 
primaryKey - Variable in class org.h2.table.Column
 
primaryKeyHash - Variable in class org.h2.command.ddl.AlterTableAddConstraint
 
print(String) - Method in class org.h2.tools.Shell
Print the string without newline, and flush.
println(String) - Method in class org.h2.tools.Shell
 
printLockInfo(PrintWriter, LockInfo[], String, ArrayList<String>, ArrayList<String>) - Static method in class org.h2.util.ThreadDeadlockDetector
 
printNextExceptions(SQLException, PrintStream) - Static method in exception org.h2.message.DbException
Prints up to 100 next exceptions for a specified SQL exception.
printNextExceptions(SQLException, PrintWriter) - Static method in exception org.h2.message.DbException
Prints up to 100 next exceptions for a specified SQL exception.
printNoDatabaseFilesFound(String, String) - Method in class org.h2.util.Tool
Print to the output stream that no database files have been found.
printProblem(Exception, Server) - Method in class org.h2.tools.Console
 
printResult(ResultSet, boolean) - Method in class org.h2.tools.Shell
 
printResultAsList(ResultSet) - Method in class org.h2.tools.Shell
 
printResultAsTable(ResultSet) - Method in class org.h2.tools.Shell
 
printRows(ArrayList<String[]>, int) - Method in class org.h2.tools.Shell
 
printStackTrace() - Method in exception org.h2.jdbc.JdbcBatchUpdateException
INTERNAL
printStackTrace(PrintStream) - Method in exception org.h2.jdbc.JdbcBatchUpdateException
INTERNAL
printStackTrace(PrintStream) - Method in exception org.h2.jdbc.JdbcSQLDataException
 
printStackTrace(PrintStream) - Method in exception org.h2.jdbc.JdbcSQLException
 
printStackTrace(PrintStream) - Method in exception org.h2.jdbc.JdbcSQLFeatureNotSupportedException
 
printStackTrace(PrintStream) - Method in exception org.h2.jdbc.JdbcSQLIntegrityConstraintViolationException
 
printStackTrace(PrintStream) - Method in exception org.h2.jdbc.JdbcSQLInvalidAuthorizationSpecException
 
printStackTrace(PrintStream) - Method in exception org.h2.jdbc.JdbcSQLNonTransientConnectionException
 
printStackTrace(PrintStream) - Method in exception org.h2.jdbc.JdbcSQLNonTransientException
 
printStackTrace(PrintStream) - Method in exception org.h2.jdbc.JdbcSQLSyntaxErrorException
 
printStackTrace(PrintStream) - Method in exception org.h2.jdbc.JdbcSQLTimeoutException
 
printStackTrace(PrintStream) - Method in exception org.h2.jdbc.JdbcSQLTransactionRollbackException
 
printStackTrace(PrintStream) - Method in exception org.h2.jdbc.JdbcSQLTransientException
 
printStackTrace(PrintWriter) - Method in exception org.h2.jdbc.JdbcBatchUpdateException
INTERNAL
printStackTrace(PrintWriter) - Method in exception org.h2.jdbc.JdbcSQLDataException
 
printStackTrace(PrintWriter) - Method in exception org.h2.jdbc.JdbcSQLException
 
printStackTrace(PrintWriter) - Method in exception org.h2.jdbc.JdbcSQLFeatureNotSupportedException
 
printStackTrace(PrintWriter) - Method in exception org.h2.jdbc.JdbcSQLIntegrityConstraintViolationException
 
printStackTrace(PrintWriter) - Method in exception org.h2.jdbc.JdbcSQLInvalidAuthorizationSpecException
 
printStackTrace(PrintWriter) - Method in exception org.h2.jdbc.JdbcSQLNonTransientConnectionException
 
printStackTrace(PrintWriter) - Method in exception org.h2.jdbc.JdbcSQLNonTransientException
 
printStackTrace(PrintWriter) - Method in exception org.h2.jdbc.JdbcSQLSyntaxErrorException
 
printStackTrace(PrintWriter) - Method in exception org.h2.jdbc.JdbcSQLTimeoutException
 
printStackTrace(PrintWriter) - Method in exception org.h2.jdbc.JdbcSQLTransactionRollbackException
 
printStackTrace(PrintWriter) - Method in exception org.h2.jdbc.JdbcSQLTransientException
 
printThread(PrintWriter, ThreadInfo) - Static method in class org.h2.util.ThreadDeadlockDetector
 
printThreadInfo(PrintWriter, ThreadInfo) - Static method in class org.h2.util.ThreadDeadlockDetector
 
printWriter - Variable in class org.h2.message.TraceSystem
 
procedure - Variable in class org.h2.command.dml.ExecuteProcedure
 
Procedure - Class in org.h2.engine
Represents a procedure.
Procedure(String, Prepared) - Constructor for class org.h2.engine.Procedure
 
PROCEDURE - Static variable in class org.h2.bnf.context.DbContextRule
 
PROCEDURE_COLUMN_IN - Static variable in class org.h2.jdbc.meta.DatabaseMetaLocal
 
PROCEDURE_COLUMN_RETURN - Static variable in class org.h2.jdbc.meta.DatabaseMetaLocal
 
PROCEDURE_NO_RESULT - Static variable in class org.h2.jdbc.meta.DatabaseMetaLocal
 
PROCEDURE_RETURNS_RESULT - Static variable in class org.h2.jdbc.meta.DatabaseMetaLocal
 
procedureName - Variable in class org.h2.command.ddl.DeallocateProcedure
 
procedureName - Variable in class org.h2.command.ddl.PrepareProcedure
 
procedures - Variable in class org.h2.bnf.context.DbSchema
The procedures list.
procedures - Variable in class org.h2.engine.SessionLocal
 
process() - Method in class org.h2.server.pg.PgServerThread
 
process() - Method in class org.h2.server.TcpServerThread
 
process() - Method in class org.h2.server.web.WebThread
 
process(String, boolean) - Static method in class org.h2.tools.DeleteDbFiles
 
process(String, boolean, char[]) - Method in class org.h2.tools.ChangeFileEncryption
 
process(String, String) - Method in class org.h2.tools.Recover
 
process(String, String, boolean) - Method in class org.h2.tools.DeleteDbFiles
Deletes the database files.
process(String, String, String, boolean) - Method in class org.h2.tools.Backup
 
process(String, String, String, char[], char[], boolean) - Method in class org.h2.tools.ChangeFileEncryption
 
process(String, String, String, String, String) - Static method in class org.h2.tools.CreateCluster
 
process(String, String, String, String, String, String) - Static method in class org.h2.tools.Script
Backs up a database to a stream.
process(String, String, String, String, Charset, boolean) - Method in class org.h2.tools.RunScript
Executes the SQL commands in a script file against a database.
process(String, NetworkConnectionInfo) - Method in class org.h2.server.web.WebApp
 
process(Connection, boolean, String, Reader, Charset) - Method in class org.h2.tools.RunScript
 
process(Connection, String, boolean, Charset) - Method in class org.h2.tools.RunScript
 
process(Connection, String, String, String) - Static method in class org.h2.tools.Script
Backs up a database to a stream.
process(SessionLocal, int, Value[]) - Static method in class org.h2.jdbc.meta.DatabaseMetaServer
Process a database meta data request.
processGroup(HashMap<Integer, Value>, Value, ArrayList<Value[]>, int, int, int, boolean) - Method in class org.h2.expression.aggregate.AbstractAggregate
 
processGroupResult(int, LocalResult, long, boolean, boolean) - Method in class org.h2.command.query.Select
 
processHelpText(String) - Static method in class org.h2.command.dml.Help
Sanitize value read from csv file (i.e.
processId - Variable in class org.h2.server.pg.PgServerThread
 
processList(List<Object[]>) - Method in class org.h2.util.Profiler
 
processQueue() - Method in class org.h2.util.SoftValuesHashMap
 
processRemovalInfo(long) - Method in class org.h2.mvstore.CursorPos
Calculate the memory used by changes that are not yet stored.
processRequest(String, NetworkConnectionInfo) - Method in class org.h2.server.web.WebApp
Process an HTTP request.
processRunscript(String, String, String, String, String) - Static method in class org.h2.tools.RunScript
 
processThreadList(ThreadInfo[]) - Method in class org.h2.util.AbbaLockingDetector
 
processUescape(String, ArrayList<Token>) - Static method in class org.h2.command.Tokenizer
 
profiler - Variable in class org.h2.server.web.WebApp
 
Profiler - Class in org.h2.util
A simple CPU profiling tool similar to java -Xrunhprof.
Profiler() - Constructor for class org.h2.util.Profiler
 
PROLEPTIC_GREGORIAN_CHANGE - Static variable in class org.h2.util.LegacyDateTimeUtils
Gregorian change date for a GregorianCalendar that represents a proleptic Gregorian calendar.
promoteSnapshot() - Method in class org.h2.mvstore.tx.TransactionMap
 
promptLoop() - Method in class org.h2.tools.Shell
 
prop - Variable in class org.h2.engine.ConnectionInfo
 
properties - Variable in class org.h2.security.auth.ConfigProperties
 
properties - Variable in class org.h2.security.auth.RealmConfig
 
properties - Variable in class org.h2.security.auth.UserToRolesMapperConfig
 
properties - Variable in class org.h2.store.FileLock
 
PropertyConfig - Class in org.h2.security.auth
Configuration property
PropertyConfig() - Constructor for class org.h2.security.auth.PropertyConfig
 
PropertyConfig(String, String) - Constructor for class org.h2.security.auth.PropertyConfig
 
provider - Variable in class org.h2.command.Tokenizer
 
provider - Variable in class org.h2.mvstore.db.ValueDataType
 
providers - Static variable in class org.h2.store.fs.FilePath
 
pruneStack() - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
Ensure the last entry of the stack is cold.
PUBLIC_ROLE_NAME - Static variable in class org.h2.engine.Constants
Every user belongs to this role.
PUBLIC_STATIC_JAVA_METHOD_NOT_FOUND_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90139 is thrown when the specified public static Java method was not found in the class.
publicRole - Variable in class org.h2.engine.Database
 
push(byte) - Method in class org.h2.util.ByteStack
Pushes an item onto the top of this stack.
pushBack() - Method in class org.h2.tools.Csv
 
put(byte) - Method in class org.h2.mvstore.WriteBuffer
Put a byte.
put(byte[]) - Method in class org.h2.mvstore.WriteBuffer
Put a byte array.
put(byte[], int, int) - Method in class org.h2.mvstore.WriteBuffer
Put a byte array.
put(long, int, V, int) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
Add an entry to the cache.
put(long, V) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Add an entry to the cache using the average memory size.
put(long, V, int) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Add an entry to the cache.
put(ByteArrayOutputStream, InputStream, int) - Method in class org.h2.mvstore.StreamStore
 
put(InputStream) - Method in class org.h2.mvstore.StreamStore
Store the stream, and return the id.
put(String, Object) - Method in class org.h2.server.web.WebSession
Put an attribute value in the map.
put(String, V) - Method in class org.h2.value.CaseInsensitiveConcurrentMap
 
put(String, V) - Method in class org.h2.value.CaseInsensitiveMap
 
put(ByteBuffer) - Method in class org.h2.mvstore.WriteBuffer
Put the contents of a byte buffer.
put(K, V) - Method in class org.h2.mvstore.MVMap
Add or replace a key-value pair.
put(K, V) - Method in class org.h2.mvstore.tx.TransactionMap
Update the value for the given key.
put(K, V) - Method in class org.h2.store.fs.mem.FileMemData.Cache
 
put(K, V) - Method in class org.h2.store.fs.niomem.FileNioMemData.CompressLaterCache
 
put(K, V) - Method in class org.h2.util.SoftValuesHashMap
Store the object.
put(Spatial, V) - Method in class org.h2.mvstore.rtree.MVRTreeMap
 
put(CacheObject) - Method in interface org.h2.util.Cache
Add an element to the cache.
put(CacheObject) - Method in class org.h2.util.CacheLRU
 
put(CacheObject) - Method in class org.h2.util.CacheSecondLevel
 
put(CacheObject) - Method in class org.h2.util.CacheTQ
 
PUT - org.h2.mvstore.MVMap.Decision
 
PUT - Static variable in class org.h2.mvstore.MVMap.DecisionMaker
Decision maker for put().
putAll(Map<Long, ? extends V>) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Add all elements of the map to this cache.
putChar(char) - Method in class org.h2.mvstore.WriteBuffer
Put a character.
putCommitted(K, V) - Method in class org.h2.mvstore.tx.TransactionMap
Update the value for the given key, without adding an undo log entry.
putDouble(double) - Method in class org.h2.mvstore.WriteBuffer
Put a double.
putFloat(float) - Method in class org.h2.mvstore.WriteBuffer
Put a float.
putIfAbsent(String, V) - Method in class org.h2.value.CaseInsensitiveConcurrentMap
 
putIfAbsent(String, V) - Method in class org.h2.value.CaseInsensitiveMap
 
putIfAbsent(K, V) - Method in class org.h2.mvstore.MVMap
Add a key-value pair if it does not yet exist.
putIfAbsent(K, V) - Method in class org.h2.mvstore.tx.TransactionMap
Put the value for the given key if entry for this key does not exist.
PutIfAbsentDecisionMaker(int, Transaction, Function<K, V>) - Constructor for class org.h2.mvstore.tx.TxDecisionMaker.PutIfAbsentDecisionMaker
 
putIndirectId(ByteArrayOutputStream) - Method in class org.h2.mvstore.StreamStore
 
putInt(int) - Method in class org.h2.mvstore.WriteBuffer
Put an integer.
putInt(int, int) - Method in class org.h2.mvstore.WriteBuffer
Update an integer at the given index.
putLong(long) - Method in class org.h2.mvstore.WriteBuffer
Put a long.
putShort(int, short) - Method in class org.h2.mvstore.WriteBuffer
Update a short at the given index.
putShort(short) - Method in class org.h2.mvstore.WriteBuffer
Put a short.
putStringData(String, int) - Method in class org.h2.mvstore.WriteBuffer
Write the characters of a string in a format similar to UTF-8.
putToCache(List<ToDateTokenizer.FormatTokenEnum>[], ToDateTokenizer.FormatTokenEnum, String) - Static method in enum org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
putVarInt(int) - Method in class org.h2.mvstore.WriteBuffer
Write a variable size integer.
putVarLong(long) - Method in class org.h2.mvstore.WriteBuffer
Write a variable size long.

Q

Q - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
quadraticSplit - Variable in class org.h2.mvstore.rtree.MVRTreeMap
 
qualifiedTableName - Variable in class org.h2.table.TableLink
 
qualifier - Variable in class org.h2.api.Interval
 
qualify - Variable in class org.h2.command.query.Select
QUALIFY condition.
QUALIFY - Static variable in class org.h2.util.ParserUtil
The token "QUALIFY".
qualifyIndex - Variable in class org.h2.command.query.Select
 
QUARTER - Static variable in class org.h2.expression.function.DateTimeFunction
Quarter.
query - Variable in class org.h2.bnf.Sentence
The complete query string.
query - Variable in class org.h2.command.dml.Insert
 
query - Variable in class org.h2.command.dml.Merge
 
query - Variable in class org.h2.expression.ArrayConstructorByQuery
The subquery.
query - Variable in class org.h2.expression.condition.PredicateWithSubquery
The subquery.
query - Variable in class org.h2.expression.Subquery
 
query - Variable in class org.h2.index.ViewIndex
 
query() - Method in class org.h2.server.web.WebApp
 
query(long) - Method in class org.h2.command.Command
Execute a query statement, if this is possible.
query(long) - Method in class org.h2.command.CommandContainer
 
query(long) - Method in class org.h2.command.CommandList
 
query(long) - Method in class org.h2.command.dml.Call
 
query(long) - Method in class org.h2.command.dml.ExecuteProcedure
 
query(long) - Method in class org.h2.command.dml.Explain
 
query(long) - Method in class org.h2.command.dml.Help
 
query(long) - Method in class org.h2.command.dml.ScriptCommand
 
query(long) - Method in class org.h2.command.Prepared
Execute the query.
query(long) - Method in class org.h2.command.query.Query
 
query(long, ResultTarget) - Method in class org.h2.command.query.Query
Execute the query, writing the result to the target result.
query(Connection, String, int, int, StringBuilder) - Method in class org.h2.server.web.WebApp
Execute a query and append the result to the buffer.
Query - Class in org.h2.command.query
Represents a SELECT statement (simple, or union).
Query(SessionLocal) - Constructor for class org.h2.command.query.Query
 
QUERY_COMPARABLE - Static variable in class org.h2.expression.ExpressionVisitor
Can the expression be added to a condition of an outer query.
QUERY_COMPARABLE_VISITOR - Static variable in class org.h2.expression.ExpressionVisitor
The visitor singleton for the type QUERY_COMPARABLE.
QUERY_ENTRY_COMPARATOR - Static variable in class org.h2.engine.QueryStatisticsData
 
QUERY_STATISTICS - Static variable in class org.h2.command.dml.SetTypes
The type of a SET QUERY_STATISTICS statement.
QUERY_STATISTICS - Static variable in class org.h2.table.InformationSchemaTable
 
QUERY_STATISTICS - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
QUERY_STATISTICS_MAX_ENTRIES - Static variable in class org.h2.command.dml.SetTypes
The type of a SET QUERY_STATISTICS_MAX_ENTRIES statement.
QUERY_STATISTICS_MAX_ENTRIES - Static variable in class org.h2.engine.Constants
The maximum number of entries in query statistics.
QUERY_TIMEOUT - Static variable in class org.h2.command.dml.SetTypes
The type of a SET QUERY_TIMEOUT statement.
Query.OffsetFetch - Class in org.h2.command.query
Evaluated values of OFFSET and FETCH clauses.
queryCache - Variable in class org.h2.engine.SessionLocal
 
queryCacheSize - Variable in class org.h2.engine.DbSettings
Database setting QUERY_CACHE_SIZE (default: 8).
queryCacheSize - Variable in class org.h2.engine.SessionLocal
 
queryColumnIndexes - Variable in class org.h2.result.SortOrder
The column indexes of the order by expressions within the query.
queryCurrentYearAndMonth() - Method in class org.h2.mode.ToDateParser
 
queryDistinct(ResultTarget, long, long, boolean, boolean) - Method in class org.h2.command.query.Select
 
QueryEntry(String) - Constructor for class org.h2.engine.QueryStatisticsData.QueryEntry
 
queryFlat(int, ResultTarget, long, long, boolean, boolean) - Method in class org.h2.command.query.Select
 
queryGroup(int, LocalResult, long, boolean) - Method in class org.h2.command.query.Select
 
queryGroupSorted(int, ResultTarget, long, boolean) - Method in class org.h2.command.query.Select
 
queryGroupWindow(int, LocalResult, long, boolean) - Method in class org.h2.command.query.Select
 
queryLevel - Variable in class org.h2.expression.ExpressionColumn
 
queryLevel - Variable in class org.h2.expression.ExpressionVisitor
 
queryMeta() - Method in class org.h2.command.Command
Get an empty result set containing the meta data.
queryMeta() - Method in class org.h2.command.CommandContainer
 
queryMeta() - Method in class org.h2.command.CommandList
 
queryMeta() - Method in class org.h2.command.ddl.DefineCommand
 
queryMeta() - Method in class org.h2.command.dml.BackupCommand
 
queryMeta() - Method in class org.h2.command.dml.Call
 
queryMeta() - Method in class org.h2.command.dml.DataChangeStatement
 
queryMeta() - Method in class org.h2.command.dml.ExecuteImmediate
 
queryMeta() - Method in class org.h2.command.dml.ExecuteProcedure
 
queryMeta() - Method in class org.h2.command.dml.Explain
 
queryMeta() - Method in class org.h2.command.dml.Help
 
queryMeta() - Method in class org.h2.command.dml.NoOperation
 
queryMeta() - Method in class org.h2.command.dml.RunScriptCommand
 
queryMeta() - Method in class org.h2.command.dml.ScriptCommand
 
queryMeta() - Method in class org.h2.command.dml.Set
 
queryMeta() - Method in class org.h2.command.dml.SetSessionCharacteristics
 
queryMeta() - Method in class org.h2.command.dml.TransactionCommand
 
queryMeta() - Method in class org.h2.command.Prepared
Get an empty result set containing the meta data.
queryMeta() - Method in class org.h2.command.query.Query
 
QueryOrderBy - Class in org.h2.command.query
Describes one element of the ORDER BY clause of a query.
QueryOrderBy() - Constructor for class org.h2.command.query.QueryOrderBy
 
queryQuick(int, ResultTarget, boolean) - Method in class org.h2.command.query.Select
 
querySQL - Variable in class org.h2.index.ViewIndex
 
querySQL - Variable in class org.h2.table.TableView
 
queryStatistics - Variable in class org.h2.engine.Database
 
queryStatistics(SessionLocal, ArrayList<Row>) - Method in class org.h2.table.InformationSchemaTable
 
queryStatisticsData - Variable in class org.h2.engine.Database
 
QueryStatisticsData - Class in org.h2.engine
Maintains query statistics.
QueryStatisticsData(int) - Constructor for class org.h2.engine.QueryStatisticsData
 
QueryStatisticsData.QueryEntry - Class in org.h2.engine
The collected statistics for one query.
queryStatisticsMaxEntries - Variable in class org.h2.engine.Database
 
queryTimeout - Variable in class org.h2.engine.SessionLocal
 
queryTimeoutCache - Variable in class org.h2.jdbc.JdbcConnection
 
queryUpper - Variable in class org.h2.bnf.Sentence
The uppercase version of the query string.
queryWindow(int, LocalResult, long, boolean) - Method in class org.h2.command.query.Select
 
queryWithoutCache(long, ResultTarget) - Method in class org.h2.command.query.Query
Execute the query without checking the cache.
queryWithoutCache(long, ResultTarget) - Method in class org.h2.command.query.Select
 
queryWithoutCache(long, ResultTarget) - Method in class org.h2.command.query.SelectUnion
 
queryWithoutCache(long, ResultTarget) - Method in class org.h2.command.query.TableValueConstructor
 
queryWithoutCacheLazyCheck(long, ResultTarget) - Method in class org.h2.command.query.Query
 
queue - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
The queue of resident cold entries.
queue - Static variable in class org.h2.util.CloseWatcher
The queue (might be set to null at any time).
queue - Variable in class org.h2.util.SoftValuesHashMap
 
queue - Variable in class org.h2.util.TempFileDeleter
 
queue2 - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
The queue of non-resident cold entries.
queue2Size - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
The size of the LIRS queue for non-resident cold entries.
queueNext - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Entry
The next entry in the queue (either the resident queue or the non-resident queue).
queuePrev - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Entry
The previous entry in the queue.
queueSize - Variable in class org.h2.command.ddl.CreateTrigger
 
queueSize - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
The size of the LIRS queue for resident cold entries.
queueSize - Variable in class org.h2.schema.TriggerObject
 
quirksMode - Variable in class org.h2.command.dml.RunScriptCommand
 
quirksMode - Variable in class org.h2.engine.SessionLocal
Whether commands are executed in quirks mode to support scripts from older versions of H2.
quote(String) - Static method in exception org.h2.message.DbException
 
quote(String) - Static method in class org.h2.message.TraceObject
Format a string as a Java string literal.
QUOTE_IDENT - Static variable in class org.h2.expression.function.StringFunction1
QUOTE_IDENT() (non-standard).
QUOTE_ONLY_WHEN_REQUIRED - Static variable in interface org.h2.util.HasSQL
Quote identifiers only when it is strictly required (different case or identifier is also a keyword).
quoteArray(String[]) - Static method in class org.h2.message.TraceObject
Format a string array to the Java source code that represents this object.
quoteBigDecimal(BigDecimal) - Static method in class org.h2.message.TraceObject
Format a big decimal to the Java source code that represents this object.
quoteBytes(byte[]) - Static method in class org.h2.message.TraceObject
Format a byte array to the Java source code that represents this object.
quoted - Variable in class org.h2.command.Token.IdentifierToken
 
quoteDate(Date) - Static method in class org.h2.message.TraceObject
Format a date to the Java source code that represents this object.
quotedName - Variable in class org.h2.bnf.context.DbColumn
 
quotedName - Variable in class org.h2.bnf.context.DbProcedure
 
quotedName - Variable in class org.h2.bnf.context.DbSchema
The quoted schema name.
quotedName - Variable in class org.h2.bnf.context.DbTableOrView
The quoted table name.
quotedName - Variable in class org.h2.expression.ExpressionColumn
 
quotedObjectName - Variable in class org.h2.engine.Comment
 
quoteFlags(int) - Static method in class org.h2.jdbcx.JdbcXAConnection
 
quoteIdentifier(String) - Method in class org.h2.bnf.context.DbContents
Add double quotes around an identifier if required.
quoteIdentifier(String) - Static method in class org.h2.util.StringUtils
Enclose a string with double quotes.
quoteIdentifier(StringBuilder, String) - Static method in class org.h2.util.StringUtils
Enclose a string with double quotes and append it to the specified string builder.
quoteIdentifier(StringBuilder, String, int) - Static method in class org.h2.util.ParserUtil
Add double quotes around an identifier if required and appends it to the specified string builder.
quoteIdentifier(String, int) - Static method in class org.h2.command.Parser
Add double quotes around an identifier if required.
quoteIdentifierOrLiteral(StringBuilder, String, char) - Static method in class org.h2.util.StringUtils
 
quoteIntArray(int[]) - Static method in class org.h2.message.TraceObject
Format an int array to the Java source code that represents this object.
quoteJavaIntArray(int[]) - Static method in class org.h2.util.StringUtils
Convert an int array to the Java source code that represents this array.
quoteJavaString(String) - Static method in class org.h2.util.StringUtils
Convert a string to the Java literal and enclose it with double quotes.
quoteJavaStringArray(String[]) - Static method in class org.h2.util.StringUtils
Convert a string array to the Java source code that represents this array.
quoteMap(Map<String, Class<?>>) - Static method in class org.h2.message.TraceObject
Format a map to the Java source code that represents this object.
quoteSQL(Object, int) - Static method in class org.h2.fulltext.FullText
INTERNAL.
quoteString(String) - Static method in class org.h2.fulltext.FullText
 
quoteStringSQL(String) - Static method in class org.h2.util.StringUtils
Convert a string to a SQL literal.
quoteStringSQL(StringBuilder, String) - Static method in class org.h2.util.StringUtils
Convert a string to a SQL character string literal.
quoteTime(Time) - Static method in class org.h2.message.TraceObject
Format a time to the Java source code that represents this object.
quoteTimestamp(Timestamp) - Static method in class org.h2.message.TraceObject
Format a timestamp to the Java source code that represents this object.
quoteXid(Xid) - Static method in class org.h2.jdbcx.JdbcXAConnection
 

R

r - Variable in class org.h2.command.query.SelectUnion.LazyResultUnion
 
r - Variable in class org.h2.store.RangeReader
 
R - Static variable in class org.h2.store.fs.FileUtils
StandardOpenOption.READ.
RADIANS - Static variable in class org.h2.expression.function.MathFunction1
RADIANS() (non-standard).
RAND - Static variable in class org.h2.expression.function.RandFunction
RAND() (non-standard).
RandFunction - Class in org.h2.expression.function
A RAND, SECURE_RAND, or RANDOM_UUID function.
RandFunction(Expression, int) - Constructor for class org.h2.expression.function.RandFunction
 
random - Variable in class org.h2.command.query.Optimizer
 
random - Variable in class org.h2.engine.SessionLocal
 
RANDOM_BYTES - Static variable in class org.h2.store.FileLock
 
RANDOM_UUID - Static variable in class org.h2.expression.function.RandFunction
RANDOM_UUID() (non-standard).
randomAccessResult - Variable in class org.h2.command.query.Query
Whether the result needs to support random access.
randomBytes(byte[]) - Static method in class org.h2.util.MathUtils
Get a number of pseudo random bytes.
randomInt(int) - Static method in class org.h2.util.MathUtils
Get a pseudo random int value between 0 (including and the given value (excluding).
RANGE - org.h2.expression.analysis.WindowFrameUnits
RANGE unit.
RANGE - Static variable in class org.h2.index.IndexCondition
A search mask meaning 'between'.
rangeCheck(long, long, long) - Static method in class org.h2.value.Value
Check the range of the parameters.
rangeCheckUnknown(long, long) - Static method in class org.h2.value.ValueLob
 
RangeCursor - Class in org.h2.index
The cursor implementation for the range index.
RangeCursor(long, long, long) - Constructor for class org.h2.index.RangeCursor
 
RangeIndex - Class in org.h2.index
An index for the SYSTEM_RANGE table.
RangeIndex(RangeTable, IndexColumn[]) - Constructor for class org.h2.index.RangeIndex
 
rangeInputStream(InputStream, long, long, long) - Static method in class org.h2.value.ValueLob
Create an input stream that is s subset of the given stream.
RangeInputStream - Class in org.h2.store
Input stream that reads only a specified range from the source stream.
RangeInputStream(InputStream, long, long) - Constructor for class org.h2.store.RangeInputStream
Creates new instance of range input stream.
rangeReader(Reader, long, long, long) - Static method in class org.h2.value.ValueLob
Create a reader that is s subset of the given reader.
RangeReader - Class in org.h2.store
Reader that reads only a specified range from the source reader.
RangeReader(Reader, long, long) - Constructor for class org.h2.store.RangeReader
Creates new instance of range reader.
rangeTable - Variable in class org.h2.index.RangeIndex
 
RangeTable - Class in org.h2.table
The table SYSTEM_RANGE is a virtual table that generates incrementing numbers with a given start end point.
RangeTable(Schema, Expression, Expression) - Constructor for class org.h2.table.RangeTable
Create a new range with the given start and end expressions.
RangeTable(Schema, Expression, Expression, Expression) - Constructor for class org.h2.table.RangeTable
 
RANK - org.h2.expression.aggregate.AggregateType
The type for RANK() hypothetical set function.
RANK - org.h2.expression.analysis.WindowFunctionType
The type for RANK() window function.
rate - Variable in class org.h2.security.SHA3
 
RATIO_TO_REPORT - org.h2.expression.analysis.WindowFunctionType
The type for RATIO_TO_REPORT() window function.
rawToHex(Value, Mode) - Static method in class org.h2.expression.function.StringFunction1
 
RAWTOHEX - Static variable in class org.h2.expression.function.StringFunction1
RAWTOHEX() (non-standard).
RCON - Static variable in class org.h2.security.AES
 
read() - Method in class org.h2.bnf.Bnf
 
read() - Method in class org.h2.command.Parser
 
read() - Method in class org.h2.compress.LZFInputStream
 
read() - Method in class org.h2.mvstore.db.LobStorageMap.LobInputStream
 
read() - Method in class org.h2.mvstore.StreamStore.Stream
 
read() - Method in class org.h2.server.TcpServerThread.CachedInputStream
 
read() - Method in class org.h2.store.CountingReaderInputStream
 
read() - Method in class org.h2.store.FileStoreInputStream
 
read() - Method in class org.h2.store.fs.FileChannelInputStream
 
read() - Method in class org.h2.store.LobStorageRemoteInputStream
 
read() - Method in class org.h2.store.RangeInputStream
 
read() - Method in class org.h2.store.RangeReader
 
read() - Method in class org.h2.util.ScriptReader
 
read(byte[]) - Method in class org.h2.compress.LZFInputStream
 
read(byte[]) - Method in class org.h2.store.FileStoreInputStream
 
read(byte[]) - Method in class org.h2.store.fs.FileChannelInputStream
 
read(byte[]) - Method in class org.h2.store.LobStorageRemoteInputStream
 
read(byte[], int, int) - Method in class org.h2.compress.LZFInputStream
 
read(byte[], int, int) - Method in class org.h2.mvstore.db.LobStorageMap.LobInputStream
 
read(byte[], int, int) - Method in class org.h2.mvstore.StreamStore.Stream
 
read(byte[], int, int) - Method in class org.h2.server.TcpServerThread.CachedInputStream
 
read(byte[], int, int) - Method in class org.h2.store.CountingReaderInputStream
 
read(byte[], int, int) - Method in class org.h2.store.Data
Copy a number of bytes to the given buffer from the current position.
read(byte[], int, int) - Method in class org.h2.store.FileStoreInputStream
 
read(byte[], int, int) - Method in class org.h2.store.fs.FileChannelInputStream
 
read(byte[], int, int) - Method in class org.h2.store.LobStorageRemoteInputStream
 
read(byte[], int, int) - Method in class org.h2.store.RangeInputStream
 
read(char) - Method in class org.h2.util.geometry.EWKTUtils.EWKTSource
 
read(char[], int, int) - Method in class org.h2.store.DataReader
 
read(char[], int, int) - Method in class org.h2.store.RangeReader
 
read(int) - Method in class org.h2.command.Parser
 
read(InputStream, byte[]) - Static method in class org.h2.mvstore.StreamStore
 
read(Reader, String[]) - Method in class org.h2.tools.Csv
Reads CSV data from a reader and returns a result set.
read(String) - Method in class org.h2.command.Parser
 
read(String) - Method in class org.h2.server.web.PageParser
 
read(String, String[], String) - Method in class org.h2.tools.Csv
Reads from the CSV file and returns a result set.
read(ByteBuffer) - Method in class org.h2.mvstore.cache.FilePathCache.FileCache
 
read(ByteBuffer) - Method in class org.h2.mvstore.db.LobStorageMap.BlobMeta.Type
 
read(ByteBuffer) - Method in class org.h2.mvstore.db.LobStorageMap.BlobReference.Type
 
read(ByteBuffer) - Method in class org.h2.mvstore.db.NullValueDataType
 
read(ByteBuffer) - Method in class org.h2.mvstore.db.RowDataType
 
read(ByteBuffer) - Method in class org.h2.mvstore.db.ValueDataType
 
read(ByteBuffer) - Method in class org.h2.mvstore.MVStoreTool.GenericDataType
 
read(ByteBuffer) - Method in class org.h2.mvstore.Page
Read the page from the buffer.
read(ByteBuffer) - Method in class org.h2.mvstore.rtree.SpatialDataType
 
read(ByteBuffer) - Method in class org.h2.mvstore.tx.Record.Type
 
read(ByteBuffer) - Method in class org.h2.mvstore.tx.VersionedValueType
 
read(ByteBuffer) - Method in class org.h2.mvstore.type.BasicDataType
 
read(ByteBuffer) - Method in class org.h2.mvstore.type.ByteArrayDataType
 
read(ByteBuffer) - Method in interface org.h2.mvstore.type.DataType
Read an object.
read(ByteBuffer) - Method in class org.h2.mvstore.type.LongDataType
 
read(ByteBuffer) - Method in class org.h2.mvstore.type.MetaType
 
read(ByteBuffer) - Method in class org.h2.mvstore.type.ObjectDataType.BigDecimalType
 
read(ByteBuffer) - Method in class org.h2.mvstore.type.ObjectDataType.BigIntegerType
 
read(ByteBuffer) - Method in class org.h2.mvstore.type.ObjectDataType.BooleanType
 
read(ByteBuffer) - Method in class org.h2.mvstore.type.ObjectDataType.ByteType
 
read(ByteBuffer) - Method in class org.h2.mvstore.type.ObjectDataType.CharacterType
 
read(ByteBuffer) - Method in class org.h2.mvstore.type.ObjectDataType.DateType
 
read(ByteBuffer) - Method in class org.h2.mvstore.type.ObjectDataType.DoubleType
 
read(ByteBuffer) - Method in class org.h2.mvstore.type.ObjectDataType.FloatType
 
read(ByteBuffer) - Method in class org.h2.mvstore.type.ObjectDataType.IntegerType
 
read(ByteBuffer) - Method in class org.h2.mvstore.type.ObjectDataType.LongType
 
read(ByteBuffer) - Method in class org.h2.mvstore.type.ObjectDataType.NullType
 
read(ByteBuffer) - Method in class org.h2.mvstore.type.ObjectDataType.ObjectArrayType
 
read(ByteBuffer) - Method in class org.h2.mvstore.type.ObjectDataType
 
read(ByteBuffer) - Method in class org.h2.mvstore.type.ObjectDataType.SerializedObjectType
 
read(ByteBuffer) - Method in class org.h2.mvstore.type.ObjectDataType.ShortType
 
read(ByteBuffer) - Method in class org.h2.mvstore.type.ObjectDataType.StringType
 
read(ByteBuffer) - Method in class org.h2.mvstore.type.ObjectDataType.UUIDType
 
read(ByteBuffer) - Method in class org.h2.mvstore.type.StringDataType
 
read(ByteBuffer) - Method in class org.h2.store.fs.FakeFileChannel
 
read(ByteBuffer) - Method in class org.h2.store.fs.FileBaseDefault
 
read(ByteBuffer) - Method in class org.h2.store.fs.rec.FileRec
 
read(ByteBuffer) - Method in class org.h2.store.fs.retry.FileRetryOnInterrupt
 
read(ByteBuffer) - Method in class org.h2.store.fs.zip.FileZip
 
read(ByteBuffer[], int, int) - Method in class org.h2.store.fs.FakeFileChannel
 
read(ByteBuffer[], int, int) - Method in class org.h2.store.fs.FileBase
 
read(ByteBuffer, int) - Method in class org.h2.mvstore.type.ObjectDataType.AutoDetectDataType
Read an object from the buffer.
read(ByteBuffer, int) - Method in class org.h2.mvstore.type.ObjectDataType.BigDecimalType
 
read(ByteBuffer, int) - Method in class org.h2.mvstore.type.ObjectDataType.BigIntegerType
 
read(ByteBuffer, int) - Method in class org.h2.mvstore.type.ObjectDataType.BooleanType
 
read(ByteBuffer, int) - Method in class org.h2.mvstore.type.ObjectDataType.ByteType
 
read(ByteBuffer, int) - Method in class org.h2.mvstore.type.ObjectDataType.CharacterType
 
read(ByteBuffer, int) - Method in class org.h2.mvstore.type.ObjectDataType.DateType
 
read(ByteBuffer, int) - Method in class org.h2.mvstore.type.ObjectDataType.DoubleType
 
read(ByteBuffer, int) - Method in class org.h2.mvstore.type.ObjectDataType.FloatType
 
read(ByteBuffer, int) - Method in class org.h2.mvstore.type.ObjectDataType.IntegerType
 
read(ByteBuffer, int) - Method in class org.h2.mvstore.type.ObjectDataType.LongType
 
read(ByteBuffer, int) - Method in class org.h2.mvstore.type.ObjectDataType.NullType
 
read(ByteBuffer, int) - Method in class org.h2.mvstore.type.ObjectDataType.ObjectArrayType
 
read(ByteBuffer, int) - Method in class org.h2.mvstore.type.ObjectDataType.SerializedObjectType
 
read(ByteBuffer, int) - Method in class org.h2.mvstore.type.ObjectDataType.ShortType
 
read(ByteBuffer, int) - Method in class org.h2.mvstore.type.ObjectDataType.StringType
 
read(ByteBuffer, int) - Method in class org.h2.mvstore.type.ObjectDataType.UUIDType
 
read(ByteBuffer, long) - Method in class org.h2.mvstore.cache.FilePathCache.FileCache
 
read(ByteBuffer, long) - Method in class org.h2.store.fs.async.FileAsync
 
read(ByteBuffer, long) - Method in class org.h2.store.fs.encrypt.FileEncrypt
 
read(ByteBuffer, long) - Method in class org.h2.store.fs.FakeFileChannel
 
read(ByteBuffer, long) - Method in class org.h2.store.fs.FileBase
 
read(ByteBuffer, long) - Method in class org.h2.store.fs.mem.FileMem
 
read(ByteBuffer, long) - Method in class org.h2.store.fs.niomapped.FileNioMapped
 
read(ByteBuffer, long) - Method in class org.h2.store.fs.niomem.FileNioMem
 
read(ByteBuffer, long) - Method in class org.h2.store.fs.rec.FileRec
 
read(ByteBuffer, long) - Method in class org.h2.store.fs.retry.FileRetryOnInterrupt
 
read(ByteBuffer, long) - Method in class org.h2.store.fs.split.FileSplit
 
read(ByteBuffer, long, MVMap<K, V>) - Static method in class org.h2.mvstore.Page
Read a page.
read(ByteBuffer, Object, int) - Method in class org.h2.mvstore.db.NullValueDataType
 
read(ByteBuffer, Object, int) - Method in class org.h2.mvstore.tx.VersionedValueType
 
read(ByteBuffer, Object, int) - Method in class org.h2.mvstore.type.BasicDataType
 
read(ByteBuffer, Object, int) - Method in interface org.h2.mvstore.type.DataType
Read a list of objects.
read_(String, int, int, int, ArrayList<Token>) - Method in class org.h2.command.Tokenizer
 
READ_COMMITTED - org.h2.engine.IsolationLevel
Dirty reads aren't allowed; non-repeatable reads and phantom reads are allowed.
READ_LOCK - Static variable in class org.h2.table.Table
Read lock.
READ_UNCOMMITTED - org.h2.engine.IsolationLevel
Dirty reads, non-repeatable reads and phantom reads are allowed.
readA(String, int, int, int, ArrayList<Token>) - Method in class org.h2.command.Tokenizer
 
readAggregate(AggregateType, String) - Method in class org.h2.command.Parser
 
readAggregateOrder(Aggregate, Expression, boolean) - Method in class org.h2.command.Parser
 
readAnd(Expression) - Method in class org.h2.command.Parser
 
readArrayElements(int, TypeInfo) - Method in class org.h2.value.Transfer
 
readArrayElements(ByteBuffer, TypeInfo) - Method in class org.h2.mvstore.db.ValueDataType
 
readB(String, int, int, int, ArrayList<Token>) - Method in class org.h2.command.Tokenizer
 
readBinaryString(String, int, int, int, ArrayList<Token>) - Static method in class org.h2.command.Tokenizer
 
readBlobMap(Connection, long, long) - Static method in class org.h2.tools.Recover
INTERNAL
readBlock(byte[], int, int) - Method in class org.h2.compress.LZFInputStream
 
readBlock(byte[], int, int) - Method in class org.h2.store.FileStoreInputStream
 
readBoolean() - Method in class org.h2.value.Transfer
Read a boolean.
readBooleanSetting() - Method in class org.h2.command.Parser
 
readBuffer() - Method in class org.h2.tools.Csv
 
readBuffer() - Method in class org.h2.util.ScriptReader
 
readBufferForPage(FileStore, int, long) - Method in class org.h2.mvstore.Chunk
Read a page of data into a ByteBuffer.
readBuiltinFunctionIf(String) - Method in class org.h2.command.Parser
 
readByte() - Method in class org.h2.server.pg.PgServerThread
 
readByte() - Method in class org.h2.store.Data
Read one single byte.
readByte() - Method in class org.h2.store.DataReader
Read a byte.
readByte() - Method in class org.h2.util.geometry.EWKBUtils.EWKBSource
Reads one byte.
readByte() - Method in class org.h2.value.Transfer
Read a byte.
readBytes - Variable in class org.h2.mvstore.FileStore
The number of read bytes.
readBytes() - Method in class org.h2.value.Transfer
Read a byte array.
readBytes(byte[], int, int) - Method in class org.h2.value.Transfer
Read a number of bytes.
readBytes(int) - Method in class org.h2.value.ValueLob
 
readBytesAndClose(InputStream, int) - Static method in class org.h2.util.IOUtils
Read a number of bytes from an input stream and close the stream.
readC(String, int, int, int, ArrayList<Token>) - Method in class org.h2.command.Tokenizer
 
readCase() - Method in class org.h2.command.Parser
 
readChar() - Method in class org.h2.store.DataReader
Read one character from the input stream.
readChar() - Method in class org.h2.tools.Csv
 
readCharacterString(String, int, int, int, boolean, ArrayList<Token>) - Static method in class org.h2.command.Tokenizer
 
readChunkFooter(long) - Method in class org.h2.mvstore.MVStore
Try to read a chunk footer.
readChunkHeader(long) - Method in class org.h2.mvstore.MVStore
 
readChunkHeader(ByteBuffer, long) - Static method in class org.h2.mvstore.Chunk
Read the header from the byte buffer.
readChunkHeaderAndFooter(long, int) - Method in class org.h2.mvstore.MVStore
Read a chunk header and footer, and verify the stored data is consistent.
readChunkHeaderOptionally(long) - Method in class org.h2.mvstore.MVStore
 
readChunkHeaderOptionally(long, int) - Method in class org.h2.mvstore.MVStore
 
readClobMap(Connection, long, long) - Static method in class org.h2.tools.Recover
INTERNAL
readCoalesceFunction(int) - Method in class org.h2.command.Parser
 
readColumnConstraints(CommandWithColumns, Schema, String, Column) - Method in class org.h2.command.Parser
 
readColumnIfNotFunction() - Method in class org.h2.command.Parser
 
readColumns(DatabaseMetaData, PreparedStatement) - Method in class org.h2.bnf.context.DbTableOrView
Read the column for this table from the database meta data.
readCommentIf() - Method in class org.h2.command.Parser
 
readComparison(Expression, int, boolean) - Method in class org.h2.command.Parser
 
readCompatibilityCase(Expression) - Method in class org.h2.command.Parser
 
readCompatibilityFunction(String) - Method in class org.h2.command.Parser
 
readCompatibilitySequenceValueFunction(boolean) - Method in class org.h2.command.Parser
 
readConcat() - Method in class org.h2.command.Parser
 
readConcatFunction(int) - Method in class org.h2.command.Parser
 
readCondition() - Method in class org.h2.command.Parser
 
readConditionIs(Expression, boolean) - Method in class org.h2.command.Parser
 
readConditionRightHandSide(Expression, boolean, boolean) - Method in class org.h2.command.Parser
 
readContents(String, Connection) - Method in class org.h2.bnf.context.DbContents
Read the contents of this database from the database meta data.
readCoordinate() - Method in class org.h2.util.geometry.EWKBUtils.EWKBSource
Reads a 64-bit floating point using current byte order.
readCoordinate() - Method in class org.h2.util.geometry.EWKTUtils.EWKTSource
 
readCoordinate(EWKTUtils.EWKTSource, int) - Static method in class org.h2.util.geometry.EWKTUtils
 
readCoordinate(JSONValue[], int) - Static method in class org.h2.util.geometry.GeoJsonUtils
 
readCorrelation(TableFilter) - Method in class org.h2.command.Parser
 
readCount - Variable in class org.h2.mvstore.FileStore
The number of read operations.
readCurrentDateTimeValueFunction(int, boolean, String) - Method in class org.h2.command.Parser
 
readCurrentGeneralValueSpecification(int) - Method in class org.h2.command.Parser
 
readD(String, int, int, int, ArrayList<Token>) - Method in class org.h2.command.Tokenizer
 
readDataChangeDeltaTable(String, int) - Method in class org.h2.command.Parser
 
readDateTimeField() - Method in class org.h2.command.Parser
 
readDateTimeFormatFunction(int) - Method in class org.h2.command.Parser
 
readDerivedColumnNames() - Method in class org.h2.command.Parser
 
readDerivedTableWithCorrelation() - Method in class org.h2.command.Parser
 
readDimensionSystem() - Method in class org.h2.util.geometry.EWKTUtils.EWKTSource
 
readDistinctAgg() - Method in class org.h2.command.Parser
 
readDouble() - Method in class org.h2.value.Transfer
Read a double.
readDouble(byte[], int) - Static method in class org.h2.util.Bits
Reads a double value from the byte array at the given position in big-endian order.
readDoubleLE(byte[], int) - Static method in class org.h2.util.Bits
Reads a double value from the byte array at the given position in little-endian order.
readE(String, int, int, int, ArrayList<Token>) - Method in class org.h2.command.Tokenizer
 
readEmpty() - Method in class org.h2.util.geometry.EWKTUtils.EWKTSource
 
reader - Variable in class org.h2.command.dml.ScriptBase
The input reader.
reader - Variable in class org.h2.store.CountingReaderInputStream
 
reader - Variable in class org.h2.tools.Shell
 
reader - Variable in class org.h2.util.ScriptReader
 
readException(Transfer) - Static method in class org.h2.engine.SessionRemote
Reads an exception.
readExpression() - Method in class org.h2.command.Parser
 
readExpressionOrDefault() - Method in class org.h2.command.Parser
 
readExpressionOrIdentifier() - Method in class org.h2.command.Parser
 
readExpressionPart2(Expression) - Method in class org.h2.command.Parser
 
readExpressionWithGlobalConditions() - Method in class org.h2.command.Parser
 
readF(String, int, int, int, ArrayList<Token>) - Method in class org.h2.command.Tokenizer
 
readFactor() - Method in class org.h2.command.Parser
 
readFetchOrLimit() - Method in class org.h2.command.Parser
 
readFilterAndOver(AbstractAggregate) - Method in class org.h2.command.Parser
 
readFloat() - Method in class org.h2.value.Transfer
Read a float.
readFromAlias(String) - Method in class org.h2.command.Parser
 
readFromFirstOrLast(WindowFunction) - Method in class org.h2.command.Parser
 
readFully(byte[]) - Method in class org.h2.server.pg.PgServerThread
 
readFully(byte[], int) - Method in class org.h2.compress.LZFInputStream
 
readFully(byte[], int, int) - Method in class org.h2.security.SecureFileStore
 
readFully(byte[], int, int) - Method in class org.h2.store.FileStore
Read a number of bytes.
readFully(long, int) - Method in class org.h2.mvstore.FileStore
Read from the file.
readFully(long, int) - Method in class org.h2.mvstore.OffHeapStore
 
readFully(InputStream, byte[], int) - Static method in class org.h2.util.IOUtils
Try to read the given number of bytes to the buffer.
readFully(Reader, char[], int) - Static method in class org.h2.util.IOUtils
Try to read the given number of characters to the buffer.
readFully(FileChannel, long, ByteBuffer) - Static method in class org.h2.mvstore.DataUtils
Read from a file channel until the buffer is full.
readFully(FileChannel, long, ByteBuffer) - Static method in class org.h2.store.fs.encrypt.FileEncrypt
 
readFully(FileChannel, ByteBuffer) - Static method in class org.h2.store.fs.FileUtils
Fully read from the file.
readFullyDirect(byte[], int, int) - Method in class org.h2.security.SecureFileStore
 
readFullyDirect(byte[], int, int) - Method in class org.h2.store.FileStore
Read a number of bytes without decrypting.
readFunction(Schema, String) - Method in class org.h2.command.Parser
 
readFunctionWithSchema(Schema, String, String) - Method in class org.h2.command.Parser
 
readG(String, int, int, int, ArrayList<Token>) - Method in class org.h2.command.Tokenizer
 
readH(String, int, int, int, ArrayList<Token>) - Method in class org.h2.command.Tokenizer
 
readHeader() - Method in class org.h2.tools.Csv
 
readHeaderLine() - Method in class org.h2.server.web.WebThread
 
readHex() - Method in class org.h2.util.json.JSONBytesSource
 
readHex() - Method in class org.h2.util.json.JSONStringSource
 
readHex() - Method in class org.h2.util.json.JSONTextSource
Read 4 hex characters (0-9, a-f, A-F), and return the Unicode character.
readHexInt(Map<String, ?>, String, int) - Static method in class org.h2.mvstore.DataUtils
Read a hex int value from a map.
readHexLong(Map<String, ?>, String, long) - Static method in class org.h2.mvstore.DataUtils
Read a hex long value from a map.
readHexNumber(String, CastDataProvider, int, int, int, ArrayList<Token>) - Static method in class org.h2.command.Tokenizer
 
readI(String, int, int, int, ArrayList<Token>) - Method in class org.h2.command.Tokenizer
 
readIdentifier() - Method in class org.h2.command.Parser
 
readIdentifier(String, int, int, int, int, ArrayList<Token>) - Method in class org.h2.command.Tokenizer
 
readIdentifierOrKeyword(String, int, ArrayList<Token>, int, int) - Method in class org.h2.command.Tokenizer
 
readIdentifierWithSchema() - Method in class org.h2.command.Parser
 
readIdentifierWithSchema(String) - Method in class org.h2.command.Parser
 
readIdentifierWithSchema2(String) - Method in class org.h2.command.Parser
 
readIf(int) - Method in class org.h2.command.Parser
 
readIf(String) - Method in class org.h2.command.Parser
 
readIf(String) - Method in class org.h2.server.web.PageParser
 
readIfArgument() - Method in class org.h2.command.Parser
 
readIfDataType() - Method in class org.h2.command.Parser
 
readIfDataType1() - Method in class org.h2.command.Parser
 
readIfEqualOrTo() - Method in class org.h2.command.Parser
 
readIfExists(boolean) - Method in class org.h2.command.Parser
 
readIfMore() - Method in class org.h2.command.Parser
Read comma or closing brace.
readIfNotExists() - Method in class org.h2.command.Parser
 
readIfOrderBy() - Method in class org.h2.command.Parser
 
readIfOverriding() - Method in class org.h2.command.Parser
 
readIfSequencePseudoColumn(String, String) - Method in class org.h2.command.Parser
 
readIfSingleArgument() - Method in class org.h2.command.Parser
 
readIfUseIndex() - Method in class org.h2.command.Parser
 
readIfWildcardRowidOrSequencePseudoColumn(String, String) - Method in class org.h2.command.Parser
 
readIndexes(DatabaseMetaData, HashMap<String, Column>) - Method in class org.h2.table.TableLink
 
readIndexes(ResultSet, HashMap<String, Column>, String) - Method in class org.h2.table.TableLink
 
readInPredicate(Expression, boolean, boolean) - Method in class org.h2.command.Parser
 
readInt() - Method in class org.h2.command.Parser
 
readInt() - Method in class org.h2.compress.LZFInputStream
 
readInt() - Method in class org.h2.server.pg.PgServerThread
 
readInt() - Method in class org.h2.store.Data
Read an integer at the current position.
readInt() - Method in class org.h2.util.geometry.EWKBUtils.EWKBSource
Reads a 32-bit integer using current byte order.
readInt() - Method in class org.h2.value.Transfer
Read an int.
readInt(byte[], int) - Static method in class org.h2.util.Bits
Reads a int value from the byte array at the given position in big-endian order.
readIntArray(ByteBuffer) - Static method in class org.h2.mvstore.db.RowDataType.Factory
 
readIntArray(ByteBuffer) - Static method in class org.h2.mvstore.db.ValueDataType.Factory
 
readInternal(ByteBuffer, long, int, XTS) - Method in class org.h2.store.fs.encrypt.FileEncrypt
 
readInterval() - Method in class org.h2.command.Parser
 
readIntervalQualifier() - Method in class org.h2.command.Parser
 
readIntLE(byte[], int) - Static method in class org.h2.util.Bits
Reads a int value from the byte array at the given position in little-endian order.
readJ(String, int, int, int, ArrayList<Token>) - Method in class org.h2.command.Tokenizer
 
readJoinSpecification(TableFilter, TableFilter, boolean) - Method in class org.h2.command.Parser
 
readJsonObjectFunctionFlags(ExpressionWithFlags, boolean) - Method in class org.h2.command.Parser
 
readJsonPredicate(Expression, boolean, boolean) - Method in class org.h2.command.Parser
 
readK(String, int, int, int, ArrayList<Token>) - Method in class org.h2.command.Tokenizer
 
readKeyword1(String) - Method in class org.h2.util.json.JSONBytesSource
 
readKeyword1(String) - Method in class org.h2.util.json.JSONStringSource
 
readKeyword1(String) - Method in class org.h2.util.json.JSONTextSource
Read the specified keyword, or (it there is no match), throw an IllegalArgumentException.
readKeywordCompatibilityFunctionOrColumn() - Method in class org.h2.command.Parser
 
readL(String, int, int, int, ArrayList<Token>) - Method in class org.h2.command.Tokenizer
 
readLastArgument() - Method in class org.h2.command.Parser
 
readLikePredicate(Expression, CompareLike.LikeType, boolean, boolean) - Method in class org.h2.command.Parser
 
readLine() - Method in class org.h2.tools.Shell
 
readLine(String) - Method in class org.h2.tools.Shell
 
readLob(long, byte[], long, byte[], int, int) - Method in class org.h2.engine.Database
 
readLob(long, byte[], long, byte[], int, int) - Method in class org.h2.engine.SessionRemote
 
readLob(long, byte[], long, byte[], int, int) - Method in interface org.h2.store.DataHandler
Read from a lob.
readLob(long, byte[], long, byte[], int, int) - Method in class org.h2.tools.Recover
INTERNAL
readLobDataDatabase(ByteBuffer) - Method in class org.h2.mvstore.db.ValueDataType
 
readLong() - Method in class org.h2.command.Parser
 
readLong() - Method in class org.h2.value.Transfer
Read a long.
readLong(byte[], int) - Static method in class org.h2.util.Bits
Reads a long value from the byte array at the given position in big-endian order.
readLongLE(byte[], int) - Static method in class org.h2.util.Bits
Reads a long value from the byte array at the given position in little-endian order.
readM(String, int, int, int, ArrayList<Token>) - Method in class org.h2.command.Tokenizer
 
readMetaData() - Method in class org.h2.table.TableLink
 
readMetaData(Transfer) - Method in class org.h2.expression.ParameterRemote
Read the parameter meta data from the transfer object.
readMySQLCharset() - Method in class org.h2.command.Parser
 
readN(String, int, int, int, ArrayList<Token>) - Method in class org.h2.command.Tokenizer
 
readNextArgument() - Method in class org.h2.command.Parser
 
readNonNegativeInt() - Method in class org.h2.command.Parser
 
readNull(String) - Method in class org.h2.tools.Csv
 
readNumeric(String, int, int, int, char, boolean, boolean, ArrayList<Token>) - Static method in class org.h2.command.Tokenizer
 
readNumeric(String, int, int, int, char, ArrayList<Token>) - Static method in class org.h2.command.Tokenizer
 
readO(String, int, int, int, ArrayList<Token>) - Method in class org.h2.command.Tokenizer
 
readObject(ObjectInputStream) - Method in class org.h2.jdbcx.JdbcDataSource
Called when de-serializing the object.
readOnDuplicateKeyValues(Table, Update) - Method in class org.h2.command.Parser
 
readonly - Variable in class org.h2.command.CommandRemote
 
readOnly - Variable in class org.h2.command.CommandContainer
 
readOnly - Variable in class org.h2.command.ddl.CreateLinkedTable
 
readOnly - Variable in class org.h2.engine.Database
 
readOnly - Variable in class org.h2.mvstore.FileStore
Whether this store is read-only.
readOnly - Variable in class org.h2.mvstore.MVMap
 
readOnly - Variable in class org.h2.store.fs.mem.FileMem
 
readOnly - Variable in class org.h2.store.fs.niomem.FileNioMem
 
readOnly - Variable in class org.h2.table.TableLink
 
readOnly() - Method in class org.h2.mvstore.MVStore.Builder
Open the file in read-only mode.
READONLY - Static variable in class org.h2.command.dml.SetTypes
The type of a SET READONLY statement.
READONLY - Static variable in class org.h2.expression.ExpressionVisitor
Does the expression have no side effects (change the data)?
READONLY - Static variable in class org.h2.expression.function.SysInfoFunction
READONLY().
READONLY_VISITOR - Static variable in class org.h2.expression.ExpressionVisitor
The visitor singleton for the type EVALUATABLE.
readOnlyKnown - Variable in class org.h2.command.CommandContainer
 
readOrCreateRootPage(long) - Method in class org.h2.mvstore.MVMap
 
readOver(DataAnalysisOperation) - Method in class org.h2.command.Parser
 
readP(String, int, int, int, ArrayList<Token>) - Method in class org.h2.command.Tokenizer
 
readPage(long) - Method in class org.h2.mvstore.MVMap
Read a page.
readPage(MVMap<K, V>, long) - Method in class org.h2.mvstore.MVStore
Read a page.
readPageFromCache(long) - Method in class org.h2.mvstore.MVStore
 
readParam(String) - Method in class org.h2.server.web.PageParser
 
readParameter() - Method in class org.h2.command.Parser
 
readParameters(DatabaseMetaData) - Method in class org.h2.bnf.context.DbProcedure
Read the column for this table from the database meta data.
readParameters(T) - Method in class org.h2.command.Parser
 
readPassword() - Method in class org.h2.tools.Shell
 
readPayLoad(ByteBuffer) - Method in class org.h2.mvstore.Page.Leaf
 
readPayLoad(ByteBuffer) - Method in class org.h2.mvstore.Page.NonLeaf
 
readPayLoad(ByteBuffer) - Method in class org.h2.mvstore.Page
Read the page payload from the buffer.
readPositiveLong() - Method in class org.h2.command.Parser
 
readPrecision(int) - Method in class org.h2.command.Parser
 
readPrimaryKey(ResultSet, HashMap<String, Column>) - Method in class org.h2.table.TableLink
 
readProcedures(DatabaseMetaData) - Method in class org.h2.bnf.context.DbSchema
Read all procedures in the database.
readProperties(Properties) - Method in class org.h2.engine.ConnectionInfo
 
readQ(String, int, int, int, ArrayList<Token>) - Method in class org.h2.command.Tokenizer
 
readQuotedIdentifier(String, int, int, int, char, boolean, ArrayList<Token>) - Method in class org.h2.command.Tokenizer
 
readR(String, int, int, int, ArrayList<Token>) - Method in class org.h2.command.Tokenizer
 
readRespectOrIgnoreNulls(WindowFunction) - Method in class org.h2.command.Parser
 
readResultSet(String[]) - Method in class org.h2.tools.Csv
 
readResultSetMeta(Session, ResultSetMetaData, int) - Static method in class org.h2.value.ValueToObjectConverter
 
readRing(EWKTUtils.EWKTSource, int) - Static method in class org.h2.util.geometry.EWKTUtils
 
readRow() - Method in class org.h2.tools.Csv
INTERNAL
readRow() - Method in interface org.h2.tools.SimpleRowSource
Get the next row.
readRow(ResultInterface) - Method in class org.h2.expression.Subquery
 
readRow(Value[]) - Method in class org.h2.result.UpdatableRow
Re-reads a row from the database and updates the values in the array.
readRowCount() - Method in class org.h2.value.Transfer
Read a row count.
readRunnableStackTraces(int) - Static method in class org.h2.util.Profiler
 
readS(String, int, int, int, ArrayList<Token>) - Method in class org.h2.command.Tokenizer
 
readSequence() - Method in class org.h2.command.Parser
 
readSessionState() - Method in class org.h2.engine.Session
Read the session state if necessary.
readSetCompatibility(Mode.ModeEnum) - Method in class org.h2.command.Parser
 
readSetFunction() - Method in class org.h2.command.Parser
 
readSettingsFromURL() - Method in class org.h2.engine.ConnectionInfo
 
readShort() - Method in class org.h2.server.pg.PgServerThread
 
readShort() - Method in class org.h2.value.Transfer
Read a short.
readSimpleTableFilter() - Method in class org.h2.command.Parser
 
readSimpleWhenClause(Expression) - Method in class org.h2.command.Parser
 
readSingleArgument() - Method in class org.h2.command.Parser
 
readSRID() - Method in class org.h2.util.geometry.EWKTUtils.EWKTSource
 
readStackTrace(LineNumberReader) - Static method in class org.h2.util.Profiler
 
readStatement() - Method in class org.h2.util.ScriptReader
Read a statement from the reader.
readStatementLoop() - Method in class org.h2.util.ScriptReader
 
readStoreHeader() - Method in class org.h2.mvstore.MVStore
 
readString() - Method in class org.h2.command.Parser
 
readString() - Method in class org.h2.server.pg.PgServerThread
 
readString() - Method in class org.h2.util.json.JSONTextSource
 
readString() - Method in class org.h2.value.Transfer
Read a string.
readString(int) - Method in class org.h2.value.ValueLob
 
readString(ByteBuffer) - Static method in class org.h2.mvstore.DataUtils
Read a string.
readString(ByteBuffer, int) - Static method in class org.h2.mvstore.DataUtils
Read a string.
readStringAndClose(Reader, int) - Static method in class org.h2.util.IOUtils
Read a number of characters from a reader and close it.
readStringOrIdentifier() - Method in class org.h2.command.Parser
 
readSubstringFunction() - Method in class org.h2.command.Parser
 
readSum() - Method in class org.h2.command.Parser
 
readT(String, int, int, int, ArrayList<Token>) - Method in class org.h2.command.Tokenizer
 
readTableColumn(TableFilter) - Method in class org.h2.command.Parser
 
readTableColumn(TableFilter, String) - Method in class org.h2.command.Parser
 
readTableEngineParams() - Method in class org.h2.command.Parser
 
readTableFunction(int) - Method in class org.h2.command.Parser
 
readTableFunction(String, Schema) - Method in class org.h2.command.Parser
 
readTableOrView() - Method in class org.h2.command.Parser
 
readTableOrView(String) - Method in class org.h2.command.Parser
 
readTablePrimary() - Method in class org.h2.command.Parser
 
readTableReference() - Method in class org.h2.command.Parser
 
readTables(DatabaseMetaData, String[]) - Method in class org.h2.bnf.context.DbSchema
Read all tables for this schema from the database meta data.
readTerm() - Method in class org.h2.command.Parser
 
readTermObjectDot(String) - Method in class org.h2.command.Parser
 
readTermWithIdentifier(String, boolean) - Method in class org.h2.command.Parser
 
readTildeCondition(Expression, boolean) - Method in class org.h2.command.Parser
 
readTimestampTime(ByteBuffer) - Static method in class org.h2.mvstore.db.ValueDataType
 
readTimeZone(ByteBuffer) - Static method in class org.h2.mvstore.db.ValueDataType
 
readToC(FileStore) - Method in class org.h2.mvstore.Chunk
 
readTranslations(WebSession, String) - Method in class org.h2.server.web.WebServer
Read the translation for this language and save them in the 'text' property of this session.
readTrimFunction() - Method in class org.h2.command.Parser
 
readType() - Method in class org.h2.util.geometry.EWKTUtils.EWKTSource
 
readTypeInfo() - Method in class org.h2.value.Transfer
Read a type information.
readTypeInfo19() - Method in class org.h2.value.Transfer
 
readTypeInfo20() - Method in class org.h2.value.Transfer
 
readTypeInfoEnum() - Method in class org.h2.value.Transfer
 
readTypeInfoGeometry() - Method in class org.h2.value.Transfer
 
readTypeInfoRow() - Method in class org.h2.value.Transfer
 
readTypePredicate(Expression, boolean, boolean) - Method in class org.h2.command.Parser
 
readU(String, int, int, int, ArrayList<Token>) - Method in class org.h2.command.Tokenizer
 
readUnnestFunction() - Method in class org.h2.command.Parser
 
readUpdateSetClause(TableFilter) - Method in class org.h2.command.Parser
 
readUserDefinedFunctionIf(Schema, String) - Method in class org.h2.command.Parser
 
readV(String, int, int, int, ArrayList<Token>) - Method in class org.h2.command.Tokenizer
 
readValue() - Method in class org.h2.tools.Csv
 
readValue(ByteBuffer, TypeInfo) - Method in class org.h2.mvstore.db.ValueDataType
Read a value.
readValue(Session, ResultSet, int, int) - Static method in class org.h2.value.ValueToObjectConverter2
Read a value from the given result set.
readValue(Session, JdbcResultSet, int) - Static method in class org.h2.value.ValueToObjectConverter
Read a value from the given result set.
readValue(TypeInfo) - Method in class org.h2.value.Transfer
Read a value.
readValueOther(Session, ResultSet, int, int) - Static method in class org.h2.value.ValueToObjectConverter2
 
readVarBytes(ByteBuffer) - Static method in class org.h2.mvstore.db.ValueDataType
 
readVariableInt(byte[], int) - Static method in class org.h2.tools.CompressTool
Read a variable size integer using Rice coding.
readVarInt() - Method in class org.h2.store.DataReader
Read a variable size integer.
readVarInt(ByteBuffer) - Static method in class org.h2.mvstore.DataUtils
Read a variable size int.
readVarIntRest(ByteBuffer, int) - Static method in class org.h2.mvstore.DataUtils
 
readVarLong(ByteBuffer) - Static method in class org.h2.mvstore.DataUtils
Read a variable size long.
readW(String, int, int, int, ArrayList<Token>) - Method in class org.h2.command.Tokenizer
 
readWhenOperand(Expression) - Method in class org.h2.command.Parser
 
readWindowFrame() - Method in class org.h2.command.Parser
 
readWindowFrameRange() - Method in class org.h2.command.Parser
 
readWindowFrameStarting() - Method in class org.h2.command.Parser
 
readWindowFunction(String) - Method in class org.h2.command.Parser
 
readWindowNameOrSpecification() - Method in class org.h2.command.Parser
 
readWindowSpecification() - Method in class org.h2.command.Parser
 
readWithinGroup(AggregateType, Expression[], boolean, Object, boolean, boolean) - Method in class org.h2.command.Parser
 
readWrite(long, byte[], int, int, boolean) - Method in class org.h2.store.fs.mem.FileMemData
Read or write.
readWrite(long, ByteBuffer, int, int, boolean) - Method in class org.h2.store.fs.niomem.FileNioMemData
Read or write.
ready() - Method in class org.h2.store.RangeReader
 
readY(String, int, int, int, ArrayList<Token>) - Method in class org.h2.command.Tokenizer
 
REAL - Static variable in class org.h2.api.H2Type
The REAL data type.
REAL - Static variable in class org.h2.mvstore.db.ValueDataType
 
REAL - Static variable in class org.h2.value.Transfer
 
REAL - Static variable in class org.h2.value.Value
The value type for REAL values.
REAL_0_1 - Static variable in class org.h2.mvstore.db.ValueDataType
 
realm - Variable in class org.h2.security.auth.AuthenticationInfo
 
RealmConfig - Class in org.h2.security.auth
Configuration for authentication realm.
RealmConfig() - Constructor for class org.h2.security.auth.RealmConfig
 
realms - Variable in class org.h2.security.auth.DefaultAuthenticator
 
realms - Variable in class org.h2.security.auth.H2AuthConfig
 
rebuild() - Method in class org.h2.constraint.Constraint
This method is called after a related table has changed (the table was renamed, or columns have been renamed).
rebuild() - Method in class org.h2.constraint.ConstraintCheck
 
rebuild() - Method in class org.h2.constraint.ConstraintDomain
 
rebuild() - Method in class org.h2.constraint.ConstraintReferential
 
rebuild() - Method in class org.h2.constraint.ConstraintUnique
 
rebuildIndex(SessionLocal, MVIndex<?, ?>, String) - Method in class org.h2.mvstore.db.MVTable
 
rebuildIndexBlockMerge(SessionLocal, MVIndex<?, ?>) - Method in class org.h2.mvstore.db.MVTable
 
rebuildIndexBuffered(SessionLocal, Index) - Method in class org.h2.mvstore.db.MVTable
 
rec - Variable in class org.h2.store.fs.rec.FileRec
 
recalculateMemory() - Method in class org.h2.mvstore.Page
Recalculate estimated memory used in persistent case.
recalculateTotalCount() - Method in class org.h2.mvstore.Page.NonLeaf
 
recentlyUsed - Variable in class org.h2.util.CacheTQ
 
recompile(SessionLocal, boolean, boolean) - Method in class org.h2.table.TableView
Re-compile the view query and all views that depend on this object.
recompileAlways - Variable in class org.h2.command.Parser
 
recompileAlways - Variable in class org.h2.engine.DbSettings
Database setting RECOMPILE_ALWAYS (default: false).
recompileIfRequired() - Method in class org.h2.command.CommandContainer
 
recompileInvalidViews() - Method in class org.h2.engine.Database
 
Record<K,​V> - Class in org.h2.mvstore.tx
Class Record is a value for undoLog.
Record(int, K, VersionedValue<V>) - Constructor for class org.h2.mvstore.tx.Record
 
Record.Type<K,​V> - Class in org.h2.mvstore.tx
A data type for undo log values
recordCount - Variable in class org.h2.util.CacheLRU
 
recorder - Static variable in class org.h2.store.fs.rec.FilePathRec
 
Recorder - Interface in org.h2.store.fs
A recorder for the recording file system.
recordLength - Variable in class org.h2.tools.Recover
 
recover(int) - Method in class org.h2.jdbcx.JdbcXAConnection
Get the list of prepared transaction branches.
Recover - Class in org.h2.tools
Helps recovering a corrupted database.
Recover() - Constructor for class org.h2.tools.Recover
 
RecoverTester - Class in org.h2.store
A tool that simulates a crash while writing to the database, and then verifies the database doesn't get corrupt.
RecoverTester() - Constructor for class org.h2.store.RecoverTester
 
recoveryMode - Variable in class org.h2.mvstore.MVStore
 
recoveryMode() - Method in class org.h2.mvstore.MVStore.Builder
Open the file in recovery mode, where some errors may be ignored.
recreateSessionState() - Method in class org.h2.engine.Session
Re-create the session state using the stored sessionState list.
recursive - Variable in class org.h2.index.ViewIndex
 
recursiveResult - Variable in class org.h2.table.TableView
 
recycleConnection(PooledConnection) - Method in class org.h2.jdbcx.JdbcConnectionPool
This method usually puts the connection back into the pool.
recycledConnections - Variable in class org.h2.jdbcx.JdbcConnectionPool
 
REDO_LOG_BINARY - Static variable in class org.h2.command.dml.SetTypes
The type of a SET REDO_LOG_BINARY statement.
refColumns - Variable in class org.h2.constraint.ConstraintReferential
 
refConstraint - Variable in class org.h2.constraint.ConstraintReferential
 
reference - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Entry
Weak reference to the value.
REFERENTIAL - org.h2.constraint.Constraint.Type
The constraint type for referential constraints.
REFERENTIAL_CONSTRAINTS - Static variable in class org.h2.table.InformationSchemaTable
 
REFERENTIAL_CONSTRAINTS - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
REFERENTIAL_INTEGRITY - Static variable in class org.h2.command.dml.SetTypes
The type of a SET REFERENTIAL_INTEGRITY statement.
REFERENTIAL_INTEGRITY_VIOLATED_CHILD_EXISTS_1 - Static variable in class org.h2.api.ErrorCode
The error with code 23503 is thrown when trying to delete or update a row when this would violate a referential constraint, because there is a child row that would become an orphan.
REFERENTIAL_INTEGRITY_VIOLATED_PARENT_MISSING_1 - Static variable in class org.h2.api.ErrorCode
The error with code 23506 is thrown when trying to insert or update a row that would violate a referential constraint, because the referenced row does not exist.
referentialConstraints(SessionLocal, ArrayList<Row>, String, ConstraintReferential, String) - Method in class org.h2.table.InformationSchemaTable
 
referentialConstraints(SessionLocal, Value, Value, ArrayList<Row>, String) - Method in class org.h2.table.InformationSchemaTable
 
referentialIntegrity - Variable in class org.h2.engine.Database
 
refIndex - Variable in class org.h2.command.ddl.AlterTableAddConstraint
 
refIndexColumns - Variable in class org.h2.command.ddl.AlterTableAddConstraint
 
refMap - Variable in class org.h2.mvstore.db.LobStorageMap
The reference map.
refMap - Variable in class org.h2.util.TempFileDeleter
 
refreshRow() - Method in class org.h2.jdbc.JdbcResultSet
Re-reads the current row from the database.
refreshRow() - Method in class org.h2.tools.SimpleResultSet
INTERNAL
refs - Static variable in class org.h2.util.CloseWatcher
The reference set.
refSchema - Variable in class org.h2.command.ddl.AlterTableAddConstraint
 
refTable - Variable in class org.h2.constraint.ConstraintReferential
 
refTableName - Variable in class org.h2.command.ddl.AlterTableAddConstraint
 
Regclass - Class in org.h2.mode
A ::regclass expression.
Regclass(Expression) - Constructor for class org.h2.mode.Regclass
 
REGEXP - org.h2.expression.condition.CompareLike.LikeType
REGEXP
REGEXP_LIKE - Static variable in class org.h2.expression.function.RegexpFunction
REGEXP_LIKE() (non-standard).
REGEXP_REPLACE - Static variable in class org.h2.expression.function.RegexpFunction
REGEXP_REPLACE() (non-standard).
REGEXP_SUBSTR - Static variable in class org.h2.expression.function.RegexpFunction
REGEXP_SUBSTR() (non-standard).
RegexpFunction - Class in org.h2.expression.function
A regular expression function.
RegexpFunction(int) - Constructor for class org.h2.expression.function.RegexpFunction
 
regexpReplace(SessionLocal, String, String, String, int, int, String) - Static method in class org.h2.expression.function.RegexpFunction
 
regexpReplaceBackslashReferences - Variable in class org.h2.engine.Mode
The function REGEXP_REPLACE() uses \ for back-references.
regexpSubstr(Value, Value, Value, Value, Value, Value, SessionLocal) - Static method in class org.h2.expression.function.RegexpFunction
 
register() - Static method in class org.h2.store.fs.encrypt.FilePathEncrypt
Register this file system.
register() - Static method in class org.h2.store.fs.rec.FilePathRec
Register the file system.
register(Object, AutoCloseable, boolean) - Static method in class org.h2.util.CloseWatcher
Register an object.
register(Database) - Static method in class org.h2.engine.OnExitDatabaseCloser
Register database instance to close one on the JVM process shutdown.
register(FilePath) - Static method in class org.h2.store.fs.FilePath
Register a file provider.
registerDataType(DataType<?>) - Method in class org.h2.mvstore.tx.TransactionStore.TxMapBuilder
 
registered - Static variable in class org.h2.Driver
 
registered - Static variable in class org.h2.engine.OnExitDatabaseCloser
 
registerMBean(ConnectionInfo, Database) - Static method in class org.h2.jmx.DatabaseInfo
Registers an MBean for the database.
registerOutParameter(int) - Method in class org.h2.jdbc.JdbcCallableStatement
 
registerOutParameter(int, int) - Method in class org.h2.jdbc.JdbcCallableStatement
Registers the given OUT parameter.
registerOutParameter(int, int, int) - Method in class org.h2.jdbc.JdbcCallableStatement
Registers the given OUT parameter.
registerOutParameter(int, int, String) - Method in class org.h2.jdbc.JdbcCallableStatement
Registers the given OUT parameter.
registerOutParameter(String, int) - Method in class org.h2.jdbc.JdbcCallableStatement
Registers the given OUT parameter.
registerOutParameter(String, int, int) - Method in class org.h2.jdbc.JdbcCallableStatement
Registers the given OUT parameter.
registerOutParameter(String, int, String) - Method in class org.h2.jdbc.JdbcCallableStatement
Registers the given OUT parameter.
registerService(BundleContext, Driver) - Static method in class org.h2.util.OsgiDataSourceFactory
Register the H2 JDBC driver service.
registerTableAsLocked(Table) - Method in class org.h2.engine.SessionLocal
Register table as locked within current transaction.
registerTableAsUpdated(Table) - Method in class org.h2.engine.SessionLocal
Register table as updated within current transaction.
registerTransaction(int, int, String, long, int, int, IsolationLevel, TransactionStore.RollbackListener) - Method in class org.h2.mvstore.tx.TransactionStore
 
registerUnsavedMemory(int) - Method in class org.h2.mvstore.MVStore
Adjust amount of "unsaved memory" meaning amount of RAM occupied by pages not saved yet to the file.
registerVersionUsage() - Method in class org.h2.mvstore.MVStore
Register opened operation (transaction).
REGR_AVGX - org.h2.expression.aggregate.AggregateType
The aggregate type for REGR_AVGX binary set function.
REGR_AVGY - org.h2.expression.aggregate.AggregateType
The aggregate type for REGR_AVGY binary set function.
REGR_COUNT - org.h2.expression.aggregate.AggregateType
The aggregate type for REGR_COUNT binary set function.
REGR_INTERCEPT - org.h2.expression.aggregate.AggregateType
The aggregate type for REGR_INTERCEPT binary set function.
REGR_R2 - org.h2.expression.aggregate.AggregateType
The aggregate type for REGR_R2 binary set function.
REGR_SLOPE - org.h2.expression.aggregate.AggregateType
The aggregate type for REGR_SLOPE binary set function.
REGR_SXX - org.h2.expression.aggregate.AggregateType
The aggregate type for REGR_SXX binary set function.
REGR_SXY - org.h2.expression.aggregate.AggregateType
The aggregate type for REGR_SXY binary set function.
REGR_SYY - org.h2.expression.aggregate.AggregateType
The aggregate type for REGR_SYY binary set function.
REGULAR - org.h2.engine.Mode.ModeEnum
 
rehash() - Method in class org.h2.command.ddl.Analyze.SelectivityData
 
reindex(Connection) - Static method in class org.h2.fulltext.FullText
Re-creates the full text index for this database.
reindex(Connection) - Static method in class org.h2.fulltext.FullTextLucene
Re-creates the full text index for this database.
rejectPoolingOptions(Properties) - Static method in class org.h2.util.OsgiDataSourceFactory
Checker method that will throw if any pooling related standard OSGi options are present.
rejectUnsupportedOptions(Properties) - Static method in class org.h2.util.OsgiDataSourceFactory
Checker method that will throw if any unsupported standard OSGi options is present.
relationSize(SessionLocal, Value) - Static method in class org.h2.mode.FunctionsPostgreSQL
 
relative(int) - Method in class org.h2.jdbc.JdbcResultSet
Moves the current position to a specific row relative to the current row.
relative(int) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
release() - Method in class org.h2.jdbc.JdbcSavepoint
Release this savepoint.
release() - Method in class org.h2.store.fs.retry.FileRetryOnInterrupt.FileLockRetry
 
releaseDatabaseObjectIds(BitSet) - Method in class org.h2.engine.Database
Mark some database ids as unused.
releaseLock() - Method in class org.h2.store.FileStore
Release the file lock.
releaseSavedPages() - Method in class org.h2.mvstore.Page.Leaf
 
releaseSavedPages() - Method in class org.h2.mvstore.Page.NonLeaf
 
releaseSavedPages() - Method in class org.h2.mvstore.Page
Unlink the children recursively after all data is written.
releaseSavepoint(Savepoint) - Method in class org.h2.jdbc.JdbcConnection
Releases a savepoint.
releaseSnapshot() - Method in class org.h2.mvstore.tx.Transaction
 
releaseWriteBuffer(WriteBuffer) - Method in class org.h2.mvstore.MVStore
Release a buffer for writing.
reLock() - Method in class org.h2.store.fs.retry.FileRetryOnInterrupt
 
remaining - Variable in class org.h2.api.Interval
Non-negative long with combined value of all remaining field, or 0 for single-field intervals, with exception for INTERVAL SECOND that uses this field to store fractional part of seconds measured in nanoseconds.
remaining - Variable in class org.h2.command.CommandList
 
remaining - Variable in class org.h2.store.CountingReaderInputStream
 
remaining - Variable in class org.h2.value.ValueInterval
 
remainingCommand - Variable in class org.h2.command.CommandList
 
remainingInBuffer - Variable in class org.h2.store.FileStoreInputStream
 
reMap() - Method in class org.h2.store.fs.niomapped.FileNioMapped
Re-map byte buffer into memory, called when file size has changed or file was created.
remapIfOld() - Method in class org.h2.result.ResultRemote
 
remapURL(String) - Static method in class org.h2.engine.ConnectionInfo
 
remarkStart - Variable in class org.h2.util.ScriptReader
The position in buffer of start of comment
rememberExpressions(SessionLocal, Value[]) - Method in class org.h2.expression.aggregate.Aggregate
 
rememberExpressions(SessionLocal, Value[]) - Method in class org.h2.expression.aggregate.JavaAggregate
 
rememberExpressions(SessionLocal, Value[]) - Method in class org.h2.expression.analysis.DataAnalysisOperation
Stores current values of expressions into the specified array.
rememberExpressions(SessionLocal, Value[]) - Method in class org.h2.expression.analysis.WindowFunction
 
remote - Variable in class org.h2.engine.ConnectionInfo
 
REMOTE_CONNECTION_NOT_ALLOWED - Static variable in class org.h2.api.ErrorCode
The error with code 90117 is thrown when trying to connect to a TCP server from another machine, if remote connections are not allowed.
REMOTE_DATABASE_NOT_FOUND_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90149 is thrown when trying to open a database that does not exist remotely without enabling remote database creation first.
remoteSettingsId - Variable in class org.h2.engine.Database
Used to trigger the client side to reload some of the settings.
remove() - Method in interface org.h2.api.Trigger
This method is called when the trigger is dropped.
remove() - Method in class org.h2.command.query.SelectGroups.Grouped
 
remove() - Method in class org.h2.command.query.SelectGroups
Removes the data for the current key.
remove() - Method in class org.h2.fulltext.FullText.FullTextTrigger
INTERNAL
remove() - Method in class org.h2.util.DebuggingThreadLocal
Remove the value for the current thread.
remove() - Method in class org.h2.value.ValueLob
Remove the underlying resource, if any.
remove(byte[]) - Method in class org.h2.mvstore.StreamStore
Remove all stored blocks for the given id.
remove(int) - Method in class org.h2.mvstore.Page.Leaf
 
remove(int) - Method in class org.h2.mvstore.Page.NonLeaf
 
remove(int) - Method in class org.h2.mvstore.Page
Remove the key and value (or child) at the given index.
remove(int) - Method in interface org.h2.util.Cache
Remove an object from the cache.
remove(int) - Method in class org.h2.util.CacheLRU
 
remove(int) - Method in class org.h2.util.CacheSecondLevel
 
remove(int) - Method in class org.h2.util.CacheTQ
 
remove(int) - Method in class org.h2.util.IntArray
Remove the value at the given index.
remove(long) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Remove an entry.
remove(long, int) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
Remove an entry.
remove(Object) - Method in class org.h2.mvstore.MVMap
Remove a key-value pair, if the key exists.
remove(Object) - Method in class org.h2.mvstore.rtree.MVRTreeMap
Remove a key-value pair, if the key exists.
remove(Object) - Method in class org.h2.mvstore.tx.TransactionMap
Remove an entry.
remove(Object) - Method in class org.h2.util.SoftValuesHashMap
Remove an object.
remove(Object) - Method in class org.h2.value.CaseInsensitiveConcurrentMap
 
remove(Object) - Method in class org.h2.value.CaseInsensitiveMap
 
remove(Object, Object) - Method in class org.h2.mvstore.MVMap
Remove a key-value pair if the value matches the stored one.
remove(String) - Method in class org.h2.server.web.WebSession
Remove a session attribute from the map.
remove(String, String) - Method in class org.h2.mode.ToDateParser
Remove a token from a string.
remove(ArrayList<? extends DbObject>, DbObject) - Static method in class org.h2.table.Table
 
remove(SessionLocal) - Method in class org.h2.index.Index
Remove the index.
remove(SessionLocal) - Method in class org.h2.index.LinkedIndex
 
remove(SessionLocal) - Method in class org.h2.index.MetaIndex
 
remove(SessionLocal) - Method in class org.h2.index.ViewIndex
 
remove(SessionLocal) - Method in class org.h2.index.VirtualTableIndex
 
remove(SessionLocal) - Method in class org.h2.mvstore.db.MVDelegateIndex
 
remove(SessionLocal) - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
remove(SessionLocal) - Method in class org.h2.mvstore.db.MVSecondaryIndex
 
remove(SessionLocal) - Method in class org.h2.mvstore.db.MVSpatialIndex
 
remove(SessionLocal, Row) - Method in class org.h2.index.Index
Remove a row from the index.
remove(SessionLocal, Row) - Method in class org.h2.index.LinkedIndex
 
remove(SessionLocal, Row) - Method in class org.h2.index.MetaIndex
 
remove(SessionLocal, Row) - Method in class org.h2.index.ViewIndex
 
remove(SessionLocal, Row) - Method in class org.h2.index.VirtualTableIndex
 
remove(SessionLocal, Row) - Method in class org.h2.mvstore.db.MVDelegateIndex
 
remove(SessionLocal, Row) - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
remove(SessionLocal, Row) - Method in class org.h2.mvstore.db.MVSecondaryIndex
 
remove(SessionLocal, Row) - Method in class org.h2.mvstore.db.MVSpatialIndex
 
remove(SchemaObject) - Method in class org.h2.schema.Schema
Remove an object from this schema.
remove(PgServerThread) - Method in class org.h2.server.pg.PgServer
Remove a thread from the list.
remove(TcpServerThread) - Method in class org.h2.server.TcpServer
Remove a thread from the list.
remove(WebThread) - Method in class org.h2.server.web.WebServer
Remove this web thread from the set of running threads.
remove(ValueLob) - Method in class org.h2.value.lob.LobData
Remove the underlying resource, if any.
remove(ValueLob) - Method in class org.h2.value.lob.LobDataDatabase
 
remove(ValueLob) - Method in class org.h2.value.lob.LobDataFile
 
REMOVE - org.h2.mvstore.MVMap.Decision
 
REMOVE - Static variable in class org.h2.mvstore.MVMap.DecisionMaker
Decision maker for remove().
removeAllForTable(int) - Method in class org.h2.mvstore.db.LobStorageMap
 
removeAllForTable(int) - Method in class org.h2.store.LobStorageFrontend
 
removeAllForTable(int) - Method in interface org.h2.store.LobStorageInterface
Remove all LOBs for this table.
removeAllIndexes() - Method in class org.h2.fulltext.FullTextSettings
Remove all indexes from the settings.
removeAllRecursive(long) - Method in class org.h2.mvstore.Page.Leaf
 
removeAllRecursive(long) - Method in class org.h2.mvstore.Page.NonLeaf
 
removeAllRecursive(long) - Method in class org.h2.mvstore.Page
Remove all page data recursively.
removeAllTriggers(Connection, String) - Static method in class org.h2.fulltext.FullText
Remove all triggers that start with the given prefix.
removeAnonFromLegacyAlgorithms() - Static method in class org.h2.security.CipherFactory
Attempts to weaken the security properties to allow anonymous TLS.
removeAtCommit(ValueLob) - Method in class org.h2.engine.SessionLocal
Remember that the given LOB value must be removed at commit.
removeAtCommitStop(ValueLob) - Method in class org.h2.engine.SessionLocal
Do not remove this LOB value at commit any longer.
removeChildrenAndResources(SessionLocal) - Method in class org.h2.constraint.ConstraintCheck
 
removeChildrenAndResources(SessionLocal) - Method in class org.h2.constraint.ConstraintDomain
 
removeChildrenAndResources(SessionLocal) - Method in class org.h2.constraint.ConstraintReferential
 
removeChildrenAndResources(SessionLocal) - Method in class org.h2.constraint.ConstraintUnique
 
removeChildrenAndResources(SessionLocal) - Method in class org.h2.engine.Comment
 
removeChildrenAndResources(SessionLocal) - Method in class org.h2.engine.DbObject
Delete all dependent children objects and resources of this object.
removeChildrenAndResources(SessionLocal) - Method in class org.h2.engine.Right
 
removeChildrenAndResources(SessionLocal) - Method in class org.h2.engine.Role
 
removeChildrenAndResources(SessionLocal) - Method in class org.h2.engine.Setting
 
removeChildrenAndResources(SessionLocal) - Method in class org.h2.engine.User
 
removeChildrenAndResources(SessionLocal) - Method in class org.h2.index.Index
 
removeChildrenAndResources(SessionLocal) - Method in class org.h2.mvstore.db.MVTable
 
removeChildrenAndResources(SessionLocal) - Method in class org.h2.schema.Constant
 
removeChildrenAndResources(SessionLocal) - Method in class org.h2.schema.Domain
 
removeChildrenAndResources(SessionLocal) - Method in class org.h2.schema.FunctionAlias
 
removeChildrenAndResources(SessionLocal) - Method in class org.h2.schema.Schema
 
removeChildrenAndResources(SessionLocal) - Method in class org.h2.schema.Sequence
 
removeChildrenAndResources(SessionLocal) - Method in class org.h2.schema.TriggerObject
 
removeChildrenAndResources(SessionLocal) - Method in class org.h2.schema.UserAggregate
 
removeChildrenAndResources(SessionLocal) - Method in class org.h2.table.MetaTable
 
removeChildrenAndResources(SessionLocal) - Method in class org.h2.table.Table
 
removeChildrenAndResources(SessionLocal) - Method in class org.h2.table.TableLink
 
removeChildrenAndResources(SessionLocal) - Method in class org.h2.table.TableSynonym
 
removeChildrenAndResources(SessionLocal) - Method in class org.h2.table.TableView
 
removeChildrenFromMap(SessionLocal, ConcurrentHashMap<String, ? extends SchemaObject>) - Method in class org.h2.schema.Schema
 
removeClassFactory(Utils.ClassFactory) - Static method in class org.h2.util.JdbcUtils
Remove a class factory
removeColumnExpressionsDependencies(SessionLocal) - Method in class org.h2.table.Table
Removes dependencies of column expressions, used for tables with circular dependencies.
removeConnection(int) - Method in class org.h2.server.TcpServer
Remove a connection from the management database.
removeConnectionEventListener(ConnectionEventListener) - Method in class org.h2.jdbcx.JdbcXAConnection
Remove the event listener.
removeConstraint(Constraint) - Method in class org.h2.schema.Domain
Remove the given constraint from the list.
removeConstraint(Constraint) - Method in class org.h2.table.Table
Remove the given constraint from the list.
removeCurrentViewFromOtherTables() - Method in class org.h2.table.TableView
 
removeDatabaseObject(SessionLocal, DbObject) - Method in class org.h2.engine.Database
Remove the object from the database.
removeDependentView(TableView) - Method in class org.h2.table.Table
Remove the given view from the dependent views list.
removeDhAnonFromCommaSeparatedList(String) - Static method in class org.h2.security.CipherFactory
Removes DH_anon and ECDH_anon from a comma separated list of ciphers.
removeDistinct(Value[]) - Method in class org.h2.result.LocalResult
Remove the row from the result set if it exists.
removedPageInfo - Variable in class org.h2.mvstore.MVStore.RemovedPageInfo
 
RemovedPageInfo(long, boolean, long, int) - Constructor for class org.h2.mvstore.MVStore.RemovedPageInfo
 
removedPages - Variable in class org.h2.mvstore.MVStore
 
removeEldestEntry(Map.Entry<K, V>) - Method in class org.h2.store.fs.mem.FileMemData.Cache
 
removeEldestEntry(Map.Entry<K, V>) - Method in class org.h2.store.fs.niomem.FileNioMemData.CompressLaterCache
 
removeEldestEntry(Map.Entry<K, V>) - Method in class org.h2.util.SmallLRUCache
 
removeFilterCondition() - Method in class org.h2.table.TableFilter
Remove the filter condition.
removeFirstChar() - Method in class org.h2.mode.ToDateParser
 
removeFromLinkedList(CacheObject) - Method in class org.h2.util.CacheLRU
 
removeFromQueue(CacheLongKeyLIRS.Entry<V>) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
 
removeFromStack(CacheLongKeyLIRS.Entry<V>) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
Remove the entry from the stack.
removeIndex(Index) - Method in class org.h2.table.Table
Remove the given index from the list.
removeIndexAccess(String) - Static method in class org.h2.fulltext.FullTextLucene
Close the index writer and searcher and remove them from the index access set.
removeIndexFiles(Connection) - Static method in class org.h2.fulltext.FullTextLucene
 
removeIndexInfo(IndexInfo) - Method in class org.h2.fulltext.FullTextSettings
Remove an index from the settings.
removeIndexOrTransferOwnership(SessionLocal, Index) - Method in class org.h2.table.Table
If the index is still required by a constraint, transfer the ownership to it.
removeJoin() - Method in class org.h2.table.TableFilter
Remove the joined table
removeJoinCondition() - Method in class org.h2.table.TableFilter
Remove the join condition.
removeLob(int, long) - Method in class org.h2.mvstore.db.LobStorageMap
 
removeLob(ValueLob) - Method in class org.h2.mvstore.db.LobStorageMap
 
removeLob(ValueLob) - Method in class org.h2.store.LobStorageFrontend
 
removeLob(ValueLob) - Method in interface org.h2.store.LobStorageInterface
Delete a LOB (from the database, if it is stored there).
removeLobMap - Variable in class org.h2.engine.SessionLocal
 
removeLocalTempTable(Table) - Method in class org.h2.engine.SessionLocal
Drop and remove the given local temporary table from this session.
removeLocalTempTableConstraint(Constraint) - Method in class org.h2.engine.SessionLocal
Drop and remove the given local temporary constraint from this session.
removeLocalTempTableIndex(Index) - Method in class org.h2.engine.SessionLocal
Drop and remove the given local temporary index from this session.
removeMap(String) - Method in class org.h2.mvstore.MVStore
Remove map by name.
removeMap(MVMap<?, ?>) - Method in class org.h2.mvstore.MVStore
Remove a map from the current version of the store.
removeMap(TransactionMap<?, ?>) - Method in class org.h2.mvstore.tx.TransactionStore
Remove the given map.
removeMap(TransactionMap<K, V>) - Method in class org.h2.mvstore.tx.Transaction
Remove the map.
removeMeta(SessionLocal, int) - Method in class org.h2.engine.Database
Remove the given object from the meta data.
removeNewlines(String) - Static method in class org.h2.tools.ConvertTraceFile
 
removeNonIdentityProperties() - Method in class org.h2.table.Column
 
removeOld() - Method in class org.h2.util.CacheLRU
 
removeOldIfRequired() - Method in class org.h2.util.CacheLRU
 
removeOrphanedLobs() - Method in class org.h2.engine.Database
 
removePage(long) - Method in class org.h2.mvstore.Page
Make accounting changes (chunk occupancy or "unsaved" RAM), related to this page removal.
removePassword() - Method in class org.h2.engine.ConnectionInfo
 
removeProcedure(String) - Method in class org.h2.engine.SessionLocal
Remove a procedure from this session.
removeProperty(String, boolean) - Method in class org.h2.engine.ConnectionInfo
Remove a boolean property if it is set and return the value.
removeProperty(String, String) - Method in class org.h2.engine.ConnectionInfo
Remove a String property if it is set and return the value.
removeRange(int, int) - Method in class org.h2.util.IntArray
Remove a number of elements.
removeRow(SessionLocal, Row) - Method in class org.h2.mvstore.db.MVTable
 
removeRow(SessionLocal, Row) - Method in class org.h2.table.MetaTable
 
removeRow(SessionLocal, Row) - Method in class org.h2.table.Table
Remove a row from the table and all indexes.
removeRow(SessionLocal, Row) - Method in class org.h2.table.TableLink
 
removeRow(SessionLocal, Row) - Method in class org.h2.table.TableView
 
removeRow(SessionLocal, Row) - Method in class org.h2.table.VirtualTable
 
removeRow(Value[]) - Method in class org.h2.mvstore.db.MVPlainTempResult
 
removeRow(Value[]) - Method in class org.h2.mvstore.db.MVSortedTempResult
 
removeRow(Value[]) - Method in interface org.h2.result.ResultExternal
Remove the row with the given values from this object if such a row exists.
removeSchemaObject(SessionLocal, SchemaObject) - Method in class org.h2.engine.Database
Remove an object from the system table.
removeSequence(Sequence) - Method in class org.h2.table.Table
Remove a sequence from the table.
removeSequence(Table, Sequence) - Method in class org.h2.command.ddl.AlterTableAlterColumn
 
removeServer(IOException, int, int) - Method in class org.h2.engine.SessionRemote
Remove a server from the list of cluster nodes and disables the cluster mode.
removeSession(SessionLocal) - Method in class org.h2.engine.Database
Remove a session.
removeSetting(String) - Method in class org.h2.server.web.WebServer
Remove a connection information setting from the list
removeStatementEventListener(StatementEventListener) - Method in class org.h2.jdbcx.JdbcXAConnection
[Not supported] Remove a statement event listener.
removeSynonym(TableSynonym) - Method in class org.h2.table.Table
Remove the given view from the list.
removeTable(MVTable) - Method in class org.h2.mvstore.db.Store
Remove a table.
removeTemporaryLobs(boolean) - Method in class org.h2.engine.SessionLocal
 
removeTemporaryMaps(BitSet) - Method in class org.h2.mvstore.db.Store
Remove all temporary maps.
removeTrigger(TriggerObject) - Method in class org.h2.table.Table
Remove the given trigger from the list.
removeUndoLogRecord(int) - Method in class org.h2.mvstore.tx.TransactionStore
Remove an undo log entry.
removeUnusableIndexConditions() - Method in class org.h2.table.Plan
Remove all index conditions that can not be used.
removeUnusableIndexConditions() - Method in class org.h2.table.TableFilter
Remove all index conditions that are not used by the current index.
removeUnusedOldVersions(long) - Method in class org.h2.mvstore.RootReference
Removed old versions that are not longer used.
removeUnusedOldVersions(RootReference<K, V>) - Method in class org.h2.mvstore.MVMap
Forget those old versions that are no longer needed.
rename(String) - Method in class org.h2.engine.DbObject
Rename the object.
rename(String) - Method in class org.h2.engine.RightOwner
 
rename(String) - Method in class org.h2.table.Column
Rename the column.
rename(String) - Method in class org.h2.table.Table
 
rename(String) - Method in class org.h2.table.TableSynonym
 
rename(String, boolean) - Static method in class org.h2.tools.Upgrade
 
rename(String, String, boolean) - Static method in class org.h2.tools.Upgrade
 
rename(SchemaObject, String) - Method in class org.h2.schema.Schema
Rename an object.
RENAME - Static variable in interface org.h2.store.fs.Recorder
Rename a file.
renameColumn(Column, String) - Method in class org.h2.table.Table
Rename a column of this table.
renameDatabaseObject(SessionLocal, DbObject, String) - Method in class org.h2.engine.Database
Rename a database object.
renameMap(MVMap<?, ?>, String) - Method in class org.h2.mvstore.MVStore
Rename a map.
renameSchemaObject(SessionLocal, SchemaObject, String) - Method in class org.h2.engine.Database
Rename a schema object.
reopen(int, IOException) - Method in class org.h2.store.fs.retry.FileRetryOnInterrupt
 
repair(String) - Static method in class org.h2.mvstore.MVStoreTool
Repair a store by rolling back to the newest good version.
REPEAT - org.h2.mvstore.MVMap.Decision
 
REPEAT - Static variable in class org.h2.expression.function.StringFunction2
REPEAT() (non-standard).
REPEATABLE_READ - org.h2.engine.IsolationLevel
Dirty reads and non-repeatable reads aren't allowed; phantom reads are allowed.
RepeatableIterator(TransactionMap<K, V>, K, K, boolean, boolean) - Constructor for class org.h2.mvstore.tx.TransactionMap.RepeatableIterator
 
RepeatableReadLockDecisionMaker(int, Transaction, DataType<VersionedValue<V>>, Function<K, V>) - Constructor for class org.h2.mvstore.tx.TxDecisionMaker.RepeatableReadLockDecisionMaker
 
replace(String, Column[], SessionLocal, boolean, boolean, boolean) - Method in class org.h2.table.TableView
Try to replace the SQL statement of the view and re-compile this and all dependent views.
replace(K, V) - Method in class org.h2.mvstore.MVMap
Replace a value for an existing key.
replace(K, V, V) - Method in class org.h2.mvstore.MVMap
Replace a value for an existing key, if the value matches.
REPLACE - Static variable in interface org.h2.command.CommandInterface
The type of a REPLACE statement.
REPLACE - Static variable in class org.h2.expression.function.StringFunction
REPLACE() (non-standard).
REPLACE_LOBS_FOR_TRACE - Static variable in interface org.h2.util.HasSQL
Replace long LOB values with some generated values.
replaceAll(String, String, String) - Static method in class org.h2.util.StringUtils
Replace all occurrences of the before string with the after string.
replaceInto - Variable in class org.h2.engine.Mode
MySQL style REPLACE INTO.
replaceNullWithEmpty(String) - Static method in class org.h2.table.InformationSchemaTableLegacy
 
replacePage(CursorPos<K, V>, Page<K, V>, MVMap.IntValueHolder) - Static method in class org.h2.mvstore.MVMap
 
replaceTags() - Method in class org.h2.server.web.PageParser
 
replaceTags(String) - Method in class org.h2.server.web.PageParser
 
REPOSITORY - Static variable in class org.h2.tools.Upgrade
 
requireStore() - Method in class org.h2.mvstore.MVStore
 
requiresWindowOrdering() - Method in enum org.h2.expression.analysis.WindowFunctionType
Returns whether window function of this type requires window ordering clause.
reserveUniqueName(String) - Method in class org.h2.schema.Schema
Reserve a unique object name.
reset() - Method in class org.h2.command.dml.ScriptCommand
 
reset() - Method in class org.h2.command.query.Select.LazyResultGroupSorted
 
reset() - Method in class org.h2.command.query.Select.LazyResultSelect
 
reset() - Method in class org.h2.command.query.SelectGroups.Grouped
 
reset() - Method in class org.h2.command.query.SelectGroups.Plain
 
reset() - Method in class org.h2.command.query.SelectGroups
Resets this group data for reuse.
reset() - Method in class org.h2.command.query.SelectUnion.LazyResultUnion
 
reset() - Method in class org.h2.engine.DelayedDatabaseCloser
Stop and disable the database closer.
reset() - Method in class org.h2.mvstore.db.MVPlainTempResult
 
reset() - Method in class org.h2.mvstore.db.MVSortedTempResult
 
reset() - Method in class org.h2.mvstore.MVMap.DecisionMaker
Resets internal state (if any) of a this DecisionMaker to it's initial state.
reset() - Method in class org.h2.mvstore.MVMap.EqualsDecisionMaker
 
reset() - Method in class org.h2.mvstore.MVMap.RewriteDecisionMaker
 
reset() - Method in class org.h2.mvstore.tx.CommitDecisionMaker
 
reset() - Method in class org.h2.mvstore.tx.RollbackDecisionMaker
 
reset() - Method in class org.h2.mvstore.tx.TxDecisionMaker
 
reset() - Method in class org.h2.result.LazyResult
 
reset() - Method in class org.h2.result.LocalResult
 
reset() - Method in interface org.h2.result.ResultExternal
Reset the current position of this object.
reset() - Method in interface org.h2.result.ResultInterface
Go to the beginning of the result, that means before the first row.
reset() - Method in class org.h2.result.ResultRemote
 
reset() - Method in class org.h2.result.ResultWithPaddedStrings
 
reset() - Method in class org.h2.result.SimpleResult
 
reset() - Method in class org.h2.store.Data
Set the position to 0.
reset() - Method in class org.h2.store.RangeInputStream
 
reset() - Method in class org.h2.store.RangeReader
 
reset() - Method in class org.h2.table.TableFilter
Reset to the current position.
reset() - Method in class org.h2.tools.Csv
INTERNAL
reset() - Method in interface org.h2.tools.SimpleRowSource
Reset the position (before the first row).
reset() - Method in class org.h2.util.AbbaLockingDetector
Reset the state.
resetCalendar() - Static method in class org.h2.util.DateTimeUtils
Reset the cached calendar for default timezone, for example after changing the default timezone.
resetColumnName() - Method in class org.h2.constraint.DomainColumnResolver
 
resetDefaultLegacyAlgorithms() - Static method in class org.h2.security.CipherFactory
Attempts to resets the security property to the default value.
resetLazy() - Method in class org.h2.command.query.SelectGroups.Grouped
 
resetLazy() - Method in class org.h2.command.query.SelectGroups
Resets this group data for reuse in lazy mode.
resetPos() - Method in class org.h2.mvstore.Page.PageReference
Re-acquire position from in-memory page.
resetResult() - Method in class org.h2.jdbc.JdbcResultSet
 
resetSchema() - Method in class org.h2.tools.Recover
 
resetThreadLocalSession(Session) - Method in class org.h2.engine.Session
Resets old thread local session.
resetThreadLocalSession(Session) - Method in class org.h2.engine.SessionLocal
 
resetTokenIndex() - Method in class org.h2.command.Parser
 
resizeIfNeeded(CacheLongKeyLIRS.Segment<V>, int) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
 
resolver - Variable in class org.h2.constraint.ConstraintDomain
 
resolver - Variable in class org.h2.expression.ExpressionVisitor
 
resolveTableOrView(SessionLocal, String) - Method in class org.h2.schema.Schema
Try to find a table or view with this name.
resolveWindows(ColumnResolver) - Method in class org.h2.expression.analysis.Window
 
resources - Variable in class org.h2.jmx.DocumentedMBean
 
resources - Variable in class org.h2.util.Tool
 
RESOURCES - Static variable in class org.h2.util.Utils
 
restart - Variable in class org.h2.command.ddl.SequenceOptions
 
restart - Variable in class org.h2.command.ddl.TruncateTable
 
Restore - Class in org.h2.tools
Restores a H2 database by extracting the database files from a .zip file.
Restore() - Constructor for class org.h2.tools.Restore
 
RESTRICT - org.h2.constraint.ConstraintActionType
The action is to restrict the operation.
result - Variable in class org.h2.command.CommandContainer.GeneratedKeysCollector
 
result - Variable in class org.h2.command.dml.Explain
 
result - Variable in class org.h2.command.dml.ScriptCommand
 
result - Variable in class org.h2.expression.analysis.PartitionData
Evaluated result.
result - Variable in class org.h2.expression.condition.UniquePredicate.Target
 
result - Variable in class org.h2.expression.SimpleCase.SimpleWhen
 
result - Variable in class org.h2.index.ViewCursor
 
result - Variable in class org.h2.index.VirtualTableCursor
 
result - Variable in class org.h2.jdbc.JdbcResultSet
 
result - Variable in class org.h2.jdbc.JdbcResultSetMetaData
 
result - Variable in class org.h2.result.ResultRemote
 
result - Variable in class org.h2.result.UpdatableRow
 
result - Variable in class org.h2.security.auth.H2AuthConfigXml
 
result - Variable in class org.h2.server.pg.PgServerThread.Prepared
The current result (for suspended portal).
result - Variable in class org.h2.server.web.PageParser
 
result - Variable in class org.h2.server.web.WebSession
The current updatable result set.
result - Variable in class org.h2.util.json.JSONValueTarget
 
result - Variable in class org.h2.util.Task
The result, if any.
result(int) - Static method in class org.h2.jdbc.meta.DatabaseMetaServer
 
result(SessionLocal, String) - Static method in class org.h2.jdbc.meta.DatabaseMetaServer
 
result(Value) - Static method in class org.h2.jdbc.meta.DatabaseMetaServer
 
RESULT_CLOSE - Static variable in class org.h2.engine.SessionRemote
 
RESULT_FETCH_ROWS - Static variable in class org.h2.engine.SessionRemote
 
RESULT_RESET - Static variable in class org.h2.engine.SessionRemote
 
RESULT_SET - Static variable in class org.h2.message.TraceObject
The trace type id for result sets.
RESULT_SET_META_DATA - Static variable in class org.h2.message.TraceObject
The trace type id for result set meta data objects.
RESULT_SET_NOT_SCROLLABLE - Static variable in class org.h2.api.ErrorCode
The error with code 90128 is thrown when trying to call a method of the ResultSet that is only supported for scrollable result sets, and the result set is not scrollable.
RESULT_SET_NOT_UPDATABLE - Static variable in class org.h2.api.ErrorCode
The error with code 90127 is thrown when trying to update or delete a row in a result set if the result set is not updatable.
RESULT_SET_READONLY - Static variable in class org.h2.api.ErrorCode
The error with code 90140 is thrown when trying to update or delete a row in a result set if the statement was not created with updatable concurrency.
ResultColumn - Class in org.h2.result
A result set column of a remote result.
ResultColumn(Transfer) - Constructor for class org.h2.result.ResultColumn
Read an object from the given transfer object.
resultColumnCount - Variable in class org.h2.command.query.Query
Number of columns including visible columns and additional virtual columns for ORDER BY and DISTINCT ON clauses.
resultColumnCount - Variable in class org.h2.mvstore.db.MVTempResult
Total count of columns.
resultColumnCount - Variable in class org.h2.result.LocalResult
 
resultColumnFormat - Variable in class org.h2.server.pg.PgServerThread.Portal
The format used in the result set columns (if set).
resultCount - Variable in class org.h2.tools.ConvertTraceFile.Stat
 
ResultExternal - Interface in org.h2.result
This interface is used to extend the LocalResult class, if data does not fit in memory.
ResultInterface - Interface in org.h2.result
The result interface is used by the LocalResult and ResultRemote class.
resultOption - Variable in class org.h2.table.DataChangeDeltaTable
 
ResultOption() - Constructor for enum org.h2.table.DataChangeDeltaTable.ResultOption
 
ResultRemote - Class in org.h2.result
The client side part of a result set that is kept on the server.
ResultRemote(SessionRemote, Transfer, int, int, int) - Constructor for class org.h2.result.ResultRemote
 
resultSet - Variable in class org.h2.jdbc.JdbcStatement
 
resultSetConcurrency - Variable in class org.h2.jdbc.JdbcStatement
 
resultSetToResult(SessionLocal, ResultSet, int) - Static method in class org.h2.schema.FunctionAlias.JavaMethod
Create a result for the given result set.
resultSetToValue(Session, ResultSet) - Static method in class org.h2.value.ValueToObjectConverter
 
resultSetType - Variable in class org.h2.jdbc.JdbcStatement
 
ResultTarget - Interface in org.h2.result
A object where rows are written to.
ResultWithGeneratedKeys - Class in org.h2.result
Result of update command with optional generated keys.
ResultWithGeneratedKeys(long) - Constructor for class org.h2.result.ResultWithGeneratedKeys
 
ResultWithGeneratedKeys.WithKeys - Class in org.h2.result
Result of update command with generated keys;
ResultWithPaddedStrings - Class in org.h2.result
Result with padded fixed length strings.
ResultWithPaddedStrings(ResultInterface) - Constructor for class org.h2.result.ResultWithPaddedStrings
Creates new instance of result.
RETENTION_TIME - Static variable in class org.h2.command.dml.SetTypes
The type of a SET RETENTION_TIME statement.
retentionTime - Variable in class org.h2.mvstore.MVStore
How long to retain old, persisted chunks, in milliseconds.
returnDataType - Variable in class org.h2.mode.FunctionInfo
The data type of the return value.
returnSearcher(IndexSearcher) - Method in class org.h2.fulltext.FullTextLucene.IndexAccess
Stop using the searcher.
returnsResult - Variable in class org.h2.bnf.context.DbProcedure
 
reuse - Variable in class org.h2.mvstore.WriteBuffer
The buffer that is used after a clear operation.
reuse() - Method in class org.h2.command.Command
The command is now re-used, therefore reset the canReuse flag, and the parameter values.
reusePreparedStatement(PreparedStatement, String) - Method in class org.h2.table.TableLink
Add this prepared statement to the list of cached statements.
reuseSpace - Variable in class org.h2.engine.DbSettings
Database setting REUSE_SPACE (default: true).
reuseSpace - Variable in class org.h2.mvstore.MVStore
 
reverse - Variable in class org.h2.mvstore.Cursor
 
reverseAfter(int) - Method in class org.h2.util.Permutations
Reverse the elements to the right of the specified index.
REVOKE - Static variable in interface org.h2.command.CommandInterface
The type of a REVOKE statement.
revokeRight() - Method in class org.h2.command.ddl.GrantRevoke
 
revokeRight(DbObject) - Method in class org.h2.command.ddl.GrantRevoke
 
revokeRight(DbObject) - Method in class org.h2.engine.RightOwner
Revoke the right for the given object (table or schema).
revokeRole(Role) - Method in class org.h2.command.ddl.GrantRevoke
 
revokeRole(Role) - Method in class org.h2.engine.RightOwner
Remove the right for the given role.
revokeTemporaryRightsOnRoles() - Method in class org.h2.engine.RightOwner
Remove all the temporary rights granted on roles
rewriteChunks(int, int) - Method in class org.h2.mvstore.MVStore
 
rewriteChunks(Set<Integer>, boolean) - Method in class org.h2.mvstore.MVStore
 
RewriteDecisionMaker(long) - Constructor for class org.h2.mvstore.MVMap.RewriteDecisionMaker
 
rewritePage(long) - Method in class org.h2.mvstore.MVMap
 
right - Variable in class org.h2.command.query.SelectUnion
The right hand side of the union (the second subquery).
right - Variable in class org.h2.expression.condition.BooleanTest
 
right - Variable in class org.h2.expression.condition.CompareLike
 
right - Variable in class org.h2.expression.condition.Comparison
 
right - Variable in class org.h2.expression.condition.ConditionAndOr
 
right - Variable in class org.h2.expression.Operation1_2
The right part of the operation (the second argument).
right - Variable in class org.h2.expression.Operation2
The right part of the operation (the second argument).
Right - Class in org.h2.engine
An access right.
Right(Database, int, RightOwner, int, DbObject) - Constructor for class org.h2.engine.Right
 
Right(Database, int, RightOwner, Role) - Constructor for class org.h2.engine.Right
 
RIGHT - Static variable in class org.h2.engine.DbObject
This object is a right.
RIGHT - Static variable in class org.h2.expression.function.StringFunction2
RIGHT() (non-standard).
RIGHT - Static variable in class org.h2.util.ParserUtil
The token "RIGHT".
rightDone - Variable in class org.h2.command.query.SelectUnion.LazyResultUnion
 
rightMask - Variable in class org.h2.command.ddl.GrantRevoke
 
rightmostDip() - Method in class org.h2.util.Permutations
Get the index of the first element from the right that is less than its neighbor on the right.
RightOwner - Class in org.h2.engine
A right owner (sometimes called principal).
RightOwner(Database, int, String, int) - Constructor for class org.h2.engine.RightOwner
 
rightPadWithSpaces(String, int) - Static method in class org.h2.result.ResultWithPaddedStrings
 
rights - Variable in class org.h2.engine.Database
 
rights(SessionLocal, Value, Value, ArrayList<Row>) - Method in class org.h2.table.InformationSchemaTable
 
RIGHTS - Static variable in class org.h2.table.InformationSchemaTable
 
RIGHTS - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
rightsChecked - Variable in class org.h2.command.Parser
 
RM - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
RN - Static variable in class org.h2.server.web.WebThread
 
RNRN - Static variable in class org.h2.server.web.WebThread
 
Role - Class in org.h2.engine
Represents a role.
Role(Database, int, String, boolean) - Constructor for class org.h2.engine.Role
 
ROLE - Static variable in class org.h2.engine.DbObject
This object is a role.
ROLE_ALREADY_EXISTS_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90069 is thrown when trying to create a role if an object with this name already exists.
ROLE_ALREADY_GRANTED_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90074 is thrown when trying to grant a role that has already been granted.
ROLE_CAN_NOT_BE_DROPPED_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90091 is thrown when trying to drop the role PUBLIC.
ROLE_NOT_FOUND_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90070 is thrown when trying to drop or grant a role that does not exists.
roleName - Variable in class org.h2.command.ddl.CreateRole
 
roleName - Variable in class org.h2.command.ddl.DropRole
 
roleNameFormat - Variable in class org.h2.security.auth.impl.AssignRealmNameRole
 
roleNames - Variable in class org.h2.command.ddl.GrantRevoke
 
roles - Variable in class org.h2.security.auth.impl.StaticRolesMapper
 
roles(SessionLocal, ArrayList<Row>) - Method in class org.h2.table.InformationSchemaTable
 
ROLES - Static variable in class org.h2.table.InformationSchemaTable
 
ROLES - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
ROLES_AND_RIGHT_CANNOT_BE_MIXED - Static variable in class org.h2.api.ErrorCode
The error with code 90072 is thrown when trying to grant or revoke both roles and rights at the same time.
rollback - Variable in class org.h2.jdbc.JdbcConnection
 
rollback() - Method in class org.h2.engine.SessionLocal
Fully roll back the current transaction.
rollback() - Method in class org.h2.jdbc.JdbcConnection
Rolls back the current transaction.
rollback() - Method in class org.h2.jdbc.JdbcSavepoint
Roll back to this savepoint.
rollback() - Method in class org.h2.mvstore.MVStore
Revert to the beginning of the current version, reverting all uncommitted changes.
rollback() - Method in class org.h2.mvstore.tx.Transaction
Roll the transaction back.
rollback(String, long, Writer) - Static method in class org.h2.mvstore.MVStoreTool
Roll back to a given revision into a file called *.temp.
rollback(Savepoint) - Method in class org.h2.jdbc.JdbcConnection
Rolls back to a savepoint.
rollback(Xid) - Method in class org.h2.jdbcx.JdbcXAConnection
Roll back a transaction.
ROLLBACK - Static variable in interface org.h2.command.CommandInterface
The type of a ROLLBACK statement.
ROLLBACK - Static variable in interface org.h2.store.InDoubtTransaction
The transaction state meaning this transaction is rolled back.
ROLLBACK_LISTENER_NONE - Static variable in class org.h2.mvstore.tx.TransactionStore
 
ROLLBACK_TO_SAVEPOINT - Static variable in interface org.h2.command.CommandInterface
The type of a ROLLBACK TO SAVEPOINT statement.
ROLLBACK_TRANSACTION - Static variable in interface org.h2.command.CommandInterface
The type of a ROLLBACK TRANSACTION statement.
RollbackDecisionMaker - Class in org.h2.mvstore.tx
Class RollbackDecisionMaker process undo log record during transaction rollback.
RollbackDecisionMaker(TransactionStore, long, long, TransactionStore.RollbackListener) - Constructor for class org.h2.mvstore.tx.RollbackDecisionMaker
 
rollbackInternal() - Method in class org.h2.jdbc.JdbcConnection
 
rollbackRoot(long) - Method in class org.h2.mvstore.MVMap
Roll the root back to the specified version.
rollbackTo(long) - Method in class org.h2.mvstore.MVMap
Rollback to the given version.
rollbackTo(long) - Method in class org.h2.mvstore.MVStore
Revert to the beginning of the given version.
rollbackTo(SessionLocal.Savepoint) - Method in class org.h2.engine.SessionLocal
Partially roll back the current transaction.
rollbackTo(Transaction, long, long) - Method in class org.h2.mvstore.tx.TransactionStore
Rollback to an old savepoint.
rollbackToSavepoint(long) - Method in class org.h2.mvstore.tx.Transaction
Roll back to the given savepoint.
rollbackToSavepoint(String) - Method in class org.h2.engine.SessionLocal
Undo all operations back to the log position of the given savepoint.
ROMAN_MONTH - Static variable in class org.h2.mode.ToDateTokenizer.MonthParslet
 
ROMAN_NUMERALS - Static variable in class org.h2.expression.function.ToCharFunction
 
ROMAN_VALUES - Static variable in class org.h2.expression.function.ToCharFunction
 
root - Variable in class org.h2.mvstore.MVMap
Reference to the current root page.
root - Variable in class org.h2.mvstore.RootReference
The root page.
root - Variable in class org.h2.mvstore.rtree.MVRTreeMap.RTreeCursor
 
root - Variable in class org.h2.mvstore.tx.Snapshot
The root reference.
RootReference<K,​V> - Class in org.h2.mvstore
Class RootReference is an immutable structure to represent state of the MVMap as a whole (not related to a particular B-Tree node).
RootReference(Page<K, V>, long) - Constructor for class org.h2.mvstore.RootReference
 
RootReference(RootReference<K, V>, int) - Constructor for class org.h2.mvstore.RootReference
 
RootReference(RootReference<K, V>, long, int) - Constructor for class org.h2.mvstore.RootReference
 
RootReference(RootReference<K, V>, Page<K, V>, boolean, int) - Constructor for class org.h2.mvstore.RootReference
 
RootReference(RootReference<K, V>, Page<K, V>, long) - Constructor for class org.h2.mvstore.RootReference
 
rot8(int) - Static method in class org.h2.security.AES
 
rotate(Value, long, boolean) - Static method in class org.h2.expression.function.BitFunction
 
ROTATELEFT - Static variable in class org.h2.expression.function.BitFunction
ROTATELEFT() (non-standard).
ROTATERIGHT - Static variable in class org.h2.expression.function.BitFunction
ROTATERIGHT() (non-standard).
round(Value, Value, RoundingMode) - Method in class org.h2.expression.function.MathFunction
 
ROUND - Static variable in class org.h2.expression.function.MathFunction
ROUND() (non-standard)
ROUND_CONSTANTS - Static variable in class org.h2.security.SHA3
 
roundMagic(double) - Static method in class org.h2.expression.function.MathFunction
 
ROUNDMAGIC - Static variable in class org.h2.expression.function.MathFunction
ROUNDMAGIC() (non-standard)
roundUp(int, int) - Static method in class org.h2.tools.MultiDimension
 
roundUpInt(int, int) - Static method in class org.h2.util.MathUtils
Round the value up to the next block size.
roundUpLong(long, long) - Static method in class org.h2.util.MathUtils
Round the value up to the next block size.
routines(SessionLocal, ArrayList<Row>, String) - Method in class org.h2.table.InformationSchemaTable
 
routines(SessionLocal, ArrayList<Row>, String, String, String, String, String, String, String, String, String, TypeInfo, boolean, String) - Method in class org.h2.table.InformationSchemaTable
 
ROUTINES - Static variable in class org.h2.table.InformationSchemaTable
 
row - Variable in class org.h2.command.dml.SetClauseList.SetMultiple
 
row - Variable in class org.h2.index.SingleRowCursor
 
row - Variable in class org.h2.index.VirtualTableCursor
 
row - Variable in class org.h2.mvstore.db.MVPrimaryIndex.MVStoreCursor
 
row - Variable in class org.h2.mvstore.db.MVSecondaryIndex.MVStoreCursor
 
row - Variable in class org.h2.mvstore.db.MVSpatialIndex.MVStoreCursor
 
row(H2Type...) - Static method in class org.h2.api.H2Type
Returns ROW data type with specified types of fields and default names.
Row - Class in org.h2.result
Represents a row in a table.
Row() - Constructor for class org.h2.result.Row
 
ROW - Static variable in class org.h2.mvstore.db.ValueDataType
 
ROW - Static variable in class org.h2.util.ParserUtil
The token "ROW".
ROW - Static variable in class org.h2.value.Transfer
 
ROW - Static variable in class org.h2.value.Value
The value type for ROW values.
ROW_COUNT_APPROXIMATION - Static variable in class org.h2.table.MetaTable
The approximate number of rows of a meta table.
ROW_COUNT_APPROXIMATION - Static variable in class org.h2.table.TableLink
 
ROW_COUNT_APPROXIMATION - Static variable in class org.h2.table.TableView
 
ROW_NOT_FOUND_IN_PRIMARY_INDEX - Static variable in class org.h2.api.ErrorCode
The error with code 90143 is thrown when trying to fetch a row from the primary index and the row is not there.
ROW_NOT_FOUND_WHEN_DELETING_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90112 is thrown when a row was deleted twice while locking was disabled.
ROW_NUMBER - org.h2.expression.analysis.WindowFunctionType
The type for ROW_NUMBER() window function.
rowBased - Variable in class org.h2.command.ddl.CreateTrigger
 
rowBased - Variable in class org.h2.schema.TriggerObject
 
rowCount - Variable in class org.h2.index.LinkedIndex
 
rowCount - Variable in class org.h2.mvstore.db.MVTempResult
Count of rows.
rowCount - Variable in class org.h2.result.LocalResult
 
rowCount - Variable in class org.h2.result.ResultRemote
 
rowCountCumulative - Variable in class org.h2.engine.QueryStatisticsData.QueryEntry
The total number of rows.
rowCountM2 - Variable in class org.h2.engine.QueryStatisticsData.QueryEntry
 
rowCountMax - Variable in class org.h2.engine.QueryStatisticsData.QueryEntry
The maximum number of rows.
rowCountMean - Variable in class org.h2.engine.QueryStatisticsData.QueryEntry
The mean number of rows.
rowCountMin - Variable in class org.h2.engine.QueryStatisticsData.QueryEntry
The minimum number of rows.
RowDataType - Class in org.h2.mvstore.db
The data type for rows.
RowDataType(CastDataProvider, CompareMode, DataHandler, int[], int[], int, boolean) - Constructor for class org.h2.mvstore.db.RowDataType
 
RowDataType.Factory - Class in org.h2.mvstore.db
 
rowDeleted() - Method in class org.h2.jdbc.JdbcResultSet
Detects if the row was deleted (by somebody else or the caller).
rowDeleted() - Method in class org.h2.tools.SimpleResultSet
INTERNAL
RowExpression(Expression, int[]) - Constructor for class org.h2.command.dml.SetClauseList.RowExpression
 
rowFactory - Variable in class org.h2.engine.Database
 
rowFactory - Variable in class org.h2.index.Index
 
rowFactory - Variable in class org.h2.mvstore.db.ValueDataType
 
rowFactory - Variable in class org.h2.table.Table
 
RowFactory - Class in org.h2.result
Creates rows.
RowFactory() - Constructor for class org.h2.result.RowFactory
 
RowFactory.DefaultRowFactory - Class in org.h2.result
Default implementation of row factory.
RowFactory.Holder - Class in org.h2.result
 
rowForResult(Value[], int) - Method in class org.h2.command.query.Select
Removes HAVING and QUALIFY columns from the row.
rowId - Variable in class org.h2.expression.ExpressionColumn
 
rowId - Variable in class org.h2.result.FetchedResult
 
rowId - Variable in class org.h2.result.LocalResult
 
rowId - Variable in class org.h2.result.SimpleResult
 
rowId - Variable in class org.h2.table.Column
 
rowId - Variable in class org.h2.tools.SimpleResultSet
 
ROWID - Static variable in class org.h2.table.Column
The name of the rowid pseudo column.
ROWID_INDEX - Static variable in class org.h2.result.SearchRow
Index of a virtual "_ROWID_" column within a row or a table
rowIdColumn - Variable in class org.h2.mvstore.db.MVTable
 
rowInserted() - Method in class org.h2.jdbc.JdbcResultSet
Detects if the row was inserted.
rowInserted() - Method in class org.h2.tools.SimpleResultSet
INTERNAL
Rownum - Class in org.h2.expression
Represents the ROWNUM function.
Rownum(Prepared) - Constructor for class org.h2.expression.Rownum
 
ROWNUM - Static variable in class org.h2.util.ParserUtil
The token "ROWNUM".
rowNumber - Variable in class org.h2.command.dml.Insert
 
rowNumber - Variable in class org.h2.command.query.Select.LazyResultSelect
 
rowNumber - Variable in class org.h2.engine.SessionLocal.RowNumberAndValue
 
RowNumberAndValue(long, Value) - Constructor for class org.h2.engine.SessionLocal.RowNumberAndValue
 
rowOffset - Variable in class org.h2.result.ResultRemote
 
rows - Variable in class org.h2.command.query.SelectGroups.Plain
 
rows - Variable in class org.h2.command.query.TableValueConstructor
 
rows - Variable in class org.h2.index.MetaCursor
 
rows - Variable in class org.h2.result.LocalResult
 
rows - Variable in class org.h2.result.SimpleResult
 
rows - Variable in class org.h2.table.TableValueConstructorTable
 
rows - Variable in class org.h2.tools.SimpleResultSet
 
ROWS - org.h2.expression.analysis.WindowFrameUnits
ROWS unit.
rowsAreEqual(SearchRow, SearchRow) - Method in class org.h2.mvstore.db.MVSecondaryIndex
 
rowScanCount - Variable in class org.h2.command.Prepared
 
rowUpdated() - Method in class org.h2.jdbc.JdbcResultSet
Detects if the row was updated (by somebody else or the caller).
rowUpdated() - Method in class org.h2.tools.SimpleResultSet
INTERNAL
RPAD - Static variable in class org.h2.expression.function.StringFunction
RPAD() (non-standard).
RR - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
RRRR - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
rs - Variable in class org.h2.index.LinkedCursor
 
rs - Variable in class org.h2.jdbc.JdbcResultSetMetaData
 
RS - Static variable in class org.h2.security.AES
 
RSHIFT - Static variable in class org.h2.expression.function.BitFunction
RSHIFT() (non-standard).
RT0 - Static variable in class org.h2.security.AES
 
RT1 - Static variable in class org.h2.security.AES
 
RT2 - Static variable in class org.h2.security.AES
 
RT3 - Static variable in class org.h2.security.AES
 
RTreeCursor(Page<Spatial, V>, Spatial) - Constructor for class org.h2.mvstore.rtree.MVRTreeMap.RTreeCursor
 
rule - Variable in class org.h2.bnf.RuleExtension
 
rule - Variable in class org.h2.bnf.RuleHead
 
rule - Variable in class org.h2.bnf.RuleOptional
 
rule - Variable in class org.h2.bnf.RuleRepeat
 
Rule - Interface in org.h2.bnf
Represents a BNF rule.
RuleElement - Class in org.h2.bnf
A single terminal rule in a BNF object.
RuleElement(String, String) - Constructor for class org.h2.bnf.RuleElement
 
RuleExtension - Class in org.h2.bnf
Represents a non-standard syntax.
RuleExtension(Rule, boolean) - Constructor for class org.h2.bnf.RuleExtension
 
RuleFixed - Class in org.h2.bnf
Represents a hard coded terminal rule in a BNF object.
RuleFixed(int) - Constructor for class org.h2.bnf.RuleFixed
 
RuleHead - Class in org.h2.bnf
Represents the head of a BNF rule.
RuleHead(String, String, Rule) - Constructor for class org.h2.bnf.RuleHead
 
RuleList - Class in org.h2.bnf
Represents a sequence of BNF rules, or a list of alternative rules.
RuleList(Rule, Rule, boolean) - Constructor for class org.h2.bnf.RuleList
 
ruleMap - Variable in class org.h2.bnf.Bnf
The rule map.
RuleOptional - Class in org.h2.bnf
Represents an optional BNF rule.
RuleOptional(Rule) - Constructor for class org.h2.bnf.RuleOptional
 
RuleRepeat - Class in org.h2.bnf
Represents a loop in a BNF object.
RuleRepeat(Rule, boolean) - Constructor for class org.h2.bnf.RuleRepeat
 
run() - Method in class org.h2.engine.DelayedDatabaseCloser
 
run() - Method in class org.h2.engine.OnExitDatabaseCloser
 
run() - Method in class org.h2.mvstore.MVStore.BackgroundWriterThread
 
run() - Method in class org.h2.server.pg.PgServerThread
 
run() - Method in class org.h2.server.TcpServerThread
 
run() - Method in class org.h2.server.web.WebServer.TranslateThread
 
run() - Method in class org.h2.server.web.WebThread
 
run() - Method in class org.h2.store.FileLock
 
run() - Method in class org.h2.tools.Server
INTERNAL
run() - Method in class org.h2.tools.Shell
INTERNAL.
run() - Method in class org.h2.util.AbbaLockingDetector
 
run() - Method in class org.h2.util.Profiler
 
run() - Method in class org.h2.util.Task
 
run(String...) - Method in class org.h2.util.Profiler
 
running - Variable in class org.h2.server.pg.PgServer
 
running - Variable in class org.h2.server.TcpServer
 
running - Variable in class org.h2.server.web.WebServer
 
RUNNING - org.h2.engine.SessionLocal.State
 
RunScript - Class in org.h2.tools
Runs a SQL script against a database.
RunScript() - Constructor for class org.h2.tools.RunScript
 
RUNSCRIPT - Static variable in interface org.h2.command.CommandInterface
The type of a RUNSCRIPT statement.
RunScriptCommand - Class in org.h2.command.dml
This class represents the statement RUNSCRIPT
RunScriptCommand(SessionLocal) - Constructor for class org.h2.command.dml.RunScriptCommand
 
runTool(String...) - Method in class org.h2.tools.Backup
 
runTool(String...) - Method in class org.h2.tools.ChangeFileEncryption
 
runTool(String...) - Method in class org.h2.tools.Console
This tool starts the H2 Console (web-) server, as well as the TCP and PG server.
runTool(String...) - Method in class org.h2.tools.ConvertTraceFile
 
runTool(String...) - Method in class org.h2.tools.CreateCluster
 
runTool(String...) - Method in class org.h2.tools.DeleteDbFiles
 
runTool(String...) - Method in class org.h2.tools.Recover
Dumps the contents of a database file to a human readable text file.
runTool(String...) - Method in class org.h2.tools.Restore
 
runTool(String...) - Method in class org.h2.tools.RunScript
Executes the contents of a SQL script file against a database.
runTool(String...) - Method in class org.h2.tools.Script
 
runTool(String...) - Method in class org.h2.tools.Server
 
runTool(String...) - Method in class org.h2.tools.Shell
Run the shell tool with the given command line settings.
runTool(String...) - Method in class org.h2.util.Tool
Run the tool with the given output stream and arguments.
runTool(Connection, String...) - Method in class org.h2.tools.Shell
Run the shell tool with the given connection and command line settings.
RW - Static variable in class org.h2.store.fs.FileUtils
StandardOpenOption.READ, StandardOpenOption.WRITE, and StandardOpenOption.CREATE.
RWD - Static variable in class org.h2.store.fs.FileUtils
StandardOpenOption.READ, StandardOpenOption.WRITE, StandardOpenOption.CREATE, and StandardOpenOption.DSYNC.
rwLock - Variable in class org.h2.store.fs.niomem.FileNioMemData
 
RWS - Static variable in class org.h2.store.fs.FileUtils
StandardOpenOption.READ, StandardOpenOption.WRITE, StandardOpenOption.CREATE, and StandardOpenOption.SYNC.

S

salt - Variable in class org.h2.command.ddl.AlterUser
 
salt - Variable in class org.h2.command.ddl.CreateUser
 
salt - Variable in class org.h2.engine.User
 
salt - Variable in class org.h2.security.auth.impl.StaticUserCredentialsValidator
 
SALT_LEN - Static variable in class org.h2.engine.Constants
The number of bytes in random salt that is used to hash passwords.
SALT_LENGTH - Static variable in class org.h2.store.fs.encrypt.FileEncrypt
The length of the salt, in bytes.
SALT_POS - Static variable in class org.h2.store.fs.encrypt.FileEncrypt
 
sameResultAsLast(Value[], Value[], long) - Method in class org.h2.command.query.Query
 
sampleRows - Variable in class org.h2.command.ddl.Analyze
The sample size.
samplingPct(AtomicLong) - Static method in class org.h2.mvstore.MVMap
 
samplingPct(AtomicLong) - Static method in class org.h2.util.MemoryEstimator
Calculates percentage of how many times actual calculation happened (vs.
sanitize(String) - Static method in class org.h2.value.ExtTypeInfoEnum
 
save() - Method in class org.h2.store.FileLock
Save the lock file.
save(WriteBuffer, MetaType<D>) - Method in class org.h2.mvstore.tx.VersionedValueType
 
save(WriteBuffer, MetaType<D>) - Method in interface org.h2.mvstore.type.StatefulDataType
Save the state.
save(WriteBuffer, MetaType<Database>) - Method in class org.h2.mvstore.db.RowDataType
 
save(WriteBuffer, MetaType<Database>) - Method in class org.h2.mvstore.db.ValueDataType
 
saveChunkLock - Variable in class org.h2.mvstore.MVStore
 
saveCommandHistoryList(ArrayList<String>) - Method in class org.h2.server.web.WebServer
Save the command history to the properties file.
saveNeeded - Variable in class org.h2.mvstore.MVStore
 
Savepoint() - Constructor for class org.h2.engine.SessionLocal.Savepoint
 
SAVEPOINT - Static variable in interface org.h2.command.CommandInterface
The type of a SAVEPOINT statement.
SAVEPOINT - Static variable in class org.h2.message.TraceObject
The trace type id for savepoint objects.
SAVEPOINT_IS_INVALID_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90063 is thrown when trying to rollback to a savepoint that is not defined.
SAVEPOINT_IS_NAMED - Static variable in class org.h2.api.ErrorCode
The error with code 90065 is thrown when Savepoint.getSavepointId() is called on a named savepoint.
SAVEPOINT_IS_UNNAMED - Static variable in class org.h2.api.ErrorCode
The error with code 90064 is thrown when Savepoint.getSavepointName() is called on an unnamed savepoint.
savepointId - Variable in class org.h2.jdbc.JdbcConnection
 
savepointId - Variable in class org.h2.jdbc.JdbcSavepoint
 
savepointName - Variable in class org.h2.command.dml.TransactionCommand
 
savepoints - Variable in class org.h2.engine.SessionLocal
 
saveProperties(Properties) - Method in class org.h2.server.web.WebServer
Save the settings to the properties file.
SCALAR - org.h2.util.json.JSONItemType
JSON scalar value: string, number, true, false, or null.
SCALAR_SUBQUERY_CONTAINS_MORE_THAN_ONE_ROW - Static variable in class org.h2.api.ErrorCode
The error with code 90053 is thrown when a subquery that is used as a value contains more than one row.
scale - Variable in class org.h2.expression.function.CurrentDateTimeValueFunction
 
scale - Variable in class org.h2.util.SimpleColumnInfo
Scale of the column.
scale - Variable in class org.h2.value.TypeInfo
 
scaleForAvailableMemory(int) - Static method in class org.h2.util.Utils
Scale the value with the available memory.
scan - Variable in class org.h2.index.IndexType
 
scan - Variable in class org.h2.index.MetaIndex
 
scanCount - Variable in class org.h2.table.TableFilter
 
scanToCloseParen(int) - Method in class org.h2.command.Parser
 
SCC - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
scheduleDatabaseObjectIdForRelease(int) - Method in class org.h2.engine.SessionLocal
Arranges for the specified database object id to be released at the end of the current transaction.
schema - Variable in class org.h2.bnf.context.DbProcedure
 
schema - Variable in class org.h2.bnf.context.DbTableOrView
The schema this table belongs to.
schema - Variable in class org.h2.command.ddl.CreateSynonymData
The schema.
schema - Variable in class org.h2.command.ddl.CreateTableData
The schema.
schema - Variable in class org.h2.command.ddl.DropTable.SchemaAndTable
 
schema - Variable in class org.h2.command.ddl.GrantRevoke
 
schema - Variable in class org.h2.command.ddl.SchemaCommand
 
schema - Variable in class org.h2.expression.Wildcard
 
schema - Variable in class org.h2.fulltext.FullTextLucene.FullTextTrigger
 
schema - Variable in class org.h2.fulltext.IndexInfo
The schema name.
schema - Variable in class org.h2.schema.SchemaObject
 
schema - Variable in class org.h2.tools.Recover
 
Schema - Class in org.h2.schema
A schema as created by the SQL statement CREATE SCHEMA
Schema(Database, int, String, RightOwner, boolean) - Constructor for class org.h2.schema.Schema
Create a new schema object.
SCHEMA - Static variable in class org.h2.bnf.context.DbContextRule
 
SCHEMA - Static variable in class org.h2.command.dml.SetTypes
The type of a SET SCHEMA statement.
SCHEMA - Static variable in class org.h2.engine.DbObject
This object is a schema.
SCHEMA - Static variable in class org.h2.fulltext.FullText
 
SCHEMA - Static variable in class org.h2.fulltext.FullTextLucene
 
SCHEMA - Static variable in class org.h2.message.Trace
The trace module id for schemas.
SCHEMA_ALREADY_EXISTS_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90078 is thrown when trying to create a schema if an object with this name already exists.
SCHEMA_CAN_NOT_BE_DROPPED_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90090 is thrown when trying to drop a schema that may not be dropped (the schema PUBLIC and the schema INFORMATION_SCHEMA).
SCHEMA_MAIN - Static variable in class org.h2.engine.Constants
The name of the default schema.
SCHEMA_MAIN - Static variable in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
SCHEMA_NAME_MUST_MATCH - Static variable in class org.h2.api.ErrorCode
The error with code 90080 is thrown when trying to rename a object to a different schema, or when trying to create a related object in another schema.
SCHEMA_NOT_FOUND_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90079 is thrown when trying to drop a schema that does not exist.
SCHEMA_OWNER - Static variable in class org.h2.engine.Right
The right bit mask that means: user is a schema owner.
SCHEMA_PG_CATALOG - Static variable in class org.h2.engine.Constants
The name of the pg_catalog schema.
SCHEMA_SEARCH_PATH - Static variable in class org.h2.command.dml.SetTypes
The type of a SET SCHEMA_SEARCH_PATH statement.
SchemaAndTable(Schema, String) - Constructor for class org.h2.command.ddl.DropTable.SchemaAndTable
 
SchemaCommand - Class in org.h2.command.ddl
This class represents a non-transaction statement that involves a schema.
SchemaCommand(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.SchemaCommand
Create a new command.
schemaName - Variable in class org.h2.command.ddl.CreateSchema
 
schemaName - Variable in class org.h2.command.ddl.DropSchema
 
schemaName - Variable in class org.h2.command.ddl.SetComment
 
schemaName - Variable in class org.h2.command.Parser
 
schemaName - Variable in class org.h2.expression.ExpressionColumn
 
schemaName - Variable in class org.h2.result.ResultColumn
The schema name or null.
schemaName - Variable in class org.h2.result.SimpleResult
 
schemaName - Variable in class org.h2.result.UpdatableRow
 
schemaName - Variable in class org.h2.tools.TriggerAdapter
The schema name.
schemaNames - Variable in class org.h2.command.dml.ScriptCommand
 
SchemaObject - Class in org.h2.schema
Any database object that is stored in a schema.
SchemaObject(Schema, int, String, int) - Constructor for class org.h2.schema.SchemaObject
Initialize some attributes of this object.
SchemaOwnerCommand - Class in org.h2.command.ddl
This class represents a non-transaction statement that involves a schema and requires schema owner rights.
SchemaOwnerCommand(SessionLocal, Schema) - Constructor for class org.h2.command.ddl.SchemaOwnerCommand
Create a new command.
schemas - Variable in class org.h2.bnf.context.DbContents
 
schemas - Variable in class org.h2.engine.Database
 
schemaSearchPath - Variable in class org.h2.engine.SessionLocal
 
schemata(SessionLocal, ArrayList<Row>, String) - Method in class org.h2.table.InformationSchemaTable
 
SCHEMATA - Static variable in class org.h2.table.InformationSchemaTable
 
SCHEMATA - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
SCHEME - Static variable in class org.h2.store.fs.encrypt.FilePathEncrypt
 
SCHEME - Static variable in class org.h2.store.fs.retry.FilePathRetryOnInterrupt
The prefix.
SCOPE_IDENTITY - Static variable in class org.h2.mode.FunctionsLegacy
 
SCOPE_IDENTITY - Static variable in class org.h2.mode.FunctionsMSSQLServer
 
SCOPE_IDENTITY_TYPE - Static variable in class org.h2.mode.FunctionsMSSQLServer
 
Script - Class in org.h2.tools
Creates a SQL script file by extracting the schema and data of a database.
Script() - Constructor for class org.h2.tools.Script
 
SCRIPT - Static variable in interface org.h2.command.CommandInterface
The type of a SCRIPT statement.
SCRIPT_SQL - Static variable in class org.h2.command.dml.ScriptBase
The default name of the script file if .zip compression is used.
ScriptBase - Class in org.h2.command.dml
This class is the base for RunScriptCommand and ScriptCommand.
ScriptBase(SessionLocal) - Constructor for class org.h2.command.dml.ScriptBase
 
ScriptCommand - Class in org.h2.command.dml
This class represents the statement SCRIPT
ScriptCommand(SessionLocal) - Constructor for class org.h2.command.dml.ScriptCommand
 
ScriptReader - Class in org.h2.util
This class can split SQL scripts to single SQL statements.
ScriptReader(Reader) - Constructor for class org.h2.util.ScriptReader
Create a new SQL script reader from the given reader
scrollable - Variable in class org.h2.jdbc.JdbcResultSet
 
scrubLayoutMap() - Method in class org.h2.mvstore.MVStore
 
scrubMetaMap() - Method in class org.h2.mvstore.MVStore
 
search(Connection, String, int, int) - Static method in class org.h2.fulltext.FullText
Searches from the full text index for this database.
search(Connection, String, int, int) - Static method in class org.h2.fulltext.FullTextLucene
Searches from the full text index for this database.
search(Connection, String, int, int, boolean) - Static method in class org.h2.fulltext.FullText
Do the search.
search(Connection, String, int, int, boolean) - Static method in class org.h2.fulltext.FullTextLucene
Do the search.
searchData(Connection, String, int, int) - Static method in class org.h2.fulltext.FullText
Searches from the full text index for this database.
searchData(Connection, String, int, int) - Static method in class org.h2.fulltext.FullTextLucene
Searches from the full text index for this database.
SearchedCase - Class in org.h2.expression
A searched case.
SearchedCase() - Constructor for class org.h2.expression.SearchedCase
 
SearchedCase(Expression[]) - Constructor for class org.h2.expression.SearchedCase
 
searcher - Variable in class org.h2.fulltext.FullTextLucene.IndexAccess
The index searcher.
searchRow - Variable in class org.h2.mvstore.db.MVSpatialIndex.MVStoreCursor
 
SearchRow - Class in org.h2.result
The base class for rows stored in a table, and for partial rows stored in the index.
SearchRow() - Constructor for class org.h2.result.SearchRow
 
second - Variable in class org.h2.mode.ToDateParser
 
SECOND - org.h2.api.IntervalQualifier
SECOND
SECOND - Static variable in class org.h2.expression.function.DateTimeFunction
Second.
SECOND - Static variable in class org.h2.util.ParserUtil
The token "SECOND".
SECOND_PRIMARY_KEY - Static variable in class org.h2.api.ErrorCode
The error with code 90017 is thrown when trying to define a second primary key constraint for this table.
SECONDS_PER_DAY - Static variable in class org.h2.util.DateTimeUtils
The number of seconds per day.
SECONDS_PER_PERIOD - Static variable in class org.h2.util.TimeZoneProvider.WithTimeZone
Number of seconds in 400 years.
SECONDS_PER_YEAR - Static variable in class org.h2.util.TimeZoneProvider.WithTimeZone
Number of seconds per year.
secret - Variable in class org.h2.server.pg.PgServerThread
 
section - Variable in class org.h2.bnf.RuleHead
 
secure - Variable in class org.h2.security.auth.impl.LdapCredentialsValidator
 
SECURE_RAND - Static variable in class org.h2.expression.function.RandFunction
SECURE_RAND() (non-standard).
secureFeatureMap - Static variable in class org.h2.jdbc.JdbcSQLXML
 
SecureFileStore - Class in org.h2.security
A file store that encrypts all data before writing, and decrypts all data after reading.
SecureFileStore(DataHandler, String, String, String, byte[], int) - Constructor for class org.h2.security.SecureFileStore
 
secureRandom - Static variable in class org.h2.util.MathUtils
The secure random object.
secureRandomBytes(int) - Static method in class org.h2.util.MathUtils
Get a number of cryptographically secure pseudo random bytes.
secureRandomInt(int) - Static method in class org.h2.util.MathUtils
Get a cryptographically secure pseudo random int value between 0 (including and the given value (excluding).
secureRandomLong() - Static method in class org.h2.util.MathUtils
Get a cryptographically secure pseudo random long value.
seeded - Static variable in class org.h2.util.MathUtils
True if the secure random object is seeded.
seek() - Method in class org.h2.store.fs.zip.FileZip
 
seek(long) - Method in class org.h2.security.SecureFileStore
 
seek(long) - Method in class org.h2.store.FileStore
Go to the specified file location.
Segment(long, int, int, int, int) - Constructor for class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
Create a new cache segment.
Segment(CacheLongKeyLIRS.Segment<V>, int) - Constructor for class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
Create a new cache segment from an existing one.
segmentCount - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Config
The number of cache segments (must be a power of 2).
segmentCount - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS
 
segmentMask - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS
 
segments - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS
 
segmentShift - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS
 
select - Variable in class org.h2.command.ddl.CreateView
 
select - Variable in class org.h2.command.query.SelectListColumnResolver
 
select - Variable in class org.h2.expression.analysis.DataAnalysisOperation
SELECT
select - Variable in class org.h2.table.TableFilter
 
Select - Class in org.h2.command.query
This class represents a simple SELECT statement.
Select(SessionLocal, Select) - Constructor for class org.h2.command.query.Select
 
SELECT - Static variable in interface org.h2.api.Trigger
The trigger is called for SELECT statements.
SELECT - Static variable in interface org.h2.command.CommandInterface
The type of a SELECT statement.
SELECT - Static variable in class org.h2.engine.Right
The right bit mask that means: selecting from a table is allowed.
SELECT - Static variable in class org.h2.util.ParserUtil
The token "SELECT".
SELECT_MAP_BY_WORD_ID - Static variable in class org.h2.fulltext.FullText
 
SELECT_ROW - Static variable in class org.h2.fulltext.FullText.FullTextTrigger
 
SELECT_ROW_BY_ID - Static variable in class org.h2.fulltext.FullText
 
Select.LazyResultGroupSorted - Class in org.h2.command.query
Lazy execution for a group sorted query.
Select.LazyResultQueryFlat - Class in org.h2.command.query
Lazy execution for a flat query.
Select.LazyResultSelect - Class in org.h2.command.query
Lazy execution for this select.
selectDataType(int) - Method in class org.h2.mvstore.type.ObjectDataType
 
SelectGroups - Class in org.h2.command.query
Grouped data for aggregates.
SelectGroups(SessionLocal, ArrayList<Expression>) - Constructor for class org.h2.command.query.SelectGroups
 
SelectGroups.Grouped - Class in org.h2.command.query
 
SelectGroups.Plain - Class in org.h2.command.query
 
selectivity - Variable in class org.h2.table.Column
 
SELECTIVITY_DEFAULT - Static variable in class org.h2.engine.Constants
The default selectivity (used if the selectivity is not calculated).
SELECTIVITY_DISTINCT_COUNT - Static variable in class org.h2.engine.Constants
The number of distinct values to keep in memory when running ANALYZE.
SelectivityData() - Constructor for class org.h2.command.ddl.Analyze.SelectivityData
 
SelectListColumnResolver - Class in org.h2.command.query
This class represents a column resolver for the column list of a SELECT statement.
SelectListColumnResolver(Select) - Constructor for class org.h2.command.query.SelectListColumnResolver
 
selectSQL - Variable in class org.h2.command.ddl.CreateView
 
SelectUnion - Class in org.h2.command.query
Represents a union SELECT statement.
SelectUnion(SessionLocal, SelectUnion.UnionType, Query, Query) - Constructor for class org.h2.command.query.SelectUnion
 
SelectUnion.LazyResultUnion - Class in org.h2.command.query
Lazy execution for this union.
SelectUnion.UnionType - Enum in org.h2.command.query
 
selectValue(T, T) - Method in class org.h2.mvstore.MVMap.DecisionMaker
Provides revised value for insert/update based on original input value and value currently existing in the map.
selectValue(T, T) - Method in class org.h2.mvstore.MVMap.RewriteDecisionMaker
 
selectValue(T, T) - Method in class org.h2.mvstore.tx.CommitDecisionMaker
 
selectValue(T, T) - Method in class org.h2.mvstore.tx.TxDecisionMaker
 
SEMICOLON - Static variable in class org.h2.command.Token
The token ";".
sendAuthenticationCleartextPassword() - Method in class org.h2.server.pg.PgServerThread
 
sendAuthenticationOk() - Method in class org.h2.server.pg.PgServerThread
 
sendBackendKeyData() - Method in class org.h2.server.pg.PgServerThread
 
sendBindComplete() - Method in class org.h2.server.pg.PgServerThread
 
sendCancelQueryResponse() - Method in class org.h2.server.pg.PgServerThread
 
sendClose() - Method in class org.h2.result.ResultRemote
 
sendCloseComplete() - Method in class org.h2.server.pg.PgServerThread
 
sendCommandComplete(CommandInterface, long) - Method in class org.h2.server.pg.PgServerThread
 
sendCommandSuspended() - Method in class org.h2.server.pg.PgServerThread
 
sendDataRow(ResultInterface, int[]) - Method in class org.h2.server.pg.PgServerThread
 
sendError(Throwable, boolean) - Method in class org.h2.server.TcpServerThread
 
sendErrorOrCancelResponse(Exception) - Method in class org.h2.server.pg.PgServerThread
 
sendErrorResponse(Exception) - Method in class org.h2.server.pg.PgServerThread
 
sendErrorResponse(String) - Method in class org.h2.server.pg.PgServerThread
 
sendMessage() - Method in class org.h2.server.pg.PgServerThread
 
sendNoData() - Method in class org.h2.server.pg.PgServerThread
 
sendParameterDescription(ArrayList<? extends ParameterInterface>, int[]) - Method in class org.h2.server.pg.PgServerThread
 
sendParameters(Transfer) - Method in class org.h2.command.CommandRemote
 
sendParameterStatus(String, String) - Method in class org.h2.server.pg.PgServerThread
 
sendParseComplete() - Method in class org.h2.server.pg.PgServerThread
 
sendReadyForQuery() - Method in class org.h2.server.pg.PgServerThread
 
sendRowDescription(ResultInterface, int[]) - Method in class org.h2.server.pg.PgServerThread
 
sendRows(ResultInterface, long) - Method in class org.h2.server.TcpServerThread
 
Sentence - Class in org.h2.bnf
A query context object.
Sentence() - Constructor for class org.h2.bnf.Sentence
 
separator - Variable in class org.h2.expression.aggregate.ListaggArguments
 
sequence - Variable in class org.h2.command.ddl.AlterSequence
 
sequence - Variable in class org.h2.engine.SessionLocal.SequenceAndPrepared
 
sequence - Variable in class org.h2.expression.SequenceValue
 
sequence - Variable in class org.h2.table.Column
 
Sequence - Class in org.h2.schema
A sequence is created using the statement CREATE SEQUENCE
Sequence(SessionLocal, Schema, int, String, SequenceOptions, boolean) - Constructor for class org.h2.schema.Sequence
Creates a new sequence.
SEQUENCE - Static variable in class org.h2.engine.DbObject
This object is a sequence.
SEQUENCE - Static variable in class org.h2.message.Trace
The trace module id for sequences.
SEQUENCE_ALREADY_EXISTS_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90035 is thrown when trying to create a sequence if a sequence with this name already exists.
SEQUENCE_ATTRIBUTES_INVALID_7 - Static variable in class org.h2.api.ErrorCode
The error with code 90009 is thrown when trying to create a sequence with an invalid combination of attributes (min value, max value, start value, etc).
SEQUENCE_BELONGS_TO_A_TABLE_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90082 is thrown when trying to drop a system generated sequence.
SEQUENCE_EXHAUSTED - Static variable in class org.h2.api.ErrorCode
The error with code 90006 is thrown when trying to get a value from a sequence that has run out of numbers and does not have cycling enabled.
SEQUENCE_NOT_FOUND_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90036 is thrown when trying to access a sequence that does not exist.
Sequence.Cycle - Enum in org.h2.schema
CYCLE clause and sequence state.
SequenceAndPrepared(Sequence, Prepared) - Constructor for class org.h2.engine.SessionLocal.SequenceAndPrepared
 
sequenceName - Variable in class org.h2.command.ddl.AlterSequence
 
sequenceName - Variable in class org.h2.command.ddl.CreateSequence
 
sequenceName - Variable in class org.h2.command.ddl.DropSequence
 
sequenceNum - Variable in class org.h2.mvstore.tx.Transaction
This is really a transaction identity, because it's not re-used.
SequenceOptions - Class in org.h2.command.ddl
Sequence options.
SequenceOptions() - Constructor for class org.h2.command.ddl.SequenceOptions
Creates new instance of sequence options.
SequenceOptions(Sequence, TypeInfo) - Constructor for class org.h2.command.ddl.SequenceOptions
Creates new instance of sequence options.
sequences - Variable in class org.h2.schema.Schema
 
sequences - Variable in class org.h2.table.Table
 
sequences(SessionLocal, ArrayList<Row>, String, Sequence, String) - Method in class org.h2.table.InformationSchemaTable
 
sequences(SessionLocal, Value, Value, ArrayList<Row>, String) - Method in class org.h2.table.InformationSchemaTable
 
SEQUENCES - Static variable in class org.h2.table.InformationSchemaTable
 
SEQUENCES - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
SequenceValue - Class in org.h2.expression
Wraps a sequence when used in a statement.
SequenceValue(Sequence) - Constructor for class org.h2.expression.SequenceValue
Creates new instance of CURRENT VALUE FOR expression.
SequenceValue(Sequence, Prepared) - Constructor for class org.h2.expression.SequenceValue
Creates new instance of NEXT VALUE FOR expression.
serialDataTypes - Variable in class org.h2.engine.Mode
Whether SERIAL and BIGSERIAL pseudo data types are supported.
serialId - Variable in class org.h2.engine.SessionLocal
 
SERIALIZABLE - org.h2.engine.IsolationLevel
Dirty reads, non-repeatable reads and phantom reads are'n allowed.
SERIALIZATION_FAILED_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90026 is thrown when an object could not be serialized.
serializationExecutor - Variable in class org.h2.mvstore.MVStore
Single-threaded executor for serialization of the store snapshot into ByteBuffer
serializationLock - Variable in class org.h2.mvstore.MVStore
 
serialize(Object) - Method in interface org.h2.api.JavaObjectSerializer
Serialize object to byte array.
serialize(Object) - Static method in class org.h2.mvstore.type.ObjectDataType
Serialize the object to a byte array.
serialize(Object, JavaObjectSerializer) - Static method in class org.h2.util.JdbcUtils
Serialize the object to a byte array, using the serializer specified by the connection info if set, or the default serializer.
serializeAndStore(boolean, long, Supplier<Long>, ArrayList<Page<?, ?>>, long, long) - Method in class org.h2.mvstore.MVStore
 
SerializedObjectType(ObjectDataType) - Constructor for class org.h2.mvstore.type.ObjectDataType.SerializedObjectType
 
serializer - Static variable in class org.h2.util.JdbcUtils
The serializer to use.
serializeToBuffer(WriteBuffer, ArrayList<Page<?, ?>>, Chunk, long, Supplier<Long>) - Method in class org.h2.mvstore.MVStore
 
serialVersionUID - Static variable in exception org.h2.jdbc.JdbcBatchUpdateException
 
serialVersionUID - Static variable in exception org.h2.jdbc.JdbcSQLDataException
 
serialVersionUID - Static variable in exception org.h2.jdbc.JdbcSQLException
 
serialVersionUID - Static variable in exception org.h2.jdbc.JdbcSQLFeatureNotSupportedException
 
serialVersionUID - Static variable in exception org.h2.jdbc.JdbcSQLIntegrityConstraintViolationException
 
serialVersionUID - Static variable in exception org.h2.jdbc.JdbcSQLInvalidAuthorizationSpecException
 
serialVersionUID - Static variable in exception org.h2.jdbc.JdbcSQLNonTransientConnectionException
 
serialVersionUID - Static variable in exception org.h2.jdbc.JdbcSQLNonTransientException
 
serialVersionUID - Static variable in exception org.h2.jdbc.JdbcSQLSyntaxErrorException
 
serialVersionUID - Static variable in exception org.h2.jdbc.JdbcSQLTimeoutException
 
serialVersionUID - Static variable in exception org.h2.jdbc.JdbcSQLTransactionRollbackException
 
serialVersionUID - Static variable in exception org.h2.jdbc.JdbcSQLTransientException
 
serialVersionUID - Static variable in class org.h2.jdbcx.JdbcDataSource
 
serialVersionUID - Static variable in exception org.h2.message.DbException
 
serialVersionUID - Static variable in exception org.h2.mvstore.MVStoreException
 
serialVersionUID - Static variable in class org.h2.mvstore.tx.VersionedBitSet
 
serialVersionUID - Static variable in exception org.h2.security.auth.AuthConfigException
 
serialVersionUID - Static variable in exception org.h2.security.auth.AuthenticationException
 
serialVersionUID - Static variable in class org.h2.server.web.JakartaWebServlet
 
serialVersionUID - Static variable in class org.h2.server.web.WebServlet
 
serialVersionUID - Static variable in exception org.h2.store.DataReader.FastEOFException
 
serialVersionUID - Static variable in class org.h2.store.fs.mem.FileMemData.Cache
 
serialVersionUID - Static variable in class org.h2.store.fs.niomem.FileNioMemData.CompressLaterCache
 
serialVersionUID - Static variable in class org.h2.util.SmallLRUCache
 
serialVersionUID - Static variable in class org.h2.util.SortedProperties
 
serialVersionUID - Static variable in class org.h2.value.CaseInsensitiveConcurrentMap
 
serialVersionUID - Static variable in class org.h2.value.CaseInsensitiveMap
 
server - Variable in class org.h2.engine.Database
 
server - Variable in class org.h2.server.pg.PgServerThread
 
server - Variable in class org.h2.server.TcpServerThread
 
server - Variable in class org.h2.server.web.DbStarter
 
server - Variable in class org.h2.server.web.JakartaDbStarter
 
server - Variable in class org.h2.server.web.JakartaWebServlet
 
server - Variable in class org.h2.server.web.WebApp
The web server.
server - Variable in class org.h2.server.web.WebServlet
 
server - Variable in class org.h2.server.web.WebSession
 
server - Variable in class org.h2.util.NetworkConnectionInfo
 
Server - Class in org.h2.tools
Starts the H2 Console (web-) server, TCP, and PG server.
Server() - Constructor for class org.h2.tools.Server
 
Server(Service, String...) - Constructor for class org.h2.tools.Server
Create a new server for the given service.
SERVER_CACHED_OBJECTS - Static variable in class org.h2.engine.SysProperties
System property h2.serverCachedObjects (default: 64).
SERVER_PROPERTIES_DIR - Static variable in class org.h2.engine.Constants
The default directory name of the server properties file for the H2 Console.
SERVER_PROPERTIES_NAME - Static variable in class org.h2.engine.Constants
The name of the server properties file for the H2 Console.
SERVER_RESULT_SET_FETCH_SIZE - Static variable in class org.h2.engine.SysProperties
System property h2.serverResultSetFetchSize (default: 100).
serverPropertiesDir - Variable in class org.h2.server.web.WebServer
 
serverPropertiesDir - Variable in class org.h2.tools.Shell
 
SERVERS - Static variable in class org.h2.server.TcpServer
 
serverSocket - Variable in class org.h2.server.pg.PgServer
 
serverSocket - Variable in class org.h2.server.TcpServer
 
serverSocket - Variable in class org.h2.server.web.WebServer
 
serverSocket - Variable in class org.h2.store.FileLock
The server socket (only used when using the SOCKET mode).
service - Variable in class org.h2.tools.Server
 
Service - Interface in org.h2.server
Classes implementing this interface usually provide a TCP/IP listener such as an FTP server.
session - Variable in class org.h2.command.Command
The session.
session - Variable in class org.h2.command.CommandRemote
 
session - Variable in class org.h2.command.ddl.CreateSynonymData
The session.
session - Variable in class org.h2.command.ddl.CreateTableData
The session.
session - Variable in class org.h2.command.Parser
 
session - Variable in class org.h2.command.Prepared
The session.
session - Variable in class org.h2.command.query.Optimizer
 
session - Variable in class org.h2.command.query.SelectGroups
The database session.
session - Variable in class org.h2.constraint.ConstraintDomain.CheckExistingData
 
session - Variable in class org.h2.index.IndexCursor
 
session - Variable in class org.h2.index.LinkedCursor
 
session - Variable in class org.h2.jdbc.JdbcConnection
 
session - Variable in class org.h2.jdbc.JdbcStatement
 
session - Variable in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
session - Variable in class org.h2.jdbc.meta.DatabaseMetaLocal
 
session - Variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
session - Variable in class org.h2.mode.ToDateParser
 
session - Variable in class org.h2.mvstore.db.MVSecondaryIndex.MVStoreCursor
 
session - Variable in class org.h2.mvstore.db.MVSpatialIndex.FindBoundsCursor
 
session - Variable in class org.h2.mvstore.db.MVSpatialIndex.MVStoreCursor
 
session - Variable in class org.h2.result.LazyResult
 
session - Variable in class org.h2.result.LocalResult
 
session - Variable in class org.h2.result.ResultRemote
 
session - Variable in class org.h2.result.SortOrder
 
session - Variable in class org.h2.server.pg.PgServerThread
 
session - Variable in class org.h2.server.TcpServerThread
 
session - Variable in class org.h2.server.web.WebApp
The session.
session - Variable in class org.h2.table.TableFilter
 
session - Variable in class org.h2.value.Transfer
 
Session - Class in org.h2.engine
A local or remote session.
Session() - Constructor for class org.h2.engine.Session
 
SESSION_CANCEL_STATEMENT - Static variable in class org.h2.engine.SessionRemote
 
SESSION_CHECK_KEY - Static variable in class org.h2.engine.SessionRemote
 
SESSION_CLOSE - Static variable in class org.h2.engine.SessionRemote
 
SESSION_HAS_PENDING_TRANSACTION - Static variable in class org.h2.engine.SessionRemote
 
SESSION_ID - Static variable in class org.h2.expression.function.SysInfoFunction
SESSION_ID().
SESSION_PREPARE - Static variable in class org.h2.engine.SessionRemote
 
SESSION_PREPARE_READ_PARAMS2 - Static variable in class org.h2.engine.SessionRemote
 
SESSION_SET_AUTOCOMMIT - Static variable in class org.h2.engine.SessionRemote
 
SESSION_SET_ID - Static variable in class org.h2.engine.SessionRemote
 
SESSION_STATE - Static variable in class org.h2.table.InformationSchemaTable
 
SESSION_STATE - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
SESSION_TIMEOUT - Static variable in class org.h2.server.web.WebServer
The session timeout (the default is 30 minutes).
SESSION_USER - Static variable in class org.h2.expression.function.CurrentGeneralValueSpecification
The function "SESSION_USER" general value specification.
SESSION_USER - Static variable in class org.h2.util.ParserUtil
The token "SESSION_USER".
Session.DynamicSettings - Class in org.h2.engine
Dynamic settings.
Session.StaticSettings - Class in org.h2.engine
Static settings.
SessionControlFunction - Class in org.h2.expression.function
An ABORT_SESSION() or CANCEL_SESSION() function.
SessionControlFunction(Expression, int) - Constructor for class org.h2.expression.function.SessionControlFunction
 
sessionId - Variable in class org.h2.engine.SessionRemote
 
sessionId - Variable in class org.h2.server.TcpServerThread
 
SessionLocal - Class in org.h2.engine
A session represents an embedded database connection.
SessionLocal(Database, User, int) - Constructor for class org.h2.engine.SessionLocal
 
SessionLocal.RowNumberAndValue - Class in org.h2.engine
 
SessionLocal.Savepoint - Class in org.h2.engine
Represents a savepoint (a position in a transaction to where one can roll back to).
SessionLocal.SequenceAndPrepared - Class in org.h2.engine
 
SessionLocal.State - Enum in org.h2.engine
 
SessionLocal.TimeoutValue - Class in org.h2.engine
An LOB object with a timeout.
sessionRemote - Variable in class org.h2.store.LobStorageFrontend
 
sessionRemote - Variable in class org.h2.store.LobStorageRemoteInputStream
 
SessionRemote - Class in org.h2.engine
The client side part of a session when using the server mode.
SessionRemote(ConnectionInfo) - Constructor for class org.h2.engine.SessionRemote
 
sessions - Variable in class org.h2.server.web.WebServer
 
sessions(SessionLocal, ArrayList<Row>) - Method in class org.h2.table.InformationSchemaTable
 
sessions(SessionLocal, ArrayList<Row>, SessionLocal) - Method in class org.h2.table.InformationSchemaTable
 
SESSIONS - Static variable in class org.h2.table.InformationSchemaTable
 
SESSIONS - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
sessionStart - Variable in class org.h2.engine.SessionLocal
 
sessionState - Variable in class org.h2.engine.Session
 
sessionState(SessionLocal, ArrayList<Row>) - Method in class org.h2.table.InformationSchemaTable
 
sessionStateChanged - Variable in class org.h2.engine.Session
 
sessionStateUpdating - Variable in class org.h2.engine.Session
 
set - Variable in class org.h2.expression.ExpressionVisitor
 
set - Variable in class org.h2.mvstore.FreeSpaceBitSet
The bit set.
set - Variable in class org.h2.util.geometry.GeometryUtils.EnvelopeTarget
Whether envelope was set.
set(Object, TxDecisionMaker<K, V>) - Method in class org.h2.mvstore.tx.TransactionMap
 
set(String, boolean) - Method in class org.h2.engine.SettingsBase
Set an entry in the key-value pair.
set(String, Object) - Method in class org.h2.mvstore.MVStore.Builder
 
set(PreparedStatement, int, Value, JdbcConnection) - Static method in class org.h2.util.JdbcUtils
Set a value as a parameter in a prepared statement.
set(K, V) - Method in class org.h2.mvstore.tx.TransactionMap
 
set(Row) - Method in class org.h2.table.GeneratedColumnResolver
Set the current row.
set(Row) - Method in class org.h2.table.TableFilter
Set the current row.
set(T) - Method in class org.h2.util.DebuggingThreadLocal
 
Set - Class in org.h2.command.dml
This class represents the statement SET
Set(SessionLocal, int) - Constructor for class org.h2.command.dml.Set
 
SET - Static variable in interface org.h2.command.CommandInterface
The type of a SET statement.
SET - Static variable in class org.h2.util.ParserUtil
The token "SET".
SET_AUTOCOMMIT_FALSE - Static variable in interface org.h2.command.CommandInterface
The type of a SET AUTOCOMMIT statement.
SET_AUTOCOMMIT_TRUE - Static variable in interface org.h2.command.CommandInterface
The type of a SET AUTOCOMMIT statement.
SET_CALLED - org.h2.jdbc.JdbcLob.State
One of setter methods is invoked, but stream is not closed yet.
SET_CONFIG - Static variable in class org.h2.mode.FunctionsPostgreSQL
 
SET_DEFAULT - org.h2.constraint.ConstraintActionType
The action is to set the value to the default value.
SET_DEFAULT - Static variable in class org.h2.command.dml.SetClauseList.UpdateAction
 
SET_MAX_DATA_MODIFICATION_ID - Static variable in class org.h2.expression.ExpressionVisitor
Request to set the latest modification id (addDataModificationId).
SET_NULL - org.h2.constraint.ConstraintActionType
The action is to set the value to NULL.
setAbsoluteDay(int) - Method in class org.h2.mode.ToDateParser
 
setActiveRequest(CommandInterface) - Method in class org.h2.server.pg.PgServerThread
 
setAddAfter(String) - Method in class org.h2.command.ddl.AlterTableAlterColumn
 
setAddBefore(String) - Method in class org.h2.command.ddl.AlterTableAlterColumn
 
setAddFirst() - Method in class org.h2.command.ddl.AlterTableAlterColumn
Add the column as the first column of the table.
setAdmin(boolean) - Method in class org.h2.command.ddl.AlterUser
 
setAdmin(boolean) - Method in class org.h2.command.ddl.CreateUser
 
setAdmin(boolean) - Method in class org.h2.engine.User
 
setAdminPassword(String) - Method in class org.h2.server.web.WebServer
 
setAlias(String) - Method in class org.h2.table.TableFilter
 
setAliasName(String) - Method in class org.h2.command.ddl.CreateFunctionAlias
 
setAliasName(String) - Method in class org.h2.command.ddl.DropFunctionAlias
 
setAllowBuiltinAliasOverride(boolean) - Method in class org.h2.engine.Database
 
setAllowChunked(boolean) - Method in class org.h2.server.web.WebServer
 
setAllowLiterals(boolean) - Method in class org.h2.engine.SessionLocal
 
setAllowLiterals(int) - Method in class org.h2.engine.Database
 
setAllowOthers(boolean) - Method in class org.h2.server.web.WebServer
 
setAllowSecureCreation(boolean) - Method in class org.h2.server.web.WebServer
 
setAllowUserRegistration(boolean) - Method in class org.h2.security.auth.DefaultAuthenticator
If set totrue creates external users in the database if not present.
setAllowUserRegistration(boolean) - Method in class org.h2.security.auth.H2AuthConfig
 
setAmPm(boolean) - Method in class org.h2.mode.ToDateParser
 
setAndCondition(Expression) - Method in class org.h2.command.dml.MergeUsing.When
Sets the specified AND condition.
setArray(int, Array) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter as an Array.
setAsciiStream(int, InputStream) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter as an ASCII stream.
setAsciiStream(int, InputStream, int) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter as an ASCII stream.
setAsciiStream(int, InputStream, long) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter as an ASCII stream.
setAsciiStream(long) - Method in class org.h2.jdbc.JdbcClob
[Not supported] Returns an output stream.
setAsciiStream(String, InputStream) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter as an ASCII stream.
setAsciiStream(String, InputStream, int) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter as an ASCII stream.
setAsciiStream(String, InputStream, long) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter as an ASCII stream.
setAuthenticator(Authenticator) - Method in class org.h2.engine.Database
Set current database authenticator
setAuthorization(String) - Method in class org.h2.command.ddl.CreateSchema
 
setAutoClose(boolean) - Method in class org.h2.tools.SimpleResultSet
Set the auto-close behavior.
setAutoCommit(boolean) - Method in class org.h2.command.ddl.CreateLinkedTable
Specify if the autocommit mode is activated or not
setAutoCommit(boolean) - Method in class org.h2.engine.Session
Set the auto-commit mode.
setAutoCommit(boolean) - Method in class org.h2.engine.SessionLocal
 
setAutoCommit(boolean) - Method in class org.h2.engine.SessionRemote
 
setAutoCommit(boolean) - Method in class org.h2.jdbc.JdbcConnection
Switches auto commit on or off.
setAutoCommit(boolean) - Method in class org.h2.table.TableLink
Specify if the autocommit mode is activated or not
setAutoCommit(boolean) - Method in class org.h2.table.TableLinkConnection
Specify if the autocommit mode is activated or not
setAutoCommitDelay(int) - Method in class org.h2.mvstore.MVStore
Set the maximum delay in milliseconds to auto-commit changes.
setAutoCommitFromServer(boolean) - Method in class org.h2.engine.SessionRemote
 
setAutoCommitSend(boolean) - Method in class org.h2.engine.SessionRemote
 
setBackgroundException(DbException) - Method in class org.h2.engine.Database
 
setBaseDir(String) - Method in class org.h2.engine.ConnectionInfo
Set the base directory of persistent databases, unless the database is in the user home folder (~).
setBaseDir(String) - Static method in class org.h2.engine.SysProperties
INTERNAL
setBC(boolean) - Method in class org.h2.mode.ToDateParser
 
setBefore(boolean) - Method in class org.h2.command.ddl.CreateTrigger
 
setBefore(boolean) - Method in class org.h2.schema.TriggerObject
 
setBelongsToConstraint(boolean) - Method in class org.h2.index.IndexType
Sets if this index belongs to a constraint.
setBelongsToTable(boolean) - Method in class org.h2.command.ddl.CreateSequence
 
setBelongsToTable(boolean) - Method in class org.h2.schema.Sequence
 
setBigDecimal(int, BigDecimal) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter.
setBigDecimal(String, BigDecimal) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter.
setBinaryStream() - Method in class org.h2.jdbc.JdbcSQLXML
 
setBinaryStream(int, InputStream) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter as an input stream.
setBinaryStream(int, InputStream, int) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter as an input stream.
setBinaryStream(int, InputStream, long) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter as an input stream.
setBinaryStream(long) - Method in class org.h2.jdbc.JdbcBlob
Get a writer to update the Blob.
setBinaryStream(String, InputStream) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter as an input stream.
setBinaryStream(String, InputStream, int) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter as an input stream.
setBinaryStream(String, InputStream, long) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter as an input stream.
setBlob(int, InputStream) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter as a Blob.
setBlob(int, InputStream, long) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter as a Blob.
setBlob(int, Blob) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter as a Blob.
setBlob(String, InputStream) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter as a Blob.
setBlob(String, InputStream, long) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter as a Blob.
setBlob(String, Blob) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter as a Blob.
setBoolean(int, boolean) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter.
setBoolean(String, boolean) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter.
setBooleanFlag(boolean) - Method in class org.h2.command.ddl.AlterTableAlterColumn
 
setByName(ToDateParser, int) - Static method in class org.h2.mode.ToDateTokenizer
Set the given field in the calendar.
setByte(int, byte) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter.
setByte(String, byte) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter.
setBytes(int, byte[]) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter as a byte array.
setBytes(long, byte[]) - Method in class org.h2.jdbc.JdbcBlob
Fills the Blob.
setBytes(long, byte[], int, int) - Method in class org.h2.jdbc.JdbcBlob
Sets some bytes of the object.
setBytes(String, byte[]) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter as a byte array.
setCachedColumnLabelMap(HashMap<String, Integer>) - Method in class org.h2.jdbc.JdbcPreparedStatement
Cache the column labels (looking up the column index can sometimes show up on the performance profile).
setCacheSize(int) - Method in class org.h2.engine.Database
 
setCacheSize(int) - Method in class org.h2.mvstore.db.Store
Set the maximum memory to be used by the cache.
setCacheSize(int) - Method in class org.h2.mvstore.MVStore
Set the read cache size in MB.
setCacheSize(int) - Method in class org.h2.store.fs.niomem.FileNioMemData.CompressLaterCache
 
setCacheSize(Expression) - Method in class org.h2.command.ddl.SequenceOptions
Sets cache size.
setCacheSizeMax(int) - Method in class org.h2.jmx.DatabaseInfo
 
setCacheSizeMax(int) - Method in interface org.h2.jmx.DatabaseInfoMBean
Change the maximum size.
setCanReuse(boolean) - Method in class org.h2.command.Command
 
setCaseSensitiveColumnNames(boolean) - Method in class org.h2.tools.Csv
Override the case sensitive column names setting.
setCatalog(String) - Method in class org.h2.jdbc.JdbcConnection
Set the default catalog name.
setChanged(boolean) - Method in class org.h2.util.CacheObject
 
setCharacterStream() - Method in class org.h2.jdbc.JdbcSQLXML
 
setCharacterStream(int, Reader) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter as a character stream.
setCharacterStream(int, Reader, int) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter as a character stream.
setCharacterStream(int, Reader, long) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter as a character stream.
setCharacterStream(long) - Method in class org.h2.jdbc.JdbcClob
Get a writer to update the Clob.
setCharacterStream(String, Reader) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter as a character stream.
setCharacterStream(String, Reader, int) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter as a character stream.
setCharacterStream(String, Reader, long) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter as a character stream.
setCharacterStreamImpl() - Method in class org.h2.jdbc.JdbcLob
Returns the writer.
setCharset(Charset) - Method in class org.h2.command.dml.RunScriptCommand
 
setCharset(Charset) - Method in class org.h2.command.dml.ScriptCommand
 
setCheckedWriting(boolean) - Method in class org.h2.store.FileStore
 
setCheckExisting(boolean) - Method in class org.h2.command.ddl.AlterDomainAddConstraint
 
setCheckExisting(boolean) - Method in class org.h2.command.ddl.AlterTableAddConstraint
 
setCheckExisting(boolean) - Method in class org.h2.command.dml.AlterTableSet
 
setCheckExpression(Expression) - Method in class org.h2.command.ddl.AlterDomainAddConstraint
 
setCheckExpression(Expression) - Method in class org.h2.command.ddl.AlterTableAddConstraint
 
setCheckForeignKeyConstraints(SessionLocal, boolean, boolean) - Method in class org.h2.table.Table
Enable or disable foreign key constraint checking for this table.
setChild(int, Page<K, V>) - Method in class org.h2.mvstore.Page.Leaf
 
setChild(int, Page<K, V>) - Method in class org.h2.mvstore.Page.NonLeaf
 
setChild(int, Page<K, V>) - Method in class org.h2.mvstore.Page
Replace the child page.
setCipher(String) - Method in class org.h2.command.dml.ScriptBase
 
setClassName(String) - Method in class org.h2.security.auth.UserToRolesMapperConfig
 
setClauseList - Variable in class org.h2.command.dml.MergeUsing.WhenMatchedThenUpdate
 
setClauseList - Variable in class org.h2.command.dml.Update
 
SetClauseList - Class in org.h2.command.dml
Set clause list.
SetClauseList(Table) - Constructor for class org.h2.command.dml.SetClauseList
 
SetClauseList.RowExpression - Class in org.h2.command.dml
 
SetClauseList.SetMultiple - Class in org.h2.command.dml
 
SetClauseList.SetSimple - Class in org.h2.command.dml
 
SetClauseList.UpdateAction - Class in org.h2.command.dml
 
setClientInfo(String, String) - Method in class org.h2.jdbc.JdbcConnection
Set a client property.
setClientInfo(Properties) - Method in class org.h2.jdbc.JdbcConnection
Set the client properties.
setClob(int, Reader) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter as a Clob.
setClob(int, Reader, long) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter as a Clob.
setClob(int, Clob) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter as a Clob.
setClob(String, Reader) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter as a character stream.
setClob(String, Reader, long) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter as a Clob.
setClob(String, Clob) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter as a Clob.
setClobOutputStreamImpl() - Method in class org.h2.jdbc.JdbcLob
Returns the writer stream.
setCloseDelay(int) - Method in class org.h2.engine.Database
 
setCluster(String) - Method in class org.h2.engine.Database
 
setColumn(boolean) - Method in class org.h2.command.ddl.SetComment
 
setColumn(Column) - Method in class org.h2.expression.Parameter
 
setColumn(Column, Boolean) - Method in class org.h2.command.ddl.AlterSequence
Set the column
setColumnName(String) - Method in class org.h2.command.ddl.SetComment
 
setColumnName(String) - Method in class org.h2.constraint.DomainColumnResolver
 
setColumnNames(String[]) - Method in class org.h2.command.ddl.CreateView
 
setColumns(int[], ArrayList<String>, ArrayList<String>) - Static method in class org.h2.fulltext.FullText
Set the column indices of a set of keys.
setColumns(ArrayList<Column>) - Method in class org.h2.expression.function.table.ArrayTableFunction
 
setColumns(Column[]) - Method in class org.h2.command.dml.Insert
 
setColumns(Column[]) - Method in class org.h2.command.dml.Merge
 
setColumns(Column[]) - Method in class org.h2.table.Table
 
setColumns(IndexColumn[]) - Method in class org.h2.constraint.ConstraintReferential
 
setColumns(IndexColumn[]) - Method in class org.h2.constraint.ConstraintUnique
 
setColumnsToRemove(ArrayList<Column>) - Method in class org.h2.command.ddl.AlterTableAlterColumn
 
setColumnType(String) - Method in class org.h2.bnf.context.DbContextRule
 
setCommand(Command) - Method in class org.h2.command.dml.Insert
 
setCommand(Command) - Method in class org.h2.command.dml.Merge
 
setCommand(Command) - Method in class org.h2.command.Prepared
Set the command.
setCommand(Prepared) - Method in class org.h2.command.dml.Explain
 
setCommandHistoryAllowed(boolean) - Method in class org.h2.server.web.WebServer
 
setComment(String) - Method in class org.h2.command.ddl.AlterDomainAddConstraint
 
setComment(String) - Method in class org.h2.command.ddl.AlterTableAddConstraint
 
setComment(String) - Method in class org.h2.command.ddl.CreateDomain
 
setComment(String) - Method in class org.h2.command.ddl.CreateIndex
 
setComment(String) - Method in class org.h2.command.ddl.CreateLinkedTable
 
setComment(String) - Method in class org.h2.command.ddl.CreateSynonym
 
setComment(String) - Method in class org.h2.command.ddl.CreateTable
 
setComment(String) - Method in class org.h2.command.ddl.CreateUser
 
setComment(String) - Method in class org.h2.command.ddl.CreateView
 
setComment(String) - Method in class org.h2.engine.DbObject
Change the comment of this object.
setComment(String) - Method in class org.h2.table.Column
 
SetComment - Class in org.h2.command.ddl
This class represents the statement COMMENT
SetComment(SessionLocal) - Constructor for class org.h2.command.ddl.SetComment
 
setCommentExpression(Expression) - Method in class org.h2.command.ddl.SetComment
 
setCommentText(String) - Method in class org.h2.engine.Comment
Set the comment text.
setCommitOrRollbackDisabled(boolean) - Method in class org.h2.engine.SessionLocal
 
setCompactMode(int) - Method in class org.h2.engine.Database
 
setCompareMode(CompareMode) - Method in class org.h2.engine.Database
 
setComplete() - Method in class org.h2.mvstore.Page.IncompleteNonLeaf
 
setComplete() - Method in class org.h2.mvstore.Page
Called when done with copying page.
setCompressionAlgorithm(String) - Method in class org.h2.command.dml.ScriptBase
 
setCondition(Expression) - Method in class org.h2.command.dml.FilteredDataChangeStatement
 
setConnection(Connection) - Method in class org.h2.server.web.WebSession
 
setConstantName(String) - Method in class org.h2.command.ddl.CreateConstant
 
setConstantName(String) - Method in class org.h2.command.ddl.DropConstant
 
setConstraintName(String) - Method in class org.h2.command.ddl.AlterDomainAddConstraint
 
setConstraintName(String) - Method in class org.h2.command.ddl.AlterDomainDropConstraint
 
setConstraintName(String) - Method in class org.h2.command.ddl.AlterDomainRenameConstraint
 
setConstraintName(String) - Method in class org.h2.command.ddl.AlterTableAddConstraint
 
setConstraintName(String) - Method in class org.h2.command.ddl.AlterTableDropConstraint
 
setConstraintName(String) - Method in class org.h2.command.ddl.AlterTableRenameConstraint
 
setCreateMissingRoles(boolean) - Method in class org.h2.security.auth.DefaultAuthenticator
Sets the flag that define behavior in case external roles not found in the database.
setCreateMissingRoles(boolean) - Method in class org.h2.security.auth.H2AuthConfig
When set create roles not found in the database.
setCsvDelimiterEscape(Csv, String, String, String) - Static method in class org.h2.expression.function.CSVWriteFunction
Sets delimiter options.
setCteCleanups(List<TableView>) - Method in class org.h2.command.Prepared
Set the temporary views created for CTE's.
setCurrentCommand(Command) - Method in class org.h2.engine.SessionLocal
Set the current command of this session.
setCurrentGroupExprData(Expression, Object) - Method in class org.h2.command.query.SelectGroups
Set the group-by data for the current group and the passed in expression.
setCurrentRowNumber(long) - Method in class org.h2.command.Prepared
Set the current row number.
setCurrentSchema(Schema) - Method in class org.h2.engine.SessionLocal
 
setCurrentSchemaName(String) - Method in class org.h2.engine.Session
Set current schema.
setCurrentSchemaName(String) - Method in class org.h2.engine.SessionLocal
 
setCurrentSchemaName(String) - Method in class org.h2.engine.SessionRemote
 
setCursorName(String) - Method in class org.h2.jdbc.JdbcStatement
Sets the name of the cursor.
setCycle(Sequence.Cycle) - Method in class org.h2.command.ddl.SequenceOptions
Sets cycle option.
setData(boolean) - Method in class org.h2.command.dml.ScriptCommand
 
setDatabaseName(String) - Method in class org.h2.tools.Recover
 
setDataType(TypeInfo) - Method in class org.h2.command.ddl.CreateDomain
 
setDataType(TypeInfo) - Method in class org.h2.command.ddl.SequenceOptions
 
setDataType(TypeInfo) - Method in class org.h2.schema.Domain
 
setDate(int, Date) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter.
setDate(int, Date, Calendar) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the date using a specified time zone.
setDate(String, Date) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter.
setDate(String, Date, Calendar) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the date using a specified time zone.
setDay(int) - Method in class org.h2.mode.ToDateParser
 
setDayOfYear(int) - Method in class org.h2.mode.ToDateParser
 
setDecision(MVMap.Decision) - Method in class org.h2.mvstore.tx.TxDecisionMaker
Record for future references specified value as a decision that has been made.
setDefaultConnection(Connection) - Static method in class org.h2.Driver
INTERNAL Sets, on a per-thread basis, the default-connection for user-defined functions.
setDefaultExpression(SessionLocal, Expression) - Method in class org.h2.schema.Domain
 
setDefaultExpression(SessionLocal, Expression) - Method in class org.h2.table.Column
 
setDefaultExpression(SessionLocal, Expression) - Method in interface org.h2.table.ColumnTemplate
Set the default expression.
setDefaultExpression(Expression) - Method in class org.h2.command.ddl.AlterTableAlterColumn
Set default or on update expression.
setDefaultExpression(Expression) - Method in class org.h2.command.ddl.CreateDomain
 
setDefaultNullOrdering(DefaultNullOrdering) - Method in class org.h2.engine.Database
 
setDefaultOnNull(boolean) - Method in class org.h2.table.Column
 
setDefaultTableType(int) - Method in class org.h2.engine.Database
 
setDeleteAction(ConstraintActionType) - Method in class org.h2.command.ddl.AlterTableAddConstraint
 
setDeleteAction(ConstraintActionType) - Method in class org.h2.constraint.ConstraintReferential
Set the action to apply (restrict, cascade,...) on a delete.
setDeleteFiles(boolean) - Method in class org.h2.command.ddl.DropDatabase
 
setDeleteFilesOnDisconnect(boolean) - Method in class org.h2.engine.Database
 
setDerivedColumns(ArrayList<String>) - Method in class org.h2.table.TableFilter
Set derived column list.
setDescription(String) - Method in class org.h2.jdbcx.JdbcDataSource
Set the description.
setDeterministic(boolean) - Method in class org.h2.command.ddl.CreateFunctionAlias
 
setDeterministic(boolean) - Method in class org.h2.schema.FunctionAlias
 
setDistinct() - Method in class org.h2.command.query.Select
Set the distinct flag.
setDistinct() - Method in class org.h2.result.LocalResult
Remove duplicate rows.
setDistinct(int[]) - Method in class org.h2.result.LocalResult
Remove rows with duplicates in columns with specified indexes.
setDistinct(Expression[]) - Method in class org.h2.command.query.Select
Set the DISTINCT ON expressions.
setDistinctIfPossible() - Method in class org.h2.command.query.Query
Set the distinct flag only if it is possible, may be used as a possible optimization only.
setDomain(Domain) - Method in class org.h2.schema.Domain
 
setDomain(Domain) - Method in class org.h2.table.Column
 
setDomain(Domain) - Method in interface org.h2.table.ColumnTemplate
 
setDomainName(String) - Method in class org.h2.command.ddl.AlterDomain
 
setDouble(int, double) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter.
setDouble(String, double) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter.
setDriver(String) - Method in class org.h2.command.ddl.CreateLinkedTable
 
setDrop(boolean) - Method in class org.h2.command.dml.ScriptCommand
 
setDropAction(ConstraintActionType) - Method in class org.h2.command.ddl.AlterTableDropConstraint
 
setDropAction(ConstraintActionType) - Method in class org.h2.command.ddl.DropDomain
 
setDropAction(ConstraintActionType) - Method in class org.h2.command.ddl.DropSchema
 
setDropAction(ConstraintActionType) - Method in class org.h2.command.ddl.DropTable
 
setDropAction(ConstraintActionType) - Method in class org.h2.command.ddl.DropView
 
setDropAllObjects(boolean) - Method in class org.h2.command.ddl.DropDatabase
 
setEmitUpdates(boolean) - Method in class org.h2.command.ddl.CreateLinkedTable
 
setErr(PrintStream) - Method in class org.h2.tools.Shell
Sets the standard error stream.
setError(int) - Method in class org.h2.server.web.PageParser
 
setEscapeCharacter(char) - Method in class org.h2.tools.Csv
Set the escape character.
setEscapeProcessing(boolean) - Method in class org.h2.jdbc.JdbcStatement
Enables or disables processing or JDBC escape syntax.
setEvaluatable(boolean) - Method in class org.h2.table.TableFilter
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.command.query.Query
Change the evaluatable flag.
setEvaluatable(TableFilter, boolean) - Method in class org.h2.command.query.Select
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.command.query.SelectUnion
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.command.query.TableValueConstructor
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.aggregate.AbstractAggregate
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.aggregate.Aggregate
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.Alias
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.analysis.DataAnalysisOperation
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.analysis.Window
Tell the expression columns whether the table filter can return values now.
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.analysis.WindowFunction
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.ArrayConstructorByQuery
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.condition.BetweenPredicate
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.condition.CompareLike
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.condition.Comparison
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.condition.ConditionAndOr
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.condition.ConditionAndOrN
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.condition.ConditionIn
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.condition.ConditionInConstantSet
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.condition.ConditionInParameter
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.condition.ConditionInQuery
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.condition.ConditionLocalAndGlobal
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.condition.ConditionNot
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.condition.IsJsonPredicate
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.condition.PredicateWithSubquery
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.condition.SimplePredicate
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.Expression
Tell the expression columns whether the table filter can return values now.
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.ExpressionColumn
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.ExpressionList
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.function.Function0_1
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.function.JavaFunction
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.Operation0
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.Operation1_2
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.Operation1
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.Operation2
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.OperationN
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.SimpleCase
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.Subquery
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.expression.Wildcard
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.table.Plan
 
setEvaluatable(TableFilter, boolean) - Method in class org.h2.table.TableFilter
Update the filter and join conditions of this and all joined tables with the information that the given table filter and all nested filter can now return rows or not.
setEvaluatableRecursive(TableFilter) - Method in class org.h2.command.query.Select
 
setEventListener(DatabaseEventListener) - Method in class org.h2.engine.Database
 
setEventListenerClass(String) - Method in class org.h2.engine.Database
 
setExceptColumns(ArrayList<ExpressionColumn>) - Method in class org.h2.expression.Wildcard
 
setExclusiveSession(SessionLocal, boolean) - Method in class org.h2.engine.Database
Set the session that can exclusively access the database.
setExecuteCommand(boolean) - Method in class org.h2.command.dml.Explain
 
setExecutingStatement(Statement) - Method in class org.h2.jdbc.JdbcConnection
INTERNAL
setExecutingStatement(CommandInterface) - Method in class org.h2.jdbc.JdbcStatement
INTERNAL.
setExplicitTable() - Method in class org.h2.command.query.Select
Convert this SELECT to an explicit table (TABLE tableName).
setExpression(int, Expression) - Method in class org.h2.command.dml.ExecuteProcedure
Set the expression at the given index.
setExpression(SessionLocal, Expression) - Method in class org.h2.constraint.ConstraintDomain
Set the expression.
setExpression(Expression) - Method in class org.h2.command.ddl.AlterDomainExpressions
 
setExpression(Expression) - Method in class org.h2.command.ddl.CreateConstant
 
setExpression(Expression) - Method in class org.h2.command.dml.Call
 
setExpression(Expression) - Method in class org.h2.command.dml.Set
 
setExpression(Expression) - Method in class org.h2.constraint.ConstraintCheck
 
setExpressionIndex(int) - Method in class org.h2.expression.analysis.WindowFrameBound
Sets the index of preserved expression.
setExpressions(ArrayList<Expression>) - Method in class org.h2.command.query.Select
 
setExternalNames(String) - Method in class org.h2.server.web.WebServer
 
setExtraArguments(Object) - Method in class org.h2.expression.aggregate.Aggregate
Sets the additional arguments.
setFetch(Expression) - Method in class org.h2.command.dml.FilteredDataChangeStatement
 
setFetch(Expression) - Method in class org.h2.command.query.Query
 
setFetchDirection(int) - Method in class org.h2.jdbc.JdbcResultSet
[Not supported] Sets (changes) the fetch direction for this result set.
setFetchDirection(int) - Method in class org.h2.jdbc.JdbcStatement
Sets the fetch direction.
setFetchDirection(int) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
setFetchPercent(boolean) - Method in class org.h2.command.query.Query
 
setFetchPercent(boolean) - Method in class org.h2.result.LocalResult
 
setFetchSize(int) - Method in class org.h2.command.ddl.CreateLinkedTable
Specify the number of rows fetched by the linked table command
setFetchSize(int) - Method in class org.h2.jdbc.JdbcResultSet
Sets the number of rows suggested to read in one step.
setFetchSize(int) - Method in class org.h2.jdbc.JdbcStatement
Sets the number of rows suggested to read in one step.
setFetchSize(int) - Method in class org.h2.result.LazyResult
 
setFetchSize(int) - Method in class org.h2.result.LocalResult
 
setFetchSize(int) - Method in interface org.h2.result.ResultInterface
Set the fetch size for this result set.
setFetchSize(int) - Method in class org.h2.result.ResultRemote
 
setFetchSize(int) - Method in class org.h2.result.ResultWithPaddedStrings
 
setFetchSize(int) - Method in class org.h2.result.SimpleResult
 
setFetchSize(int) - Method in class org.h2.table.TableLink
Specify the number of rows fetched by the linked table command
setFetchSize(int) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
setFieldDelimiter(char) - Method in class org.h2.tools.Csv
Set the field delimiter.
setFieldSeparatorRead(char) - Method in class org.h2.tools.Csv
Override the field separator for reading.
setFieldSeparatorWrite(String) - Method in class org.h2.tools.Csv
Override the field separator for writing.
setFileEncryptionKey(byte[]) - Method in class org.h2.engine.ConnectionInfo
 
setFileLength(long) - Method in class org.h2.store.fs.niomapped.FileNioMapped
 
setFileName(String) - Method in class org.h2.message.TraceSystem
Set the trace file name.
setFileName(Expression) - Method in class org.h2.command.dml.BackupCommand
 
setFileNameExpr(Expression) - Method in class org.h2.command.dml.ScriptBase
 
setFilePasswordHash(byte[]) - Method in class org.h2.engine.ConnectionInfo
Set the file password hash.
setFilter(String) - Method in class org.h2.expression.aggregate.ListaggArguments
Sets the custom LISTAGG truncation filter.
setFilterCondition(Expression) - Method in class org.h2.expression.aggregate.AbstractAggregate
Sets the FILTER condition.
setFlags(int) - Method in class org.h2.expression.aggregate.Aggregate
 
setFlags(int) - Method in interface org.h2.expression.ExpressionWithFlags
Set the flags for this expression.
setFlags(int) - Method in class org.h2.expression.function.JsonConstructorFunction
 
setFloat(int, float) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter.
setFloat(String, float) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter.
setForce(boolean) - Method in class org.h2.command.ddl.CreateAggregate
 
setForce(boolean) - Method in class org.h2.command.ddl.CreateFunctionAlias
 
setForce(boolean) - Method in class org.h2.command.ddl.CreateLinkedTable
 
setForce(boolean) - Method in class org.h2.command.ddl.CreateTrigger
 
setForce(boolean) - Method in class org.h2.command.ddl.CreateView
 
setForcedType(TypeInfo) - Method in class org.h2.expression.BinaryOperation
Sets a forced data type of a datetime minus datetime operation.
setForDataChangeDeltaTable() - Method in class org.h2.result.LocalResult
Sets value collection mode for data change delta tables.
setForUpdate(boolean) - Method in class org.h2.command.query.Query
Set the 'for update' flag.
setForUpdate(boolean) - Method in class org.h2.command.query.Select
 
setForUpdate(boolean) - Method in class org.h2.command.query.SelectUnion
 
setForUpdate(boolean) - Method in class org.h2.command.query.TableValueConstructor
 
setFrom1X() - Method in class org.h2.command.dml.RunScriptCommand
Enables quirks for parsing scripts from H2 1.*.*.
setFromLast(boolean) - Method in class org.h2.expression.analysis.WindowFunction
Sets FROM FIRST or FROM LAST clause value.
setFromTableFilter(TableFilter) - Method in class org.h2.command.dml.Update
 
setFullCondition(Expression) - Method in class org.h2.table.TableFilter
 
SetFunction - Class in org.h2.expression.function
A SET function.
SetFunction(Expression, Expression) - Constructor for class org.h2.expression.function.SetFunction
 
setGeneratedExpression(Expression) - Method in class org.h2.table.Column
Set the default value in the form of a generated expression of other columns.
setGlobalTemporary(boolean) - Method in class org.h2.command.ddl.CreateLinkedTable
 
setGlobalTemporary(boolean) - Method in class org.h2.command.ddl.CreateTable
 
setGlobalTemporary(boolean) - Method in class org.h2.table.TableLink
 
setGranteeName(String) - Method in class org.h2.command.ddl.GrantRevoke
 
setGroupBy(ArrayList<Expression>) - Method in class org.h2.command.query.Select
 
setGroupData(SelectGroups) - Method in class org.h2.command.query.Select
 
setGroupQuery() - Method in class org.h2.command.query.Select
Set when SELECT statement contains (non-window) aggregate functions, GROUP BY clause or HAVING clause.
setHash(boolean) - Method in class org.h2.command.ddl.CreateIndex
 
setHash(Expression) - Method in class org.h2.command.ddl.AlterUser
 
setHash(Expression) - Method in class org.h2.command.ddl.CreateUser
 
setHaving(Expression) - Method in class org.h2.command.query.Select
 
setHidden(boolean) - Method in class org.h2.command.ddl.AlterTableRename
 
setHidden(boolean) - Method in class org.h2.command.ddl.CreateTable
 
setHidden(boolean) - Method in class org.h2.table.Table
 
setHoldability(int) - Method in class org.h2.jdbc.JdbcConnection
Changes the current result set holdability.
setHour(int) - Method in class org.h2.mode.ToDateParser
 
setHour12(int) - Method in class org.h2.mode.ToDateParser
 
setIdentityOptions(SequenceOptions, boolean) - Method in class org.h2.table.Column
Set the identity options of this column.
setIfDomainExists(boolean) - Method in class org.h2.command.ddl.AlterDomain
 
setIfExists(boolean) - Method in class org.h2.command.ddl.AlterIndexRename
 
setIfExists(boolean) - Method in class org.h2.command.ddl.AlterSequence
 
setIfExists(boolean) - Method in class org.h2.command.ddl.AlterTableRenameColumn
 
setIfExists(boolean) - Method in class org.h2.command.ddl.AlterView
 
setIfExists(boolean) - Method in class org.h2.command.ddl.DropAggregate
 
setIfExists(boolean) - Method in class org.h2.command.ddl.DropConstant
 
setIfExists(boolean) - Method in class org.h2.command.ddl.DropFunctionAlias
 
setIfExists(boolean) - Method in class org.h2.command.ddl.DropIndex
 
setIfExists(boolean) - Method in class org.h2.command.ddl.DropRole
 
setIfExists(boolean) - Method in class org.h2.command.ddl.DropSchema
 
setIfExists(boolean) - Method in class org.h2.command.ddl.DropSequence
 
setIfExists(boolean) - Method in class org.h2.command.ddl.DropSynonym
 
setIfExists(boolean) - Method in class org.h2.command.ddl.DropTable
 
setIfExists(boolean) - Method in class org.h2.command.ddl.DropTrigger
 
setIfExists(boolean) - Method in class org.h2.command.ddl.DropUser
 
setIfExists(boolean) - Method in class org.h2.command.ddl.DropView
 
setIfNotExists(boolean) - Method in class org.h2.command.ddl.AlterTableAlterColumn
 
setIfNotExists(boolean) - Method in class org.h2.command.ddl.CreateAggregate
 
setIfNotExists(boolean) - Method in class org.h2.command.ddl.CreateConstant
 
setIfNotExists(boolean) - Method in class org.h2.command.ddl.CreateDomain
 
setIfNotExists(boolean) - Method in class org.h2.command.ddl.CreateFunctionAlias
 
setIfNotExists(boolean) - Method in class org.h2.command.ddl.CreateIndex
 
setIfNotExists(boolean) - Method in class org.h2.command.ddl.CreateLinkedTable
 
setIfNotExists(boolean) - Method in class org.h2.command.ddl.CreateRole
 
setIfNotExists(boolean) - Method in class org.h2.command.ddl.CreateSchema
 
setIfNotExists(boolean) - Method in class org.h2.command.ddl.CreateSequence
 
setIfNotExists(boolean) - Method in class org.h2.command.ddl.CreateSynonym
 
setIfNotExists(boolean) - Method in class org.h2.command.ddl.CreateTable
 
setIfNotExists(boolean) - Method in class org.h2.command.ddl.CreateTrigger
 
setIfNotExists(boolean) - Method in class org.h2.command.ddl.CreateUser
 
setIfNotExists(boolean) - Method in class org.h2.command.ddl.CreateView
 
setIfTableExists(boolean) - Method in class org.h2.command.ddl.AlterTable
 
setIfTableExists(boolean) - Method in class org.h2.command.ddl.AlterTableAlterColumn
 
setIfTableExists(boolean) - Method in class org.h2.command.ddl.CreateIndex
 
setIfTableExists(boolean) - Method in class org.h2.command.dml.AlterTableSet
 
setIgnore(boolean) - Method in class org.h2.command.dml.Insert
Sets MySQL-style INSERT IGNORE mode or PostgreSQL-style ON CONFLICT DO NOTHING.
setIgnoreCase(boolean) - Method in class org.h2.engine.Database
 
setIgnoreCatalogs(boolean) - Method in class org.h2.engine.Database
 
setIgnoreList(Connection, String) - Static method in class org.h2.fulltext.FullText
Change the ignore list.
setIgnoreList(FullTextSettings, String) - Static method in class org.h2.fulltext.FullText
 
setIgnoreNulls(boolean) - Method in class org.h2.expression.analysis.WindowFunction
Sets RESPECT NULLS or IGNORE NULLS clause value.
setIn(InputStream) - Method in class org.h2.tools.Shell
Redirects the standard input.
setIncrement(Expression) - Method in class org.h2.command.ddl.SequenceOptions
Sets increment value expression.
setIndex(Index) - Method in class org.h2.command.ddl.AlterTableAddConstraint
 
setIndex(Index) - Method in class org.h2.index.IndexCursor
 
setIndex(Index) - Method in class org.h2.table.PlanItem
 
setIndex(Index) - Method in class org.h2.table.TableFilter
 
setIndex(Index, boolean) - Method in class org.h2.constraint.ConstraintReferential
Set the index to use for this constraint.
setIndex(Index, boolean) - Method in class org.h2.constraint.ConstraintUnique
Set the index to use for this unique constraint.
setIndexColumns(IndexColumn[]) - Method in class org.h2.command.ddl.AlterTableAddConstraint
 
setIndexColumns(IndexColumn[]) - Method in class org.h2.command.ddl.CreateIndex
 
setIndexName(String) - Method in class org.h2.command.ddl.CreateIndex
 
setIndexName(String) - Method in class org.h2.command.ddl.DropIndex
 
setIndexOwner(Index) - Method in class org.h2.constraint.Constraint
This index is now the owner of the specified index.
setIndexOwner(Index) - Method in class org.h2.constraint.ConstraintCheck
 
setIndexOwner(Index) - Method in class org.h2.constraint.ConstraintDomain
 
setIndexOwner(Index) - Method in class org.h2.constraint.ConstraintReferential
 
setIndexOwner(Index) - Method in class org.h2.constraint.ConstraintUnique
 
setInitialized(boolean) - Method in class org.h2.fulltext.FullTextSettings
Set the initialized flag.
setInitialPowerOffCount(int) - Static method in class org.h2.engine.Database
 
setInitialRoot(Page<K, V>, long) - Method in class org.h2.mvstore.MVMap
Set the initial root.
setInReader(BufferedReader) - Method in class org.h2.tools.Shell
Redirects the standard input.
setInsertFromSelect(boolean) - Method in class org.h2.command.dml.Insert
 
setInsteadOf(boolean) - Method in class org.h2.command.ddl.CreateTrigger
 
setInsteadOf(boolean) - Method in class org.h2.schema.TriggerObject
 
setInt(int) - Method in class org.h2.command.dml.Set
 
setInt(int, int) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter.
setInt(String, int) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter.
setIntValue(int) - Method in class org.h2.engine.Setting
 
setIsolationLevel(IsolationLevel) - Method in class org.h2.engine.Session
Sets the isolation level.
setIsolationLevel(IsolationLevel) - Method in class org.h2.engine.SessionLocal
 
setIsolationLevel(IsolationLevel) - Method in class org.h2.engine.SessionRemote
 
setJavaClassMethod(String) - Method in class org.h2.command.ddl.CreateAggregate
 
setJavaClassMethod(String) - Method in class org.h2.command.ddl.CreateFunctionAlias
Set the qualified method name after removing whitespace.
setJavaObjectSerializerName(String) - Method in class org.h2.engine.Database
 
setJavaSystemCompiler(boolean) - Method in class org.h2.util.SourceCompiler
Enable or disable the usage of the Java system compiler.
setJoinPlan(PlanItem) - Method in class org.h2.table.PlanItem
 
setKey(byte[]) - Method in class org.h2.security.AES
 
setKey(byte[]) - Method in interface org.h2.security.BlockCipher
Set the encryption key used for encrypting and decrypting.
setKey(byte[]) - Method in class org.h2.security.Fog
 
setKey(byte[]) - Method in class org.h2.security.XTEA
 
setKey(int, K) - Method in class org.h2.mvstore.Page
Replace the key at an index in this page.
setKey(long) - Method in class org.h2.result.SearchRow
Set the unique key of the row.
setKey(String) - Method in class org.h2.server.web.WebServer
Sets the key for privileged connections.
setKey(PreparedStatement, int, Value[]) - Method in class org.h2.result.UpdatableRow
 
setKeys(Column[]) - Method in class org.h2.command.dml.Merge
 
setKeystore() - Static method in class org.h2.security.CipherFactory
 
setKeyType(DataType<? super K>) - Method in class org.h2.mvstore.MVMap.BasicBuilder
 
setKeyType(DataType<? super K>) - Method in interface org.h2.mvstore.MVMap.MapBuilder
 
setLargeMaxRows(long) - Method in class org.h2.jdbc.JdbcStatement
Gets the maximum number of rows for a ResultSet.
setLastChunk(Chunk) - Method in class org.h2.mvstore.MVStore
 
setLastIdentity(Value) - Method in class org.h2.engine.SessionLocal
 
setLastMatchedSchema(DbSchema) - Method in class org.h2.bnf.Sentence
Set the last matched schema if the last match was a schema, or null if it was not.
setLastMatchedTable(DbTableOrView) - Method in class org.h2.bnf.Sentence
Set the last matched table if the last match was a table.
setLazyQueryExecution(boolean) - Method in class org.h2.engine.SessionLocal
 
setLegacyAlgorithmsSilently(String) - Static method in class org.h2.security.CipherFactory
 
setLength(long) - Method in class org.h2.store.FileStore
Set the length of the file.
setLevel(int) - Method in class org.h2.message.Trace
Set the trace level of this component.
setLevelFile(int) - Method in class org.h2.message.TraceSystem
Set the file trace level.
setLevelSystemOut(int) - Method in class org.h2.message.TraceSystem
Set the trace level to use for System.out
setLimit(long) - Method in class org.h2.result.LazyResult
 
setLimit(long) - Method in class org.h2.result.LocalResult
Set the number of rows that this result will return at the maximum.
setLineCommentCharacter(char) - Method in class org.h2.tools.Csv
Set the line comment character.
setLineSeparator(String) - Method in class org.h2.tools.Csv
Set the line separator used for writing.
setLinks(HashMap<String, RuleHead>) - Method in class org.h2.bnf.context.DbContextRule
 
setLinks(HashMap<String, RuleHead>) - Method in interface org.h2.bnf.Rule
Update cross references.
setLinks(HashMap<String, RuleHead>) - Method in class org.h2.bnf.RuleElement
 
setLinks(HashMap<String, RuleHead>) - Method in class org.h2.bnf.RuleExtension
 
setLinks(HashMap<String, RuleHead>) - Method in class org.h2.bnf.RuleFixed
 
setLinks(HashMap<String, RuleHead>) - Method in class org.h2.bnf.RuleList
 
setLinks(HashMap<String, RuleHead>) - Method in class org.h2.bnf.RuleOptional
 
setLinks(HashMap<String, RuleHead>) - Method in class org.h2.bnf.RuleRepeat
 
setLiteralsChecked(boolean) - Method in class org.h2.command.Parser
 
setLob(PreparedStatement, int, ValueLob) - Static method in class org.h2.util.JdbcUtils
 
setLobBlockSize(long) - Method in class org.h2.command.dml.ScriptCommand
 
setLockMode(int) - Method in class org.h2.engine.Database
 
setLockTimeout(int) - Method in class org.h2.engine.SessionLocal
 
setLoginTimeout(int) - Method in class org.h2.jdbcx.JdbcConnectionPool
Sets the maximum time in seconds to wait for a free connection.
setLoginTimeout(int) - Method in class org.h2.jdbcx.JdbcDataSource
Set the login timeout in seconds, 0 meaning no timeout.
setLogWriter(PrintWriter) - Method in class org.h2.jdbcx.JdbcConnectionPool
INTERNAL
setLogWriter(PrintWriter) - Method in class org.h2.jdbcx.JdbcDataSource
Set the current log writer for this object.
setLong(int, long) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter.
setLong(String, long) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter.
setMainIndexColumn(int) - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
setMasks(int[]) - Method in class org.h2.table.PlanItem
 
setMasterUser(User) - Method in class org.h2.engine.Database
 
setMax(int, float) - Method in class org.h2.mvstore.db.SpatialKey
 
setMax(int, float) - Method in class org.h2.mvstore.rtree.DefaultSpatial
 
setMax(int, float) - Method in interface org.h2.mvstore.rtree.Spatial
Set the maximum value for the given dimension.
setMaxBlockSize(int) - Method in class org.h2.mvstore.StreamStore
Set the maximum block size.
setMaxConnections(int) - Method in class org.h2.jdbcx.JdbcConnectionPool
Sets the maximum number of connections to use from now on.
setMaxFieldSize(int) - Method in class org.h2.jdbc.JdbcStatement
Sets the maximum number of bytes for a result set column.
setMaxFileSize(int) - Method in class org.h2.message.TraceSystem
Set the maximum trace file size in bytes.
setMaxLengthInplaceLob(int) - Method in class org.h2.engine.Database
 
setMaxMemory(int) - Method in interface org.h2.util.Cache
Set the maximum memory to be used by this cache.
setMaxMemory(int) - Method in class org.h2.util.CacheLRU
 
setMaxMemory(int) - Method in class org.h2.util.CacheSecondLevel
 
setMaxMemory(int) - Method in class org.h2.util.CacheTQ
 
setMaxMemory(long) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
Set the maximum memory this cache should use.
setMaxMemory(long) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Set the maximum memory this cache should use.
setMaxMemoryRows(int) - Method in class org.h2.engine.Database
 
setMaxMemoryRows(int) - Method in class org.h2.result.LocalResult
Redefine count of maximum rows holds in memory for the result.
setMaxOperationMemory(int) - Method in class org.h2.engine.Database
 
setMaxQueryEntries(int) - Method in class org.h2.engine.QueryStatisticsData
 
setMaxRows(int) - Method in class org.h2.jdbc.JdbcStatement
Gets the maximum number of rows for a ResultSet.
setMaxSize(int) - Method in class org.h2.util.SmallLRUCache
 
setMaxTransactionId(int) - Method in class org.h2.mvstore.tx.TransactionStore
Set the maximum transaction id, after which ids are re-used.
setMaxValue(Expression) - Method in class org.h2.command.ddl.SequenceOptions
Sets max value expression.
setMayHaveStandardViews(boolean) - Method in class org.h2.bnf.context.DbContents
 
setMetaTableName(String) - Method in class org.h2.table.MetaTable
 
setMin(int, float) - Method in class org.h2.mvstore.db.SpatialKey
 
setMin(int, float) - Method in class org.h2.mvstore.rtree.DefaultSpatial
 
setMin(int, float) - Method in interface org.h2.mvstore.rtree.Spatial
Set the minimum value for the given dimension.
setMinBlockSize(int) - Method in class org.h2.mvstore.StreamStore
Set the minimum block size.
setMinute(int) - Method in class org.h2.mode.ToDateParser
 
setMinValue(Expression) - Method in class org.h2.command.ddl.SequenceOptions
Sets min value expression.
setMode(Mode) - Method in class org.h2.engine.Database
 
setModificationMetaId(long) - Method in class org.h2.command.Prepared
Set the meta data modification id of this statement.
setModified() - Method in class org.h2.engine.DbObject
Tell the object that is was modified.
setMonth(int) - Method in class org.h2.mode.ToDateParser
 
SetMultiple(SetClauseList.RowExpression, int, boolean, boolean) - Constructor for class org.h2.command.dml.SetClauseList.SetMultiple
 
setName(String) - Method in class org.h2.command.ddl.CreateAggregate
 
setName(String) - Method in class org.h2.command.ddl.CreateSynonym
 
setName(String) - Method in class org.h2.command.ddl.DropAggregate
 
setName(String) - Method in class org.h2.message.TraceSystem
 
setName(String) - Method in interface org.h2.message.TraceWriter
Set the name of the database or trace object.
setName(String) - Method in class org.h2.message.TraceWriterAdapter
 
setName(String) - Method in class org.h2.mvstore.tx.Transaction
 
setName(String) - Method in class org.h2.security.auth.PropertyConfig
 
setName(String) - Method in class org.h2.security.auth.RealmConfig
Sets realm's name.
setName(String) - Method in class org.h2.store.fs.mem.FileMemData
Set the file name.
setName(String) - Method in class org.h2.store.fs.niomem.FileNioMemData
Set the file name.
setNanos(int) - Method in class org.h2.mode.ToDateParser
 
setNCharacterStream(int, Reader) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter as a character stream.
setNCharacterStream(int, Reader, long) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter as a character stream.
setNCharacterStream(String, Reader) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter as a character stream.
setNCharacterStream(String, Reader, long) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter as a character stream.
setNClob(int, Reader) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter as a Clob.
setNClob(int, Reader, long) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter as a Clob.
setNClob(int, NClob) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter as a Clob.
setNClob(String, Reader) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter as a Clob.
setNClob(String, Reader, long) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter as a Clob.
setNClob(String, NClob) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter as a Clob.
setNestedIdentity(Object) - Method in class org.h2.security.auth.AuthenticationInfo
Method used by authenticators to hold information about authenticated user
setNestedJoin(TableFilter) - Method in class org.h2.table.TableFilter
Set a nested joined table.
setNestedJoinPlan(PlanItem) - Method in class org.h2.table.PlanItem
 
setNetworkConnectionInfo(NetworkConnectionInfo) - Method in class org.h2.engine.ConnectionInfo
Sets the network connection information.
setNetworkConnectionInfo(NetworkConnectionInfo) - Method in class org.h2.engine.Session
Sets the network connection information if possible.
setNetworkConnectionInfo(NetworkConnectionInfo) - Method in class org.h2.engine.SessionLocal
 
setNetworkConnectionInfo(NetworkConnectionInfo) - Method in class org.h2.engine.SessionRemote
 
setNetworkTimeout(Executor, int) - Method in class org.h2.jdbc.JdbcConnection
[Not supported]
setNeverLazy(boolean) - Method in class org.h2.command.query.Query
 
setNewColumn(Column) - Method in class org.h2.command.ddl.AlterTableAlterColumn
 
setNewColumnName(String) - Method in class org.h2.command.ddl.AlterTableRenameColumn
 
setNewConstraintName(String) - Method in class org.h2.command.ddl.AlterDomainRenameConstraint
 
setNewConstraintName(String) - Method in class org.h2.command.ddl.AlterTableRenameConstraint
 
setNewDomainName(String) - Method in class org.h2.command.ddl.AlterDomainRename
 
setNewName(String) - Method in class org.h2.command.ddl.AlterIndexRename
 
setNewName(String) - Method in class org.h2.command.ddl.AlterSchemaRename
 
setNewName(String) - Method in class org.h2.command.ddl.AlterUser
 
setNewTableName(String) - Method in class org.h2.command.ddl.AlterTableRename
 
setNextKey(long) - Method in class org.h2.mvstore.StreamStore
 
setNonKeywords(BitSet) - Method in class org.h2.engine.SessionLocal
Sets bit set of non-keywords.
setNoWait(boolean) - Method in class org.h2.command.ddl.CreateTrigger
 
setNoWait(boolean) - Method in class org.h2.schema.TriggerObject
 
setNString(int, String) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter.
setNString(String, String) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter.
setNull(int, int) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets a parameter to null.
setNull(int, int, String) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets a parameter to null.
setNull(String, int) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets a parameter to null.
setNull(String, int, String) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets a parameter to null.
setNullable(boolean) - Method in class org.h2.table.Column
 
setNullRow() - Method in class org.h2.table.TableFilter
Set the state of this and all nested tables to the NULL row.
setNullString(String) - Method in class org.h2.tools.Csv
Set the value that represents NULL.
setObject(int, Object) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter.
setObject(int, Object, int) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter.
setObject(int, Object, int, int) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter.
setObject(int, Object, SQLType) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter.
setObject(int, Object, SQLType, int) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter.
setObject(String, Object) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter.
setObject(String, Object, int) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter.
setObject(String, Object, int, int) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter.
setObject(String, Object, SQLType) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter.
setObject(String, Object, SQLType, int) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter.
setObjectName(String) - Method in class org.h2.command.ddl.SetComment
 
setObjectName(String) - Method in class org.h2.engine.DbObject
 
setObjectType(int) - Method in class org.h2.command.ddl.SetComment
 
setObjectWithType(int, Object, int) - Method in class org.h2.jdbc.JdbcPreparedStatement
 
setOffset(long) - Method in class org.h2.result.LocalResult
Set the offset of the first row to return.
setOffset(Expression) - Method in class org.h2.command.query.Query
 
setOldColumn(Column) - Method in class org.h2.command.ddl.AlterTableAlterColumn
 
setOldColumnName(String) - Method in class org.h2.command.ddl.AlterTableRenameColumn
 
setOldestVersionToKeep(long) - Method in class org.h2.mvstore.MVStore
 
setOldInformationSchema(boolean) - Method in class org.h2.engine.SessionLocal
Changes INFORMATION_SCHEMA content.
setOldName(String) - Method in class org.h2.command.ddl.AlterIndexRename
 
setOldSchema(Schema) - Method in class org.h2.command.ddl.AlterIndexRename
 
setOldSchema(Schema) - Method in class org.h2.command.ddl.AlterSchemaRename
 
setOnCommitDrop() - Method in class org.h2.command.ddl.CreateTable
This temporary table is dropped on commit.
setOnCommitDrop(boolean) - Method in class org.h2.table.Table
 
setOnCommitTruncate() - Method in class org.h2.command.ddl.CreateTable
This temporary table is truncated on commit.
setOnCommitTruncate(boolean) - Method in class org.h2.table.Table
 
setOnCondition(Expression) - Method in class org.h2.command.dml.MergeUsing
 
setOnDuplicateKeyInsert(Insert) - Method in class org.h2.command.dml.Update
 
setOnOverflowTruncate(boolean) - Method in class org.h2.expression.aggregate.ListaggArguments
Sets the LISTAGG overflow behavior.
setOnRollback(boolean) - Method in class org.h2.command.ddl.CreateTrigger
 
setOnRollback(boolean) - Method in class org.h2.schema.TriggerObject
 
setOnUpdateExpression(SessionLocal, Expression) - Method in class org.h2.schema.Domain
 
setOnUpdateExpression(SessionLocal, Expression) - Method in class org.h2.table.Column
 
setOnUpdateExpression(SessionLocal, Expression) - Method in interface org.h2.table.ColumnTemplate
Set the on update expression.
setOnUpdateExpression(Expression) - Method in class org.h2.command.ddl.CreateDomain
 
setOperationType(int) - Method in class org.h2.command.ddl.GrantRevoke
 
setOptimizeReuseResults(boolean) - Method in class org.h2.engine.Database
 
setOptions(String) - Method in class org.h2.compress.CompressDeflate
 
setOptions(String) - Method in class org.h2.compress.CompressLZF
 
setOptions(String) - Method in class org.h2.compress.CompressNo
 
setOptions(String) - Method in interface org.h2.compress.Compressor
Set the compression options.
setOptions(String) - Method in class org.h2.tools.Csv
INTERNAL.
setOptions(SequenceOptions) - Method in class org.h2.command.ddl.AlterSequence
 
setOptions(SequenceOptions) - Method in class org.h2.command.ddl.CreateSequence
 
setOrder(ArrayList<QueryOrderBy>) - Method in class org.h2.command.query.Query
Set the order by list.
setOrderByList(ArrayList<QueryOrderBy>) - Method in class org.h2.expression.aggregate.Aggregate
Set the order for ARRAY_AGG() or GROUP_CONCAT() aggregate.
setOrderedResult(HashMap<Integer, Value>) - Method in class org.h2.expression.analysis.PartitionData
Sets the ordered result.
setOriginalSchema(String) - Method in class org.h2.command.ddl.CreateLinkedTable
 
setOriginalTable(String) - Method in class org.h2.command.ddl.CreateLinkedTable
 
setOriginalURL(String) - Method in class org.h2.engine.ConnectionInfo
Set the original database URL.
setOrReplace(boolean) - Method in class org.h2.command.ddl.CreateSynonym
 
setOrReplace(boolean) - Method in class org.h2.command.ddl.CreateView
 
setOther(PreparedStatement, int, Value, JdbcConnection) - Static method in class org.h2.util.JdbcUtils
 
setOut(PrintStream) - Method in class org.h2.util.Tool
Sets the standard output stream.
setOverCondition(Window) - Method in class org.h2.expression.analysis.DataAnalysisOperation
Sets the OVER condition.
setOverridingSystem(Boolean) - Method in class org.h2.command.dml.Insert
 
setOwner(User) - Method in class org.h2.table.TableView
 
setPage(int, byte[], byte[], boolean) - Method in class org.h2.store.fs.mem.FileMemData
Set the page data.
setParameter(int, Value) - Method in class org.h2.jdbc.JdbcPreparedStatement
 
setParameter(ArrayList<? extends ParameterInterface>, int, int, int[]) - Method in class org.h2.server.pg.PgServerThread
 
setParameter(ArrayList<Parameter>, int, Value) - Static method in class org.h2.index.ViewIndex
 
setParameterList(ArrayList<Parameter>) - Method in class org.h2.command.Prepared
Set the parameter list of this statement.
setParameters() - Method in class org.h2.command.dml.ExecuteProcedure
 
setParameters(Command) - Method in class org.h2.server.TcpServerThread
 
setParentDomain(Domain) - Method in class org.h2.command.ddl.CreateDomain
 
setParsingCreateView(boolean) - Method in class org.h2.engine.SessionLocal
This method is called before and after parsing of view definition and may be called recursively.
setPassword(String) - Method in class org.h2.command.ddl.CreateLinkedTable
 
setPassword(String) - Method in class org.h2.jdbcx.JdbcDataSource
Set the current password.
setPassword(User, SessionLocal, Expression) - Static method in class org.h2.command.ddl.CreateUser
Set the password for the given user.
setPassword(Expression) - Method in class org.h2.command.ddl.AlterUser
 
setPassword(Expression) - Method in class org.h2.command.ddl.CreateUser
 
setPassword(Expression) - Method in class org.h2.command.dml.ScriptBase
 
setPasswordChars(char[]) - Method in class org.h2.jdbcx.JdbcDataSource
Set the current password in the form of a char array.
setPasswords(boolean) - Method in class org.h2.command.dml.ScriptCommand
 
setPersistData(boolean) - Method in class org.h2.command.ddl.CreateTable
 
setPersistedObjectId(int) - Method in class org.h2.command.Prepared
Set the persisted object id for this statement.
setPersistIndexes(boolean) - Method in class org.h2.command.ddl.CreateTable
 
setPersistUsers(boolean) - Method in class org.h2.security.auth.DefaultAuthenticator
If set to true saves users externals defined during the authentication.
setPlanItem(PlanItem) - Method in class org.h2.table.TableFilter
Set what plan item (index, cost, masks) to use.
setPoolable(boolean) - Method in class org.h2.jdbc.JdbcStatement
Requests that this object should be pooled or not.
setPort(int) - Method in class org.h2.server.web.WebServer
 
setPos(int) - Method in class org.h2.store.Data
Set the current read / write position.
setPos(int) - Method in class org.h2.util.CacheObject
 
setPowerOffCount(int) - Method in class org.h2.engine.Database
 
setPrecisionAndScale(TypeInfo, Object) - Method in class org.h2.value.ValueInterval
 
setPrepareAlways(boolean) - Method in class org.h2.command.Prepared
Set the prepare always flag.
setPrepared(Prepared) - Method in class org.h2.command.ddl.PrepareProcedure
 
setPreparedTransaction(String, boolean) - Method in class org.h2.engine.SessionLocal
Commit or roll back the given transaction.
setPreserveWhitespace(boolean) - Method in class org.h2.tools.Csv
Enable or disable preserving whitespace in unquoted text.
setPrimaryKey(boolean) - Method in class org.h2.command.ddl.CreateIndex
 
setPrimaryKey(boolean) - Method in class org.h2.table.Column
 
setPrimaryKey(AlterTableAddConstraint) - Method in class org.h2.command.ddl.CommandWithColumns
Set the primary key, but also check if a primary key with different columns is already defined.
setPrimaryKeyHash(boolean) - Method in class org.h2.command.ddl.AlterTableAddConstraint
 
setProcedure(Procedure) - Method in class org.h2.command.dml.ExecuteProcedure
 
setProcedureName(String) - Method in class org.h2.command.ddl.DeallocateProcedure
 
setProcedureName(String) - Method in class org.h2.command.ddl.PrepareProcedure
 
setProcessId(int) - Method in class org.h2.server.pg.PgServerThread
 
setProgress() - Method in class org.h2.command.Prepared
Notifies query progress via the DatabaseEventListener
setProgress(int) - Method in class org.h2.command.Command
 
setProgress(int, String, long, long) - Method in interface org.h2.api.DatabaseEventListener
This method is called for long running events, such as recovering, scanning a file or building an index.
setProgress(int, String, long, long) - Method in class org.h2.engine.Database
Set the progress of a long running operation.
setProperty(String, String) - Method in class org.h2.engine.ConnectionInfo
Overwrite a property.
setProperty(String, String) - Method in class org.h2.store.FileLock
Add or change a setting to the properties.
setQuadraticSplit(boolean) - Method in class org.h2.mvstore.rtree.MVRTreeMap
 
setQualify(Expression) - Method in class org.h2.command.query.Select
 
setQuery(String) - Method in class org.h2.bnf.Sentence
Set the query string.
setQuery(Query) - Method in class org.h2.command.ddl.CreateTable
 
setQuery(Query) - Method in class org.h2.command.dml.Insert
 
setQuery(Query) - Method in class org.h2.command.dml.Merge
 
setQueryStatistics(boolean) - Method in class org.h2.engine.Database
 
setQueryStatisticsMaxEntries(int) - Method in class org.h2.engine.Database
 
setQueryTimeout - Variable in class org.h2.jdbc.JdbcConnection
 
setQueryTimeout(int) - Method in class org.h2.engine.SessionLocal
 
setQueryTimeout(int) - Method in class org.h2.jdbc.JdbcConnection
INTERNAL
setQueryTimeout(int) - Method in class org.h2.jdbc.JdbcStatement
Sets the current query timeout in seconds.
setQueueSize(int) - Method in class org.h2.command.ddl.CreateTrigger
 
setQueueSize(int) - Method in class org.h2.schema.TriggerObject
 
setQuirksMode(boolean) - Method in class org.h2.command.dml.RunScriptCommand
Enables or disables the quirks mode.
setQuirksMode(boolean) - Method in class org.h2.engine.SessionLocal
Enables or disables the quirks mode.
setRandomAccessResult(boolean) - Method in class org.h2.command.query.Query
Whether results need to support random access.
setReadOnly() - Method in class org.h2.store.fs.disk.FilePathDisk
 
setReadOnly() - Method in class org.h2.store.fs.FilePath
Disable the ability to write.
setReadOnly() - Method in class org.h2.store.fs.FilePathWrapper
 
setReadOnly() - Method in class org.h2.store.fs.mem.FileMemData
Set the read-only flag.
setReadOnly() - Method in class org.h2.store.fs.mem.FilePathMem
 
setReadOnly() - Method in class org.h2.store.fs.niomem.FileNioMemData
Set the read-only flag.
setReadOnly() - Method in class org.h2.store.fs.niomem.FilePathNioMem
 
setReadOnly() - Method in class org.h2.store.fs.split.FilePathSplit
 
setReadOnly() - Method in class org.h2.store.fs.zip.FilePathZip
 
setReadOnly(boolean) - Method in class org.h2.command.ddl.CreateLinkedTable
 
setReadOnly(boolean) - Method in class org.h2.engine.Database
Switch the database to read-only mode.
setReadOnly(boolean) - Method in class org.h2.jdbc.JdbcConnection
According to the JDBC specs, this setting is only a hint to the database to enable optimizations - it does not cause writes to be prohibited.
setReadOnly(boolean) - Method in class org.h2.table.TableLink
 
setReadOnly(String) - Static method in class org.h2.store.fs.FileUtils
Disable the ability to write.
setRealms(List<RealmConfig>) - Method in class org.h2.security.auth.H2AuthConfig
Sets configuration of authentication realms.
setRecorder(Recorder) - Static method in class org.h2.store.fs.rec.FilePathRec
Set the recorder class.
setRecoveryReference(boolean) - Method in class org.h2.value.lob.LobDataDatabase
 
setRecursive(boolean) - Method in class org.h2.index.ViewIndex
 
setRecursiveResult(ResultInterface) - Method in class org.h2.table.TableView
 
setRef(int, Ref) - Method in class org.h2.jdbc.JdbcPreparedStatement
[Not supported] Sets the value of a column as a reference.
setRefColumns(IndexColumn[]) - Method in class org.h2.constraint.ConstraintReferential
 
setRefConstraint(ConstraintUnique) - Method in class org.h2.constraint.ConstraintReferential
Set the unique constraint of the referenced table to use for this constraint.
setReferentialIntegrity(boolean) - Method in class org.h2.engine.Database
 
setRefIndex(Index) - Method in class org.h2.command.ddl.AlterTableAddConstraint
 
setRefIndexColumns(IndexColumn[]) - Method in class org.h2.command.ddl.AlterTableAddConstraint
 
setRefTable(Table) - Method in class org.h2.constraint.ConstraintReferential
 
setRefTableName(Schema, String) - Method in class org.h2.command.ddl.AlterTableAddConstraint
Set the referenced table.
setRestart(boolean) - Method in class org.h2.command.ddl.TruncateTable
 
setRestartValue(Expression) - Method in class org.h2.command.ddl.SequenceOptions
Sets restart value expression, or ValueExpression.DEFAULT.
setResult(Class<T>) - Method in class org.h2.jdbc.JdbcSQLXML
 
setResult(Value) - Method in class org.h2.expression.analysis.PartitionData
Sets the result.
setRetentionTime(int) - Method in class org.h2.engine.Database
 
setRetentionTime(int) - Method in class org.h2.mvstore.MVStore
How long to retain old, persisted chunks, in milliseconds.
setReuseSpace(boolean) - Method in class org.h2.mvstore.MVStore
Whether empty space in the file should be re-used.
setRightMask(int) - Method in class org.h2.engine.Right
 
setRightsChecked(boolean) - Method in class org.h2.command.Parser
 
setRoleName(String) - Method in class org.h2.command.ddl.CreateRole
 
setRoleName(String) - Method in class org.h2.command.ddl.DropRole
 
setRootPos(long, long) - Method in class org.h2.mvstore.MVMap
Set the position of the root page.
setRow(DbException, long, String) - Method in class org.h2.command.Prepared
Set the SQL statement of the exception to the given row.
setRowBased(boolean) - Method in class org.h2.command.ddl.CreateTrigger
 
setRowBased(boolean) - Method in class org.h2.schema.TriggerObject
 
setRowFactory(RowFactory) - Method in class org.h2.engine.Database
 
setRowFactory(RowFactory) - Method in class org.h2.mvstore.db.RowDataType
 
setRowFactory(RowFactory) - Method in class org.h2.mvstore.db.ValueDataType
 
setRowId(boolean) - Method in class org.h2.table.Column
Set row identity flag.
setRowId(int, RowId) - Method in class org.h2.jdbc.JdbcPreparedStatement
[Not supported] Sets the value of a parameter as a row id.
setRowId(String, RowId) - Method in class org.h2.jdbc.JdbcCallableStatement
[Not supported] Sets the value of a parameter as a row id.
setRowKey(Row, long) - Static method in class org.h2.mvstore.db.MVPrimaryIndex
 
setRule(Rule) - Method in class org.h2.bnf.RuleHead
 
setSalt(Expression) - Method in class org.h2.command.ddl.AlterUser
 
setSalt(Expression) - Method in class org.h2.command.ddl.CreateUser
 
setSaltAndHash(byte[], byte[]) - Method in class org.h2.engine.User
Set the salt and hash of the password for this user.
setSaltAndHash(User, SessionLocal, Expression, Expression) - Static method in class org.h2.command.ddl.CreateUser
Set the salt and hash for the given user.
setSavepoint() - Method in class org.h2.engine.SessionLocal
Create a savepoint to allow rolling back to this state.
setSavepoint() - Method in class org.h2.jdbc.JdbcConnection
Creates a new unnamed savepoint.
setSavepoint() - Method in class org.h2.mvstore.tx.Transaction
Create a new savepoint.
setSavepoint(String) - Method in class org.h2.jdbc.JdbcConnection
Creates a new named savepoint.
setSavepointName(String) - Method in class org.h2.command.dml.TransactionCommand
 
setScale(BigDecimal, int) - Static method in class org.h2.value.ValueNumeric
Set the scale of a BigDecimal value.
setScanIndexes() - Method in class org.h2.table.TableFilter
Set all missing indexes to scan indexes recursively.
setSchema(String) - Method in class org.h2.jdbc.JdbcConnection
Sets the given schema name to access.
setSchema(Schema) - Method in class org.h2.command.ddl.GrantRevoke
Set the specified schema
setSchemaName(String) - Method in class org.h2.command.ddl.CreateSchema
 
setSchemaName(String) - Method in class org.h2.command.ddl.DropSchema
 
setSchemaName(String) - Method in class org.h2.command.ddl.SetComment
 
setSchemaNames(Set<String>) - Method in class org.h2.command.dml.ScriptCommand
 
setSchemaSearchPath(String[]) - Method in class org.h2.engine.SessionLocal
 
setSecond(int) - Method in class org.h2.mode.ToDateParser
 
setSelect(Query) - Method in class org.h2.command.ddl.CreateView
 
setSelectivity(int) - Method in class org.h2.table.Column
Set the new selectivity of a column.
setSelectivity(Expression) - Method in class org.h2.command.ddl.AlterTableAlterColumn
 
setSelectSQL(String) - Method in class org.h2.command.ddl.CreateView
 
setSeparator(String) - Method in class org.h2.expression.aggregate.ListaggArguments
Sets the custom LISTAGG separator.
setSequence(Sequence, boolean) - Method in class org.h2.table.Column
Set the sequence to generate the value.
setSequenceName(String) - Method in class org.h2.command.ddl.AlterSequence
 
setSequenceName(String) - Method in class org.h2.command.ddl.CreateSequence
 
setSequenceName(String) - Method in class org.h2.command.ddl.DropSequence
 
setServerKey(String) - Method in class org.h2.engine.ConnectionInfo
Switch to server mode, and set the server name and database key.
setSession(Session) - Method in class org.h2.value.Transfer
Set the session.
setSession(SessionLocal) - Method in class org.h2.command.Prepared
Set the session for this statement.
setSession(WebSession, Properties) - Method in class org.h2.server.web.WebApp
Set the web session and attributes.
SetSessionCharacteristics - Class in org.h2.command.dml
This class represents the statement SET SESSION CHARACTERISTICS
SetSessionCharacteristics(SessionLocal, IsolationLevel) - Constructor for class org.h2.command.dml.SetSessionCharacteristics
 
setSetClauseList(SetClauseList) - Method in class org.h2.command.dml.MergeUsing.WhenMatchedThenUpdate
 
setSetClauseList(SetClauseList) - Method in class org.h2.command.dml.Update
 
setSettings(boolean) - Method in class org.h2.command.dml.ScriptCommand
 
setSharedArgument(Value) - Method in class org.h2.expression.aggregate.AggregateDataCollecting
Sets value of a shared argument.
setShort(int, short) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter.
setShort(String, short) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter.
setShutdownHandler(ShutdownHandler) - Method in class org.h2.server.TcpServer
 
setShutdownHandler(ShutdownHandler) - Method in class org.h2.server.web.WebServer
 
setShutdownHandler(ShutdownHandler) - Method in class org.h2.tools.Server
INTERNAL
setShutdownServerOnDisconnect() - Method in class org.h2.server.web.WebSession
Shutdown the server when disconnecting.
setSimple(boolean) - Method in class org.h2.command.dml.ScriptCommand
 
SetSimple(Expression) - Constructor for class org.h2.command.dml.SetClauseList.SetSimple
 
setSkipRemarks(boolean) - Method in class org.h2.util.ScriptReader
If comments should be skipped completely by this reader.
setSortOrder(SortOrder) - Method in class org.h2.result.LocalResult
Sets sort order to be used by this result.
setSource(Object) - Method in exception org.h2.message.DbException
 
setSource(String) - Method in class org.h2.command.ddl.CreateFunctionAlias
 
setSource(String, String) - Method in class org.h2.util.SourceCompiler
Set the source code for the specified class.
setSourceTableFilter(TableFilter) - Method in class org.h2.command.dml.MergeUsing
 
setSpatial(boolean) - Method in class org.h2.command.ddl.CreateIndex
 
setSQL(String) - Method in interface org.h2.jdbc.JdbcException
INTERNAL
setSQL(String) - Method in exception org.h2.jdbc.JdbcSQLDataException
 
setSQL(String) - Method in exception org.h2.jdbc.JdbcSQLException
 
setSQL(String) - Method in exception org.h2.jdbc.JdbcSQLFeatureNotSupportedException
 
setSQL(String) - Method in exception org.h2.jdbc.JdbcSQLIntegrityConstraintViolationException
 
setSQL(String) - Method in exception org.h2.jdbc.JdbcSQLInvalidAuthorizationSpecException
 
setSQL(String) - Method in exception org.h2.jdbc.JdbcSQLNonTransientConnectionException
 
setSQL(String) - Method in exception org.h2.jdbc.JdbcSQLNonTransientException
 
setSQL(String) - Method in exception org.h2.jdbc.JdbcSQLSyntaxErrorException
 
setSQL(String) - Method in exception org.h2.jdbc.JdbcSQLTimeoutException
 
setSQL(String) - Method in exception org.h2.jdbc.JdbcSQLTransactionRollbackException
 
setSQL(String) - Method in exception org.h2.jdbc.JdbcSQLTransientException
 
setSQL(String, ArrayList<Token>) - Method in class org.h2.command.Prepared
Set the SQL statement.
setSQL(Prepared, int) - Method in class org.h2.command.Parser
 
setSQLXML(int, SQLXML) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter as a SQLXML.
setSQLXML(String, SQLXML) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter as a SQLXML object.
setSSL(boolean) - Method in class org.h2.server.web.WebServer
 
setSSL(boolean) - Method in class org.h2.value.Transfer
Enable or disable SSL.
setStart(int) - Method in class org.h2.command.Token
 
setStartValue(Expression) - Method in class org.h2.command.ddl.SequenceOptions
Sets start value expression.
setState(int) - Method in class org.h2.mvstore.db.MVInDoubtTransaction
 
setState(int) - Method in interface org.h2.store.InDoubtTransaction
Change the state of this transaction.
setStatementSnapshot(Snapshot<K, VersionedValue<V>>) - Method in class org.h2.mvstore.tx.TransactionMap
 
setStatus(int) - Method in class org.h2.mvstore.tx.Transaction
Changes transaction status to a specified value
setStorage(int) - Method in class org.h2.tools.Recover
 
setStoreVersion(int) - Method in class org.h2.mvstore.MVStore
Update the store version.
setString(int, String) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter.
setString(long, String) - Method in class org.h2.jdbc.JdbcClob
Fills the Clob.
setString(long, String, int, int) - Method in class org.h2.jdbc.JdbcClob
Fills the Clob.
setString(String) - Method in class org.h2.command.dml.Set
 
setString(String) - Method in class org.h2.jdbc.JdbcSQLXML
 
setString(String, String) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter.
setStringArray(String[]) - Method in class org.h2.command.dml.Set
 
setStringValue(String) - Method in class org.h2.engine.Setting
 
setSuppliedParameters(ArrayList<Parameter>) - Method in class org.h2.command.Parser
 
setSynonymFor(String) - Method in class org.h2.command.ddl.CreateSynonym
 
setSynonymForSchema(Schema) - Method in class org.h2.command.ddl.CreateSynonym
 
setSynonymName(String) - Method in class org.h2.command.ddl.DropSynonym
 
setSysOut(PrintStream) - Method in class org.h2.message.TraceSystem
Set the print stream to use instead of System.out.
setTable(Table) - Method in class org.h2.command.ddl.Analyze
 
setTable(Table) - Method in class org.h2.command.ddl.TruncateTable
 
setTable(Table) - Method in class org.h2.command.dml.Insert
 
setTable(Table) - Method in class org.h2.command.dml.Merge
 
setTable(Table, int) - Method in class org.h2.table.Column
Set the table and column id.
setTableEngine(String) - Method in class org.h2.command.ddl.CreateTable
 
setTableEngineParams(ArrayList<String>) - Method in class org.h2.command.ddl.CreateSchema
 
setTableEngineParams(ArrayList<String>) - Method in class org.h2.command.ddl.CreateTable
 
setTableEngineParams(ArrayList<String>) - Method in class org.h2.schema.Schema
Set table engine params of this schema.
setTableExpression(boolean) - Method in class org.h2.command.ddl.CreateView
 
setTableExpression(boolean) - Method in class org.h2.table.Table
 
setTableFilter(TableFilter) - Method in class org.h2.command.dml.FilteredDataChangeStatement
 
setTableFilter(TableFilter) - Method in class org.h2.constraint.ConstraintCheck
 
setTableFunction(TableFunction) - Method in class org.h2.command.dml.Call
 
setTableName(String) - Method in class org.h2.command.ddl.AlterTable
 
setTableName(String) - Method in class org.h2.command.ddl.AlterTableAlterColumn
 
setTableName(String) - Method in class org.h2.command.ddl.CreateIndex
 
setTableName(String) - Method in class org.h2.command.ddl.CreateLinkedTable
 
setTableName(String) - Method in class org.h2.command.ddl.CreateTable
 
setTableName(String) - Method in class org.h2.command.ddl.CreateTrigger
 
setTableName(String) - Method in class org.h2.command.dml.AlterTableSet
 
setTables(Collection<Table>) - Method in class org.h2.command.dml.ScriptCommand
 
setTargetTableFilter(TableFilter) - Method in class org.h2.command.dml.MergeUsing
 
setTcpQuickack(Socket, boolean) - Static method in class org.h2.util.Utils10
Sets the value of TCP_QUICKACK option.
setTemporary(boolean) - Method in class org.h2.command.ddl.CreateLinkedTable
 
setTemporary(boolean) - Method in class org.h2.command.ddl.CreateTable
 
setTemporary(boolean) - Method in class org.h2.engine.DbObject
Tell this object that it is temporary or not.
setTestEvery(int) - Method in class org.h2.store.RecoverTester
 
setThread(Thread) - Method in class org.h2.server.pg.PgServerThread
 
setThread(Thread) - Method in class org.h2.server.TcpServerThread
 
setThreadContextClassLoader(Thread) - Static method in class org.h2.Driver
INTERNAL
setThreadLocalSession() - Method in class org.h2.engine.Session
Sets this session as thread local session, if this session is a local session.
setThreadLocalSession() - Method in class org.h2.engine.SessionLocal
 
setThrottle(int) - Method in class org.h2.engine.SessionLocal
 
setTime(int, Time) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter.
setTime(int, Time, Calendar) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the time using a specified time zone.
setTime(String, Time) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the time using a specified time zone.
setTime(String, Time, Calendar) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the time using a specified time zone.
setTimeoutMillis(int) - Method in class org.h2.mvstore.tx.Transaction
Sets the new lock timeout.
setTimestamp(int, Timestamp) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the value of a parameter.
setTimestamp(int, Timestamp, Calendar) - Method in class org.h2.jdbc.JdbcPreparedStatement
Sets the timestamp using a specified time zone.
setTimestamp(String, Timestamp) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the value of a parameter.
setTimestamp(String, Timestamp, Calendar) - Method in class org.h2.jdbc.JdbcCallableStatement
Sets the timestamp using a specified time zone.
setTimeZone(TimeZoneProvider) - Method in class org.h2.engine.SessionLocal
Sets current time zone.
setTimeZone(TimeZoneProvider) - Method in class org.h2.mode.ToDateParser
 
setTimeZoneHour(int) - Method in class org.h2.mode.ToDateParser
 
setTimeZoneMinute(int) - Method in class org.h2.mode.ToDateParser
 
setting - Variable in class org.h2.fulltext.FullText.FullTextTrigger
 
Setting - Class in org.h2.engine
A persistent database setting.
Setting(Database, int, String) - Constructor for class org.h2.engine.Setting
 
SETTING - Static variable in class org.h2.engine.DbObject
This object is a setting.
SETTING - Static variable in class org.h2.message.Trace
The trace module id for settings.
settingRemove() - Method in class org.h2.server.web.WebApp
 
settings - Variable in class org.h2.command.dml.ScriptCommand
 
settings - Variable in class org.h2.engine.Database
 
settings - Variable in class org.h2.engine.SettingsBase
 
settings - Variable in class org.h2.server.web.PageParser
 
settings(SessionLocal, ArrayList<Row>) - Method in class org.h2.table.InformationSchemaTable
 
SETTINGS - Static variable in class org.h2.fulltext.FullTextSettings
The settings of open indexes.
SETTINGS - Static variable in class org.h2.table.InformationSchemaTable
 
SETTINGS - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
settingSave() - Method in class org.h2.server.web.WebApp
Save the current connection settings to the properties file.
SettingsBase - Class in org.h2.engine
The base class for settings.
SettingsBase(HashMap<String, String>) - Constructor for class org.h2.engine.SettingsBase
 
setTokenIndex(int) - Method in class org.h2.command.Parser
 
setTop(int) - Method in class org.h2.command.ddl.Analyze
 
setTopQuery(Query) - Method in class org.h2.table.TableView
 
setTrace(boolean) - Method in class org.h2.store.fs.rec.FilePathRec
 
setTrace(Trace, int, int) - Method in class org.h2.message.TraceObject
Set the options to use when writing trace message.
setTraceLevel(int) - Method in class org.h2.jmx.DatabaseInfo
 
setTraceLevel(int) - Method in interface org.h2.jmx.DatabaseInfoMBean
Set the trace level.
setTransactional(boolean) - Method in class org.h2.command.ddl.DefineCommand
 
setTransactionIsolation(int) - Method in class org.h2.jdbc.JdbcConnection
Changes the current transaction isolation level.
setTransactionName(String) - Method in class org.h2.command.dml.TransactionCommand
 
setTransactionTimeout(int) - Method in class org.h2.jdbcx.JdbcXAConnection
Set the transaction timeout.
setTriggerAction(String, String, boolean) - Method in class org.h2.schema.TriggerObject
 
setTriggerClassName(String) - Method in class org.h2.command.ddl.CreateTrigger
 
setTriggerClassName(String, boolean) - Method in class org.h2.schema.TriggerObject
Set the trigger class name and load the class if possible.
setTriggerName(String) - Method in class org.h2.command.ddl.CreateTrigger
 
setTriggerName(String) - Method in class org.h2.command.ddl.DropTrigger
 
setTriggerSource(String) - Method in class org.h2.command.ddl.CreateTrigger
 
setTriggerSource(String, boolean) - Method in class org.h2.schema.TriggerObject
Set the trigger source code and compile it if possible.
setTruncateLargeLength(boolean) - Method in class org.h2.engine.SessionLocal
Changes parsing mode of data types with too large length.
setType() - Method in class org.h2.expression.Subquery
 
setType(int) - Method in class org.h2.command.ddl.AlterTableAlterColumn
 
setType(int) - Method in class org.h2.command.ddl.AlterUser
 
setTypeMap(Map<String, Class<?>>) - Method in class org.h2.jdbc.JdbcConnection
[Partially supported] Sets the type map.
setTypeMask(int) - Method in class org.h2.command.ddl.CreateTrigger
 
setTypeMask(int) - Method in class org.h2.schema.TriggerObject
Set the trigger type.
setTypeName(String) - Method in class org.h2.command.ddl.CreateDomain
 
SetTypes - Class in org.h2.command.dml
The list of setting for a SET statement.
SetTypes() - Constructor for class org.h2.command.dml.SetTypes
 
setUndoKey(long) - Method in class org.h2.mvstore.tx.CommitDecisionMaker
 
setUnicodeStream(int, InputStream, int) - Method in class org.h2.jdbc.JdbcPreparedStatement
Deprecated.
since JDBC 2.0, use setCharacterStream
setUniqueColumnCount(int) - Method in class org.h2.command.ddl.CreateIndex
 
setUniqueId() - Method in class org.h2.store.FileLock
 
setUpdateAction(ConstraintActionType) - Method in class org.h2.command.ddl.AlterTableAddConstraint
 
setUpdateAction(ConstraintActionType) - Method in class org.h2.constraint.ConstraintReferential
Set the action to apply (restrict, cascade,...) on an update.
setupH2DataSource(JdbcDataSource, Properties) - Static method in class org.h2.util.OsgiDataSourceFactory
Applies common OSGi properties to a H2 data source.
setupQueryParameters(SessionLocal, SearchRow, SearchRow, SearchRow) - Method in class org.h2.index.ViewIndex
Set the query parameters.
setUrl(String) - Method in class org.h2.command.ddl.CreateLinkedTable
 
setUrl(String) - Method in class org.h2.jdbcx.JdbcDataSource
Set the current URL.
setURL(int, URL) - Method in class org.h2.jdbc.JdbcPreparedStatement
[Not supported]
setURL(String) - Method in class org.h2.jdbcx.JdbcDataSource
Set the current URL.
setURL(String, URL) - Method in class org.h2.jdbc.JdbcCallableStatement
[Not supported]
setUsed(boolean) - Method in class org.h2.table.TableFilter
 
setUser(String) - Method in class org.h2.command.ddl.CreateLinkedTable
 
setUser(String) - Method in class org.h2.jdbcx.JdbcDataSource
Set the current user name.
setUser(User) - Method in class org.h2.command.ddl.AlterUser
 
setUserName(String) - Method in class org.h2.command.ddl.CreateUser
 
setUserName(String) - Method in class org.h2.command.ddl.DropUser
 
setUserName(String) - Method in class org.h2.engine.ConnectionInfo
Overwrite the user name.
setUserPasswordHash(byte[]) - Method in class org.h2.engine.ConnectionInfo
Set the user password hash.
setUserPasswordHash(byte[]) - Method in class org.h2.engine.User
Set the user name password hash.
setUserToRolesMappers(List<UserToRolesMapperConfig>) - Method in class org.h2.security.auth.H2AuthConfig
Sets configuration of the mappers external users to database roles.
setUserToRolesMappers(UserToRolesMapper...) - Method in class org.h2.security.auth.DefaultAuthenticator
 
setUsingExpression(Expression) - Method in class org.h2.command.ddl.AlterTableAlterColumn
Set using expression.
setValidatorClass(String) - Method in class org.h2.security.auth.RealmConfig
Sets validator class name.
setValue(int, Value) - Method in class org.h2.result.DefaultRow
 
setValue(int, Value) - Method in class org.h2.result.SearchRow
Set the value for given column
setValue(int, Value) - Method in class org.h2.result.SimpleRowValue
 
setValue(int, Value) - Method in class org.h2.result.Sparse
 
setValue(int, V) - Method in class org.h2.mvstore.Page.Leaf
 
setValue(int, V) - Method in class org.h2.mvstore.Page.NonLeaf
 
setValue(int, V) - Method in class org.h2.mvstore.Page
Replace the value at an index in this page.
setValue(String) - Method in class org.h2.security.auth.PropertyConfig
 
setValue(Value) - Method in class org.h2.constraint.DomainColumnResolver
 
setValue(Value) - Method in class org.h2.expression.Parameter
 
setValue(Value) - Method in class org.h2.schema.Constant
 
setValue(Value, boolean) - Method in class org.h2.expression.Parameter
 
setValue(Value, boolean) - Method in interface org.h2.expression.ParameterInterface
Set the value of the parameter.
setValue(Value, boolean) - Method in class org.h2.expression.ParameterRemote
 
setValueInternal(int, V) - Method in class org.h2.mvstore.Page.Leaf
 
setValueType(DataType<? super V>) - Method in class org.h2.mvstore.MVMap.BasicBuilder
 
setValueType(DataType<? super V>) - Method in interface org.h2.mvstore.MVMap.MapBuilder
 
setVariable(String, Value) - Method in class org.h2.engine.SessionLocal
Set the value of the given variable for this session.
setVariableBinary(boolean) - Method in class org.h2.command.dml.RunScriptCommand
Changes parsing of a BINARY data type.
setVariableBinary(boolean) - Method in class org.h2.engine.SessionLocal
Changes parsing of a BINARY data type.
setVersion(boolean) - Method in class org.h2.command.dml.ScriptCommand
 
setVersion(int) - Method in class org.h2.value.Transfer
 
setVersion(long) - Method in class org.h2.mvstore.tx.VersionedBitSet
 
setVersionsToKeep(int) - Method in class org.h2.mvstore.MVStore
How many versions to retain for in-memory stores.
setView(TableView) - Method in class org.h2.command.ddl.AlterView
 
setViewName(String) - Method in class org.h2.command.ddl.CreateView
 
setViewName(String) - Method in class org.h2.command.ddl.DropView
 
setVisible(boolean) - Method in class org.h2.table.Column
 
setVolatile(boolean) - Method in class org.h2.mvstore.MVMap
Set the volatile flag of the map.
setWaitForLock(Table, Thread) - Method in class org.h2.engine.SessionLocal
Set the table this session is waiting for, and the thread that is waiting.
setWhen(SimpleCase.SimpleWhen) - Method in class org.h2.expression.SimpleCase.SimpleWhen
 
setWhere(Prepared, int, Row) - Method in class org.h2.constraint.ConstraintReferential
 
setWhitespaceChars(String) - Method in class org.h2.fulltext.FullTextSettings
 
setWhitespaceChars(Connection, String) - Static method in class org.h2.fulltext.FullText
Change the whitespace characters.
setWildcard() - Method in class org.h2.command.query.Select
Sets a wildcard expression as in "SELECT * FROM TEST".
setWindowExprData(DataAnalysisOperation, Value, PartitionData) - Method in class org.h2.command.query.SelectGroups
Set the window data for the specified expression.
setWindowQuery() - Method in class org.h2.command.query.Select
Called if this query contains window functions.
setWithColumns(boolean) - Method in class org.h2.command.dml.ScriptCommand
 
setWithNoData(boolean) - Method in class org.h2.command.ddl.CreateTable
 
setWithoutCount(boolean) - Method in class org.h2.expression.aggregate.ListaggArguments
Sets the LISTAGG count indication.
setWithTies(boolean) - Method in class org.h2.command.query.Query
 
setWithTies(SortOrder) - Method in class org.h2.result.LocalResult
Enables inclusion of tied rows to result and sets the sort order for tied rows.
setWriteColumnHeader(boolean) - Method in class org.h2.tools.Csv
Enable or disable writing the column header.
setWriteDelay(int) - Method in class org.h2.engine.Database
 
setWriteVersion(long) - Method in class org.h2.mvstore.MVMap
 
setWriteVersion(long) - Method in class org.h2.mvstore.MVStore
 
setYear(int) - Method in class org.h2.mode.ToDateParser
 
SHA256 - Class in org.h2.security
This class implements the cryptographic hash function SHA-256.
SHA256() - Constructor for class org.h2.security.SHA256
 
SHA3 - Class in org.h2.security
SHA-3 message digest family.
SHA3(String, int) - Constructor for class org.h2.security.SHA3
 
shared - Variable in class org.h2.expression.aggregate.AggregateDataCollecting
 
SHARED_LOCKS - Static variable in class org.h2.mvstore.db.MVTable
The tables names this thread has a shared lock on.
sharedLockCount - Variable in class org.h2.store.fs.mem.FileMemData
 
sharedLockCount - Variable in class org.h2.store.fs.niomem.FileNioMemData
 
shareLinkedConnections - Variable in class org.h2.engine.DbSettings
Database setting SHARE_LINKED_CONNECTIONS (default: true).
Shell - Class in org.h2.tools
Interactive command line tool to access a database using JDBC.
Shell() - Constructor for class org.h2.tools.Shell
 
shift(Value, long, boolean) - Static method in class org.h2.expression.function.BitFunction
 
SHIFT_MONTH - Static variable in class org.h2.util.DateTimeUtils
The offset of month bits in date values.
SHIFT_YEAR - Static variable in class org.h2.util.DateTimeUtils
The offset of year bits in date values.
SHORT_MONTHS - Static variable in class org.h2.expression.function.ToCharFunction
The month field (short form).
SHORT_WEEKDAYS - Static variable in class org.h2.expression.function.ToCharFunction
The weekday field (short form).
shortcutToContains - Variable in class org.h2.expression.condition.CompareLike
indicates that we can shortcut the comparison and use contains
shortcutToEndsWith - Variable in class org.h2.expression.condition.CompareLike
indicates that we can shortcut the comparison and use endsWith
shortcutToStartsWith - Variable in class org.h2.expression.condition.CompareLike
indicates that we can shortcut the comparison and use startsWith
ShortType() - Constructor for class org.h2.mvstore.type.ObjectDataType.ShortType
 
SHOULD_QUOTE - Static variable in class org.h2.server.pg.PgServerThread
 
shouldIgnoreRemoval(VersionedValue<?>) - Method in class org.h2.mvstore.tx.TransactionMap.UncommittedIterator
 
shouldIgnoreRemoval(VersionedValue<?>) - Method in class org.h2.mvstore.tx.TransactionMap.ValidationIterator
 
show() - Method in class org.h2.tools.Console
Overridden by GUIConsole to show a window
show() - Method in class org.h2.tools.GUIConsole
 
showCreateDatabase() - Method in class org.h2.tools.GUIConsole
 
showHelp() - Method in class org.h2.tools.Shell
 
showResults - Variable in class org.h2.tools.RunScript
 
showStatusWindow() - Method in class org.h2.tools.GUIConsole
 
showUsage() - Method in class org.h2.util.Tool
Print the usage of the tool.
showUsageAndThrowUnsupportedOption(String) - Method in class org.h2.util.Tool
Throw a SQLException saying this command line option is not supported.
shrinkFileIfPossible(int) - Method in class org.h2.mvstore.MVStore
Shrink the file if possible, and if at least a given percentage can be saved.
shuffleAll(TableFilter[]) - Method in class org.h2.command.query.Optimizer
 
shuffleTwo(TableFilter[]) - Method in class org.h2.command.query.Optimizer
 
shutdown() - Method in interface org.h2.server.ShutdownHandler
Tell the listener to shut down.
shutdown() - Method in class org.h2.server.TcpServer
Shut down this server.
shutdown() - Method in class org.h2.server.web.WebServer
Shut down the web server.
shutdown() - Method in class org.h2.tools.Console
INTERNAL.
shutdown() - Method in class org.h2.tools.GUIConsole
 
shutdown() - Method in class org.h2.tools.Server
INTERNAL
shutdown(String, String, boolean, boolean) - Static method in class org.h2.server.TcpServer
Stop the TCP server with the given URL.
SHUTDOWN - Static variable in interface org.h2.command.CommandInterface
The type of a SHUTDOWN statement.
SHUTDOWN_COMPACT - Static variable in interface org.h2.command.CommandInterface
The type of a SHUTDOWN COMPACT statement.
SHUTDOWN_DEFRAG - Static variable in interface org.h2.command.CommandInterface
The type of a SHUTDOWN DEFRAG statement.
SHUTDOWN_FORCE - Static variable in class org.h2.server.TcpServer
 
SHUTDOWN_IMMEDIATELY - Static variable in interface org.h2.command.CommandInterface
The type of a SHUTDOWN IMMEDIATELY statement.
SHUTDOWN_NORMAL - Static variable in class org.h2.server.TcpServer
 
shutdownExecutor(ThreadPoolExecutor) - Static method in class org.h2.mvstore.MVStore
 
shutdownHandler - Variable in class org.h2.server.TcpServer
 
shutdownHandler - Variable in class org.h2.server.web.WebServer
 
shutdownHandler - Variable in class org.h2.tools.Server
 
ShutdownHandler - Interface in org.h2.server
A shutdown handler is a listener for shutdown events.
shutdownImmediately() - Method in class org.h2.engine.Database
Immediately close the database.
shutdownServerOnDisconnect - Variable in class org.h2.server.web.WebSession
 
shutdownTcpServer(String, String, boolean, boolean) - Static method in class org.h2.tools.Server
Shutdown one or all TCP server.
SIGN - Static variable in class org.h2.expression.function.MathFunction
SIGN() (non-standard)
SIGNAL_PATTERN - Static variable in class org.h2.expression.function.SignalFunction
 
SignalFunction - Class in org.h2.expression.function
A SIGNAL function.
SignalFunction(Expression, Expression) - Constructor for class org.h2.expression.function.SignalFunction
 
simple - Variable in class org.h2.command.dml.ScriptCommand
 
Simple(int) - Constructor for class org.h2.util.TimeZoneProvider.Simple
 
SimpleArray(Object[]) - Constructor for class org.h2.tools.SimpleResultSet.SimpleArray
 
SimpleCase - Class in org.h2.expression
A simple case.
SimpleCase(Expression, SimpleCase.SimpleWhen, Expression) - Constructor for class org.h2.expression.SimpleCase
 
SimpleCase.SimpleWhen - Class in org.h2.expression
 
SimpleColumnInfo - Class in org.h2.util
Metadata of a column.
SimpleColumnInfo(String, int, String, int, int) - Constructor for class org.h2.util.SimpleColumnInfo
Creates metadata.
SimplePredicate - Class in org.h2.expression.condition
Base class for simple predicates.
SimplePredicate(Expression, boolean, boolean) - Constructor for class org.h2.expression.condition.SimplePredicate
 
SimpleResult - Class in org.h2.result
Simple in-memory result.
SimpleResult() - Constructor for class org.h2.result.SimpleResult
Creates new instance of simple result.
SimpleResult(String, String) - Constructor for class org.h2.result.SimpleResult
Creates new instance of simple result.
SimpleResult(ArrayList<SimpleResult.Column>, ArrayList<Value[]>, String, String) - Constructor for class org.h2.result.SimpleResult
 
SimpleResult.Column - Class in org.h2.result
Column info for the simple result.
SimpleResultSet - Class in org.h2.tools
This class is a simple result set and meta data implementation.
SimpleResultSet() - Constructor for class org.h2.tools.SimpleResultSet
This constructor is used if the result set is later populated with addRow.
SimpleResultSet(SimpleRowSource) - Constructor for class org.h2.tools.SimpleResultSet
This constructor is used if the result set should retrieve the rows using the specified row source object.
SimpleResultSet.SimpleArray - Class in org.h2.tools
A simple array implementation, backed by an object array
SimpleRowSource - Interface in org.h2.tools
This interface is for classes that create rows on demand.
SimpleRowValue - Class in org.h2.result
A simple row that contains data for only one column.
SimpleRowValue(int) - Constructor for class org.h2.result.SimpleRowValue
 
SimpleRowValue(int, int) - Constructor for class org.h2.result.SimpleRowValue
 
SimpleWhen(Expression[], Expression) - Constructor for class org.h2.expression.SimpleCase.SimpleWhen
 
SimpleWhen(Expression, Expression) - Constructor for class org.h2.expression.SimpleCase.SimpleWhen
 
SIN - Static variable in class org.h2.expression.function.MathFunction1
SIN().
SINGLE_EMPTY - Static variable in class org.h2.mvstore.Page
 
singleRow - Variable in class org.h2.expression.Rownum
 
SingleRowCursor - Class in org.h2.index
A cursor with at most one row.
SingleRowCursor(Row) - Constructor for class org.h2.index.SingleRowCursor
Create a new cursor.
singleWriter - Variable in class org.h2.mvstore.MVMap.Builder
 
singleWriter - Variable in class org.h2.mvstore.MVMap
 
singleWriter() - Method in class org.h2.mvstore.MVMap.Builder
Set up this Builder to produce MVMap, which can be used in append mode by a single thread.
SINH - Static variable in class org.h2.expression.function.MathFunction1
SINH().
size - Variable in class org.h2.command.ddl.Analyze.SelectivityData
The number of occupied slots, excluding the zero element (if any).
size - Variable in class org.h2.store.fs.encrypt.FileEncrypt
The current file size, from a user perspective.
size - Variable in class org.h2.store.fs.mem.FileMemData.Cache
 
size - Variable in class org.h2.store.fs.niomem.FileNioMemData.CompressLaterCache
 
size - Variable in class org.h2.util.ByteStack
 
size - Variable in class org.h2.util.IntArray
 
size - Variable in class org.h2.util.SmallLRUCache
 
size() - Method in class org.h2.expression.condition.ConditionInParameter.ParameterList
 
size() - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Get the number of resident entries.
size() - Method in class org.h2.mvstore.cache.FilePathCache.FileCache
 
size() - Method in class org.h2.mvstore.FileStore
Get the file size.
size() - Method in class org.h2.mvstore.MVMap
Get the number of entries, as a integer.
size() - Method in class org.h2.mvstore.tx.TransactionMap
Get the number of entries, as a integer.
size() - Method in class org.h2.store.fs.async.FileAsync
 
size() - Method in class org.h2.store.fs.disk.FilePathDisk
 
size() - Method in class org.h2.store.fs.encrypt.FileEncrypt
 
size() - Method in class org.h2.store.fs.encrypt.FilePathEncrypt
 
size() - Method in class org.h2.store.fs.FakeFileChannel
 
size() - Method in class org.h2.store.fs.FilePath
Get the size of a file in bytes
size() - Method in class org.h2.store.fs.FilePathWrapper
 
size() - Method in class org.h2.store.fs.mem.FileMem
 
size() - Method in class org.h2.store.fs.mem.FilePathMem
 
size() - Method in class org.h2.store.fs.niomapped.FileNioMapped
 
size() - Method in class org.h2.store.fs.niomem.FileNioMem
 
size() - Method in class org.h2.store.fs.niomem.FilePathNioMem
 
size() - Method in class org.h2.store.fs.rec.FileRec
 
size() - Method in class org.h2.store.fs.retry.FileRetryOnInterrupt
 
size() - Method in class org.h2.store.fs.split.FilePathSplit
 
size() - Method in class org.h2.store.fs.split.FileSplit
 
size() - Method in class org.h2.store.fs.zip.FilePathZip
 
size() - Method in class org.h2.store.fs.zip.FileZip
 
size() - Method in class org.h2.util.ByteStack
Returns the number of items in this stack.
size() - Method in class org.h2.util.IntArray
Get the size of the list.
size(String) - Static method in class org.h2.store.fs.FileUtils
Get the size of a file in bytes This method is similar to Java 7 java.nio.file.attribute.Attributes.
sizeAsLong() - Method in class org.h2.mvstore.MVMap
Get the number of entries, as a long.
sizeAsLong() - Method in class org.h2.mvstore.tx.TransactionMap
Get the size of the map as seen by this transaction.
sizeAsLongMax() - Method in class org.h2.mvstore.tx.TransactionMap
Get the size of the raw map.
sizeAsLongRepeatableReadWithChanges() - Method in class org.h2.mvstore.tx.TransactionMap
 
sizeHot() - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Get the number of hot entries in the cache.
sizeMapArray() - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Get the length of the internal map array.
sizeNonResident() - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Get the number of non-resident entries in the cache.
sizeOf(V) - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Get the size of the given value.
skip - Variable in class org.h2.mvstore.StreamStore.Stream
 
skip() - Method in class org.h2.result.LazyResult
Go to the next row and skip it.
skip(long) - Method in class org.h2.mvstore.Cursor
Skip over that many entries.
skip(long) - Method in class org.h2.mvstore.rtree.MVRTreeMap.RTreeCursor
Skip over that many entries.
skip(long) - Method in class org.h2.mvstore.StreamStore.Stream
 
skip(long) - Method in class org.h2.server.TcpServerThread.CachedInputStream
 
skip(long) - Method in class org.h2.store.RangeInputStream
 
skip(long) - Method in class org.h2.store.RangeReader
 
SKIP_BUFFER - Static variable in class org.h2.store.fs.zip.FileZip
 
SKIP_SUM_MASK - Static variable in class org.h2.util.MemoryEstimator
 
SKIP_SUM_SHIFT - Static variable in class org.h2.util.MemoryEstimator
 
skipBracketedComment(String, int, int, int) - Static method in class org.h2.command.Tokenizer
 
skipDefaultInitialization - Variable in class org.h2.security.auth.DefaultAuthenticator
 
skipFully(InputStream, long) - Static method in class org.h2.util.IOUtils
Skip a number of bytes in an input stream.
skipFully(Reader, long) - Static method in class org.h2.util.IOUtils
Skip a number of characters in a reader.
skipInt(int, boolean) - Method in class org.h2.util.json.JSONBytesSource
 
skipInt(int, boolean) - Method in class org.h2.util.json.JSONStringSource
 
skipNextRow() - Method in class org.h2.command.query.Select.LazyResultQueryFlat
 
skipNextRow() - Method in class org.h2.result.LazyResult
Skip next row.
skipOffset(Select.LazyResultSelect, long, boolean) - Static method in class org.h2.command.query.Select
 
skipOwnTable - Variable in class org.h2.constraint.ConstraintReferential
 
skipRemarks - Variable in class org.h2.util.ScriptReader
True if comments should be skipped completely by this reader.
skipSimpleComment(String, int, int) - Static method in class org.h2.command.Tokenizer
 
skipSpaces() - Method in class org.h2.server.web.PageParser
 
skipUsingRead - Variable in class org.h2.store.fs.zip.FileZip
 
skipWhitespace(String, int, int) - Static method in class org.h2.command.Tokenizer
 
skipWS() - Method in class org.h2.util.geometry.EWKTUtils.EWKTSource
 
skipWS(String, int) - Static method in class org.h2.util.IntervalUtils
 
skipWSEnd(String, int) - Static method in class org.h2.util.IntervalUtils
 
SLASH - Static variable in class org.h2.command.Token
The token "/".
sleep - Variable in class org.h2.mvstore.MVStore.BackgroundWriterThread
 
sleep - Variable in class org.h2.store.FileLock
The number of milliseconds to sleep after checking a file.
sleep(int) - Static method in class org.h2.store.FileLock
 
SLEEP - org.h2.engine.SessionLocal.State
 
SLEEP_GAP - Static variable in class org.h2.store.FileLock
 
SLOW_QUERY_LIMIT_MS - Static variable in class org.h2.engine.Constants
Queries that take longer than this number of milliseconds are written to the trace file with the level info.
small - Variable in class org.h2.value.lob.LobDataInMemory
If the LOB is below the inline size, we just store/load it directly here.
SMALLER - Static variable in class org.h2.command.Token
The token "<".
SMALLER - Static variable in class org.h2.expression.condition.Comparison
The comparison type meaning < as in ID<1.
SMALLER_EQUAL - Static variable in class org.h2.command.Token
The token "<=".
SMALLER_EQUAL - Static variable in class org.h2.expression.condition.Comparison
The comparison type meaning <= as in ID<=1.
SMALLINT - Static variable in class org.h2.api.H2Type
The SMALLINT data type.
SMALLINT - Static variable in class org.h2.mvstore.db.ValueDataType
 
SMALLINT - Static variable in class org.h2.value.Transfer
 
SMALLINT - Static variable in class org.h2.value.Value
The value type for SMALLINT values.
SmallLRUCache<K,​V> - Class in org.h2.util
This class implements a small LRU object cache.
SmallLRUCache(int) - Constructor for class org.h2.util.SmallLRUCache
 
SmallMap - Class in org.h2.util
A simple hash table with an optimization for the last recently used object.
SmallMap(int) - Constructor for class org.h2.util.SmallMap
Create a map with the given maximum number of entries.
snapshot - Variable in class org.h2.mvstore.tx.TransactionMap
Snapshot of this map as of beginning of transaction or first usage within transaction or beginning of the statement, depending on isolation level
Snapshot<K,​V> - Class in org.h2.mvstore.tx
Snapshot of the map root and committing transactions.
Snapshot(RootReference<K, V>, BitSet) - Constructor for class org.h2.mvstore.tx.Snapshot
 
SNAPSHOT - org.h2.engine.IsolationLevel
Dirty reads, non-repeatable reads and phantom reads are'n allowed.
snapshotDataModificationId - Variable in class org.h2.engine.SessionLocal
The snapshot data modification id.
snapshotKey - Variable in class org.h2.mvstore.tx.TransactionMap.RepeatableIterator
 
snapshotValue - Variable in class org.h2.mvstore.tx.TransactionMap.RepeatableIterator
 
snapshotValueSupplier - Variable in class org.h2.mvstore.tx.TxDecisionMaker.RepeatableReadLockDecisionMaker
 
socket - Variable in class org.h2.server.pg.PgServerThread
 
socket - Variable in class org.h2.server.web.WebThread
 
socket - Variable in class org.h2.value.Transfer
 
SOCKET - org.h2.store.FileLockMethod
This locking method means a socket is created on the given machine.
SOCKET - Static variable in class org.h2.store.FileLock
 
SOCKET_CONNECT_RETRY - Static variable in class org.h2.engine.SysProperties
System property h2.socketConnectRetry (default: 16).
SOCKET_CONNECT_TIMEOUT - Static variable in class org.h2.engine.SysProperties
System property h2.socketConnectTimeout (default: 2000).
softCache - Static variable in class org.h2.util.StringUtils
 
softCache - Static variable in class org.h2.value.Value
 
softCacheCreatedNs - Static variable in class org.h2.util.StringUtils
 
SoftValue(T, ReferenceQueue<T>, Object) - Constructor for class org.h2.util.SoftValuesHashMap.SoftValue
 
SoftValuesHashMap<K,​V> - Class in org.h2.util
Map which stores items using SoftReference.
SoftValuesHashMap() - Constructor for class org.h2.util.SoftValuesHashMap
 
SoftValuesHashMap.SoftValue<T> - Class in org.h2.util
A soft reference that has a hard reference to the key.
SOME - Static variable in class org.h2.util.ParserUtil
The token "SOME".
sort - Variable in class org.h2.command.query.Query
A sort order represents an ORDER BY clause in a query.
sort - Variable in class org.h2.result.LocalResult
 
sort(ArrayList<Value[]>) - Method in class org.h2.result.SortOrder
Sort a list of rows.
sort(ArrayList<Value[]>, int, int) - Method in class org.h2.result.SortOrder
Sort a list of rows using offset and limit.
sorted(Collection<T>, Class<T>) - Static method in class org.h2.command.dml.ScriptCommand
 
SortedProperties - Class in org.h2.util
Sorted properties file.
SortedProperties() - Constructor for class org.h2.util.SortedProperties
 
SortOrder - Class in org.h2.result
A sort order represents an ORDER BY clause in a query.
SortOrder(SessionLocal, int[]) - Constructor for class org.h2.result.SortOrder
Construct a new sort order object with default sort directions.
SortOrder(SessionLocal, int[], int[], ArrayList<QueryOrderBy>) - Constructor for class org.h2.result.SortOrder
Construct a new sort order object.
sortRows(ArrayList<? extends SearchRow>, Index) - Static method in class org.h2.mvstore.db.MVTable
Sorts the specified list of rows for a specified index.
sortRows(Comparator<? super Value[]>) - Method in class org.h2.result.SimpleResult
Sort rows in the list.
sortTopN(X[], int, int, Comparator<? super X>) - Static method in class org.h2.util.Utils
Find the top limit values using given comparator and place them as in a full array sort, in descending order.
sortType - Variable in class org.h2.command.query.QueryOrderBy
Sort type for this column.
sortType - Variable in class org.h2.table.IndexColumn
The sort type.
sortTypes - Variable in class org.h2.mvstore.db.RowDataType
 
sortTypes - Variable in class org.h2.mvstore.db.ValueDataType
 
sortTypes - Variable in class org.h2.result.SortOrder
The sort type bit mask (DESCENDING, NULLS_FIRST, NULLS_LAST).
sortUsingIndex - Variable in class org.h2.command.query.Select
 
sortWithOrderBy(Value[]) - Method in class org.h2.expression.aggregate.Aggregate
 
SOUNDEX - Static variable in class org.h2.expression.function.SoundexFunction
SOUNDEX() (non-standard).
SOUNDEX_INDEX - Static variable in class org.h2.expression.function.SoundexFunction
 
SoundexFunction - Class in org.h2.expression.function
A SOUNDEX or DIFFERENCE function.
SoundexFunction(Expression, Expression, int) - Constructor for class org.h2.expression.function.SoundexFunction
 
source - Variable in class org.h2.command.ddl.CreateFunctionAlias
 
source - Variable in exception org.h2.message.DbException
 
source - Variable in class org.h2.result.ResultWithPaddedStrings
 
source - Variable in class org.h2.schema.FunctionAlias
 
source - Variable in class org.h2.tools.SimpleResultSet
 
Source(Iterator<SearchRow>) - Constructor for class org.h2.mvstore.db.MVSecondaryIndex.Source
 
sourceCode - Variable in class org.h2.util.SourceCompiler.StringJavaFileObject
 
SourceCompiler - Class in org.h2.util
This class allows to convert source code to a class.
SourceCompiler() - Constructor for class org.h2.util.SourceCompiler
 
SourceCompiler.ClassFileManager - Class in org.h2.util
An in-memory class file manager.
SourceCompiler.GroovyCompiler - Class in org.h2.util
Access the Groovy compiler using reflection, so that we do not gain a compile-time dependency unnecessarily.
SourceCompiler.JavaClassObject - Class in org.h2.util
An in-memory java class object.
SourceCompiler.StringJavaFileObject - Class in org.h2.util
An in-memory java source file object.
sources - Variable in class org.h2.util.SourceCompiler
The class name to source code map.
sourceTableFilter - Variable in class org.h2.command.dml.MergeUsing
Source table filter.
SPACE - Static variable in class org.h2.expression.function.StringFunction1
SPACE() (non-standard).
Sparse - Class in org.h2.result
Class Sparse.
Sparse(int, int, int[]) - Constructor for class org.h2.result.Sparse
 
spatial - Variable in class org.h2.command.ddl.CreateIndex
 
spatial - Variable in class org.h2.index.IndexType
 
Spatial - Interface in org.h2.mvstore.rtree
Interface Spatial represents boxes in 2+ dimensional space, where total ordering is not that straight-forward.
SPATIAL_INTERSECTS - Static variable in class org.h2.command.Token
The token "&&".
SPATIAL_INTERSECTS - Static variable in class org.h2.expression.condition.Comparison
This is a comparison type that is only used for spatial index conditions (operator "&&").
SPATIAL_INTERSECTS - Static variable in class org.h2.index.IndexCondition
A bit of a search mask meaning 'spatial intersection'.
SpatialDataType - Class in org.h2.mvstore.rtree
A spatial data type.
SpatialDataType(int) - Constructor for class org.h2.mvstore.rtree.SpatialDataType
 
SpatialIndex - Interface in org.h2.index
A spatial index.
SpatialKey - Class in org.h2.mvstore.db
A unique spatial key.
SpatialKey(long, float...) - Constructor for class org.h2.mvstore.db.SpatialKey
Create a new key.
SpatialKey(long, SpatialKey) - Constructor for class org.h2.mvstore.db.SpatialKey
 
SpatialKeyIterator(TransactionMap<Spatial, Value>, Iterator<Spatial>, boolean) - Constructor for class org.h2.mvstore.db.MVSpatialIndex.SpatialKeyIterator
 
spatialMap - Variable in class org.h2.mvstore.db.MVSpatialIndex
 
specialPrecisionScale - Variable in class org.h2.value.DataType
If precision and scale have non-standard default values.
specification - Variable in class org.h2.expression.function.CurrentGeneralValueSpecification
 
split(int) - Method in class org.h2.mvstore.Page.Leaf
 
split(int) - Method in class org.h2.mvstore.Page.NonLeaf
 
split(int) - Method in class org.h2.mvstore.Page
Split the page.
split(String) - Static method in class org.h2.util.JdbcUtils
Split the string using the space separator into at least 10 entries.
split(Page<Spatial, V>) - Method in class org.h2.mvstore.rtree.MVRTreeMap
 
SPLIT_FILE_SIZE_SHIFT - Static variable in class org.h2.engine.SysProperties
System property h2.splitFileSizeShift (default: 30).
splitKeys(int, int) - Method in class org.h2.mvstore.Page
Split the current keys array into two arrays.
splitLinear(Page<Spatial, V>) - Method in class org.h2.mvstore.rtree.MVRTreeMap
 
splitQuadratic(Page<Spatial, V>) - Method in class org.h2.mvstore.rtree.MVRTreeMap
 
sql - Variable in class org.h2.command.Command
 
sql - Variable in class org.h2.command.CommandRemote
 
sql - Variable in enum org.h2.engine.IsolationLevel
 
sql - Variable in class org.h2.engine.MetaRecord
 
sql - Variable in enum org.h2.expression.analysis.WindowFrameBoundType
 
sql - Variable in enum org.h2.expression.analysis.WindowFrameExclusion
 
sql - Variable in class org.h2.index.LinkedCursor
 
sql - Variable in exception org.h2.jdbc.JdbcSQLDataException
 
sql - Variable in exception org.h2.jdbc.JdbcSQLException
 
sql - Variable in exception org.h2.jdbc.JdbcSQLFeatureNotSupportedException
 
sql - Variable in exception org.h2.jdbc.JdbcSQLIntegrityConstraintViolationException
 
sql - Variable in exception org.h2.jdbc.JdbcSQLInvalidAuthorizationSpecException
 
sql - Variable in exception org.h2.jdbc.JdbcSQLNonTransientConnectionException
 
sql - Variable in exception org.h2.jdbc.JdbcSQLNonTransientException
 
sql - Variable in exception org.h2.jdbc.JdbcSQLSyntaxErrorException
 
sql - Variable in exception org.h2.jdbc.JdbcSQLTimeoutException
 
sql - Variable in exception org.h2.jdbc.JdbcSQLTransactionRollbackException
 
sql - Variable in exception org.h2.jdbc.JdbcSQLTransientException
 
sql - Variable in class org.h2.server.pg.PgServerThread.Prepared
The SQL statement.
sql - Variable in class org.h2.tools.ConvertTraceFile.Stat
 
SQL - Static variable in class org.h2.fulltext.FullText.FullTextTrigger
 
SQL_NO_ORDER - Static variable in class org.h2.table.IndexColumn
Do not append ordering.
SQL_OOME - Static variable in exception org.h2.message.DbException
Thrown when OOME exception happens on handle error inside DbException.convert(java.lang.Throwable).
SQL_OOME - Static variable in class org.h2.message.TraceObject
 
sqlCommand - Variable in class org.h2.command.Parser
 
sqlFlags - Variable in class org.h2.index.LinkedIndex
 
sqlStatement - Variable in class org.h2.command.Prepared
The SQL string.
sqlStatement - Variable in class org.h2.engine.QueryStatisticsData.QueryEntry
The SQL statement.
sqlTokens - Variable in class org.h2.command.Prepared
The SQL tokens.
sqlType - Variable in class org.h2.value.DataType
The SQL type.
sqlTypeToString(SQLType) - Static method in class org.h2.value.DataType
Convert a SQL type to a debug string.
SQLXML - Static variable in class org.h2.message.TraceObject
The trace type id for SQLXML objects.
SQRT - Static variable in class org.h2.expression.function.MathFunction1
SQRT().
squareBracketQuotedNames - Variable in class org.h2.engine.Mode
Identifiers may be quoted using square brackets as in [Test].
srid - Variable in class org.h2.util.geometry.EWKBUtils.EWKBTarget
 
srid - Variable in class org.h2.value.ExtTypeInfoGeometry
 
srid - Variable in class org.h2.value.ValueGeometry
Spatial reference system identifier.
SS - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
ssl - Variable in class org.h2.engine.ConnectionInfo
 
ssl - Variable in class org.h2.server.TcpServer
 
ssl - Variable in class org.h2.server.web.WebServer
 
ssl - Variable in class org.h2.value.Transfer
 
SSSSS - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
stack - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
The stack of recently referenced elements.
stack - Variable in class org.h2.util.json.JSONByteArrayTarget
 
stack - Variable in class org.h2.util.json.JSONStringTarget
 
stack - Variable in class org.h2.util.json.JSONValidationTargetWithoutUniqueKeys
 
stack - Variable in class org.h2.util.json.JSONValidationTargetWithUniqueKeys
 
stack - Variable in class org.h2.util.json.JSONValueTarget
 
STACK - Static variable in class org.h2.util.AbbaDetector
 
stackMoveCounter - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
The number of times any item was moved to the top of the stack.
stackMoveDistance - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Config
How many other item are to be moved to the top of the stack before the current item is moved.
stackMoveDistance - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
How many other item are to be moved to the top of the stack before the current item is moved.
stackMoveDistance - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS
 
stackNext - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Entry
The next entry in the stack.
stackPrev - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Entry
The previous entry in the stack.
stackSize - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
The number of entries in the stack.
stackTrace - Variable in exception org.h2.jdbc.JdbcSQLDataException
 
stackTrace - Variable in exception org.h2.jdbc.JdbcSQLException
 
stackTrace - Variable in exception org.h2.jdbc.JdbcSQLFeatureNotSupportedException
 
stackTrace - Variable in exception org.h2.jdbc.JdbcSQLIntegrityConstraintViolationException
 
stackTrace - Variable in exception org.h2.jdbc.JdbcSQLInvalidAuthorizationSpecException
 
stackTrace - Variable in exception org.h2.jdbc.JdbcSQLNonTransientConnectionException
 
stackTrace - Variable in exception org.h2.jdbc.JdbcSQLNonTransientException
 
stackTrace - Variable in exception org.h2.jdbc.JdbcSQLSyntaxErrorException
 
stackTrace - Variable in exception org.h2.jdbc.JdbcSQLTimeoutException
 
stackTrace - Variable in exception org.h2.jdbc.JdbcSQLTransactionRollbackException
 
stackTrace - Variable in exception org.h2.jdbc.JdbcSQLTransientException
 
STAGE_GROUP - Static variable in class org.h2.expression.analysis.DataAnalysisOperation
Group stage, used for explicit or implicit GROUP BY operation.
STAGE_RESET - Static variable in class org.h2.expression.analysis.DataAnalysisOperation
Reset stage.
STAGE_WINDOW - Static variable in class org.h2.expression.analysis.DataAnalysisOperation
Window processing stage.
start - Variable in class org.h2.command.ddl.SequenceOptions
 
start - Variable in class org.h2.command.Token
 
start - Variable in class org.h2.index.IndexCursor
 
start - Variable in class org.h2.index.RangeCursor
 
start - Variable in class org.h2.util.Profiler
 
start() - Method in class org.h2.bnf.Sentence
Start the timer to make sure processing doesn't take too long.
start() - Method in class org.h2.command.Command
Start the stopwatch.
start() - Method in class org.h2.command.Token
 
start() - Method in class org.h2.server.pg.PgServer
 
start() - Method in interface org.h2.server.Service
Start the service.
start() - Method in class org.h2.server.TcpServer
 
start() - Method in class org.h2.server.web.WebServer
 
start() - Method in class org.h2.server.web.WebThread
Start the thread.
start() - Method in class org.h2.tools.Server
Tries to start the server.
start(Xid, int) - Method in class org.h2.jdbcx.JdbcXAConnection
Start or continue to work on a transaction.
start(BundleContext) - Method in class org.h2.util.DbDriverActivator
Start the bundle.
START - Static variable in class org.h2.index.IndexCondition
A bit of a search mask meaning 'larger or equal'.
START_URL - Static variable in class org.h2.engine.Constants
The database URL prefix of this database.
start1 - Variable in class org.h2.expression.analysis.WindowFrame.BiItr
 
start1 - Variable in class org.h2.expression.analysis.WindowFrame.BiReverseItr
 
start2 - Variable in class org.h2.expression.analysis.WindowFrame.TriItr
 
start2 - Variable in class org.h2.expression.analysis.WindowFrame.TriReverseItr
 
startArray() - Method in class org.h2.util.json.JSONByteArrayTarget
 
startArray() - Method in class org.h2.util.json.JSONStringTarget
 
startArray() - Method in class org.h2.util.json.JSONTarget
Start of an array.
startArray() - Method in class org.h2.util.json.JSONValidationTargetWithoutUniqueKeys
 
startArray() - Method in class org.h2.util.json.JSONValidationTargetWithUniqueKeys
 
startArray() - Method in class org.h2.util.json.JSONValueTarget
 
startBrowser - Variable in class org.h2.tools.GUIConsole
 
startBrowser() - Method in class org.h2.tools.GUIConsole
 
startCollecting() - Method in class org.h2.util.AbbaLockingDetector
Start collecting locking data.
startCollecting() - Method in class org.h2.util.Profiler
Start collecting profiling data.
startCollection(int, int) - Method in class org.h2.util.geometry.EWKBUtils.EWKBTarget
 
startCollection(int, int) - Method in class org.h2.util.geometry.EWKTUtils.EWKTTarget
 
startCollection(int, int) - Method in class org.h2.util.geometry.GeoJsonUtils.GeoJsonTarget
 
startCollection(int, int) - Method in class org.h2.util.geometry.GeometryUtils.Target
Invoked before writing of a collection.
startCollection(int, int) - Method in class org.h2.util.geometry.JTSUtils.GeometryTarget
 
startCollectionItem(int, int) - Method in class org.h2.util.geometry.EWKBUtils.EWKBTarget
 
startCollectionItem(int, int) - Method in class org.h2.util.geometry.EWKTUtils.EWKTTarget
 
startCollectionItem(int, int) - Method in class org.h2.util.geometry.GeoJsonUtils.GeoJsonTarget
 
startCollectionItem(int, int) - Method in class org.h2.util.geometry.GeometryUtils.Target
Invoked before writing of a collection item.
startCollectionItem(int, int) - Method in class org.h2.util.geometry.JTSUtils.GeometryTarget
 
startDateTime - Variable in class org.h2.server.web.WebServer
 
started - Variable in class org.h2.tools.Server
 
startElement(String, String, String, Attributes) - Method in class org.h2.security.auth.H2AuthConfigXml
 
startIndex - Variable in class org.h2.expression.analysis.WindowFrame.PlainReverseItr
 
starting - Variable in class org.h2.engine.Database
 
starting - Variable in class org.h2.expression.analysis.WindowFrame
 
startLineString(int) - Method in class org.h2.util.geometry.EWKBUtils.EWKBTarget
 
startLineString(int) - Method in class org.h2.util.geometry.EWKTUtils.EWKTTarget
 
startLineString(int) - Method in class org.h2.util.geometry.GeoJsonUtils.GeoJsonTarget
 
startLineString(int) - Method in class org.h2.util.geometry.GeometryUtils.EnvelopeTarget
 
startLineString(int) - Method in class org.h2.util.geometry.GeometryUtils.Target
Invoked before writing a LINESTRING.
startLineString(int) - Method in class org.h2.util.geometry.JTSUtils.GeometryTarget
 
startMessage(int) - Method in class org.h2.server.pg.PgServerThread
 
startNs - Variable in class org.h2.command.query.Optimizer
 
startObject() - Method in class org.h2.util.json.JSONByteArrayTarget
 
startObject() - Method in class org.h2.util.json.JSONStringTarget
 
startObject() - Method in class org.h2.util.json.JSONTarget
Start of an object.
startObject() - Method in class org.h2.util.json.JSONValidationTargetWithoutUniqueKeys
 
startObject() - Method in class org.h2.util.json.JSONValidationTargetWithUniqueKeys
 
startObject() - Method in class org.h2.util.json.JSONValueTarget
 
startPoint() - Method in class org.h2.util.geometry.EWKBUtils.EWKBTarget
 
startPoint() - Method in class org.h2.util.geometry.EWKTUtils.EWKTTarget
 
startPoint() - Method in class org.h2.util.geometry.GeoJsonUtils.GeoJsonTarget
 
startPoint() - Method in class org.h2.util.geometry.GeometryUtils.EnvelopeTarget
 
startPoint() - Method in class org.h2.util.geometry.GeometryUtils.Target
Invoked before writing a POINT.
startPoint() - Method in class org.h2.util.geometry.JTSUtils.GeometryTarget
 
startPolygon(int, int) - Method in class org.h2.util.geometry.EWKBUtils.EWKBTarget
 
startPolygon(int, int) - Method in class org.h2.util.geometry.EWKTUtils.EWKTTarget
 
startPolygon(int, int) - Method in class org.h2.util.geometry.GeoJsonUtils.GeoJsonTarget
 
startPolygon(int, int) - Method in class org.h2.util.geometry.GeometryUtils.EnvelopeTarget
 
startPolygon(int, int) - Method in class org.h2.util.geometry.GeometryUtils.Target
Invoked before writing a POLYGON.
startPolygon(int, int) - Method in class org.h2.util.geometry.JTSUtils.GeometryTarget
 
startPolygonInner(int) - Method in class org.h2.util.geometry.EWKBUtils.EWKBTarget
 
startPolygonInner(int) - Method in class org.h2.util.geometry.EWKTUtils.EWKTTarget
 
startPolygonInner(int) - Method in class org.h2.util.geometry.GeoJsonUtils.GeoJsonTarget
 
startPolygonInner(int) - Method in class org.h2.util.geometry.GeometryUtils.EnvelopeTarget
 
startPolygonInner(int) - Method in class org.h2.util.geometry.GeometryUtils.Target
Invoked before writing an inner polygon in POLYGON.
startPolygonInner(int) - Method in class org.h2.util.geometry.JTSUtils.GeometryTarget
 
startQuery(SessionLocal) - Method in class org.h2.table.TableFilter
Start the query.
startRemark(boolean) - Method in class org.h2.util.ScriptReader
 
startServer(String) - Method in class org.h2.engine.Database
 
startStatement - Variable in class org.h2.engine.SessionLocal
 
startStatementWithinTransaction(Command) - Method in class org.h2.engine.SessionLocal
Start a new statement within a transaction.
startsWithAny(String, String[]) - Static method in class org.h2.util.Profiler
 
startTimeNanos - Variable in class org.h2.command.Command
The last start time.
startTranslate(Map<Object, Object>) - Method in class org.h2.server.web.WebServer
Start the translation thread that reads the file once a second.
startValue - Variable in class org.h2.schema.Sequence
 
startWebServer(Connection) - Static method in class org.h2.tools.Server
Start a web server and a browser that uses the given connection.
startWebServer(Connection, boolean) - Static method in class org.h2.tools.Server
Start a web server and a browser that uses the given connection.
startWithSpace(String) - Static method in class org.h2.bnf.Bnf
Check whether the statement starts with a whitespace.
startWriter(PipedReader, Statement) - Static method in class org.h2.tools.CreateCluster
 
stat - Variable in class org.h2.jdbc.JdbcResultSet
 
stat - Variable in class org.h2.tools.Shell
 
Stat() - Constructor for class org.h2.tools.ConvertTraceFile.Stat
 
state - Variable in class org.h2.engine.SessionLocal
 
state - Variable in class org.h2.jdbc.JdbcLob
State.
state - Variable in class org.h2.mvstore.db.MVInDoubtTransaction
 
state - Variable in class org.h2.mvstore.MVStore
 
state - Variable in class org.h2.table.TableFilter
 
State() - Constructor for enum org.h2.engine.SessionLocal.State
 
State() - Constructor for enum org.h2.jdbc.JdbcLob.State
 
STATE_BACKUP_FILE - Static variable in interface org.h2.api.DatabaseEventListener
This state is used during the BACKUP command.
STATE_CLOSED - Static variable in class org.h2.mvstore.MVStore
Store is closed.
STATE_CLOSING - Static variable in class org.h2.mvstore.MVStore
Store is closing now, and any operation on it may fail.
STATE_CREATE_INDEX - Static variable in interface org.h2.api.DatabaseEventListener
This state is used when re-creating an index.
STATE_OPEN - Static variable in class org.h2.mvstore.MVStore
Store is open.
STATE_RECONNECTED - Static variable in interface org.h2.api.DatabaseEventListener
This state is used after re-connecting to a database (if auto-reconnect is enabled).
STATE_RECOVER - Static variable in interface org.h2.api.DatabaseEventListener
This state is used when re-applying the transaction log or rolling back uncommitted transactions.
STATE_SCAN_FILE - Static variable in interface org.h2.api.DatabaseEventListener
This state is used when scanning the database file.
STATE_STATEMENT_END - Static variable in interface org.h2.api.DatabaseEventListener
This state is used when a query ends.
STATE_STATEMENT_PROGRESS - Static variable in interface org.h2.api.DatabaseEventListener
This state is used for periodic notification during long-running queries.
STATE_STATEMENT_START - Static variable in interface org.h2.api.DatabaseEventListener
This state is used when a query starts.
STATE_STOPPING - Static variable in class org.h2.mvstore.MVStore
Store is about to close now, but is still operational.
state00 - Variable in class org.h2.security.SHA3
 
state01 - Variable in class org.h2.security.SHA3
 
state02 - Variable in class org.h2.security.SHA3
 
state03 - Variable in class org.h2.security.SHA3
 
state04 - Variable in class org.h2.security.SHA3
 
state05 - Variable in class org.h2.security.SHA3
 
state06 - Variable in class org.h2.security.SHA3
 
state07 - Variable in class org.h2.security.SHA3
 
state08 - Variable in class org.h2.security.SHA3
 
state09 - Variable in class org.h2.security.SHA3
 
state10 - Variable in class org.h2.security.SHA3
 
state11 - Variable in class org.h2.security.SHA3
 
state12 - Variable in class org.h2.security.SHA3
 
state13 - Variable in class org.h2.security.SHA3
 
state14 - Variable in class org.h2.security.SHA3
 
state15 - Variable in class org.h2.security.SHA3
 
state16 - Variable in class org.h2.security.SHA3
 
state17 - Variable in class org.h2.security.SHA3
 
state18 - Variable in class org.h2.security.SHA3
 
state19 - Variable in class org.h2.security.SHA3
 
state20 - Variable in class org.h2.security.SHA3
 
state21 - Variable in class org.h2.security.SHA3
 
state22 - Variable in class org.h2.security.SHA3
 
state23 - Variable in class org.h2.security.SHA3
 
state24 - Variable in class org.h2.security.SHA3
 
StatefulDataType<D> - Interface in org.h2.mvstore.type
A data type that allows to save its state.
StatefulDataType.Factory<D> - Interface in org.h2.mvstore.type
A factory for data types.
statement - Variable in class org.h2.command.dml.ExecuteImmediate
 
statement - Variable in class org.h2.table.DataChangeDeltaTable
 
STATEMENT - Static variable in class org.h2.message.TraceObject
The trace type id for statements.
STATEMENT_WAS_CANCELED - Static variable in class org.h2.api.ErrorCode
The error with code 57014 is thrown when a statement was canceled using Statement.cancel() or when the query timeout has been reached.
statements - Variable in class org.h2.bnf.Bnf
 
statementSnapshot - Variable in class org.h2.mvstore.tx.TransactionMap
Snapshot of this map as of beginning of beginning of the statement
stateToString() - Method in class org.h2.mvstore.tx.Transaction
 
stateToString(long) - Static method in class org.h2.mvstore.tx.Transaction
 
STATIC_CACHE - Static variable in class org.h2.value.ValueBigint
 
STATIC_CACHE - Static variable in class org.h2.value.ValueInteger
 
STATIC_SIZE - Static variable in class org.h2.value.ValueBigint
 
STATIC_SIZE - Static variable in class org.h2.value.ValueInteger
 
StaticRolesMapper - Class in org.h2.security.auth.impl
Assign static roles to authenticated users
StaticRolesMapper() - Constructor for class org.h2.security.auth.impl.StaticRolesMapper
 
StaticRolesMapper(String...) - Constructor for class org.h2.security.auth.impl.StaticRolesMapper
 
staticSettings - Variable in class org.h2.engine.Session
 
StaticSettings(boolean, boolean, boolean) - Constructor for class org.h2.engine.Session.StaticSettings
Creates new instance of static settings.
StaticUserCredentialsValidator - Class in org.h2.security.auth.impl
This credentials validator matches the user and password with the configured Usage should be limited to test purposes
StaticUserCredentialsValidator() - Constructor for class org.h2.security.auth.impl.StaticUserCredentialsValidator
 
StaticUserCredentialsValidator(String, String) - Constructor for class org.h2.security.auth.impl.StaticUserCredentialsValidator
 
statisticsEnd() - Method in class org.h2.mvstore.db.Store
Stop collecting statistics.
statisticsStart - Variable in class org.h2.mvstore.db.Store
 
statisticsStart() - Method in class org.h2.mvstore.db.Store
Start collecting statistics.
stats - Variable in class org.h2.tools.ConvertTraceFile
 
STATUS_BITS - Static variable in class org.h2.mvstore.tx.Transaction
 
STATUS_CLOSED - Static variable in class org.h2.engine.SessionRemote
 
STATUS_CLOSED - Static variable in class org.h2.mvstore.tx.Transaction
The status of a closed transaction (committed or rolled back).
STATUS_COMMITTED - Static variable in class org.h2.mvstore.tx.Transaction
The status of a transaction that has been logically committed or rather marked as committed, because it might be still listed among prepared, if it was prepared for commit.
STATUS_ERROR - Static variable in class org.h2.engine.SessionRemote
 
STATUS_MASK - Static variable in class org.h2.mvstore.tx.Transaction
 
STATUS_NAMES - Static variable in class org.h2.mvstore.tx.Transaction
 
STATUS_OK - Static variable in class org.h2.engine.SessionRemote
 
STATUS_OK_STATE_CHANGED - Static variable in class org.h2.engine.SessionRemote
 
STATUS_OPEN - Static variable in class org.h2.mvstore.tx.Transaction
The status of an open transaction.
STATUS_PREPARED - Static variable in class org.h2.mvstore.tx.Transaction
The status of a prepared transaction.
STATUS_ROLLED_BACK - Static variable in class org.h2.mvstore.tx.Transaction
The status of a transaction that has been rolled back completely, but undo operations are not finished yet.
STATUS_ROLLING_BACK - Static variable in class org.h2.mvstore.tx.Transaction
The status of a transaction that currently in a process of rolling back to a savepoint.
statusAndLogId - Variable in class org.h2.mvstore.tx.Transaction
 
statusFrame - Variable in class org.h2.tools.GUIConsole
 
STDDEV_POP - org.h2.expression.aggregate.AggregateType
The aggregate type for STDDEV_POP(expression).
STDDEV_SAMP - org.h2.expression.aggregate.AggregateType
The aggregate type for STDDEV_SAMP(expression).
step - Variable in class org.h2.index.RangeCursor
 
step - Variable in class org.h2.table.RangeTable
 
STEP_SIZE_MUST_NOT_BE_ZERO - Static variable in class org.h2.api.ErrorCode
The error with code 90142 is thrown when trying to set zero for step size.
stop - Variable in class org.h2.server.pg.PgServer
 
stop - Variable in class org.h2.server.pg.PgServerThread
 
stop - Variable in class org.h2.server.TcpServer
 
stop - Variable in class org.h2.server.TcpServerThread
 
stop - Variable in class org.h2.server.web.WebApp
Whether to close the connection.
stop - Variable in class org.h2.util.AbbaLockingDetector
 
stop - Variable in class org.h2.util.Profiler
 
stop - Variable in class org.h2.util.Task
A flag indicating the get() method has been called.
stop() - Method in class org.h2.command.Command
 
stop() - Method in class org.h2.command.CommandContainer
 
stop() - Method in interface org.h2.command.CommandInterface
Stop the command execution, release all locks and resources
stop() - Method in class org.h2.command.CommandList
 
stop() - Method in class org.h2.command.CommandRemote
 
stop() - Method in class org.h2.server.pg.PgServer
 
stop() - Method in interface org.h2.server.Service
Stop the service.
stop() - Method in class org.h2.server.TcpServer
 
stop() - Method in class org.h2.server.web.WebServer
 
stop() - Method in class org.h2.tools.Server
Stops the server.
stop(BundleContext) - Method in class org.h2.util.DbDriverActivator
Stop the bundle.
stopAll() - Method in class org.h2.tools.Server
 
stopAtNs - Variable in class org.h2.bnf.Sentence
 
stopAutoDelete() - Method in class org.h2.store.FileStore
No longer automatically delete the file once it is no longer in use.
stopAutoDelete(Reference<?>, Object) - Method in class org.h2.util.TempFileDeleter
This method is called if a file should no longer be deleted or a resource should no longer be closed if the object is garbage collected.
stopBackgroundThread(boolean) - Method in class org.h2.mvstore.MVStore
 
stopCollecting() - Method in class org.h2.util.AbbaLockingDetector
Stop collecting.
stopCollecting() - Method in class org.h2.util.Profiler
Stop collecting.
stopHide - Variable in class org.h2.tools.Shell
 
stopIfRequired() - Method in class org.h2.bnf.Sentence
Check if it's time to stop processing.
stopManagementDb() - Method in class org.h2.server.TcpServer
 
stopNow - Variable in class org.h2.server.web.WebServer.TranslateThread
 
stopNow() - Method in class org.h2.server.web.WebServer.TranslateThread
 
stopNow() - Method in class org.h2.server.web.WebThread
Close the connection now.
stopServer() - Method in class org.h2.engine.Database
 
stopServer(int, String, int) - Static method in class org.h2.server.TcpServer
Stop a running server.
storageId - Variable in class org.h2.tools.Recover
 
storageName - Variable in class org.h2.tools.Recover
 
store - Variable in class org.h2.command.dml.ScriptBase
 
store - Variable in class org.h2.engine.Database
 
store - Variable in class org.h2.mvstore.db.MVInDoubtTransaction
 
store - Variable in class org.h2.mvstore.db.MVTable
 
store - Variable in class org.h2.mvstore.db.MVTempResult.CloseImpl
MVStore.
store - Variable in class org.h2.mvstore.db.MVTempResult
MVStore.
store - Variable in class org.h2.mvstore.MVMap
The store.
store - Variable in class org.h2.mvstore.MVStore.BackgroundWriterThread
 
store - Variable in class org.h2.mvstore.StreamStore.Stream
 
store - Variable in class org.h2.mvstore.tx.RollbackDecisionMaker
 
store - Variable in class org.h2.mvstore.tx.Transaction
The transaction store.
store - Variable in class org.h2.mvstore.tx.TransactionStore
The store.
store - Variable in class org.h2.store.FileStoreInputStream
 
store - Variable in class org.h2.store.FileStoreOutputStream
 
store(boolean) - Method in class org.h2.mvstore.MVStore
 
store(long, long) - Method in class org.h2.mvstore.MVStore
 
store(String) - Method in class org.h2.util.SortedProperties
Store a properties file.
Store - Class in org.h2.mvstore.db
A store with open tables.
Store(Database) - Constructor for class org.h2.mvstore.db.Store
Creates the store.
STORE_DOCUMENT_TEXT_IN_INDEX - Static variable in class org.h2.fulltext.FullTextLucene
Whether the text content should be stored in the Lucene index.
storeBuffer(Chunk, WriteBuffer, ArrayList<Page<?, ?>>) - Method in class org.h2.mvstore.MVStore
 
storeHeader - Variable in class org.h2.mvstore.MVStore
 
storeKeys - Variable in class org.h2.mvstore.db.RowDataType
 
storeLock - Variable in class org.h2.mvstore.MVStore
Lock which governs access to major store operations: store(), close(), ...
storeNow(boolean, long, Supplier<Long>) - Method in class org.h2.mvstore.MVStore
 
storesLowerCase - Variable in class org.h2.table.TableLink
 
storesLowerCaseIdentifiers() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Checks if for CREATE TABLE Test(ID INT), getTables returns test as the table name.
storesLowerCaseQuotedIdentifiers() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Checks if for CREATE TABLE "Test"(ID INT), getTables returns test as the table name.
storesMixedCase - Variable in class org.h2.table.TableLink
 
storesMixedCaseIdentifiers() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Checks if for CREATE TABLE Test(ID INT), getTables returns Test as the table name and identifiers are not case sensitive.
storesMixedCaseQuoted - Variable in class org.h2.table.TableLink
 
storesMixedCaseQuotedIdentifiers() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Checks if for CREATE TABLE "Test"(ID INT), getTables returns Test as the table name and identifiers are case insensitive.
storesUpperCaseIdentifiers() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Checks if for CREATE TABLE Test(ID INT), getTables returns TEST as the table name.
storesUpperCaseQuotedIdentifiers() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Checks if for CREATE TABLE "Test"(ID INT), getTables returns TEST as the table name.
storeTransaction(Transaction) - Method in class org.h2.mvstore.tx.TransactionStore
Store a transaction.
strategy - Variable in class org.h2.compress.CompressDeflate
 
Stream(StreamStore, byte[]) - Constructor for class org.h2.mvstore.StreamStore.Stream
 
streamStore - Variable in class org.h2.mvstore.db.LobStorageMap
 
StreamStore - Class in org.h2.mvstore
A facility to store streams in a map.
StreamStore(Map<Long, byte[]>) - Constructor for class org.h2.mvstore.StreamStore
Create a stream store instance.
StreamStore.Stream - Class in org.h2.mvstore
A stream backed by a map.
streamStoreId - Variable in class org.h2.mvstore.db.LobStorageMap.BlobMeta
Stream identifier.
streamStoreId - Variable in class org.h2.mvstore.db.LobStorageMap.BlobReference
 
strength - Variable in class org.h2.value.CompareMode
 
STRICT - org.h2.engine.Mode.ModeEnum
 
string - Variable in enum org.h2.api.IntervalQualifier
 
string - Variable in class org.h2.command.Token.BinaryStringToken
 
string - Variable in class org.h2.command.Token.CharacterStringToken
 
string - Variable in class org.h2.util.json.JSONStringSource
 
STRING_FORMAT_ERROR_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90095 is thrown when calling the method STRINGDECODE with an invalid escape sequence.
StringDataType - Class in org.h2.mvstore.type
A string type.
StringDataType() - Constructor for class org.h2.mvstore.type.StringDataType
 
STRINGDECODE - Static variable in class org.h2.expression.function.StringFunction1
STRINGDECODE() (non-standard).
STRINGENCODE - Static variable in class org.h2.expression.function.StringFunction1
STRINGENCODE() (non-standard).
StringFunction - Class in org.h2.expression.function
An string function with multiple arguments.
StringFunction(Expression[], int) - Constructor for class org.h2.expression.function.StringFunction
 
StringFunction(Expression, Expression, Expression, int) - Constructor for class org.h2.expression.function.StringFunction
 
StringFunction(Expression, Expression, Expression, Expression, int) - Constructor for class org.h2.expression.function.StringFunction
 
StringFunction1 - Class in org.h2.expression.function
A string function with one argument.
StringFunction1(Expression, int) - Constructor for class org.h2.expression.function.StringFunction1
 
StringFunction2 - Class in org.h2.expression.function
A string function with two arguments.
StringFunction2(Expression, Expression, int) - Constructor for class org.h2.expression.function.StringFunction2
 
StringJavaFileObject(String, String) - Constructor for class org.h2.util.SourceCompiler.StringJavaFileObject
 
STRINGTOUTF8 - Static variable in class org.h2.expression.function.StringFunction1
STRINGTOUTF8() (non-standard).
StringType() - Constructor for class org.h2.mvstore.type.ObjectDataType.StringType
 
StringUtils - Class in org.h2.util
A few String utility functions.
StringUtils() - Constructor for class org.h2.util.StringUtils
 
stringValue - Variable in class org.h2.command.dml.Set
 
stringValue - Variable in class org.h2.engine.Setting
 
stringValueList - Variable in class org.h2.command.dml.Set
 
stripAnnotationsFromSyntax(String) - Static method in class org.h2.command.dml.Help
Strip out the special annotations we use to help build the railroad/BNF diagrams
subgeometries - Variable in class org.h2.util.geometry.JTSUtils.GeometryTarget
 
submitOrRun(ThreadPoolExecutor, Runnable, boolean) - Static method in class org.h2.mvstore.MVStore
 
Subquery - Class in org.h2.expression
A query returning a single value.
Subquery(Query) - Constructor for class org.h2.expression.Subquery
 
SUBQUERY_IS_NOT_SINGLE_COLUMN - Static variable in class org.h2.api.ErrorCode
The error with code 90052 is thrown when a single-column subquery is expected but a subquery with other number of columns was specified.
subQueryIndexCache - Variable in class org.h2.engine.SessionLocal
 
SubstringFunction - Class in org.h2.expression.function
A SUBSTRING function.
SubstringFunction() - Constructor for class org.h2.expression.function.SubstringFunction
 
subtract(Value) - Method in class org.h2.value.Value
Subtract a value and return the result.
subtract(Value) - Method in class org.h2.value.ValueBigint
 
subtract(Value) - Method in class org.h2.value.ValueDecfloat
 
subtract(Value) - Method in class org.h2.value.ValueDouble
 
subtract(Value) - Method in class org.h2.value.ValueEnumBase
 
subtract(Value) - Method in class org.h2.value.ValueInteger
 
subtract(Value) - Method in class org.h2.value.ValueInterval
 
subtract(Value) - Method in class org.h2.value.ValueNumeric
 
subtract(Value) - Method in class org.h2.value.ValueReal
 
subtract(Value) - Method in class org.h2.value.ValueSmallint
 
subtract(Value) - Method in class org.h2.value.ValueTime
 
subtract(Value) - Method in class org.h2.value.ValueTimestamp
 
subtract(Value) - Method in class org.h2.value.ValueTinyint
 
subtractFromStart(int) - Method in class org.h2.command.Token
 
suffix - Variable in class org.h2.value.DataType
The suffix required for the SQL literal representation.
SUFFIX_LOCK_FILE - Static variable in class org.h2.engine.Constants
The file name suffix of file lock files that are used to make sure a database is open by only one process at any time.
SUFFIX_MV_FILE - Static variable in class org.h2.engine.Constants
The file name suffix of a MVStore file.
SUFFIX_MV_STORE_NEW_FILE - Static variable in class org.h2.engine.Constants
The file name suffix of a new MVStore file, used when compacting a store.
SUFFIX_MV_STORE_TEMP_FILE - Static variable in class org.h2.engine.Constants
The file name suffix of a temporary MVStore file, used when compacting a store.
SUFFIX_OLD_DATABASE_FILE - Static variable in class org.h2.engine.Constants
The file name suffix of a H2 version 1.1 database file.
SUFFIX_TEMP_FILE - Static variable in class org.h2.engine.Constants
The file name suffix of temporary files.
SUFFIX_TRACE_FILE - Static variable in class org.h2.engine.Constants
The file name suffix of trace files.
SUM - org.h2.expression.aggregate.AggregateType
The aggregate type for SUM(expression).
SUM_OR_AVG_ON_WRONG_DATATYPE_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90015 is thrown when using an aggregate function with a data type that is not supported.
SUM_SHIFT - Static variable in class org.h2.util.MemoryEstimator
 
sumClasses - Variable in class org.h2.util.Profiler
 
summary - Variable in class org.h2.util.Profiler
The summary (usually one entry per package, unless sumClasses is enabled, in which case it's one entry per class).
sumMethods - Variable in class org.h2.util.Profiler
 
sumX - Variable in class org.h2.expression.aggregate.AggregateDataCorr
 
sumX - Variable in class org.h2.expression.aggregate.AggregateDataCovar
 
sumY - Variable in class org.h2.expression.aggregate.AggregateDataCorr
 
sumY - Variable in class org.h2.expression.aggregate.AggregateDataCovar
 
sumYX - Variable in class org.h2.expression.aggregate.AggregateDataCorr
 
sumYX - Variable in class org.h2.expression.aggregate.AggregateDataCovar
 
suppliedParameters - Variable in class org.h2.command.Parser
 
supportedClientInfoPropertiesRegEx - Variable in class org.h2.engine.Mode
Pattern describing the keys the java.sql.Connection.setClientInfo() method accepts.
supportPoundSymbolForColumnNames - Variable in class org.h2.engine.Mode
Support the # for column names
supportsAlterTableWithAddColumn() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether alter table with add column is supported.
supportsAlterTableWithDropColumn() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether alter table with drop column is supported.
supportsANSI92EntryLevelSQL() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether SQL-92 entry level grammar is supported.
supportsANSI92FullSQL() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether SQL-92 full level grammar is supported.
supportsANSI92IntermediateSQL() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether SQL-92 intermediate level grammar is supported.
supportsBatchUpdates() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether batch updates are supported.
supportsCatalogsInDataManipulation() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether the catalog name in INSERT, UPDATE, DELETE is supported.
supportsCatalogsInIndexDefinitions() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether the catalog name in CREATE INDEX is supported.
supportsCatalogsInPrivilegeDefinitions() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether the catalog name in GRANT is supported.
supportsCatalogsInProcedureCalls() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether the catalog name in procedure calls is supported.
supportsCatalogsInTableDefinitions() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether the catalog name in CREATE TABLE is supported.
supportsColumnAliasing() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether column aliasing is supported.
supportsConvert() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether CONVERT is supported.
supportsConvert(int, int) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether CONVERT is supported for one datatype to another.
supportsCoreSQLGrammar() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether ODBC Core SQL grammar is supported.
supportsCorrelatedSubqueries() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether correlated subqueries are supported.
supportsDataDefinitionAndDataManipulationTransactions() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether data manipulation and CREATE/DROP is supported in transactions.
supportsDataManipulationTransactionsOnly() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether only data manipulations are supported in transactions.
supportsDifferentTableCorrelationNames() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether table correlation names (table alias) are restricted to be different than table names.
supportsExpressionsInOrderBy() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether expression in ORDER BY are supported.
supportsExtendedSQLGrammar() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether ODBC Extended SQL grammar is supported.
supportsFullOuterJoins() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether full outer joins are supported.
supportsGetGeneratedKeys() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Does the database support getGeneratedKeys.
supportsGroupBy() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether GROUP BY is supported.
supportsGroupByBeyondSelect() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Checks whether a GROUP BY clause can use columns that are not in the SELECT clause, provided that it specifies all the columns in the SELECT clause.
supportsGroupByUnrelated() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether GROUP BY is supported if the column is not in the SELECT list.
supportsIntegrityEnhancementFacility() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether referential integrity is supported.
supportsLanguage(String) - Method in class org.h2.server.web.WebServer
Check if this language is supported / translated.
supportsLikeEscapeClause() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether LIKE...
supportsLimitedOuterJoins() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether limited outer joins are supported.
supportsMinimumSQLGrammar() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether ODBC Minimum SQL grammar is supported.
supportsMixedCaseIdentifiers - Variable in class org.h2.table.TableLink
 
supportsMixedCaseIdentifiers() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Checks if for CREATE TABLE Test(ID INT), getTables returns Test as the table name and identifiers are case sensitive.
supportsMixedCaseQuotedIdentifiers() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Checks if a table created with CREATE TABLE "Test"(ID INT) is a different table than a table created with CREATE TABLE "TEST"(ID INT).
supportsMultipleOpenResults() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Does the database support multiple open result sets returned from a CallableStatement.
supportsMultipleResultSets() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether multiple result sets are supported.
supportsMultipleTransactions() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether multiple transactions (on different connections) are supported.
supportsNamedParameters() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Does the database support named parameters.
supportsNonNullableColumns() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether columns with NOT NULL are supported.
supportsOpenCursorsAcrossCommit() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether open result sets across commits are supported.
supportsOpenCursorsAcrossRollback() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether open result sets across rollback are supported.
supportsOpenStatementsAcrossCommit() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether open statements across commit are supported.
supportsOpenStatementsAcrossRollback() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether open statements across rollback are supported.
supportsOrderByUnrelated() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether ORDER BY is supported if the column is not in the SELECT list.
supportsOuterJoins() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether outer joins are supported.
supportsPositionedDelete() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether positioned deletes are supported.
supportsPositionedUpdate() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether positioned updates are supported.
supportsPrecision - Variable in class org.h2.value.DataType
If the precision parameter is supported.
supportsResultSetConcurrency(int, int) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether a specific result set concurrency is supported.
supportsResultSetHoldability(int) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Does this database supports a result set holdability.
supportsResultSetType(int) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether a specific result set type is supported.
supportsSavepoints() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Does the database support savepoints.
supportsScale - Variable in class org.h2.value.DataType
If the scale parameter is supported.
supportsSchemasInDataManipulation() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether the schema name in INSERT, UPDATE, DELETE is supported.
supportsSchemasInIndexDefinitions() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether the schema name in CREATE INDEX is supported.
supportsSchemasInPrivilegeDefinitions() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether the schema name in GRANT is supported.
supportsSchemasInProcedureCalls() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether the schema name in procedure calls is supported.
supportsSchemasInTableDefinitions() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether the schema name in CREATE TABLE is supported.
supportsSelectForUpdate() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether SELECT ...
supportsStatementPooling() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Does the database support statement pooling.
supportsStoredFunctionsUsingCallSyntax() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether the database supports calling functions using the call syntax.
supportsStoredProcedures() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether stored procedures are supported.
supportsSubqueriesInComparisons() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether subqueries (SELECT) in comparisons are supported.
supportsSubqueriesInExists() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether SELECT in EXISTS is supported.
supportsSubqueriesInIns() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether IN(SELECT...) is supported.
supportsSubqueriesInQuantifieds() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether subqueries in quantified expression are supported.
supportsTableCorrelationNames() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether table correlation names (table alias) are supported.
supportsTransactionIsolationLevel(int) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether a specific transaction isolation level is supported.
supportsTransactions() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether transactions are supported.
supportsUnion() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether UNION SELECT is supported.
supportsUnionAll() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether UNION ALL SELECT is supported.
suspend() - Method in class org.h2.engine.SessionLocal
Cancel the transaction and close the session if needed.
SUSPENDED - org.h2.engine.SessionLocal.State
 
swap() - Method in class org.h2.expression.BinaryOperation
 
swap(byte[], int, int, int) - Static method in class org.h2.store.fs.encrypt.XTS
 
swapConvertFunctionParameters - Variable in class org.h2.engine.Mode
Swap the parameters of the CONVERT function.
swapLogFunctionParameters - Variable in class org.h2.engine.Mode
Swap the parameters of LOG() function.
switched - Variable in class org.h2.command.query.Optimizer
 
switchOffCluster() - Method in class org.h2.engine.SessionRemote
 
switchType(Object) - Method in class org.h2.mvstore.type.ObjectDataType
Switch the last remembered type to match the type of the given object.
symmetric - Variable in class org.h2.expression.condition.BetweenPredicate
 
SYMMETRIC - Static variable in class org.h2.util.ParserUtil
The token "SYMMETRIC".
sync - Variable in class org.h2.mvstore.MVStore.BackgroundWriterThread
 
sync() - Method in class org.h2.engine.Database
Synchronize the files with the file system.
sync() - Method in class org.h2.mvstore.db.Store
Force the changes to disk.
sync() - Method in class org.h2.mvstore.FileStore
Flush all changes.
sync() - Method in class org.h2.mvstore.MVStore
Force all stored changes to be written to the storage.
sync() - Method in class org.h2.mvstore.OffHeapStore
 
sync() - Method in class org.h2.store.FileStore
Call fsync.
syncLastModificationIdWithDatabase() - Method in class org.h2.mvstore.db.MVTable
 
SYNONYM - Static variable in class org.h2.engine.DbObject
This object is a synonym.
synonymFor - Variable in class org.h2.command.ddl.CreateSynonymData
The name of the table the synonym is created for.
synonymFor - Variable in class org.h2.table.TableSynonym
The table the synonym is created for.
synonymForSchema - Variable in class org.h2.command.ddl.CreateSynonymData
Schema synonymFor is located in.
synonymName - Variable in class org.h2.command.ddl.CreateSynonymData
The synonyms name.
synonymName - Variable in class org.h2.command.ddl.DropSynonym
 
synonyms - Variable in class org.h2.schema.Schema
 
synonyms - Variable in class org.h2.table.Table
 
synonyms(SessionLocal, ArrayList<Row>, String) - Method in class org.h2.table.InformationSchemaTable
 
SYNONYMS - Static variable in class org.h2.table.InformationSchemaTable
 
SYNONYMS - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
syntax - Variable in class org.h2.bnf.Bnf
 
SYNTAX_ERROR_1 - Static variable in class org.h2.api.ErrorCode
The error with code 42000 is thrown when trying to execute an invalid SQL statement.
SYNTAX_ERROR_2 - Static variable in class org.h2.api.ErrorCode
The error with code 42001 is thrown when trying to execute an invalid SQL statement.
SYS_GUID - Static variable in class org.h2.mode.FunctionsOracle
 
sysDummy1 - Variable in class org.h2.engine.Mode
Support the pseudo-table SYSIBM.SYSDUMMY1.
sysIdentifier(String) - Method in class org.h2.engine.Database
Returns identifier in upper or lower case depending on database settings.
SysInfoFunction - Class in org.h2.expression.function
Database or session information function.
SysInfoFunction(int) - Constructor for class org.h2.expression.function.SysInfoFunction
 
sysOut - Variable in class org.h2.message.TraceSystem
 
SysProperties - Class in org.h2.engine
The constants defined in this class are initialized from system properties.
SysProperties() - Constructor for class org.h2.engine.SysProperties
 
system - Variable in class org.h2.engine.Role
 
system - Variable in class org.h2.schema.Schema
 
SYSTEM_IDENTIFIER_PREFIX - Static variable in class org.h2.engine.SessionLocal
The prefix of generated identifiers.
SYSTEM_SAVEPOINT_PREFIX - Static variable in class org.h2.jdbc.JdbcSavepoint
 
SYSTEM_SCHEMA_COMPARATOR - Static variable in class org.h2.server.web.WebApp
 
SYSTEM_TABLE - org.h2.table.TableType
The table type name for system tables.
SYSTEM_USER - Static variable in class org.h2.expression.function.CurrentGeneralValueSpecification
The function "SYSTEM_USER" general value specification.
SYSTEM_USER - Static variable in class org.h2.util.ParserUtil
The token "SYSTEM_USER".
SYSTEM_USER_NAME - Static variable in class org.h2.engine.Database
The default name of the system user.
systemColumns - Variable in class org.h2.engine.Mode
The system columns 'ctid' and 'oid' are supported.
systemIdentifier - Variable in class org.h2.engine.SessionLocal
 
systemSession - Variable in class org.h2.engine.Database
 
systemUser - Variable in class org.h2.engine.Database
 
systemUser - Variable in class org.h2.engine.User
 
SYYYY - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 

T

TAB_WIDTH - Static variable in class org.h2.server.web.PageParser
 
table - Variable in class org.h2.command.ddl.Analyze
used in ANALYZE TABLE...
table - Variable in class org.h2.command.ddl.TruncateTable
 
table - Variable in class org.h2.command.dml.Insert
 
table - Variable in class org.h2.command.dml.Merge
 
table - Variable in class org.h2.command.dml.SetClauseList
 
table - Variable in class org.h2.command.query.TableValueConstructor
The table.
table - Variable in class org.h2.constraint.Constraint
The table for which this constraint is defined.
table - Variable in class org.h2.expression.ExpressionVisitor
 
table - Variable in class org.h2.expression.Wildcard
 
table - Variable in class org.h2.fulltext.FullTextLucene.FullTextTrigger
 
table - Variable in class org.h2.fulltext.IndexInfo
The table name.
table - Variable in class org.h2.index.Index
The table.
table - Variable in class org.h2.index.IndexCursor
 
table - Variable in class org.h2.index.ViewCursor
 
table - Variable in class org.h2.index.VirtualConstructedTableIndex
 
table - Variable in class org.h2.schema.TriggerObject
 
table - Variable in class org.h2.table.Column
 
table - Variable in class org.h2.table.GeneratedColumnResolver
 
table - Variable in class org.h2.table.TableFilter
 
Table - Class in org.h2.table
This is the base class for most tables.
Table(Schema, int, String, boolean, boolean) - Constructor for class org.h2.table.Table
 
TABLE - org.h2.table.TableType
The table type name for regular data tables.
TABLE - Static variable in class org.h2.bnf.context.DbContextRule
 
TABLE - Static variable in class org.h2.expression.function.table.ArrayTableFunction
TABLE() (non-standard).
TABLE - Static variable in class org.h2.message.Trace
The trace module id for tables.
TABLE - Static variable in class org.h2.util.ParserUtil
The token "TABLE".
TABLE_ALIAS - Static variable in class org.h2.bnf.context.DbContextRule
 
TABLE_CONSTRAINTS - Static variable in class org.h2.table.InformationSchemaTable
 
TABLE_CONSTRAINTS - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
TABLE_DISTINCT - Static variable in class org.h2.expression.function.table.ArrayTableFunction
TABLE_DISTINCT() (non-standard).
TABLE_ID_SESSION_VARIABLE - Static variable in class org.h2.store.LobStorageFrontend
The table id for session variables (LOBs not assigned to a table).
TABLE_INDEX_HASHED - Static variable in class org.h2.jdbc.meta.DatabaseMetaLocal
 
TABLE_INDEX_OTHER - Static variable in class org.h2.jdbc.meta.DatabaseMetaLocal
 
TABLE_LINK - org.h2.table.TableType
The table type name for linked tables.
TABLE_OR_VIEW - Static variable in class org.h2.engine.DbObject
The object is of the type table or view.
TABLE_OR_VIEW_ALREADY_EXISTS_1 - Static variable in class org.h2.api.ErrorCode
The error with code 42101 is thrown when trying to create a table or view if an object with this name already exists.
TABLE_OR_VIEW_NOT_FOUND_1 - Static variable in class org.h2.api.ErrorCode
The error with code 42102 is thrown when trying to query, modify or drop a table or view that does not exists in this schema and database.
TABLE_OR_VIEW_NOT_FOUND_DATABASE_EMPTY_1 - Static variable in class org.h2.api.ErrorCode
The error with code 42104 is thrown when trying to query, modify or drop a table or view that does not exists in this schema and database but it is empty anyway.
TABLE_OR_VIEW_NOT_FOUND_WITH_CANDIDATES_2 - Static variable in class org.h2.api.ErrorCode
The error with code 42103 is thrown when trying to query, modify or drop a table or view that does not exists in this schema and database but similar names were found.
TABLE_PRIVILEGES - Static variable in class org.h2.table.InformationSchemaTable
 
TABLE_PRIVILEGES - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
TABLE_RESULT - Static variable in class org.h2.store.LobStorageFrontend
The table id for result sets.
TABLE_SIZE - Static variable in class org.h2.engine.DbSettings
The initial size of the hash table.
TABLE_TEMP - Static variable in class org.h2.store.LobStorageFrontend
The table id for temporary objects (not assigned to any object).
TABLE_TYPES - Static variable in class org.h2.jdbc.meta.DatabaseMetaLocal
 
TABLE_TYPES - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
tableAlias - Variable in class org.h2.expression.ExpressionColumn
 
TableBase - Class in org.h2.table
The base class of a regular table, or a user defined table.
TableBase(CreateTableData) - Constructor for class org.h2.table.TableBase
 
tableConstraints(SessionLocal, ArrayList<Row>, String, Constraint, Constraint.Type, Table, String) - Method in class org.h2.table.InformationSchemaTable
 
tableConstraints(SessionLocal, Value, Value, ArrayList<Row>, String) - Method in class org.h2.table.InformationSchemaTable
 
tableEngine - Variable in class org.h2.command.ddl.CreateTableData
The table engine to use for creating the table.
tableEngine - Variable in class org.h2.table.TableBase
The table engine used (null for regular tables).
TableEngine - Interface in org.h2.api
A class that implements this interface can create custom table implementations.
tableEngineParams - Variable in class org.h2.command.ddl.CreateSchema
 
tableEngineParams - Variable in class org.h2.command.ddl.CreateTableData
The table engine params to use for creating the table.
tableEngineParams - Variable in class org.h2.schema.Schema
 
tableEngineParams - Variable in class org.h2.table.TableBase
Provided table parameters
tableEngines - Variable in class org.h2.engine.Database
 
tableExpression - Variable in class org.h2.table.Table
 
TableFilter - Class in org.h2.table
A table filter represents a table that is used in a query.
TableFilter(SessionLocal, Table, String, boolean, Select, int, IndexHints) - Constructor for class org.h2.table.TableFilter
Create a new table filter object.
TableFilter.MapColumnsVisitor - Class in org.h2.table
A visitor that maps columns.
TableFilter.TableFilterVisitor - Interface in org.h2.table
A visitor for table filters.
tableFunction - Variable in class org.h2.command.dml.Call
 
TableFunction - Class in org.h2.expression.function.table
A table value function.
TableFunction(Expression[]) - Constructor for class org.h2.expression.function.table.TableFunction
 
tableId - Variable in class org.h2.mvstore.db.LobStorageMap.BlobMeta
 
tableId - Variable in class org.h2.value.lob.LobDataDatabase
If the LOB is managed by the one the LobStorageBackend classes, these are the unique key inside that storage.
tableId - Variable in class org.h2.value.lob.LobDataFetchOnDemand
If the LOB is managed by the one the LobStorageBackend classes, these are the unique key inside that storage.
tableIfTableExists(Schema, String, boolean) - Method in class org.h2.command.Parser
 
TableInfoFunction - Class in org.h2.expression.function
A table information function.
TableInfoFunction(Expression, Expression, int) - Constructor for class org.h2.expression.function.TableInfoFunction
 
tableLink - Variable in class org.h2.index.LinkedCursor
 
TableLink - Class in org.h2.table
A linked table contains connection information for a table accessible by JDBC.
TableLink(Schema, int, String, String, String, String, String, String, String, boolean, boolean) - Constructor for class org.h2.table.TableLink
 
TableLinkConnection - Class in org.h2.table
A connection for a linked table.
TableLinkConnection(HashMap<TableLinkConnection, TableLinkConnection>, String, String, String, String) - Constructor for class org.h2.table.TableLinkConnection
 
tableMap - Variable in class org.h2.mvstore.db.Store
The map of open tables.
tableMap - Variable in class org.h2.tools.Recover
 
tableName - Variable in class org.h2.command.ddl.AlterTable
 
tableName - Variable in class org.h2.command.ddl.AlterTableAlterColumn
 
tableName - Variable in class org.h2.command.ddl.CreateIndex
 
tableName - Variable in class org.h2.command.ddl.CreateLinkedTable
 
tableName - Variable in class org.h2.command.ddl.CreateTableData
The table name.
tableName - Variable in class org.h2.command.ddl.CreateTrigger
 
tableName - Variable in class org.h2.command.ddl.DropTable.SchemaAndTable
 
tableName - Variable in class org.h2.command.dml.AlterTableSet
 
tableName - Variable in class org.h2.result.ResultColumn
The table name or null.
tableName - Variable in class org.h2.result.SimpleResult
 
tableName - Variable in class org.h2.result.UpdatableRow
 
tableName - Variable in class org.h2.tools.TriggerAdapter
The name of the table.
tablePrivileges(SessionLocal, Value, Value, ArrayList<Row>, String) - Method in class org.h2.table.InformationSchemaTable
 
tables - Variable in class org.h2.bnf.context.DbSchema
The table list.
tables - Variable in class org.h2.bnf.Sentence
 
tables - Variable in class org.h2.command.ddl.DropTable
 
tables - Variable in class org.h2.command.ddl.GrantRevoke
 
tables - Variable in class org.h2.command.dml.ScriptCommand
 
tables - Variable in class org.h2.mode.PgCatalogSchema
 
tables - Variable in class org.h2.table.TableView
 
tables() - Method in class org.h2.server.web.WebApp
 
tables(SessionLocal, ArrayList<Row>, String, Table, String) - Method in class org.h2.table.InformationSchemaTable
 
tables(SessionLocal, Value, Value, ArrayList<Row>, String) - Method in class org.h2.table.InformationSchemaTable
 
TABLES - Static variable in class org.h2.table.InformationSchemaTable
 
TABLES - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
tablesAndViews - Variable in class org.h2.schema.Schema
 
tablesToAnalyze - Variable in class org.h2.engine.SessionLocal
Tables marked for ANALYZE after the current transaction is committed.
TableSynonym - Class in org.h2.table
Synonym for an existing table or view.
TableSynonym(CreateSynonymData) - Constructor for class org.h2.table.TableSynonym
 
TableType - Enum in org.h2.table
The table types.
TableType() - Constructor for enum org.h2.table.TableType
 
TableValueColumnResolver() - Constructor for class org.h2.command.query.TableValueConstructor.TableValueColumnResolver
 
TableValueConstructor - Class in org.h2.command.query
Table value constructor.
TableValueConstructor(SessionLocal, ArrayList<ArrayList<Expression>>) - Constructor for class org.h2.command.query.TableValueConstructor
Creates new instance of table value constructor.
TableValueConstructor.TableValueColumnResolver - Class in org.h2.command.query
 
TableValueConstructorTable - Class in org.h2.table
A table for table value constructor.
TableValueConstructorTable(Schema, SessionLocal, Column[], ArrayList<ArrayList<Expression>>) - Constructor for class org.h2.table.TableValueConstructorTable
 
TableView - Class in org.h2.table
A view is a virtual table that is defined by a query.
TableView(Schema, int, String, String, ArrayList<Parameter>, Column[], SessionLocal, boolean, boolean, boolean, boolean) - Constructor for class org.h2.table.TableView
 
TableView.CacheKey - Class in org.h2.table
The key of the index cache for views.
TAG_BIG_DECIMAL_0 - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TAG_BIG_DECIMAL_1 - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TAG_BIG_DECIMAL_SMALL - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TAG_BIG_DECIMAL_SMALL_SCALED - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TAG_BIG_INTEGER_0 - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TAG_BIG_INTEGER_1 - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TAG_BIG_INTEGER_SMALL - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TAG_BOOLEAN_TRUE - Static variable in class org.h2.mvstore.type.ObjectDataType
For very common values (e.g.
TAG_BYTE_ARRAY_0_15 - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TAG_DOUBLE_0 - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TAG_DOUBLE_1 - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TAG_DOUBLE_FIXED - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TAG_FLOAT_0 - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TAG_FLOAT_1 - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TAG_FLOAT_FIXED - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TAG_INTEGER_0_15 - Static variable in class org.h2.mvstore.type.ObjectDataType
For small-values/small-arrays, we encode the value/array-length in the tag.
TAG_INTEGER_FIXED - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TAG_INTEGER_NEGATIVE - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TAG_LONG_0_7 - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TAG_LONG_FIXED - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TAG_LONG_NEGATIVE - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TAG_STRING_0_15 - Static variable in class org.h2.mvstore.type.ObjectDataType
 
takeGeneratedSequenceValue - Variable in class org.h2.engine.Mode
If true, last identity of the session is updated on generation of a new sequence value.
takeInsertedIdentity - Variable in class org.h2.engine.Mode
If true, last identity of the session is updated on insertion of a new value into identity column.
TAN - Static variable in class org.h2.expression.function.MathFunction1
TAN().
TANH - Static variable in class org.h2.expression.function.MathFunction1
TANH().
target - Variable in class org.h2.util.json.JSONTextSource
The output.
Target() - Constructor for class org.h2.util.geometry.GeometryUtils.Target
 
Target(int, LocalResult) - Constructor for class org.h2.expression.condition.UniquePredicate.Target
 
targetRowidsRemembered - Variable in class org.h2.command.dml.MergeUsing
Contains _ROWID_ of processed rows.
targetsMySql - Variable in class org.h2.table.TableLink
 
targetTableFilter - Variable in class org.h2.command.dml.FilteredDataChangeStatement
The target table filter.
targetTableFilter - Variable in class org.h2.command.dml.MergeUsing
Target table filter.
targetTableName - Variable in class org.h2.index.LinkedIndex
 
task - Variable in class org.h2.jdbc.JdbcLob.LobPipedOutputStream
 
Task - Class in org.h2.util
A method call that is executed in a separate thread.
Task() - Constructor for class org.h2.util.Task
 
tcp - Variable in class org.h2.tools.Console
 
tcp - Variable in class org.h2.tools.Server
 
TCP_PROTOCOL_VERSION_17 - Static variable in class org.h2.engine.Constants
The TCP protocol version number 17.
TCP_PROTOCOL_VERSION_18 - Static variable in class org.h2.engine.Constants
The TCP protocol version number 18.
TCP_PROTOCOL_VERSION_19 - Static variable in class org.h2.engine.Constants
The TCP protocol version number 19.
TCP_PROTOCOL_VERSION_20 - Static variable in class org.h2.engine.Constants
The TCP protocol version number 20.
TCP_PROTOCOL_VERSION_MAX_SUPPORTED - Static variable in class org.h2.engine.Constants
Maximum supported version of TCP protocol.
TCP_PROTOCOL_VERSION_MIN_SUPPORTED - Static variable in class org.h2.engine.Constants
Minimum supported version of TCP protocol.
TcpServer - Class in org.h2.server
The TCP server implements the native H2 database server protocol.
TcpServer() - Constructor for class org.h2.server.TcpServer
 
TcpServerThread - Class in org.h2.server
One server thread is opened per client connection.
TcpServerThread(Socket, TcpServer, int) - Constructor for class org.h2.server.TcpServerThread
 
TcpServerThread.CachedInputStream - Class in org.h2.server
An input stream with a position.
tempFile - Variable in class org.h2.value.lob.LobDataFile
 
tempFileDeleter - Variable in class org.h2.engine.Database
 
tempFileDeleter - Variable in class org.h2.engine.SessionRemote
 
tempFileDeleter - Variable in class org.h2.mvstore.db.MVTempResult
Temporary file deleter.
TempFileDeleter - Class in org.h2.util
This class deletes temporary files when they are not used any longer.
TempFileDeleter() - Constructor for class org.h2.util.TempFileDeleter
 
tempLobMap - Variable in class org.h2.mvstore.db.LobStorageMap
The lob metadata map for temporary lobs.
tempLobTableCreated - Variable in class org.h2.command.dml.ScriptCommand
 
temporary - Variable in class org.h2.command.ddl.CreateLinkedTable
 
temporary - Variable in class org.h2.command.ddl.CreateTableData
Whether this is a temporary table.
temporary - Variable in class org.h2.engine.DbObject
 
temporaryLobs - Variable in class org.h2.engine.SessionLocal
The temporary LOBs that need to be removed on commit.
temporaryMapId - Variable in class org.h2.mvstore.db.Store
 
temporaryResultLobs - Variable in class org.h2.engine.SessionLocal
Temporary LOBs from result sets.
temporaryUniqueNames - Variable in class org.h2.schema.Schema
The set of returned unique names that are not yet stored.
tempRandom - Static variable in class org.h2.store.fs.FilePath
The prefix for temporary files.
tempSequence - Static variable in class org.h2.store.fs.FilePath
 
terminated - Static variable in class org.h2.engine.OnExitDatabaseCloser
 
test(String) - Method in class org.h2.expression.condition.CompareLike
Test if the value matches the initialized pattern.
test(String, String, char) - Method in class org.h2.expression.condition.CompareLike
Test if the value matches the pattern.
test(NetworkConnectionInfo) - Method in class org.h2.server.web.WebApp
 
testColumnType(DbColumn) - Method in class org.h2.bnf.context.DbContextRule
 
testDatabase - Variable in class org.h2.store.RecoverTester
 
testDatabase(String, PrintWriter) - Method in class org.h2.store.RecoverTester
 
testEvery - Variable in class org.h2.store.RecoverTester
 
testing - Variable in class org.h2.store.RecoverTester
 
testPlan(TableFilter[]) - Method in class org.h2.command.query.Optimizer
 
thread - Variable in class org.h2.server.pg.PgServerThread
 
thread - Variable in class org.h2.server.TcpServerThread
 
thread - Variable in class org.h2.server.web.WebThread
 
thread - Variable in class org.h2.util.AbbaLockingDetector
 
thread - Variable in class org.h2.util.Profiler
 
thread - Variable in class org.h2.util.Task
 
THREAD_DEADLOCK_DETECTOR - Static variable in class org.h2.engine.SysProperties
System property h2.threadDeadlockDetector (default: false).
THREAD_LOCAL_SESSION - Static variable in class org.h2.engine.SessionLocal
Thread local session for comparison operations between different data types.
threadBean - Variable in class org.h2.util.ThreadDeadlockDetector
 
ThreadDeadlockDetector - Class in org.h2.util
Detects deadlocks between threads.
ThreadDeadlockDetector() - Constructor for class org.h2.util.ThreadDeadlockDetector
 
threadDumps - Variable in class org.h2.util.Profiler
 
threadId - Variable in class org.h2.server.TcpServerThread
 
threadMXBean - Variable in class org.h2.util.AbbaLockingDetector
 
throttle() - Method in class org.h2.engine.SessionLocal
Wait for some time if this session is throttled (slowed down).
THROTTLE - Static variable in class org.h2.command.dml.SetTypes
The type of a SET THROTTLE statement.
THROTTLE_DELAY - Static variable in class org.h2.engine.Constants
How often we check to see if we need to apply a throttling delay if SET THROTTLE has been used.
THROTTLED - org.h2.engine.SessionLocal.State
 
throttleMs - Variable in class org.h2.engine.SessionLocal
 
throwException(String) - Static method in class org.h2.fulltext.FullText
Throw a SQLException with the given message.
throwException(Database, DatabaseEventListener, DbException, String) - Static method in class org.h2.engine.MetaRecord
 
throwException(ToDateParser, String) - Static method in class org.h2.mode.ToDateTokenizer
Throw a parse exception.
throwLastBackgroundException() - Method in class org.h2.engine.Database
If there is a background store thread, and if there wasn an exception in that thread, throw it now.
throwNotFound(boolean, boolean, String) - Static method in class org.h2.engine.Engine
 
throwUnsupportedOption(String) - Method in class org.h2.util.Tool
Throw a SQLException saying this command line option is not supported.
TI_TO_VALUE - Static variable in class org.h2.value.Transfer
 
tick() - Method in class org.h2.util.AbbaLockingDetector
 
tick() - Method in class org.h2.util.Profiler
 
ticker - Static variable in class org.h2.server.web.WebServer
 
tickIntervalMs - Variable in class org.h2.util.AbbaLockingDetector
 
TILDE - Static variable in class org.h2.command.Token
The token "~".
time - Variable in class org.h2.mvstore.Chunk
When this chunk was created, in milliseconds after the store was created.
time - Variable in class org.h2.tools.ConvertTraceFile.Stat
 
time - Variable in class org.h2.util.Profiler
 
TIME - Static variable in class org.h2.api.H2Type
The TIME data type.
TIME - Static variable in class org.h2.mvstore.db.ValueDataType
 
TIME - Static variable in class org.h2.value.Transfer
 
TIME - Static variable in class org.h2.value.Value
The value type for TIME values.
TIME_GRANULARITY - Static variable in class org.h2.store.FileLock
 
TIME_TZ - Static variable in class org.h2.mvstore.db.ValueDataType
 
TIME_TZ - Static variable in class org.h2.value.Transfer
 
TIME_TZ - Static variable in class org.h2.value.Value
The value type for TIME WITH TIME ZONE values.
TIME_WITH_TIME_ZONE - Static variable in class org.h2.api.H2Type
The TIME WITH TIME ZONE data type.
TIME_ZONE - Static variable in class org.h2.command.dml.SetTypes
The type of a SET TIME ZONE statement.
TIME_ZONE_FORMATTER - Static variable in class org.h2.util.TimeZoneProvider.WithTimeZone
 
timeNanos - Variable in class org.h2.value.ValueTimestamp
The nanoseconds since midnight.
timeNanos - Variable in class org.h2.value.ValueTimestampTimeZone
The nanoseconds since midnight.
timeout - Variable in class org.h2.jdbcx.JdbcConnectionPool
 
timeoutMillis - Variable in class org.h2.mvstore.tx.Transaction
How long to wait for blocking transaction to commit or rollback.
timeoutMillis - Variable in class org.h2.mvstore.tx.TransactionStore
Default blocked transaction timeout
TimeoutValue(ValueLob) - Constructor for class org.h2.engine.SessionLocal.TimeoutValue
 
TimeParslet() - Constructor for class org.h2.mode.ToDateTokenizer.TimeParslet
 
TIMESTAMP - Static variable in class org.h2.api.H2Type
The TIMESTAMP data type.
TIMESTAMP - Static variable in class org.h2.mvstore.db.ValueDataType
 
TIMESTAMP - Static variable in class org.h2.value.Transfer
 
TIMESTAMP - Static variable in class org.h2.value.Value
The value type for TIMESTAMP values.
TIMESTAMP_TZ - Static variable in class org.h2.mvstore.db.ValueDataType
 
TIMESTAMP_TZ - Static variable in class org.h2.value.Transfer
 
TIMESTAMP_TZ - Static variable in class org.h2.value.Value
The value type for TIMESTAMP WITH TIME ZONE values.
TIMESTAMP_TZ_OLD - Static variable in class org.h2.mvstore.db.ValueDataType
 
TIMESTAMP_WITH_TIME_ZONE - Static variable in class org.h2.api.H2Type
The TIMESTAMP WITH TIME ZONE data type.
timestampFromLocalMillis(long, int) - Static method in class org.h2.util.LegacyDateTimeUtils
 
timestampTimeZoneAtOffset(long, long, int, int) - Static method in class org.h2.util.DateTimeUtils
Moves timestamp with time zone to a new time zone.
timestampToDecimal(long, long) - Static method in class org.h2.expression.aggregate.Percentile
 
timeTotal - Variable in class org.h2.tools.ConvertTraceFile
 
timeZone - Variable in class org.h2.engine.ConnectionInfo
 
timeZone - Variable in class org.h2.engine.Session.DynamicSettings
The current time zone.
timeZone - Variable in class org.h2.engine.SessionLocal
 
timeZone - Variable in class org.h2.expression.function.DateTimeFormatFunction.CacheKey
 
timeZone - Variable in class org.h2.mode.ToDateParser
 
timeZone - Variable in class org.h2.server.pg.PgServerThread
 
TIMEZONE_HOUR - Static variable in class org.h2.expression.function.DateTimeFunction
Time zone hour.
TIMEZONE_MINUTE - Static variable in class org.h2.expression.function.DateTimeFunction
Time zone minute.
TIMEZONE_SECOND - Static variable in class org.h2.expression.function.DateTimeFunction
Time zone second.
timeZoneHMValid - Variable in class org.h2.mode.ToDateParser
 
timeZoneHour - Variable in class org.h2.mode.ToDateParser
 
timeZoneMinute - Variable in class org.h2.mode.ToDateParser
 
timeZoneNameFromOffsetSeconds(int) - Static method in class org.h2.util.DateTimeUtils
Generates time zone name for the specified offset in seconds.
timeZoneOffsetSeconds - Variable in class org.h2.value.ValueTimestampTimeZone
Time zone offset from UTC in seconds, range of -18 hours to +18 hours.
timeZoneOffsetSeconds - Variable in class org.h2.value.ValueTimeTimeZone
Time zone offset from UTC in seconds, range of -18 hours to +18 hours.
TimeZoneOperation - Class in org.h2.expression
A time zone specification (AT { TIME ZONE | LOCAL }).
TimeZoneOperation(Expression, Expression) - Constructor for class org.h2.expression.TimeZoneOperation
 
TimeZoneProvider - Class in org.h2.util
Provides access to time zone API.
TimeZoneProvider() - Constructor for class org.h2.util.TimeZoneProvider
 
TimeZoneProvider.Simple - Class in org.h2.util
Time zone provider with offset.
TimeZoneProvider.WithTimeZone - Class in org.h2.util
Time zone provider with time zone.
TINYINT - Static variable in class org.h2.api.H2Type
The TINYINT data type.
TINYINT - Static variable in class org.h2.mvstore.db.ValueDataType
 
TINYINT - Static variable in class org.h2.value.Transfer
 
TINYINT - Static variable in class org.h2.value.Value
The value type for TINYINT values.
TMIterator(TransactionMap<K, V>, K, K, Snapshot<K, VersionedValue<V>>, boolean, boolean) - Constructor for class org.h2.mvstore.tx.TransactionMap.TMIterator
 
TMVMap(Map<String, Object>, DataType<K>, DataType<V>) - Constructor for class org.h2.mvstore.tx.TransactionStore.TxMapBuilder.TMVMap
 
TMVMap(MVMap<K, V>) - Constructor for class org.h2.mvstore.tx.TransactionStore.TxMapBuilder.TMVMap
 
to - Variable in class org.h2.mvstore.Cursor
 
TO - Static variable in class org.h2.util.ParserUtil
The token "TO".
TO_DATE - org.h2.mode.ToDateParser.ConfigParam
 
TO_DATE - Static variable in class org.h2.mode.FunctionsOracle
 
TO_DATE - Static variable in class org.h2.mode.FunctionsPostgreSQL
 
TO_TIMESTAMP - org.h2.mode.ToDateParser.ConfigParam
 
TO_TIMESTAMP - Static variable in class org.h2.mode.FunctionsOracle
 
TO_TIMESTAMP - Static variable in class org.h2.mode.FunctionsPostgreSQL
 
TO_TIMESTAMP_TZ - org.h2.mode.ToDateParser.ConfigParam
 
TO_TIMESTAMP_TZ - Static variable in class org.h2.mode.FunctionsOracle
 
TO_UPPER_CACHE - Static variable in class org.h2.util.StringUtils
 
TO_UPPER_CACHE_LENGTH - Static variable in class org.h2.util.StringUtils
 
TO_UPPER_CACHE_MAX_ENTRY_LENGTH - Static variable in class org.h2.util.StringUtils
 
toArray(int[]) - Method in class org.h2.util.IntArray
Convert this list to an array.
toByteArray() - Method in class org.h2.value.CharsetCollator.CharsetCollationKey
 
toBytes(String) - Method in class org.h2.value.CharsetCollator
Convert the source to bytes, using the character set.
toCanonicalDouble(double) - Static method in class org.h2.util.geometry.GeometryUtils
Normalizes all NaNs into single type on NaN and negative zero to positive zero.
toCapitalization(Boolean, Boolean) - Static method in enum org.h2.expression.function.ToCharFunction.Capitalization
Returns the capitalization / casing strategy which should be used when the first and second letters have the specified casing.
toChar(BigDecimal, String, String) - Static method in class org.h2.expression.function.ToCharFunction
Emulates Oracle's TO_CHAR(number) function.
toCharDateTime(SessionLocal, Value, String, String) - Static method in class org.h2.expression.function.ToCharFunction
Emulates Oracle's TO_CHAR(datetime) function.
ToCharFunction - Class in org.h2.expression.function
Emulates Oracle's TO_CHAR function.
ToCharFunction(Expression, Expression, Expression) - Constructor for class org.h2.expression.function.ToCharFunction
 
ToCharFunction.Capitalization - Enum in org.h2.expression.function
Represents a capitalization / casing strategy.
tocPos - Variable in class org.h2.mvstore.Chunk
Offset (from the beginning of the chunk) for the table of content.
toDate(CastDataProvider, TimeZone, Value) - Static method in class org.h2.util.LegacyDateTimeUtils
Get the date value converted to the specified time zone.
toDate(SessionLocal, String, String) - Static method in class org.h2.mode.ToDateParser
Parse a string as a date with the given format.
ToDateParser - Class in org.h2.mode
Emulates Oracle's TO_DATE function.
This class holds and handles the input data form the TO_DATE-method
ToDateParser(SessionLocal, ToDateParser.ConfigParam, String, String) - Constructor for class org.h2.mode.ToDateParser
 
ToDateParser.ConfigParam - Enum in org.h2.mode
The configuration of the date parser.
toDateParslet - Variable in enum org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
ToDateTokenizer - Class in org.h2.mode
Emulates Oracle's TO_DATE function.
ToDateTokenizer() - Constructor for class org.h2.mode.ToDateTokenizer
 
ToDateTokenizer.DayParslet - Class in org.h2.mode
Parslet responsible for parsing day parameter
ToDateTokenizer.FormatTokenEnum - Enum in org.h2.mode
The format tokens.
ToDateTokenizer.InlineParslet - Class in org.h2.mode
Parslet responsible for parsing year parameter
ToDateTokenizer.MonthParslet - Class in org.h2.mode
Parslet responsible for parsing month parameter
ToDateTokenizer.TimeParslet - Class in org.h2.mode
Parslet responsible for parsing time parameter
ToDateTokenizer.ToDateParslet - Interface in org.h2.mode
Interface of the classes that can parse a specialized small bit of the TO_DATE format-string.
ToDateTokenizer.YearParslet - Class in org.h2.mode
Parslet responsible for parsing year parameter
toDecfloatType() - Method in class org.h2.value.TypeInfo
Convert this type information to compatible DECFLOAT type information.
toElement(K, Object) - Method in class org.h2.mvstore.tx.TransactionMap.TMIterator
 
toGroupEnd(ArrayList<Value[]>, SortOrder, int, int) - Static method in class org.h2.expression.analysis.WindowFrame
 
toGroupStart(ArrayList<Value[]>, SortOrder, int, int) - Static method in class org.h2.expression.analysis.WindowFrame
 
toHex(BigDecimal, String) - Static method in class org.h2.expression.function.ToCharFunction
 
toIntArray(Value) - Static method in class org.h2.jdbc.meta.DatabaseMetaServer
 
token - Variable in class org.h2.command.Parser
 
Token - Class in org.h2.command
Token.
Token(int) - Constructor for class org.h2.command.Token
 
Token.BigintToken - Class in org.h2.command
 
Token.BinaryStringToken - Class in org.h2.command
 
Token.CharacterStringToken - Class in org.h2.command
 
Token.EndOfInputToken - Class in org.h2.command
 
Token.IdentifierToken - Class in org.h2.command
 
Token.IntegerToken - Class in org.h2.command
 
Token.KeywordOrIdentifierToken - Class in org.h2.command
 
Token.KeywordToken - Class in org.h2.command
 
Token.LiteralToken - Class in org.h2.command
 
Token.ParameterToken - Class in org.h2.command
 
Token.ValueToken - Class in org.h2.command
 
tokenIndex - Variable in class org.h2.command.Parser
 
tokenize() - Method in class org.h2.bnf.Bnf
 
tokenize(String, boolean) - Method in class org.h2.command.Tokenizer
 
Tokenizer - Class in org.h2.command
Tokenizer.
Tokenizer(CastDataProvider, boolean, boolean, BitSet) - Constructor for class org.h2.command.Tokenizer
 
tokens - Variable in class org.h2.bnf.Bnf
 
tokens - Variable in class org.h2.command.Parser
 
TOKENS - Static variable in class org.h2.command.Token
 
TOKENS - Static variable in enum org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
tokenType() - Method in class org.h2.command.Token.EndOfInputToken
 
tokenType() - Method in class org.h2.command.Token.IdentifierToken
 
tokenType() - Method in class org.h2.command.Token.KeywordOrIdentifierToken
 
tokenType() - Method in class org.h2.command.Token.KeywordToken
 
tokenType() - Method in class org.h2.command.Token.LiteralToken
 
tokenType() - Method in class org.h2.command.Token.ParameterToken
 
tokenType() - Method in class org.h2.command.Token
 
toLines() - Method in class org.h2.util.SortedProperties
Convert the map to a list of line in the form key=value.
toLogId - Variable in class org.h2.mvstore.tx.RollbackDecisionMaker
 
toLowerEnglish(String) - Static method in class org.h2.util.StringUtils
Convert a string to lowercase using the English locale.
toNumericType() - Method in class org.h2.value.TypeInfo
Convert this type information to compatible NUMERIC type information.
TOO_MANY_COLUMNS_1 - Static variable in class org.h2.api.ErrorCode
The error with code 54011 is thrown when too many columns were specified in a table, select statement, or row value.
Tool - Class in org.h2.util
Command line tools implement the tool interface so that they can be used in the H2 Console.
Tool() - Constructor for class org.h2.util.Tool
 
tools() - Method in class org.h2.server.web.WebApp
 
topFilter - Variable in class org.h2.command.query.Optimizer
 
topFilters - Variable in class org.h2.command.query.Select
 
topic - Variable in class org.h2.bnf.RuleHead
 
topInDML - Variable in class org.h2.engine.Mode
Whether TOP clause in DML commands is supported.
topInSelect - Variable in class org.h2.engine.Mode
Whether TOP clause in SELECT queries is supported.
topMove - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Entry
When the item was last moved to the top of the stack.
toPostgreDays(long) - Static method in class org.h2.server.pg.PgServerThread
 
topQuery - Variable in class org.h2.table.TableView
 
topTableFilter - Variable in class org.h2.command.query.Select
The main (top) table filter.
toRealPath() - Method in class org.h2.store.fs.disk.FilePathDisk
 
toRealPath() - Method in class org.h2.store.fs.FilePath
Normalize a file name.
toRealPath() - Method in class org.h2.store.fs.FilePathWrapper
 
toRealPath() - Method in class org.h2.store.fs.mem.FilePathMem
 
toRealPath() - Method in class org.h2.store.fs.niomem.FilePathNioMem
 
toRealPath() - Method in class org.h2.store.fs.zip.FilePathZip
 
toRealPath(String) - Static method in class org.h2.store.fs.FileUtils
Get the canonical file or directory name.
toRealPath(Path) - Static method in class org.h2.store.fs.disk.FilePathDisk
 
toRomanNumeral(int) - Static method in class org.h2.expression.function.ToCharFunction
 
toSQL(StringBuilder, int, Integer) - Static method in class org.h2.value.ExtTypeInfoGeometry
 
toSQL(StringBuilder, String[]) - Static method in class org.h2.value.ExtTypeInfoEnum
 
toSQLException(Throwable) - Static method in exception org.h2.message.DbException
Convert an exception to a SQL exception using the default mapping.
toString() - Method in class org.h2.api.H2Type
 
toString() - Method in class org.h2.api.Interval
 
toString() - Method in enum org.h2.api.IntervalQualifier
 
toString() - Method in class org.h2.bnf.Bnf
 
toString() - Method in class org.h2.bnf.RuleElement
 
toString() - Method in class org.h2.bnf.RuleExtension
 
toString() - Method in class org.h2.bnf.RuleFixed
 
toString() - Method in class org.h2.bnf.RuleList
 
toString() - Method in class org.h2.bnf.RuleOptional
 
toString() - Method in class org.h2.bnf.RuleRepeat
 
toString() - Method in class org.h2.command.Command
 
toString() - Method in class org.h2.command.CommandRemote
 
toString() - Method in class org.h2.command.Parser
 
toString() - Method in class org.h2.command.Prepared
Convert the statement to a String.
toString() - Method in class org.h2.command.Token.IdentifierToken
 
toString() - Method in class org.h2.command.Token.KeywordOrIdentifierToken
 
toString() - Method in class org.h2.command.Token.KeywordToken
 
toString() - Method in class org.h2.command.Token.LiteralToken
 
toString() - Method in class org.h2.command.Token.ParameterToken
 
toString() - Method in class org.h2.engine.Database
 
toString() - Method in class org.h2.engine.DbObject
 
toString() - Method in class org.h2.engine.MetaRecord
 
toString() - Method in class org.h2.engine.Mode
 
toString() - Method in class org.h2.engine.SessionLocal
 
toString() - Method in class org.h2.expression.analysis.Window
 
toString() - Method in class org.h2.expression.Expression
Convert this expression to a String.
toString() - Method in class org.h2.index.IndexCondition
 
toString() - Method in class org.h2.jdbc.JdbcArray
INTERNAL
toString() - Method in class org.h2.jdbc.JdbcConnection
INTERNAL
toString() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
INTERNAL
toString() - Method in interface org.h2.jdbc.JdbcException
Returns the class name, the message, and in the server mode, the stack trace of the server
toString() - Method in class org.h2.jdbc.JdbcLob
INTERNAL
toString() - Method in class org.h2.jdbc.JdbcParameterMetaData
INTERNAL
toString() - Method in class org.h2.jdbc.JdbcPreparedStatement
INTERNAL
toString() - Method in class org.h2.jdbc.JdbcResultSet
INTERNAL
toString() - Method in class org.h2.jdbc.JdbcResultSetMetaData
INTERNAL
toString() - Method in class org.h2.jdbc.JdbcSavepoint
INTERNAL
toString() - Method in exception org.h2.jdbc.JdbcSQLDataException
 
toString() - Method in exception org.h2.jdbc.JdbcSQLException
 
toString() - Method in exception org.h2.jdbc.JdbcSQLFeatureNotSupportedException
 
toString() - Method in exception org.h2.jdbc.JdbcSQLIntegrityConstraintViolationException
 
toString() - Method in exception org.h2.jdbc.JdbcSQLInvalidAuthorizationSpecException
 
toString() - Method in exception org.h2.jdbc.JdbcSQLNonTransientConnectionException
 
toString() - Method in exception org.h2.jdbc.JdbcSQLNonTransientException
 
toString() - Method in exception org.h2.jdbc.JdbcSQLSyntaxErrorException
 
toString() - Method in exception org.h2.jdbc.JdbcSQLTimeoutException
 
toString() - Method in exception org.h2.jdbc.JdbcSQLTransactionRollbackException
 
toString() - Method in exception org.h2.jdbc.JdbcSQLTransientException
 
toString() - Method in class org.h2.jdbc.JdbcStatement
INTERNAL
toString() - Method in class org.h2.jdbcx.JdbcDataSource
INTERNAL
toString() - Method in class org.h2.jdbcx.JdbcXAConnection
INTERNAL
toString() - Method in class org.h2.mode.ToDateParser
 
toString() - Method in class org.h2.mvstore.cache.FilePathCache.FileCache
 
toString() - Method in class org.h2.mvstore.Chunk
 
toString() - Method in class org.h2.mvstore.CursorPos
 
toString() - Method in class org.h2.mvstore.db.MVTable
 
toString() - Method in class org.h2.mvstore.db.SpatialKey
 
toString() - Method in class org.h2.mvstore.FileStore
 
toString() - Method in class org.h2.mvstore.FreeSpaceBitSet
 
toString() - Method in class org.h2.mvstore.MVMap.EqualsDecisionMaker
 
toString() - Method in class org.h2.mvstore.MVMap.RewriteDecisionMaker
 
toString() - Method in class org.h2.mvstore.MVMap
 
toString() - Method in class org.h2.mvstore.MVStore.Builder
 
toString() - Method in class org.h2.mvstore.MVStore.RemovedPageInfo
 
toString() - Method in class org.h2.mvstore.MVStore.TxCounter
 
toString() - Method in class org.h2.mvstore.OffHeapStore
 
toString() - Method in class org.h2.mvstore.Page.PageReference
 
toString() - Method in class org.h2.mvstore.Page
 
toString() - Method in class org.h2.mvstore.RootReference
 
toString() - Method in class org.h2.mvstore.tx.CommitDecisionMaker
 
toString() - Method in class org.h2.mvstore.tx.Record
 
toString() - Method in class org.h2.mvstore.tx.RollbackDecisionMaker
 
toString() - Method in class org.h2.mvstore.tx.Transaction
 
toString() - Method in class org.h2.mvstore.tx.TxDecisionMaker
 
toString() - Method in class org.h2.mvstore.tx.VersionedValueCommitted
 
toString() - Method in class org.h2.mvstore.tx.VersionedValueUncommitted
 
toString() - Method in class org.h2.result.DefaultRow
 
toString() - Method in class org.h2.result.LocalResult
 
toString() - Method in class org.h2.result.MergedResult
 
toString() - Method in class org.h2.result.ResultRemote
 
toString() - Method in class org.h2.result.SimpleResult.Column
 
toString() - Method in class org.h2.result.SimpleRowValue
 
toString() - Method in class org.h2.schema.FunctionAlias.JavaMethod
 
toString() - Method in class org.h2.store.fs.async.FileAsync
 
toString() - Method in class org.h2.store.fs.encrypt.FileEncrypt
 
toString() - Method in class org.h2.store.fs.FilePath
Get the string representation.
toString() - Method in class org.h2.store.fs.mem.FileMem
 
toString() - Method in class org.h2.store.fs.niomapped.FileNioMapped
 
toString() - Method in class org.h2.store.fs.niomem.FileNioMem
 
toString() - Method in class org.h2.store.fs.rec.FileRec
 
toString() - Method in class org.h2.store.fs.retry.FileRetryOnInterrupt
 
toString() - Method in class org.h2.store.fs.split.FileSplit
 
toString() - Method in class org.h2.table.Column
 
toString() - Method in class org.h2.table.IndexColumn
 
toString() - Method in class org.h2.table.IndexHints
 
toString() - Method in class org.h2.table.TableFilter
 
toString() - Method in enum org.h2.table.TableType
 
toString() - Method in class org.h2.util.geometry.EWKBUtils.EWKBSource
 
toString() - Method in class org.h2.util.geometry.EWKTUtils.EWKTSource
 
toString() - Method in class org.h2.util.IntArray
 
toString() - Method in class org.h2.util.json.JSONBytesSource
 
toString() - Method in class org.h2.util.json.JSONStringSource
 
toString() - Method in class org.h2.util.json.JSONValue
 
toString() - Method in class org.h2.util.TimeZoneProvider.Simple
 
toString() - Method in class org.h2.util.TimeZoneProvider.WithTimeZone
 
toString() - Method in class org.h2.value.ExtTypeInfo
 
toString() - Method in class org.h2.value.lob.LobDataDatabase
 
toString() - Method in class org.h2.value.lob.LobDataFetchOnDemand
 
toString() - Method in class org.h2.value.lob.LobDataFile
 
toString() - Method in class org.h2.value.Value
 
toString(byte[]) - Static method in class org.h2.mvstore.StreamStore
Convert the id to a human readable string.
toString(StringBuilder) - Method in class org.h2.value.ValueTimeTimeZone
 
toString(StringBuilder, boolean) - Method in class org.h2.value.ValueTimestamp
 
toString(StringBuilder, boolean) - Method in class org.h2.value.ValueTimestampTimeZone
 
toString(StringBuilder, Xid) - Static method in class org.h2.jdbcx.JdbcXid
INTERNAL
toStringArray(Value) - Static method in class org.h2.jdbc.meta.DatabaseMetaServer
 
toTable(String, Column[], ArrayList<Parameter>, boolean, Query) - Method in class org.h2.command.query.Query
Converts this query to a table or a view.
toTable(String, Column[], ArrayList<Parameter>, boolean, Query) - Method in class org.h2.command.query.TableValueConstructor
 
total - Variable in class org.h2.util.Profiler
 
totalCount - Variable in class org.h2.mvstore.Page.NonLeaf
The total entry count of this page and all children.
toTime(CastDataProvider, TimeZone, Value) - Static method in class org.h2.util.LegacyDateTimeUtils
Get the time value converted to the specified time zone.
toTimestamp(CastDataProvider, TimeZone, Value) - Static method in class org.h2.util.LegacyDateTimeUtils
Get the timestamp value converted to the specified time zone.
toTimestamp(SessionLocal, String, String) - Static method in class org.h2.mode.ToDateParser
Parse a string as a timestamp with the given format.
toTimestampTz(SessionLocal, String, String) - Static method in class org.h2.mode.ToDateParser
Parse a string as a timestamp with the given format.
touch(boolean) - Method in class org.h2.store.fs.mem.FileMemData
Update the last modified time.
touch(boolean) - Method in class org.h2.store.fs.niomem.FileNioMemData
Update the last modified time.
toUpperEnglish(String) - Static method in class org.h2.util.StringUtils
Convert a string to uppercase using the English locale.
trace - Variable in class org.h2.command.Command
The trace module.
trace - Variable in class org.h2.command.CommandRemote
 
trace - Variable in class org.h2.engine.Database
 
trace - Variable in class org.h2.engine.DbObject
The trace module.
trace - Variable in class org.h2.engine.DelayedDatabaseCloser
 
trace - Variable in class org.h2.engine.SessionLocal
 
trace - Variable in class org.h2.engine.SessionRemote
 
trace - Variable in class org.h2.jdbcx.JdbcDataSourceFactory
 
trace - Variable in class org.h2.message.TraceObject
The trace module used by this object.
trace - Variable in class org.h2.result.ResultRemote
 
trace - Variable in class org.h2.server.pg.PgServer
 
trace - Variable in class org.h2.server.TcpServer
 
trace - Variable in class org.h2.server.web.WebServer
 
trace - Variable in class org.h2.store.FileLock
The trace object.
trace - Variable in class org.h2.store.fs.rec.FilePathRec
 
trace - Variable in class org.h2.tools.Recover
 
trace(long, long) - Method in class org.h2.command.Prepared
Print information about the statement executed if info trace level is enabled.
trace(String) - Static method in class org.h2.mvstore.db.LobStorageMap
 
trace(String) - Method in class org.h2.server.pg.PgServer
Print a message if the trace flag is enabled.
trace(String) - Method in class org.h2.server.TcpServer
Print a message if the trace flag is enabled.
trace(String) - Method in class org.h2.server.TcpServerThread
 
trace(String) - Method in class org.h2.server.web.WebApp
 
trace(String) - Method in class org.h2.server.web.WebServer
Write trace information if trace is enabled.
trace(String) - Method in class org.h2.server.web.WebThread
 
trace(String) - Method in class org.h2.tools.Recover
 
trace(String, String, Object) - Static method in class org.h2.store.FileStore
 
trace(String, String, Object) - Static method in class org.h2.util.IOUtils
Trace input or output operations if enabled.
Trace - Class in org.h2.message
This class represents a trace module.
Trace(TraceWriter, int) - Constructor for class org.h2.message.Trace
 
Trace(TraceWriter, String) - Constructor for class org.h2.message.Trace
 
TRACE - Static variable in class org.h2.mvstore.db.LobStorageMap
 
TRACE - Static variable in class org.h2.util.AbbaDetector
 
TRACE_CONNECTION_NOT_CLOSED - Static variable in class org.h2.api.ErrorCode
The error with code 90018 is thrown when the connection was opened, but never closed.
TRACE_FILE_ERROR_2 - Static variable in class org.h2.api.ErrorCode
The error with code 90034 is thrown when writing to the trace file failed, for example because the there is an I/O exception.
TRACE_IO - Static variable in class org.h2.engine.SysProperties
System property h2.traceIO (default: false).
TRACE_LEVEL_FILE - Static variable in class org.h2.command.dml.SetTypes
The type of a SET TRACE_LEVEL_FILE statement.
TRACE_LEVEL_SYSTEM_OUT - Static variable in class org.h2.command.dml.SetTypes
The type of a SET TRACE_LEVEL_SYSTEM_OUT statement.
TRACE_LOCK_ADD_UPGRADED_FOR - org.h2.mvstore.db.MVTable.TraceLockEvent
 
TRACE_LOCK_ADDED_FOR - org.h2.mvstore.db.MVTable.TraceLockEvent
 
TRACE_LOCK_OK - org.h2.mvstore.db.MVTable.TraceLockEvent
 
TRACE_LOCK_REQUESTING_FOR - org.h2.mvstore.db.MVTable.TraceLockEvent
 
TRACE_LOCK_TIMEOUT_AFTER - org.h2.mvstore.db.MVTable.TraceLockEvent
 
TRACE_LOCK_UNLOCK - org.h2.mvstore.db.MVTable.TraceLockEvent
 
TRACE_LOCK_WAITING_FOR - org.h2.mvstore.db.MVTable.TraceLockEvent
 
TRACE_MAX_FILE_SIZE - Static variable in class org.h2.command.dml.SetTypes
The type of a SET TRACE_MAX_FILE_SIZE statement.
TRACE_SQL_FLAGS - Static variable in interface org.h2.util.HasSQL
Combined flags for trace.
traceError(Exception) - Method in class org.h2.server.pg.PgServer
Print the stack trace if the trace flag is enabled.
traceError(String, Throwable) - Method in class org.h2.tools.Recover
 
traceError(Throwable) - Method in class org.h2.server.TcpServer
Print a stack trace if the trace flag is enabled.
traceError(Throwable) - Method in class org.h2.server.web.WebServer
Write the stack trace if trace is enabled.
traceLevel - Variable in class org.h2.message.Trace
 
traceLock - Variable in class org.h2.mvstore.db.MVTable
 
traceLock(SessionLocal, int, MVTable.TraceLockEvent, String) - Method in class org.h2.mvstore.db.MVTable
 
TraceLockEvent(String) - Constructor for enum org.h2.mvstore.db.MVTable.TraceLockEvent
 
TraceObject - Class in org.h2.message
The base class for objects that can print trace information about themselves.
TraceObject() - Constructor for class org.h2.message.TraceObject
 
traceOperation(String, int) - Method in class org.h2.engine.SessionRemote
Write the operation to the trace system if debug trace is enabled.
traces - Variable in class org.h2.message.TraceSystem
 
traceSystem - Variable in class org.h2.engine.Database
 
traceSystem - Variable in class org.h2.engine.SessionRemote
 
traceSystem - Static variable in class org.h2.jdbcx.JdbcDataSourceFactory
 
TraceSystem - Class in org.h2.message
The trace mechanism is the logging facility of this database.
TraceSystem(String) - Constructor for class org.h2.message.TraceSystem
Create a new trace system object.
traceThrowable(Throwable) - Static method in exception org.h2.message.DbException
Write the exception to the driver manager log writer if configured.
traceType - Variable in class org.h2.message.TraceObject
 
traceWriter - Variable in class org.h2.message.Trace
 
TraceWriter - Interface in org.h2.message
The backend of the trace system must implement this interface.
TraceWriterAdapter - Class in org.h2.message
This adapter sends log output to SLF4J.
TraceWriterAdapter() - Constructor for class org.h2.message.TraceWriterAdapter
 
TRAILING - Static variable in class org.h2.expression.function.TrimFunction
The TRAILING flag.
transaction - Variable in class org.h2.engine.SessionLocal
 
transaction - Variable in class org.h2.mvstore.db.MVInDoubtTransaction
 
transaction - Variable in class org.h2.mvstore.tx.TransactionMap
The transaction which is used for this map.
transaction - Variable in class org.h2.mvstore.tx.TxDecisionMaker
Transaction we are operating within
Transaction - Class in org.h2.mvstore.tx
A transaction.
Transaction(TransactionStore, int, long, int, String, long, int, int, IsolationLevel, TransactionStore.RollbackListener) - Constructor for class org.h2.mvstore.tx.Transaction
 
TRANSACTION_ID - Static variable in class org.h2.expression.function.SysInfoFunction
TRANSACTION_ID().
TRANSACTION_NOT_FOUND_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90129 is thrown when trying to commit a transaction that doesn't exist.
TRANSACTION_SNAPSHOT - Static variable in class org.h2.engine.Constants
SNAPSHOT isolation level of transaction.
transactional - Variable in class org.h2.command.ddl.DefineCommand
The transactional behavior.
TransactionCommand - Class in org.h2.command.dml
Represents a transactional statement.
TransactionCommand(SessionLocal, int) - Constructor for class org.h2.command.dml.TransactionCommand
 
transactionId - Variable in class org.h2.mvstore.tx.RollbackDecisionMaker
 
transactionId - Variable in class org.h2.mvstore.tx.Transaction
The transaction id.
transactionId - Variable in class org.h2.mvstore.tx.TransactionMap.TMIterator
 
TransactionMap<K,​V> - Class in org.h2.mvstore.tx
A map that supports transactions.
TransactionMap(Transaction, MVMap<K, VersionedValue<V>>) - Constructor for class org.h2.mvstore.tx.TransactionMap
 
TransactionMap.CommittedIterator<K,​V,​X> - Class in org.h2.mvstore.tx
The iterator for read committed isolation level.
TransactionMap.RepeatableIterator<K,​V,​X> - Class in org.h2.mvstore.tx
The iterator for repeatable read and serializable isolation levels.
TransactionMap.TMIterator<K,​V,​X> - Class in org.h2.mvstore.tx
 
TransactionMap.UncommittedIterator<K,​V,​X> - Class in org.h2.mvstore.tx
The iterator for read uncommitted isolation level.
TransactionMap.ValidationIterator<K,​V,​X> - Class in org.h2.mvstore.tx
 
transactionMaps - Variable in class org.h2.mvstore.tx.Transaction
Map of transactional maps for this transaction
transactionName - Variable in class org.h2.command.dml.TransactionCommand
 
transactions - Variable in class org.h2.mvstore.tx.TransactionStore
Array holding all open transaction objects.
transactionSavepoint - Variable in class org.h2.engine.SessionLocal.Savepoint
The transaction savepoint id.
transactionStore - Variable in class org.h2.mvstore.db.MVTable
 
transactionStore - Variable in class org.h2.mvstore.db.Store
The transaction store.
transactionStore - Variable in class org.h2.mvstore.tx.Record.Type
 
TransactionStore - Class in org.h2.mvstore.tx
A store that supports concurrent MVCC read-committed transactions.
TransactionStore(MVStore) - Constructor for class org.h2.mvstore.tx.TransactionStore
Create a new transaction store.
TransactionStore(MVStore, DataType<?>) - Constructor for class org.h2.mvstore.tx.TransactionStore
 
TransactionStore(MVStore, MetaType<?>, DataType<?>, int) - Constructor for class org.h2.mvstore.tx.TransactionStore
Create a new transaction store.
TransactionStore.Change - Class in org.h2.mvstore.tx
A change in a map.
TransactionStore.RollbackListener - Interface in org.h2.mvstore.tx
This listener can be registered with the transaction to be notified of every compensating change during transaction rollback.
TransactionStore.TxMapBuilder<K,​V> - Class in org.h2.mvstore.tx
 
TransactionStore.TxMapBuilder.TMVMap<K,​V> - Class in org.h2.mvstore.tx
 
transfer - Variable in class org.h2.result.ResultRemote
 
transfer - Variable in class org.h2.server.TcpServerThread
 
Transfer - Class in org.h2.value
The transfer class is used to send and receive Value objects.
Transfer(Session, Socket) - Constructor for class org.h2.value.Transfer
Create a new transfer object for the specified session.
transferFrom(ReadableByteChannel, long, long) - Method in class org.h2.store.fs.FakeFileChannel
 
transferFrom(ReadableByteChannel, long, long) - Method in class org.h2.store.fs.FileBase
 
transferList - Variable in class org.h2.command.CommandRemote
 
transferList - Variable in class org.h2.engine.SessionRemote
 
transferList - Variable in class org.h2.jdbc.meta.DatabaseMetaRemote
 
transferTo(long, long, WritableByteChannel) - Method in class org.h2.store.fs.FakeFileChannel
 
transferTo(long, long, WritableByteChannel) - Method in class org.h2.store.fs.FileBase
 
transitionToState(SessionLocal.State, boolean) - Method in class org.h2.engine.SessionLocal
 
translate(String, String...) - Static method in exception org.h2.message.DbException
 
translate(String, String, String) - Static method in class org.h2.expression.function.StringFunction
 
TRANSLATE - Static variable in class org.h2.expression.function.StringFunction
TRANSLATE() (non-standard).
translateFileName(String) - Static method in class org.h2.store.fs.disk.FilePathDisk
Translate the file name to the native format.
translateFileName(String) - Static method in class org.h2.store.fs.zip.FilePathZip
 
translateGetEnd(String, int, char) - Static method in class org.h2.jdbc.JdbcConnection
 
translateSQL(String) - Static method in class org.h2.jdbc.JdbcConnection
Convert JDBC escape sequences in the SQL statement.
translateSQL(String, boolean) - Static method in class org.h2.jdbc.JdbcConnection
Convert JDBC escape sequences in the SQL statement if required.
translateSQLImpl(String) - Static method in class org.h2.jdbc.JdbcConnection
 
translateThread - Variable in class org.h2.server.web.WebServer
 
TranslateThread(Map<Object, Object>) - Constructor for class org.h2.server.web.WebServer.TranslateThread
 
translation - Variable in class org.h2.server.web.WebServer.TranslateThread
 
traverseDown(Page<K, V>, K) - Static method in class org.h2.mvstore.CursorPos
Searches for a given key and creates a breadcrumb trail through a B-tree rooted at a given Page.
traverseDown(Page<K, V>, K, boolean) - Static method in class org.h2.mvstore.Cursor
Fetch the next entry that is equal or larger than the given key, starting from the given page.
tray - Variable in class org.h2.tools.GUIConsole
 
trayIcon - Variable in class org.h2.tools.GUIConsole
 
trayIconUsed - Variable in class org.h2.tools.GUIConsole
 
treatEmptyStringsAsNull - Variable in class org.h2.engine.Mode
Empty strings are treated like NULL values.
Trigger - Interface in org.h2.api
A class that implements this interface can be used as a trigger.
TRIGGER - Static variable in class org.h2.engine.DbObject
This object is a trigger.
TRIGGER - Static variable in class org.h2.message.Trace
The trace module id for triggers.
TRIGGER_ALREADY_EXISTS_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90041 is thrown when trying to create a trigger and there is already a trigger with that name.
TRIGGER_NOT_FOUND_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90042 is thrown when trying to drop a trigger that does not exist.
TRIGGER_PREFIX - Static variable in class org.h2.fulltext.FullText
 
TRIGGER_PREFIX - Static variable in class org.h2.fulltext.FullTextLucene
 
TriggerAdapter - Class in org.h2.tools
An adapter for the trigger interface that allows to use the ResultSet interface instead of a row array.
TriggerAdapter() - Constructor for class org.h2.tools.TriggerAdapter
 
triggerCallback - Variable in class org.h2.schema.TriggerObject
 
triggerClassName - Variable in class org.h2.command.ddl.CreateTrigger
 
triggerClassName - Variable in class org.h2.schema.TriggerObject
 
triggerName - Variable in class org.h2.command.ddl.CreateTrigger
 
triggerName - Variable in class org.h2.command.ddl.DropTrigger
 
triggerName - Variable in class org.h2.tools.TriggerAdapter
The name of the trigger.
TriggerObject - Class in org.h2.schema
A trigger is created using the statement CREATE TRIGGER
TriggerObject(Schema, int, String, Table) - Constructor for class org.h2.schema.TriggerObject
 
triggers - Variable in class org.h2.schema.Schema
 
triggers - Variable in class org.h2.table.Table
 
triggers(SessionLocal, ArrayList<Row>, String, TriggerObject, String, Table, String) - Method in class org.h2.table.InformationSchemaTable
 
triggers(SessionLocal, Value, Value, ArrayList<Row>, String) - Method in class org.h2.table.InformationSchemaTable
 
TRIGGERS - Static variable in class org.h2.table.InformationSchemaTable
 
TRIGGERS - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
triggerSource - Variable in class org.h2.command.ddl.CreateTrigger
 
triggerSource - Variable in class org.h2.schema.TriggerObject
 
triggerUpdatable - Variable in class org.h2.jdbc.JdbcResultSet
 
triIterator(ArrayList<Value[]>, int, int, int, int, int, int, boolean) - Static method in class org.h2.expression.analysis.WindowFrame
 
TriItr(ArrayList<Value[]>, int, int, int, int, int, int) - Constructor for class org.h2.expression.analysis.WindowFrame.TriItr
 
trim(String, boolean, boolean, String) - Static method in class org.h2.util.StringUtils
Trim a character from a string.
TRIM_ARRAY - Static variable in class org.h2.expression.function.ArrayFunction
TRIM_ARRAY().
trimExternal(long, long) - Method in class org.h2.result.LocalResult
 
TrimFunction - Class in org.h2.expression.function
A TRIM function.
TrimFunction(Expression, Expression, int) - Constructor for class org.h2.expression.function.TrimFunction
 
trimLast() - Method in class org.h2.mvstore.MVMap
Removes last entry from this map.
trimNonResidentQueue() - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
 
trimNonResidentQueue() - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Loop through segments, trimming the non resident queue.
trimSubstring(StringBuilder, String, int, int) - Static method in class org.h2.util.StringUtils
Trim a whitespace from a substring and append it to a specified string builder.
trimSubstring(String, int) - Static method in class org.h2.util.StringUtils
Trim a whitespace from a substring.
trimSubstring(String, int, int) - Static method in class org.h2.util.StringUtils
Trim a whitespace from a substring.
TriReverseItr(ArrayList<Value[]>, int, int, int, int, int, int) - Constructor for class org.h2.expression.analysis.WindowFrame.TriReverseItr
 
TRUE - Static variable in class org.h2.expression.ValueExpression
The expression represents ValueBoolean.TRUE.
TRUE - Static variable in class org.h2.util.json.JSONBoolean
true value.
TRUE - Static variable in class org.h2.util.ParserUtil
The token "TRUE".
TRUE - Static variable in class org.h2.value.ValueBoolean
TRUE value.
TRUE - Static variable in class org.h2.value.ValueJson
true JSON value.
TRUE_BYTES - Static variable in class org.h2.util.json.JSONByteArrayTarget
 
TRUE_BYTES - Static variable in class org.h2.value.ValueJson
 
TRUNC - Static variable in class org.h2.expression.function.MathFunction
TRUNC() (non-standard)
truncate(long) - Method in class org.h2.jdbc.JdbcBlob
[Not supported] Truncates the object.
truncate(long) - Method in class org.h2.jdbc.JdbcClob
[Not supported] Truncates the object.
truncate(long) - Method in class org.h2.mvstore.cache.FilePathCache.FileCache
 
truncate(long) - Method in class org.h2.mvstore.FileStore
Truncate the file.
truncate(long) - Method in class org.h2.mvstore.OffHeapStore
 
truncate(long) - Method in class org.h2.store.fs.FakeFileChannel
 
truncate(long) - Method in class org.h2.store.fs.FileBaseDefault
 
truncate(long) - Method in class org.h2.store.fs.mem.FileMemData
Truncate the file.
truncate(long) - Method in class org.h2.store.fs.niomem.FileNioMemData
Truncate the file.
truncate(long) - Method in class org.h2.store.fs.rec.FileRec
 
truncate(long) - Method in class org.h2.store.fs.retry.FileRetryOnInterrupt
 
truncate(long) - Method in class org.h2.store.fs.zip.FileZip
 
truncate(SessionLocal) - Method in class org.h2.index.Index
Remove all rows from the index.
truncate(SessionLocal) - Method in class org.h2.index.LinkedIndex
 
truncate(SessionLocal) - Method in class org.h2.index.MetaIndex
 
truncate(SessionLocal) - Method in class org.h2.index.ViewIndex
 
truncate(SessionLocal) - Method in class org.h2.index.VirtualTableIndex
 
truncate(SessionLocal) - Method in class org.h2.mvstore.db.MVDelegateIndex
 
truncate(SessionLocal) - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
truncate(SessionLocal) - Method in class org.h2.mvstore.db.MVSecondaryIndex
 
truncate(SessionLocal) - Method in class org.h2.mvstore.db.MVSpatialIndex
 
truncate(SessionLocal) - Method in class org.h2.mvstore.db.MVTable
 
truncate(SessionLocal) - Method in class org.h2.table.MetaTable
 
truncate(SessionLocal) - Method in class org.h2.table.Table
Remove all rows from the table and indexes.
truncate(SessionLocal) - Method in class org.h2.table.TableLink
 
truncate(SessionLocal) - Method in class org.h2.table.TableView
 
truncate(SessionLocal) - Method in class org.h2.table.VirtualTable
 
TRUNCATE - Static variable in interface org.h2.store.fs.Recorder
Truncate the file.
TRUNCATE_LARGE_LENGTH - Static variable in class org.h2.command.dml.SetTypes
The type of a SET TRUNCATE_LARGE_LENGTH statement.
TRUNCATE_TABLE - Static variable in interface org.h2.command.CommandInterface
The type of a TRUNCATE TABLE statement.
truncateDate(SessionLocal, int, Value) - Static method in class org.h2.expression.function.DateTimeFunction
Truncate the given date-time value to the specified field.
truncateLargeLength - Variable in class org.h2.engine.SessionLocal
Whether length in definitions of data types is truncated.
truncateString(String, int) - Static method in class org.h2.util.StringUtils
Truncates the specified string to the specified length.
TruncateTable - Class in org.h2.command.ddl
This class represents the statement TRUNCATE TABLE
TruncateTable(SessionLocal) - Constructor for class org.h2.command.ddl.TruncateTable
 
truncateTableRestartIdentity - Variable in class org.h2.engine.Mode
If true TRUNCATE TABLE uses RESTART IDENTITY by default.
truncateToWeek(long, int) - Static method in class org.h2.expression.function.DateTimeFunction
 
truncateToWeekYear(long, int, int) - Static method in class org.h2.expression.function.DateTimeFunction
 
TruncateValueFunction - Class in org.h2.expression.function
A TRUNCATE_VALUE function.
TruncateValueFunction(Expression, Expression, Expression) - Constructor for class org.h2.expression.function.TruncateValueFunction
 
tryCommit() - Method in class org.h2.mvstore.MVStore
Unlike regular commit this method returns immediately if there is commit in progress on another thread, otherwise it acts as regular commit.
tryCommit(Predicate<MVStore>) - Method in class org.h2.mvstore.MVStore
 
tryDelete(String) - Static method in class org.h2.store.fs.FileUtils
Try to delete a file or directory (ignoring errors).
tryLock() - Method in class org.h2.store.FileStore
Try to lock the file.
tryLock(int) - Method in class org.h2.mvstore.RootReference
Try to lock.
tryLock(long, long, boolean) - Method in class org.h2.mvstore.cache.FilePathCache.FileCache
 
tryLock(long, long, boolean) - Method in class org.h2.store.fs.async.FileAsync
 
tryLock(long, long, boolean) - Method in class org.h2.store.fs.encrypt.FileEncrypt
 
tryLock(long, long, boolean) - Method in class org.h2.store.fs.FakeFileChannel
 
tryLock(long, long, boolean) - Method in class org.h2.store.fs.FileBase
 
tryLock(long, long, boolean) - Method in class org.h2.store.fs.mem.FileMem
 
tryLock(long, long, boolean) - Method in class org.h2.store.fs.niomapped.FileNioMapped
 
tryLock(long, long, boolean) - Method in class org.h2.store.fs.niomem.FileNioMem
 
tryLock(long, long, boolean) - Method in class org.h2.store.fs.rec.FileRec
 
tryLock(long, long, boolean) - Method in class org.h2.store.fs.retry.FileRetryOnInterrupt
 
tryLock(long, long, boolean) - Method in class org.h2.store.fs.split.FileSplit
 
tryLock(long, long, boolean) - Method in class org.h2.store.fs.zip.FileZip
 
tryLock(RootReference<K, V>, int) - Method in class org.h2.mvstore.MVMap
Try to lock the root.
tryPut(K, V) - Method in class org.h2.mvstore.tx.TransactionMap
Try to update the value for the given key.
tryRemove(K) - Method in class org.h2.mvstore.tx.TransactionMap
Try to remove the value for the given key.
trySet(K, V) - Method in class org.h2.mvstore.tx.TransactionMap
Try to set or remove the value.
tryThrowDeadLockException(boolean) - Method in class org.h2.mvstore.tx.Transaction
 
tryUnlockAndUpdateVersion(long, int) - Method in class org.h2.mvstore.RootReference
Try to unlock, and if successful update the version
tryUnlockDatabase(List<String>, String) - Static method in class org.h2.store.FileLister
Try to lock the database, and then unlock it.
tryUpdate(RootReference<K, V>) - Method in class org.h2.mvstore.RootReference
 
tryUpdate(Schema, Domain) - Method in class org.h2.command.ddl.AlterDomainAddConstraint
Try to execute the statement.
tryUpdate(Table) - Method in class org.h2.command.ddl.AlterTableAddConstraint
Try to execute the statement.
txCounter - Variable in class org.h2.mvstore.tx.Transaction
Reference to a counter for an earliest store version used by this transaction.
TxCounter(long) - Constructor for class org.h2.mvstore.MVStore.TxCounter
 
txDecisionMaker - Variable in class org.h2.mvstore.tx.TransactionMap
 
TxDecisionMaker<K,​V> - Class in org.h2.mvstore.tx
Class TxDecisionMaker is a base implementation of MVMap.DecisionMaker to be used for TransactionMap modification.
TxDecisionMaker(int, Transaction) - Constructor for class org.h2.mvstore.tx.TxDecisionMaker
 
TxDecisionMaker.LockDecisionMaker<K,​V> - Class in org.h2.mvstore.tx
 
TxDecisionMaker.PutIfAbsentDecisionMaker<K,​V> - Class in org.h2.mvstore.tx
 
TxDecisionMaker.RepeatableReadLockDecisionMaker<K,​V> - Class in org.h2.mvstore.tx
 
TxMapBuilder(MVMap<String, DataType<?>>, DataType<?>) - Constructor for class org.h2.mvstore.tx.TransactionStore.TxMapBuilder
 
type - Variable in class org.h2.bnf.context.DbContextRule
 
type - Variable in class org.h2.bnf.RuleElement
 
type - Variable in class org.h2.bnf.RuleFixed
 
type - Variable in class org.h2.command.ddl.AlterDomainExpressions
 
type - Variable in class org.h2.command.ddl.AlterTableAddConstraint
 
type - Variable in class org.h2.command.ddl.AlterTableAlterColumn
 
type - Variable in class org.h2.command.ddl.AlterUser
 
type - Variable in class org.h2.command.dml.AlterTableSet
 
type - Variable in class org.h2.command.dml.Set
 
type - Variable in class org.h2.command.dml.TransactionCommand
 
type - Variable in class org.h2.command.Token.KeywordOrIdentifierToken
 
type - Variable in class org.h2.command.Token.KeywordToken
 
type - Variable in class org.h2.expression.aggregate.AbstractAggregate
The type of the result.
type - Variable in class org.h2.expression.analysis.WindowFrameBound
 
type - Variable in class org.h2.expression.analysis.WindowFunction
 
type - Variable in class org.h2.expression.ArrayConstructorByQuery
 
type - Variable in class org.h2.expression.condition.ConditionInConstantSet
 
type - Variable in class org.h2.expression.ExpressionList
 
type - Variable in class org.h2.expression.ExpressionVisitor
 
type - Variable in class org.h2.expression.function.CurrentDateTimeValueFunction
 
type - Variable in class org.h2.expression.function.Function0_1
The type of the result.
type - Variable in class org.h2.expression.function.SysInfoFunction
 
type - Variable in class org.h2.expression.Operation1_2
The type of the result.
type - Variable in class org.h2.expression.Operation1
The type of the result.
type - Variable in class org.h2.expression.Operation2
The type of the result.
type - Variable in class org.h2.expression.OperationN
The type of the result.
type - Variable in class org.h2.expression.ParameterRemote
 
type - Variable in class org.h2.expression.SimpleCase
 
type - Variable in class org.h2.expression.TypedValueExpression
 
type - Variable in class org.h2.mode.FunctionInfo
The function type.
type - Variable in class org.h2.mvstore.db.MVSecondaryIndex.Source.Comparator
 
type - Variable in class org.h2.mvstore.tx.TransactionStore.TxMapBuilder.TMVMap
 
type - Variable in class org.h2.schema.Domain
 
type - Variable in class org.h2.server.web.WebApp.IndexInfo
The index type name.
type - Variable in class org.h2.table.Column
 
type - Variable in class org.h2.table.MetaTable
The table type.
type - Variable in class org.h2.tools.TriggerAdapter
The trigger type: INSERT, UPDATE, DELETE, SELECT, or a combination (a bit field).
type - Variable in class org.h2.util.geometry.EWKBUtils.EWKBTarget
 
type - Variable in class org.h2.util.geometry.EWKTUtils.EWKTTarget
 
type - Variable in class org.h2.util.geometry.GeoJsonUtils.GeoJsonTarget
 
type - Variable in class org.h2.util.geometry.JTSUtils.GeometryTarget
 
type - Variable in class org.h2.util.json.JSONValidationTargetWithoutUniqueKeys
 
type - Variable in class org.h2.util.json.JSONValidationTargetWithUniqueKeys
 
type - Variable in class org.h2.util.SimpleColumnInfo
Type of the column, see Types.
type - Variable in class org.h2.value.DataType
The value type of this data type.
type - Variable in class org.h2.value.ExtTypeInfoEnum
 
type - Variable in class org.h2.value.ExtTypeInfoGeometry
 
type - Variable in class org.h2.value.ValueArray
 
type - Variable in class org.h2.value.ValueBigDecimalBase
 
type - Variable in class org.h2.value.ValueBinary
Associated TypeInfo.
type - Variable in class org.h2.value.ValueLob
 
type - Variable in class org.h2.value.ValueRow
 
type - Variable in class org.h2.value.ValueStringBase
 
type - Variable in class org.h2.value.ValueVarbinary
Associated TypeInfo.
Type() - Constructor for enum org.h2.constraint.Constraint.Type
 
Type() - Constructor for class org.h2.mvstore.db.LobStorageMap.BlobMeta.Type
 
Type() - Constructor for class org.h2.mvstore.db.LobStorageMap.BlobReference.Type
 
Type(TransactionStore) - Constructor for class org.h2.mvstore.tx.Record.Type
 
TYPE_ARRAY - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TYPE_ARRAY_UNKNOWN - Static variable in class org.h2.value.TypeInfo
ARRAY type with unknown parameters.
TYPE_BIG_DECIMAL - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TYPE_BIG_INTEGER - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TYPE_BIGINT - Static variable in class org.h2.value.TypeInfo
BIGINT type with parameters.
TYPE_BINARY - Static variable in class org.h2.value.TypeInfo
BINARY type with default parameters.
TYPE_BLOB - Static variable in class org.h2.value.TypeInfo
BINARY LARGE OBJECT type with maximum parameters.
TYPE_BOOLEAN - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TYPE_BOOLEAN - Static variable in class org.h2.value.TypeInfo
BOOLEAN type with parameters.
TYPE_BYTE - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TYPE_CACHED - Static variable in class org.h2.table.Table
The table type that means this table is a regular persistent table.
TYPE_CHAR - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TYPE_CHAR - Static variable in class org.h2.value.TypeInfo
CHAR type with default parameters.
TYPE_CLOB - Static variable in class org.h2.value.TypeInfo
CHARACTER LARGE OBJECT type with maximum parameters.
TYPE_COUNT - Static variable in class org.h2.value.Value
The number of value types.
TYPE_DATE - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TYPE_DATE - Static variable in class org.h2.value.TypeInfo
DATE type with parameters.
TYPE_DECFLOAT - Static variable in class org.h2.value.TypeInfo
DECFLOAT type with maximum parameters.
TYPE_DECFLOAT_BIGINT - Static variable in class org.h2.value.TypeInfo
DECFLOAT type with parameters enough to hold a BIGINT value.
TYPE_DOUBLE - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TYPE_DOUBLE - Static variable in class org.h2.value.TypeInfo
DOUBLE PRECISION type with parameters.
TYPE_ENUM_UNDEFINED - Static variable in class org.h2.value.TypeInfo
ENUM type with undefined parameters.
TYPE_FLOAT - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TYPE_GEOMETRY - Static variable in class org.h2.value.TypeInfo
GEOMETRY type with default parameters.
TYPE_INFO - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
TYPE_INFOS_BY_VALUE_TYPE - Static variable in class org.h2.value.TypeInfo
 
TYPE_INT - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TYPE_INTEGER - Static variable in class org.h2.value.TypeInfo
INTEGER type with parameters.
TYPE_INTERVAL_DAY - Static variable in class org.h2.value.TypeInfo
INTERVAL DAY type with maximum parameters.
TYPE_INTERVAL_DAY_TO_SECOND - Static variable in class org.h2.value.TypeInfo
INTERVAL DAY TO SECOND type with maximum parameters.
TYPE_INTERVAL_HOUR_TO_SECOND - Static variable in class org.h2.value.TypeInfo
INTERVAL HOUR TO SECOND type with maximum parameters.
TYPE_INTERVAL_YEAR_TO_MONTH - Static variable in class org.h2.value.TypeInfo
INTERVAL YEAR TO MONTH type with maximum parameters.
TYPE_JAVA_OBJECT - Static variable in class org.h2.value.TypeInfo
JAVA_OBJECT type with maximum parameters.
TYPE_JSON - Static variable in class org.h2.value.TypeInfo
JSON type.
TYPE_LONG - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TYPE_MEMORY - Static variable in class org.h2.table.Table
The table type that means this table is a regular persistent table.
TYPE_NAME - Static variable in class org.h2.util.CacheLRU
 
TYPE_NAME - Static variable in class org.h2.util.CacheTQ
 
TYPE_NULL - Static variable in class org.h2.mvstore.type.ObjectDataType
The type constants are also used as tag values.
TYPE_NULL - Static variable in class org.h2.value.TypeInfo
NULL type with parameters.
TYPE_NULLABLE - Static variable in class org.h2.jdbc.meta.DatabaseMetaLocal
 
TYPE_NUMERIC_BIGINT - Static variable in class org.h2.value.TypeInfo
NUMERIC type with parameters enough to hold a BIGINT value.
TYPE_NUMERIC_FLOATING_POINT - Static variable in class org.h2.value.TypeInfo
NUMERIC type that can hold values with floating point.
TYPE_NUMERIC_SCALE_0 - Static variable in class org.h2.value.TypeInfo
NUMERIC type with maximum precision and scale 0.
TYPE_REAL - Static variable in class org.h2.value.TypeInfo
REAL type with parameters.
TYPE_REGISTRY_NAME - Static variable in class org.h2.mvstore.tx.TransactionStore
 
TYPE_ROW_EMPTY - Static variable in class org.h2.value.TypeInfo
ROW (row value) type without fields.
TYPE_SEARCHABLE - Static variable in class org.h2.jdbc.meta.DatabaseMetaLocal
 
TYPE_SERIALIZED_OBJECT - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TYPE_SHORT - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TYPE_SMALLINT - Static variable in class org.h2.value.TypeInfo
SMALLINT type with parameters.
TYPE_STRING - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TYPE_TIME - Static variable in class org.h2.value.TypeInfo
TIME type with maximum parameters.
TYPE_TIME_TZ - Static variable in class org.h2.value.TypeInfo
TIME WITH TIME ZONE type with maximum parameters.
TYPE_TIMESTAMP - Static variable in class org.h2.value.TypeInfo
TIMESTAMP type with maximum parameters.
TYPE_TIMESTAMP_TZ - Static variable in class org.h2.value.TypeInfo
TIMESTAMP WITH TIME ZONE type with maximum parameters.
TYPE_TINYINT - Static variable in class org.h2.value.TypeInfo
TINYINT type with parameters.
TYPE_UNKNOWN - Static variable in class org.h2.value.TypeInfo
UNKNOWN type with parameters.
TYPE_UUID - Static variable in class org.h2.mvstore.type.ObjectDataType
 
TYPE_UUID - Static variable in class org.h2.value.TypeInfo
UUID type with parameters.
TYPE_VARBINARY - Static variable in class org.h2.value.TypeInfo
BINARY VARYING type with maximum parameters.
TYPE_VARCHAR - Static variable in class org.h2.value.TypeInfo
CHARACTER VARYING type with maximum parameters.
TYPE_VARCHAR_IGNORECASE - Static variable in class org.h2.value.TypeInfo
VARCHAR_IGNORECASE type with maximum parameters.
type2dimensionSystem(int) - Static method in class org.h2.util.geometry.EWKBUtils
Converts geometry type with flags to a dimension system.
typeAndDimensionSystem - Variable in class org.h2.value.ValueGeometry
Geometry type and dimension system in OGC geometry code format (type + dimensionSystem * 1000).
typeByNameMap - Variable in class org.h2.engine.Mode
Custom mappings from type names to data types.
Typed - Interface in org.h2.value
An object with data type.
TypedValueExpression - Class in org.h2.expression
An expression representing a constant value with a type cast.
TypedValueExpression(Value, TypeInfo) - Constructor for class org.h2.expression.TypedValueExpression
 
typeId - Variable in class org.h2.mvstore.type.ObjectDataType.AutoDetectDataType
The type id.
typeInfo - Variable in class org.h2.api.H2Type
 
TypeInfo - Class in org.h2.value
Data type with parameters.
TypeInfo(int) - Constructor for class org.h2.value.TypeInfo
 
TypeInfo(int, int) - Constructor for class org.h2.value.TypeInfo
 
TypeInfo(int, long) - Constructor for class org.h2.value.TypeInfo
 
TypeInfo(int, long, int, ExtTypeInfo) - Constructor for class org.h2.value.TypeInfo
Creates new instance of data type with parameters.
typeList - Variable in class org.h2.expression.condition.TypePredicate
 
typeMask - Variable in class org.h2.command.ddl.CreateTrigger
 
typeMask - Variable in class org.h2.schema.TriggerObject
 
typeName - Variable in class org.h2.command.ddl.CreateDomain
 
typeName - Variable in class org.h2.util.SimpleColumnInfo
Type name of the column.
TypePredicate - Class in org.h2.expression.condition
Type predicate (IS [NOT] OF).
TypePredicate(Expression, boolean, boolean, TypeInfo[]) - Constructor for class org.h2.expression.condition.TypePredicate
 
typeRegistry - Variable in class org.h2.mvstore.tx.TransactionStore.TxMapBuilder
 
typeRegistry - Variable in class org.h2.mvstore.tx.TransactionStore
 
TYPES - Static variable in class org.h2.command.dml.SetTypes
 
TYPES - Static variable in class org.h2.expression.function.CurrentDateTimeValueFunction
 
TYPES - Static variable in class org.h2.expression.function.SysInfoFunction
 
TYPES - Static variable in class org.h2.util.geometry.EWKTUtils
0-based type names of geometries, subtract 1 from type code to get index in this array.
TYPES - Static variable in class org.h2.util.geometry.GeoJsonUtils
0-based type names of geometries, subtract 1 from type code to get index in this array.
TYPES_ARE_NOT_COMPARABLE_2 - Static variable in class org.h2.api.ErrorCode
The error with code 90110 is thrown when trying to compare values of incomparable data types.
TYPES_BY_NAME - Static variable in class org.h2.value.DataType
The map of types.
TYPES_BY_VALUE_TYPE - Static variable in class org.h2.value.DataType
Mapping from Value type numbers to DataType.
typeSet - Variable in class org.h2.server.pg.PgServer
 
typeToRow(TypeInfo) - Static method in class org.h2.value.TypeInfo
 
typeToString(StringBuilder, int) - Static method in class org.h2.result.SortOrder
Appends type information (DESC, NULLS FIRST, NULLS LAST) to the specified statement builder.
TZD - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
TZH - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
TZM - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
TZR - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 

U

U00_BYTES - Static variable in class org.h2.util.json.JSONByteArrayTarget
 
UESCAPE - Static variable in class org.h2.util.ParserUtil
The token "UESCAPE".
ULSHIFT - Static variable in class org.h2.expression.function.BitFunction
ULSHIFT() (non-standard).
UnaryOperation - Class in org.h2.expression
Unary operation.
UnaryOperation(Expression) - Constructor for class org.h2.expression.UnaryOperation
 
UNBOUNDED_FOLLOWING - org.h2.expression.analysis.WindowFrameBoundType
UNBOUNDED FOLLOWING clause.
UNBOUNDED_PRECEDING - org.h2.expression.analysis.WindowFrameBoundType
UNBOUNDED PRECEDING clause.
uncommittedCursor - Variable in class org.h2.mvstore.tx.TransactionMap.RepeatableIterator
 
UncommittedIterator(TransactionMap<K, V>, K, K, boolean, boolean) - Constructor for class org.h2.mvstore.tx.TransactionMap.UncommittedIterator
 
UncommittedIterator(TransactionMap<K, V>, K, K, Snapshot<K, VersionedValue<V>>, boolean, boolean) - Constructor for class org.h2.mvstore.tx.TransactionMap.UncommittedIterator
 
uncommittedKey - Variable in class org.h2.mvstore.tx.TransactionMap.RepeatableIterator
 
uncommittedValue - Variable in class org.h2.mvstore.tx.TransactionMap.RepeatableIterator
 
UNCOMPARABLE_REFERENCED_COLUMN_2 - Static variable in class org.h2.api.ErrorCode
The error with code 90153 is thrown when trying to reference a column of another data type when data types aren't comparable or don't have a session-independent compare order between each other.
UNDO_LOG_COMMITTED - Static variable in class org.h2.mvstore.tx.TransactionStore
 
UNDO_LOG_NAME_PREFIX - Static variable in class org.h2.mvstore.tx.TransactionStore
The prefix for undo log entries.
UNDO_LOG_OPEN - Static variable in class org.h2.mvstore.tx.TransactionStore
 
undoKey - Variable in class org.h2.mvstore.tx.CommitDecisionMaker
 
undoKey - Variable in class org.h2.mvstore.tx.TxDecisionMaker
Id for the undo log entry created for this modification
undoLogBuilder - Variable in class org.h2.mvstore.tx.TransactionStore
 
undoLogRootReferences - Variable in class org.h2.mvstore.tx.Transaction
RootReferences for undo log snapshots
undoLogs - Variable in class org.h2.mvstore.tx.TransactionStore
Undo logs.
unEscape(String) - Method in class org.h2.tools.Csv
 
unescapeData(String, ResultSet, int) - Method in class org.h2.server.web.WebApp
 
unicode - Variable in class org.h2.command.Token.CharacterStringToken
 
unicode - Variable in class org.h2.command.Token.IdentifierToken
 
union(double[], double[]) - Static method in class org.h2.util.geometry.GeometryUtils
Returns union of two envelopes.
UNION - org.h2.command.query.SelectUnion.UnionType
The type of a UNION statement.
UNION - Static variable in class org.h2.util.ParserUtil
The token "UNION".
UNION_ALL - org.h2.command.query.SelectUnion.UnionType
The type of a UNION ALL statement.
unionType - Variable in class org.h2.command.query.SelectUnion
 
UnionType() - Constructor for enum org.h2.command.query.SelectUnion.UnionType
 
unique - Variable in class org.h2.index.IndexType
 
UNIQUE - org.h2.constraint.Constraint.Type
The constraint type for unique constraints.
UNIQUE - Static variable in class org.h2.util.ParserUtil
The token "UNIQUE".
uniqueColumnColumn - Variable in class org.h2.index.Index
Count of unique columns.
uniqueColumnCount - Variable in class org.h2.command.ddl.CreateIndex
 
uniqueId - Variable in class org.h2.store.FileLock
 
uniqueIndexNullsHandling - Variable in class org.h2.engine.Mode
Determines how rows with NULL values in indexed columns are handled in unique indexes.
UniqueIndexNullsHandling() - Constructor for enum org.h2.engine.Mode.UniqueIndexNullsHandling
 
UniquePredicate - Class in org.h2.expression.condition
Unique predicate as in UNIQUE(SELECT ...)
UniquePredicate(Query) - Constructor for class org.h2.expression.condition.UniquePredicate
 
UniquePredicate.Target - Class in org.h2.expression.condition
 
uniqueRowFactory - Variable in class org.h2.index.Index
 
units - Variable in class org.h2.expression.analysis.WindowFrame
 
UNIX_TIMESTAMP - Static variable in class org.h2.mode.FunctionsMySQL
 
unixTimestamp(SessionLocal, Value) - Static method in class org.h2.mode.FunctionsMySQL
Get the seconds since 1970-01-01 00:00:00 UTC of the given timestamp.
UNKNOWN - Static variable in interface org.h2.command.CommandInterface
The type for unknown statement.
UNKNOWN - Static variable in class org.h2.expression.TypedValueExpression
The expression represents the SQL UNKNOWN value.
UNKNOWN - Static variable in class org.h2.util.ParserUtil
The token "UNKNOWN".
UNKNOWN - Static variable in class org.h2.value.Value
The data type is unknown at this time.
UNKNOWN_DATA_TYPE_1 - Static variable in class org.h2.api.ErrorCode
The error with code 50004 is thrown when creating a table with an unsupported data type, or when the data type is unknown because parameters are used.
UNKNOWN_ENVELOPE - Static variable in class org.h2.value.ValueGeometry
 
UNKNOWN_MODE_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90088 is thrown when trying to switch to an unknown mode.
unknownSqlTypeToString(StringBuilder, SQLType) - Static method in class org.h2.value.DataType
 
unload() - Static method in class org.h2.Driver
INTERNAL
unloadH2(Driver) - Static method in class org.h2.tools.Upgrade
Unloads the specified driver of H2.
unlock() - Method in class org.h2.store.FileLock
Unlock the file.
unlock() - Method in class org.h2.store.fs.mem.FileMemData
Unlock the file.
unlock() - Method in class org.h2.store.fs.niomem.FileNioMemData
Unlock the file.
unlock(SessionLocal) - Method in class org.h2.mvstore.db.MVTable
 
unlock(SessionLocal) - Method in class org.h2.table.Table
Release the lock for this session.
unlock(Table) - Method in class org.h2.engine.SessionLocal
Unlock just this table.
unlockAll() - Method in class org.h2.engine.SessionLocal
 
unlockAndCheckPanicCondition() - Method in class org.h2.mvstore.MVStore
 
unlockMeta(SessionLocal) - Method in class org.h2.engine.Database
Unlock the metadata table.
unlockMetaDebug(SessionLocal) - Static method in class org.h2.engine.Database
This method doesn't actually unlock the metadata table, all it does it reset the debugging flags.
unlockRoot() - Method in class org.h2.mvstore.MVMap
Unlock the root page, the new root being null.
unlockRoot(int) - Method in class org.h2.mvstore.MVMap
 
unlockRoot(Page<K, V>) - Method in class org.h2.mvstore.MVMap
Unlock the root page.
unlockRoot(Page<K, V>, int) - Method in class org.h2.mvstore.MVMap
 
unmap(ByteBuffer) - Static method in class org.h2.util.MemoryUnmapper
Tries to unmap memory for the specified byte buffer using Java internals in unsafe way if SysProperties.NIO_CLEANER_HACK is enabled and access is not denied by a security manager.
unMap() - Method in class org.h2.store.fs.niomapped.FileNioMapped
 
unmodifiedFormatStr - Variable in class org.h2.mode.ToDateParser
 
unmodifiedInputStr - Variable in class org.h2.mode.ToDateParser
 
unnamed - Variable in class org.h2.engine.ConnectionInfo
 
UNNEST - Static variable in class org.h2.expression.function.table.ArrayTableFunction
UNNEST().
unregister(Database) - Static method in class org.h2.engine.OnExitDatabaseCloser
Unregister database instance.
unregister(FilePath) - Static method in class org.h2.store.fs.FilePath
Unregister a file provider.
unregister(CloseWatcher) - Static method in class org.h2.util.CloseWatcher
Unregister an object, so it is no longer tracked.
unregisterMBean(String) - Static method in class org.h2.jmx.DatabaseInfo
Unregisters the MBean for the database if one is registered.
UNSAFE - Static variable in class org.h2.util.MemoryUnmapper
 
unsavedMemory - Variable in class org.h2.mvstore.MVStore
The estimated memory used by unsaved pages.
unsetExclusiveSession(SessionLocal) - Method in class org.h2.engine.Database
Stop exclusive access the database by provided session.
unsupported(String) - Method in class org.h2.message.TraceObject
Get a SQL exception meaning this feature is not supported.
UNSUPPORTED_CIPHER - Static variable in class org.h2.api.ErrorCode
The error with code 90055 is thrown when trying to open a database with an unsupported cipher algorithm.
UNSUPPORTED_COMPRESSION_ALGORITHM_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90103 is thrown when trying to use an unsupported compression algorithm.
UNSUPPORTED_COMPRESSION_OPTIONS_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90102 is thrown when trying to use unsupported options for the given compression algorithm.
UNSUPPORTED_LOCK_METHOD_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90060 is thrown when trying to use a file locking mechanism that is not supported.
UNSUPPORTED_SETTING_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90113 is thrown when the database URL contains unsupported settings.
UNSUPPORTED_SETTING_COMBINATION - Static variable in class org.h2.api.ErrorCode
The error with code 90021 is thrown when trying to change a specific database property that conflicts with other database properties.
unused - Variable in class org.h2.mvstore.Chunk
When this chunk was no longer needed, in milliseconds after the store was created.
unusedAtVersion - Variable in class org.h2.mvstore.Chunk
Version of the store at which chunk become unused and therefore can be considered "dead" and collected after this version is no longer in use.
unwrap() - Method in class org.h2.store.fs.FilePath
Get the unwrapped file name (without wrapper prefixes if wrapping / delegating file systems are used).
unwrap() - Method in class org.h2.store.fs.FilePathWrapper
 
unwrap() - Method in class org.h2.store.fs.zip.FilePathZip
 
unwrap(Class<T>) - Method in class org.h2.jdbc.JdbcConnection
Return an object of this class if possible.
unwrap(Class<T>) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Return an object of this class if possible.
unwrap(Class<T>) - Method in class org.h2.jdbc.JdbcParameterMetaData
Return an object of this class if possible.
unwrap(Class<T>) - Method in class org.h2.jdbc.JdbcResultSet
Return an object of this class if possible.
unwrap(Class<T>) - Method in class org.h2.jdbc.JdbcResultSetMetaData
Return an object of this class if possible.
unwrap(Class<T>) - Method in class org.h2.jdbc.JdbcStatement
Return an object of this class if possible.
unwrap(Class<T>) - Method in class org.h2.jdbcx.JdbcConnectionPool
Return an object of this class if possible.
unwrap(Class<T>) - Method in class org.h2.jdbcx.JdbcDataSource
Return an object of this class if possible.
unwrap(Class<T>) - Method in class org.h2.tools.SimpleResultSet
Return an object of this class if possible.
unwrap(String) - Method in class org.h2.store.fs.encrypt.FilePathEncrypt
 
unwrap(String) - Method in class org.h2.store.fs.FilePathWrapper
Get the base path for the given wrapped path.
unwrap(String) - Static method in class org.h2.store.fs.FileUtils
Get the unwrapped file name (without wrapper prefixes if wrapping / delegating file systems are used).
unwrap(String) - Method in class org.h2.store.fs.split.FilePathSplit
 
unwrapRow() - Method in class org.h2.value.TypeInfo
Returns unwrapped data type if this data type is a row type with degree 1 or this type otherwise.
updatable - Variable in class org.h2.jdbc.JdbcResultSet
 
UpdatableRow - Class in org.h2.result
This class is used for updatable result sets.
UpdatableRow(JdbcConnection, ResultInterface) - Constructor for class org.h2.result.UpdatableRow
Construct a new object that is linked to the result set.
update - Variable in class org.h2.command.dml.Merge
 
update - Variable in class org.h2.mode.OnDuplicateKeyValues
 
update() - Method in class org.h2.command.ddl.AlterIndexRename
 
update() - Method in class org.h2.command.ddl.AlterSchemaRename
 
update() - Method in class org.h2.command.ddl.AlterTable
 
update() - Method in class org.h2.command.ddl.AlterTableAlterColumn
 
update() - Method in class org.h2.command.ddl.AlterUser
 
update() - Method in class org.h2.command.ddl.AlterView
 
update() - Method in class org.h2.command.ddl.Analyze
 
update() - Method in class org.h2.command.ddl.CreateAggregate
 
update() - Method in class org.h2.command.ddl.CreateFunctionAlias
 
update() - Method in class org.h2.command.ddl.CreateIndex
 
update() - Method in class org.h2.command.ddl.CreateLinkedTable
 
update() - Method in class org.h2.command.ddl.CreateRole
 
update() - Method in class org.h2.command.ddl.CreateSchema
 
update() - Method in class org.h2.command.ddl.CreateTable
 
update() - Method in class org.h2.command.ddl.CreateTrigger
 
update() - Method in class org.h2.command.ddl.CreateUser
 
update() - Method in class org.h2.command.ddl.DeallocateProcedure
 
update() - Method in class org.h2.command.ddl.DropDatabase
 
update() - Method in class org.h2.command.ddl.DropIndex
 
update() - Method in class org.h2.command.ddl.DropRole
 
update() - Method in class org.h2.command.ddl.DropSchema
 
update() - Method in class org.h2.command.ddl.DropTable
 
update() - Method in class org.h2.command.ddl.DropTrigger
 
update() - Method in class org.h2.command.ddl.DropUser
 
update() - Method in class org.h2.command.ddl.DropView
 
update() - Method in class org.h2.command.ddl.GrantRevoke
 
update() - Method in class org.h2.command.ddl.PrepareProcedure
 
update() - Method in class org.h2.command.ddl.SchemaOwnerCommand
 
update() - Method in class org.h2.command.ddl.SetComment
 
update() - Method in class org.h2.command.ddl.TruncateTable
 
update() - Method in class org.h2.command.dml.AlterTableSet
 
update() - Method in class org.h2.command.dml.BackupCommand
 
update() - Method in class org.h2.command.dml.Call
 
update() - Method in class org.h2.command.dml.DataChangeStatement
 
update() - Method in class org.h2.command.dml.ExecuteImmediate
 
update() - Method in class org.h2.command.dml.ExecuteProcedure
 
update() - Method in class org.h2.command.dml.NoOperation
 
update() - Method in class org.h2.command.dml.RunScriptCommand
 
update() - Method in class org.h2.command.dml.Set
 
update() - Method in class org.h2.command.dml.SetSessionCharacteristics
 
update() - Method in class org.h2.command.dml.TransactionCommand
 
update() - Method in class org.h2.command.Prepared
Execute the statement.
update(int, Object) - Method in class org.h2.tools.SimpleResultSet
 
update(int, CacheObject) - Method in interface org.h2.util.Cache
Update an element in the cache.
update(int, CacheObject) - Method in class org.h2.util.CacheLRU
 
update(int, CacheObject) - Method in class org.h2.util.CacheSecondLevel
 
update(int, CacheObject) - Method in class org.h2.util.CacheTQ
 
update(int, Value) - Method in class org.h2.jdbc.JdbcResultSet
 
update(long, long) - Method in class org.h2.engine.QueryStatisticsData.QueryEntry
Update the statistics entry.
update(Object) - Method in class org.h2.command.Command
Execute an updating statement (for example insert, delete, or update), if this is possible.
update(Object) - Method in class org.h2.command.CommandContainer
 
update(Object) - Method in class org.h2.command.CommandList
 
update(String, long, long) - Method in class org.h2.engine.QueryStatisticsData
Update query statistics.
update(String, Object) - Method in class org.h2.tools.SimpleResultSet
 
update(SessionLocal) - Method in class org.h2.command.dml.SetClauseList.SetMultiple
 
update(SessionLocal) - Method in class org.h2.command.dml.SetClauseList.SetSimple
 
update(SessionLocal) - Method in class org.h2.command.dml.SetClauseList.UpdateAction
 
update(SessionLocal, Row, Row) - Method in class org.h2.index.Index
Update index after row change.
update(SessionLocal, Row, Row) - Method in class org.h2.mvstore.db.MVDelegateIndex
 
update(SessionLocal, Row, Row) - Method in class org.h2.mvstore.db.MVPrimaryIndex
 
update(SessionLocal, Row, Row) - Method in class org.h2.mvstore.db.MVSecondaryIndex
 
update(ResultTarget, DataChangeDeltaTable.ResultOption) - Method in class org.h2.command.dml.DataChangeStatement
Execute the statement with specified delta change collector and collection mode.
update(ResultTarget, DataChangeDeltaTable.ResultOption) - Method in class org.h2.command.dml.Delete
 
update(ResultTarget, DataChangeDeltaTable.ResultOption) - Method in class org.h2.command.dml.Insert
 
update(ResultTarget, DataChangeDeltaTable.ResultOption) - Method in class org.h2.command.dml.Merge
 
update(ResultTarget, DataChangeDeltaTable.ResultOption) - Method in class org.h2.command.dml.MergeUsing
 
update(ResultTarget, DataChangeDeltaTable.ResultOption) - Method in class org.h2.command.dml.Update
 
update(Row, Row, SessionLocal) - Method in class org.h2.index.LinkedIndex
Update a row using a UPDATE statement.
update(Schema) - Method in class org.h2.command.ddl.AlterDomain
 
update(Schema) - Method in class org.h2.command.ddl.AlterSequence
 
update(Schema) - Method in class org.h2.command.ddl.CreateConstant
 
update(Schema) - Method in class org.h2.command.ddl.CreateDomain
 
update(Schema) - Method in class org.h2.command.ddl.CreateSequence
 
update(Schema) - Method in class org.h2.command.ddl.CreateSynonym
 
update(Schema) - Method in class org.h2.command.ddl.CreateView
 
update(Schema) - Method in class org.h2.command.ddl.DropAggregate
 
update(Schema) - Method in class org.h2.command.ddl.DropConstant
 
update(Schema) - Method in class org.h2.command.ddl.DropFunctionAlias
 
update(Schema) - Method in class org.h2.command.ddl.DropSequence
 
update(Schema) - Method in class org.h2.command.ddl.DropSynonym
 
update(Schema) - Method in class org.h2.command.ddl.SchemaOwnerCommand
 
update(Schema, Domain) - Method in class org.h2.command.ddl.AlterDomain
 
update(Schema, Domain) - Method in class org.h2.command.ddl.AlterDomainAddConstraint
 
update(Schema, Domain) - Method in class org.h2.command.ddl.AlterDomainDropConstraint
 
update(Schema, Domain) - Method in class org.h2.command.ddl.AlterDomainExpressions
 
update(Schema, Domain) - Method in class org.h2.command.ddl.AlterDomainRename
 
update(Schema, Domain) - Method in class org.h2.command.ddl.AlterDomainRenameConstraint
 
update(Schema, Domain) - Method in class org.h2.command.ddl.DropDomain
 
update(Table) - Method in class org.h2.command.ddl.AlterTable
 
update(Table) - Method in class org.h2.command.ddl.AlterTableAddConstraint
 
update(Table) - Method in class org.h2.command.ddl.AlterTableDropConstraint
 
update(Table) - Method in class org.h2.command.ddl.AlterTableRename
 
update(Table) - Method in class org.h2.command.ddl.AlterTableRenameColumn
 
update(Table) - Method in class org.h2.command.ddl.AlterTableRenameConstraint
 
Update - Class in org.h2.command.dml
This class represents the statement UPDATE
Update(SessionLocal) - Constructor for class org.h2.command.dml.Update
 
UPDATE - Static variable in interface org.h2.api.Trigger
The trigger is called for UPDATE statements.
UPDATE - Static variable in interface org.h2.command.CommandInterface
The type of an UPDATE statement.
UPDATE - Static variable in class org.h2.engine.Right
The right bit mask that means: updating data is allowed.
updateAction - Variable in class org.h2.command.ddl.AlterTableAddConstraint
 
updateAction - Variable in class org.h2.constraint.ConstraintReferential
 
UpdateAction() - Constructor for class org.h2.command.dml.SetClauseList.UpdateAction
 
updateAgg(int, int) - Method in class org.h2.command.query.Select
Update any aggregate expressions with the query stage.
updateAggregate(SessionLocal, int) - Method in class org.h2.command.query.Query
Update all aggregate function values.
updateAggregate(SessionLocal, int) - Method in class org.h2.command.query.Select
 
updateAggregate(SessionLocal, int) - Method in class org.h2.command.query.SelectUnion
 
updateAggregate(SessionLocal, int) - Method in class org.h2.command.query.TableValueConstructor
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.Alias
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.analysis.DataAnalysisOperation
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.analysis.Window
Update an aggregate value.
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.analysis.WindowFrame
Update an aggregate value.
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.analysis.WindowFrameBound
Update an aggregate value.
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.ArrayConstructorByQuery
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.condition.BetweenPredicate
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.condition.CompareLike
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.condition.Comparison
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.condition.ConditionAndOr
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.condition.ConditionAndOrN
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.condition.ConditionIn
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.condition.ConditionInConstantSet
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.condition.ConditionInParameter
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.condition.ConditionInQuery
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.condition.ConditionLocalAndGlobal
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.condition.ConditionNot
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.condition.IsJsonPredicate
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.condition.PredicateWithSubquery
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.condition.SimplePredicate
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.Expression
Update an aggregate value.
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.ExpressionColumn
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.ExpressionList
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.function.Function0_1
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.function.JavaFunction
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.Operation0
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.Operation1_2
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.Operation1
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.Operation2
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.OperationN
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.SimpleCase
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.Subquery
 
updateAggregate(SessionLocal, int) - Method in class org.h2.expression.Wildcard
 
updateAggregate(SessionLocal, Object) - Method in class org.h2.expression.aggregate.AbstractAggregate
Updates an aggregate value.
updateAggregate(SessionLocal, Object) - Method in class org.h2.expression.aggregate.Aggregate
 
updateAggregate(SessionLocal, Object) - Method in class org.h2.expression.aggregate.JavaAggregate
 
updateAggregate(SessionLocal, SelectGroups, int) - Method in class org.h2.expression.aggregate.AbstractAggregate
 
updateAggregate(SessionLocal, SelectGroups, int) - Method in class org.h2.expression.analysis.DataAnalysisOperation
Update a row of an aggregate.
updateAggregate(SessionLocal, SelectGroups, int) - Method in class org.h2.expression.analysis.WindowFunction
 
updateArray(int, Array) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateArray(int, Array) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateArray(String, Array) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateArray(String, Array) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateArrayImpl(int, Array) - Method in class org.h2.jdbc.JdbcResultSet
 
updateAscii(int, InputStream, long) - Method in class org.h2.jdbc.JdbcResultSet
 
updateAsciiStream(int, InputStream) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateAsciiStream(int, InputStream) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateAsciiStream(int, InputStream, int) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateAsciiStream(int, InputStream, int) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateAsciiStream(int, InputStream, long) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateAsciiStream(int, InputStream, long) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateAsciiStream(String, InputStream) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateAsciiStream(String, InputStream) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateAsciiStream(String, InputStream, int) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateAsciiStream(String, InputStream, int) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateAsciiStream(String, InputStream, long) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateAsciiStream(String, InputStream, long) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateAttemptCounter - Variable in class org.h2.mvstore.MVStore
 
updateAttemptCounter - Variable in class org.h2.mvstore.RootReference
Counter for attempted root updates.
updateBigDecimal(int, BigDecimal) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateBigDecimal(int, BigDecimal) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateBigDecimal(String, BigDecimal) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateBigDecimal(String, BigDecimal) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateBinaryStream(int, InputStream) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateBinaryStream(int, InputStream) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateBinaryStream(int, InputStream, int) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateBinaryStream(int, InputStream, int) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateBinaryStream(int, InputStream, long) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateBinaryStream(int, InputStream, long) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateBinaryStream(String, InputStream) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateBinaryStream(String, InputStream) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateBinaryStream(String, InputStream, int) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateBinaryStream(String, InputStream, int) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateBinaryStream(String, InputStream, long) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateBinaryStream(String, InputStream, long) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateBlob(int, InputStream) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateBlob(int, InputStream) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateBlob(int, InputStream, long) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateBlob(int, InputStream, long) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateBlob(int, Blob) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateBlob(int, Blob) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateBlob(String, InputStream) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateBlob(String, InputStream) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateBlob(String, InputStream, long) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateBlob(String, InputStream, long) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateBlob(String, Blob) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateBlob(String, Blob) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateBlobImpl(int, InputStream, long) - Method in class org.h2.jdbc.JdbcResultSet
 
updateBlobImpl(int, Blob, long) - Method in class org.h2.jdbc.JdbcResultSet
 
updateBoolean(int, boolean) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateBoolean(int, boolean) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateBoolean(String, boolean) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateBoolean(String, boolean) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateByte(int, byte) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateByte(int, byte) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateByte(String, byte) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateByte(String, byte) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateBytes(int, byte[]) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateBytes(int, byte[]) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateBytes(String, byte[]) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateBytes(String, byte[]) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateCharacterStream(int, Reader) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateCharacterStream(int, Reader) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateCharacterStream(int, Reader, int) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateCharacterStream(int, Reader, int) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateCharacterStream(int, Reader, long) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateCharacterStream(int, Reader, long) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateCharacterStream(String, Reader) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateCharacterStream(String, Reader) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateCharacterStream(String, Reader, int) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateCharacterStream(String, Reader, int) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateCharacterStream(String, Reader, long) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateCharacterStream(String, Reader, long) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateClob(int, Reader) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateClob(int, Reader) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateClob(int, Reader, long) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateClob(int, Reader, long) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateClob(int, Clob) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateClob(int, Clob) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateClob(String, Reader) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateClob(String, Reader) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateClob(String, Reader, long) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateClob(String, Reader, long) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateClob(String, Clob) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateClob(String, Clob) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateClobImpl(int, Reader, long) - Method in class org.h2.jdbc.JdbcResultSet
 
updateClobImpl(int, Clob) - Method in class org.h2.jdbc.JdbcResultSet
 
updateCollecting(SessionLocal, Value, Value[]) - Method in class org.h2.expression.aggregate.Aggregate
 
updateCount - Variable in class org.h2.jdbc.JdbcStatement
 
updateCount - Variable in class org.h2.result.ResultWithGeneratedKeys
 
updateCounter - Variable in class org.h2.mvstore.MVStore
 
updateCounter - Variable in class org.h2.mvstore.RootReference
Counter for successful root updates.
updateCurrentGroupExprData() - Method in class org.h2.command.query.SelectGroups.Grouped
 
updateCurrentGroupExprData() - Method in class org.h2.command.query.SelectGroups.Plain
 
updateCurrentGroupExprData() - Method in class org.h2.command.query.SelectGroups
Update group-by data specified by implementation.
updateData(CreateSynonymData) - Method in class org.h2.table.TableSynonym
Set (update) the data.
updateData(SessionLocal, Object, Value[]) - Method in class org.h2.expression.aggregate.JavaAggregate
 
updateData(SessionLocal, AggregateData, Value, Value[]) - Method in class org.h2.expression.aggregate.Aggregate
 
updateDate(int, Date) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateDate(int, Date) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateDate(String, Date) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateDate(String, Date) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateDouble(int, double) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateDouble(int, double) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateDouble(String, double) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateDouble(String, double) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateFloat(int, float) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateFloat(int, float) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateFloat(String, float) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateFloat(String, float) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateFromExpressions(SessionLocal, Object, Value[]) - Method in class org.h2.expression.aggregate.AbstractAggregate
Updates the provided aggregate data from the remembered expressions.
updateFromExpressions(SessionLocal, Object, Value[]) - Method in class org.h2.expression.aggregate.Aggregate
 
updateFromExpressions(SessionLocal, Object, Value[]) - Method in class org.h2.expression.aggregate.JavaAggregate
 
updateGroupAggregates(SessionLocal, int) - Method in class org.h2.expression.aggregate.AbstractAggregate
 
updateGroupAggregates(SessionLocal, int) - Method in class org.h2.expression.aggregate.Aggregate
 
updateGroupAggregates(SessionLocal, int) - Method in class org.h2.expression.aggregate.JavaAggregate
 
updateGroupAggregates(SessionLocal, int) - Method in class org.h2.expression.analysis.DataAnalysisOperation
Invoked when processing group stage of grouped window queries to update arguments of this aggregate.
updateGroupAggregates(SessionLocal, int) - Method in class org.h2.expression.analysis.WindowFunction
 
updateInt(int, int) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateInt(int, int) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateInt(String, int) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateInt(String, int) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateLevel() - Method in class org.h2.message.TraceSystem
 
updateLong(int, long) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateLong(int, long) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateLong(String, long) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateLong(String, long) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateMeta(SessionLocal, DbObject) - Method in class org.h2.engine.Database
Update an object in the system table.
updateMetaAndFirstLevelChildren(SessionLocal, DbObject) - Method in class org.h2.engine.Database
 
updateNCharacterStream(int, Reader) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateNCharacterStream(int, Reader) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateNCharacterStream(int, Reader, long) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateNCharacterStream(int, Reader, long) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateNCharacterStream(String, Reader) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateNCharacterStream(String, Reader) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateNCharacterStream(String, Reader, long) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateNCharacterStream(String, Reader, long) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateNClob(int, Reader) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateNClob(int, Reader) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateNClob(int, Reader, long) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateNClob(int, Reader, long) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateNClob(int, NClob) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateNClob(int, NClob) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateNClob(String, Reader) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateNClob(String, Reader) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateNClob(String, Reader, long) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateNClob(String, Reader, long) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateNClob(String, NClob) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateNClob(String, NClob) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateNString(int, String) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateNString(int, String) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateNString(String, String) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateNString(String, String) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateNull(int) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateNull(int) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateNull(String) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateNull(String) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateObject(int, Object) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateObject(int, Object) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateObject(int, Object, int) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateObject(int, Object, int) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateObject(int, Object, SQLType) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateObject(int, Object, SQLType, int) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateObject(String, Object) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateObject(String, Object) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateObject(String, Object, int) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateObject(String, Object, int) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateObject(String, Object, SQLType) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateObject(String, Object, SQLType, int) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateOnTableColumnRename() - Method in class org.h2.constraint.ConstraintReferential
Update the constraint SQL when a referenced column is renamed.
updateOrderedAggregate(SessionLocal, SelectGroups, int, ArrayList<QueryOrderBy>) - Method in class org.h2.expression.analysis.DataAnalysisOperation
Update a row of an ordered aggregate.
updatePageAndLockedStatus(Page<K, V>, boolean, int) - Method in class org.h2.mvstore.RootReference
Update the page, possibly keeping it locked.
updateRef(int, Ref) - Method in class org.h2.jdbc.JdbcResultSet
[Not supported]
updateRef(int, Ref) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateRef(String, Ref) - Method in class org.h2.jdbc.JdbcResultSet
[Not supported]
updateRef(String, Ref) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateRoles(AuthenticationInfo, User, Database) - Method in class org.h2.security.auth.DefaultAuthenticator
 
updateRoot(RootReference<K, V>, Page<K, V>, int) - Static method in class org.h2.mvstore.MVMap
Use the new root page from now on.
updateRootPage(Page<K, V>, long) - Method in class org.h2.mvstore.RootReference
Try to unlock.
updateRow - Variable in class org.h2.jdbc.JdbcResultSet
 
updateRow() - Method in class org.h2.jdbc.JdbcResultSet
Updates the current row.
updateRow() - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateRow(SessionLocal, Row, Row) - Method in class org.h2.mvstore.db.MVTable
 
updateRow(SessionLocal, Row, Row) - Method in class org.h2.table.Table
Update a row to the table and all indexes.
updateRow(Value[], Value[]) - Method in class org.h2.result.UpdatableRow
Update a row in the database.
updateRowId(int, RowId) - Method in class org.h2.jdbc.JdbcResultSet
[Not supported] Updates a column in the current or insert row.
updateRowId(int, RowId) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateRowId(String, RowId) - Method in class org.h2.jdbc.JdbcResultSet
[Not supported] Updates a column in the current or insert row.
updateRowId(String, RowId) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateRows(Prepared, SessionLocal, LocalResult) - Method in class org.h2.table.Table
Update a list of rows in this table.
updateRows(Prepared, SessionLocal, LocalResult) - Method in class org.h2.table.TableLink
 
updatesAreDetected(int) - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Returns whether updates are detected.
updateSequenceIfRequired(SessionLocal, long) - Method in class org.h2.table.Column
 
updateSequenceOnManualIdentityInsertion - Variable in class org.h2.engine.Mode
If true, sequences of generated by default identity columns are updated when value is provided by user.
updateSetting(ConnectionInfo) - Method in class org.h2.server.web.WebServer
Update a connection information setting.
updateShort(int, short) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateShort(int, short) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateShort(String, short) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateShort(String, short) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateSQL - Variable in class org.h2.constraint.ConstraintReferential
 
updateSQLXML(int, SQLXML) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateSQLXML(int, SQLXML) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateSQLXML(String, SQLXML) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateSQLXML(String, SQLXML) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateSQLXMLImpl(int, SQLXML) - Method in class org.h2.jdbc.JdbcResultSet
 
updateStatsData(AtomicLong, long, int, int, long, long, int, int) - Static method in class org.h2.util.MemoryEstimator
 
updateStatsData(AtomicLong, long, long, int, int) - Static method in class org.h2.util.MemoryEstimator
 
updateString(int, String) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateString(int, String) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateString(String, String) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateString(String, String) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateSynonymFor() - Method in class org.h2.table.TableSynonym
Update the table that this is a synonym for, to know about this synonym.
updateTime(int, Time) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateTime(int, Time) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateTime(String, Time) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateTime(String, Time) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateTimestamp(int, Timestamp) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateTimestamp(int, Timestamp) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateTimestamp(String, Timestamp) - Method in class org.h2.jdbc.JdbcResultSet
Updates a column in the current or insert row.
updateTimestamp(String, Timestamp) - Method in class org.h2.tools.SimpleResultSet
INTERNAL
updateTopic(String, DbContextRule) - Method in class org.h2.bnf.Bnf
Update a topic with a context specific rule.
updateTweak(byte[]) - Static method in class org.h2.store.fs.encrypt.XTS
 
updateURL() - Method in class org.h2.server.web.WebServer
 
updateWithSkipCheck(Prepared) - Method in class org.h2.constraint.ConstraintReferential
 
upgrade(String, Properties, int) - Static method in class org.h2.tools.Upgrade
Performs database upgrade from an older version of H2.
Upgrade - Class in org.h2.tools
Upgrade utility.
Upgrade() - Constructor for class org.h2.tools.Upgrade
 
UPPER - Static variable in class org.h2.expression.function.StringFunction1
UPPER().
upperBound(Page<K, V>) - Static method in class org.h2.mvstore.Cursor
 
UPPERCASE - org.h2.expression.function.ToCharFunction.Capitalization
All letters are uppercased.
upperName(String) - Method in class org.h2.command.Parser
 
url - Variable in class org.h2.command.ddl.CreateLinkedTable
 
url - Variable in class org.h2.engine.ConnectionInfo
 
url - Variable in class org.h2.jdbc.JdbcConnection
 
url - Variable in class org.h2.jdbcx.JdbcDataSource
 
url - Variable in class org.h2.security.auth.impl.LdapCredentialsValidator
 
url - Variable in class org.h2.server.web.ConnectionInfo
The database URL.
url - Variable in class org.h2.server.web.WebServer
 
url - Variable in class org.h2.table.TableLink
 
url - Variable in class org.h2.table.TableLinkConnection
The connection information.
URL_FORMAT - Static variable in class org.h2.engine.Constants
The database URL format in simplified Backus-Naur form.
URL_FORMAT_ERROR_2 - Static variable in class org.h2.api.ErrorCode
The error with code 90046 is thrown when trying to open a connection to a database using an unsupported URL format.
URL_MAP - Static variable in class org.h2.engine.SysProperties
System property h2.urlMap (default: null).
URL_RELATIVE_TO_CWD - Static variable in class org.h2.api.ErrorCode
The error with code 90011 is thrown when trying to open a connection to a database using an implicit relative path, such as "jdbc:h2:test" (in which case the database file would be stored in the current working directory of the application).
urlDecode(String) - Static method in class org.h2.util.StringUtils
Decode the URL to a string.
urlEncode(String) - Static method in class org.h2.util.StringUtils
Encode the string as a URL.
urlText - Variable in class org.h2.tools.GUIConsole
 
URSHIFT - Static variable in class org.h2.expression.function.BitFunction
URSHIFT() (non-standard).
USE_THREAD_CONTEXT_CLASS_LOADER - Static variable in class org.h2.engine.SysProperties
System property h2.useThreadContextClassLoader (default: false).
useCounter - Variable in class org.h2.table.TableLinkConnection
How many times the connection is used.
used - Variable in class org.h2.table.TableFilter
Indicates that this filter is used in the plan.
USED_OR_IMPOSSIBLE - org.h2.expression.aggregate.AggregateDataCollecting.NullCollectionMode
Rows with NULL values are aggregated just like rows with any other values, should also be used when NULL values aren't passed to AggregateDataCollecting.
usedMemory - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Segment
The currently used memory.
useJavaSystemCompiler - Variable in class org.h2.util.SourceCompiler
Whether to use the ToolProvider.getSystemJavaCompiler().
user - Variable in class org.h2.command.ddl.AlterUser
 
user - Variable in class org.h2.command.ddl.CreateLinkedTable
 
user - Variable in class org.h2.engine.ConnectionInfo
 
user - Variable in class org.h2.engine.SessionLocal
 
user - Variable in class org.h2.jdbc.JdbcConnection
 
user - Variable in class org.h2.server.web.ConnectionInfo
The user name.
user - Variable in class org.h2.table.TableLink
 
user - Variable in class org.h2.table.TableLinkConnection
The connection information.
User - Class in org.h2.engine
Represents a user object.
User(Database, int, String, boolean) - Constructor for class org.h2.engine.User
 
USER - Static variable in class org.h2.engine.DbObject
This object is a user.
USER - Static variable in class org.h2.message.Trace
The trace module id for users.
USER - Static variable in class org.h2.util.ParserUtil
The token "USER".
USER_ALREADY_EXISTS_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90033 is thrown when trying to create a user or role if a user with this name already exists.
USER_DATA_TYPE_ALREADY_EXISTS_1 - Static variable in class org.h2.api.ErrorCode
Deprecated.
USER_DATA_TYPE_NOT_FOUND_1 - Static variable in class org.h2.api.ErrorCode
Deprecated.
USER_HOME - Static variable in class org.h2.engine.SysProperties
System property user.home (empty string if not set).
USER_NOT_FOUND_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90032 is thrown when trying to drop or alter a user that does not exist.
USER_OR_ROLE_NOT_FOUND_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90071 is thrown when trying to grant or revoke if no role or user with that name exists.
USER_PACKAGE - Static variable in class org.h2.engine.Constants
The package name of user defined classes.
userAggregate - Variable in class org.h2.expression.aggregate.JavaAggregate
 
UserAggregate - Class in org.h2.schema
Represents a user-defined aggregate function.
UserAggregate(Schema, int, String, String, boolean) - Constructor for class org.h2.schema.UserAggregate
 
UserAggregate.AggregateWrapper - Class in org.h2.schema
Wrap AggregateFunction in order to behave as Aggregate
UserBuilder - Class in org.h2.engine
 
UserBuilder() - Constructor for class org.h2.engine.UserBuilder
 
userClassFactories - Static variable in class org.h2.util.JdbcUtils
In order to manage more than one class loader
userConnection - Variable in class org.h2.expression.aggregate.JavaAggregate
 
UserDefinedFunction - Class in org.h2.schema
User-defined Java function or aggregate function.
UserDefinedFunction(Schema, int, String, int) - Constructor for class org.h2.schema.UserDefinedFunction
 
userField - Variable in class org.h2.tools.GUIConsole
 
userName - Variable in class org.h2.command.ddl.CreateUser
 
userName - Variable in class org.h2.command.ddl.DropUser
 
userName - Variable in class org.h2.jdbcx.JdbcDataSource
 
userName - Variable in class org.h2.server.pg.PgServerThread
 
userNamePattern - Variable in class org.h2.security.auth.impl.StaticUserCredentialsValidator
 
userPasswordHash - Variable in class org.h2.engine.ConnectionInfo
 
users(SessionLocal, ArrayList<Row>) - Method in class org.h2.table.InformationSchemaTable
 
users(SessionLocal, ArrayList<Row>, User) - Method in class org.h2.table.InformationSchemaTable
 
USERS - Static variable in class org.h2.table.InformationSchemaTable
 
USERS - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
usersAndRoles - Variable in class org.h2.engine.Database
 
userSessions - Variable in class org.h2.engine.Database
 
UserToRolesMapper - Interface in org.h2.api
A class that implement this interface can be used during authentication to map external users to database roles.
UserToRolesMapperConfig - Class in org.h2.security.auth
Configuration for class that maps users to their roles.
UserToRolesMapperConfig() - Constructor for class org.h2.security.auth.UserToRolesMapperConfig
 
userToRolesMappers - Variable in class org.h2.security.auth.DefaultAuthenticator
 
userToRolesMappers - Variable in class org.h2.security.auth.H2AuthConfig
 
usesIndex(Index) - Method in class org.h2.constraint.Constraint
Check if this constraint needs the specified index.
usesIndex(Index) - Method in class org.h2.constraint.ConstraintCheck
 
usesIndex(Index) - Method in class org.h2.constraint.ConstraintDomain
 
usesIndex(Index) - Method in class org.h2.constraint.ConstraintReferential
 
usesIndex(Index) - Method in class org.h2.constraint.ConstraintUnique
 
usesLocalFilePerTable() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Checks if this database use one file per table.
usesLocalFiles() - Method in class org.h2.jdbc.JdbcDatabaseMetaData
Checks if this database store data in local files.
useSnapshot(BiFunction<RootReference<K, VersionedValue<V>>, BitSet, R>) - Method in class org.h2.mvstore.tx.TransactionMap
Gets a coherent picture of committing transactions and root reference, passes it to the specified function, and returns its result.
USING - Static variable in class org.h2.util.ParserUtil
The token "USING".
usingExpression - Variable in class org.h2.command.ddl.AlterTableAlterColumn
 
UTC - Static variable in class org.h2.util.LegacyDateTimeUtils
UTC time zone.
UTC - Static variable in class org.h2.util.TimeZoneProvider
The UTC time zone provider.
UTF8_BOM - Static variable in class org.h2.command.dml.RunScriptCommand
The byte order mark.
UTF8TOSTRING - Static variable in class org.h2.expression.function.StringFunction1
UTF8TOSTRING() (non-standard).
Utils - Class in org.h2.util
This utility class contains miscellaneous functions.
Utils() - Constructor for class org.h2.util.Utils
 
Utils.ClassFactory - Interface in org.h2.util
The utility methods will try to use the provided class factories to convert binary name of class to Class object.
Utils10 - Class in org.h2.util
Utilities with specialized implementations for Java 10 and later versions.
Utils10() - Constructor for class org.h2.util.Utils10
 
UUID - Static variable in class org.h2.api.H2Type
The UUID data type.
UUID - Static variable in class org.h2.mvstore.db.ValueDataType
 
UUID - Static variable in class org.h2.value.Transfer
 
UUID - Static variable in class org.h2.value.Value
The value type for UUID values.
UUID_PREFIX - Static variable in class org.h2.util.JdbcUtils
 
uuidToBytes(long, long) - Static method in class org.h2.util.Bits
Converts UUID value to byte array in big-endian order.
uuidToBytes(UUID) - Static method in class org.h2.util.Bits
Converts UUID value to byte array in big-endian order.
UUIDType() - Constructor for class org.h2.mvstore.type.ObjectDataType.UUIDType
 

V

validateConvertUpdateSequence(SessionLocal, Value, Row) - Method in class org.h2.table.Column
Validate the value, convert it if required, and update the sequence value if required.
validateCredentials(AuthenticationInfo) - Method in interface org.h2.api.CredentialsValidator
Validate user credential.
validateCredentials(AuthenticationInfo) - Method in class org.h2.security.auth.impl.JaasCredentialsValidator
 
validateCredentials(AuthenticationInfo) - Method in class org.h2.security.auth.impl.LdapCredentialsValidator
 
validateCredentials(AuthenticationInfo) - Method in class org.h2.security.auth.impl.StaticUserCredentialsValidator
 
validateFileLength(String) - Method in class org.h2.mvstore.MVStore
 
validateFilePasswordHash(String, byte[]) - Method in class org.h2.engine.Database
Check if the file password hash is correct.
validateInterval(IntervalQualifier, boolean, long, long) - Static method in class org.h2.util.IntervalUtils
Ensures that all fields in interval are valid.
validateUserAndPassword(boolean) - Static method in class org.h2.engine.Engine
This method is called after validating user name and password.
validateUserPasswordHash(byte[]) - Method in class org.h2.engine.User
Check the password of this user.
ValidationIterator(TransactionMap<K, V>, K, K) - Constructor for class org.h2.mvstore.tx.TransactionMap.ValidationIterator
 
validatorClass - Variable in class org.h2.security.auth.RealmConfig
 
value - Variable in class org.h2.command.dml.AlterTableSet
 
value - Variable in class org.h2.command.Token.LiteralToken
 
value - Variable in class org.h2.constraint.DomainColumnResolver
 
value - Variable in class org.h2.engine.SessionLocal.TimeoutValue
The value.
value - Variable in class org.h2.expression.aggregate.AggregateDataDefault
 
value - Variable in class org.h2.expression.analysis.WindowFrameBound
 
value - Variable in class org.h2.expression.Parameter
 
value - Variable in class org.h2.expression.ParameterRemote
 
value - Variable in class org.h2.expression.ValueExpression
The value.
value - Variable in class org.h2.jdbc.JdbcArray
 
value - Variable in class org.h2.jdbc.JdbcLob
Value.
value - Variable in class org.h2.mvstore.cache.CacheLongKeyLIRS.Entry
The value.
value - Variable in class org.h2.mvstore.MVMap.IntValueHolder
 
value - Variable in class org.h2.mvstore.tx.TransactionStore.Change
The value.
value - Variable in class org.h2.mvstore.tx.TxDecisionMaker
Value for the map entry
value - Variable in class org.h2.mvstore.tx.VersionedValueCommitted
The current value.
value - Variable in class org.h2.schema.Constant
 
value - Variable in class org.h2.security.auth.PropertyConfig
 
value - Variable in class org.h2.tools.SimpleResultSet.SimpleArray
 
value - Variable in class org.h2.util.json.JSONBoolean
 
value - Variable in class org.h2.util.json.JSONNumber
 
value - Variable in class org.h2.util.json.JSONString
 
value - Variable in class org.h2.value.ValueBigDecimalBase
 
value - Variable in class org.h2.value.ValueBigint
 
value - Variable in class org.h2.value.ValueBoolean
 
value - Variable in class org.h2.value.ValueBytesBase
The value.
value - Variable in class org.h2.value.ValueDouble
 
value - Variable in class org.h2.value.ValueInteger
 
value - Variable in class org.h2.value.ValueReal
 
value - Variable in class org.h2.value.ValueSmallint
 
value - Variable in class org.h2.value.ValueStringBase
The value.
value - Variable in class org.h2.value.ValueTinyint
 
value(CastDataProvider) - Method in class org.h2.command.Token.BigintToken
 
value(CastDataProvider) - Method in class org.h2.command.Token.BinaryStringToken
 
value(CastDataProvider) - Method in class org.h2.command.Token.CharacterStringToken
 
value(CastDataProvider) - Method in class org.h2.command.Token.IntegerToken
 
value(CastDataProvider) - Method in class org.h2.command.Token
 
value(CastDataProvider) - Method in class org.h2.command.Token.ValueToken
 
Value - Class in org.h2.value
This is the base class for all value classes.
Value() - Constructor for class org.h2.value.Value
 
VALUE - org.h2.util.json.JSONItemType
VALUE - Static variable in class org.h2.util.ParserUtil
The token "VALUE".
VALUE_TO_TI - Static variable in class org.h2.value.Transfer
 
VALUE_TOO_LONG_2 - Static variable in class org.h2.api.ErrorCode
The error with code 22001 is thrown when trying to insert a value that is too long for the column.
ValueArray - Class in org.h2.value
Implementation of the ARRAY data type.
ValueArray(TypeInfo, Value[], CastDataProvider) - Constructor for class org.h2.value.ValueArray
 
ValueBigDecimalBase - Class in org.h2.value
Base class for BigDecimal-based values.
ValueBigDecimalBase(BigDecimal) - Constructor for class org.h2.value.ValueBigDecimalBase
 
ValueBigint - Class in org.h2.value
Implementation of the BIGINT data type.
ValueBigint(long) - Constructor for class org.h2.value.ValueBigint
 
ValueBinary - Class in org.h2.value
Implementation of the BINARY data type.
ValueBinary(byte[]) - Constructor for class org.h2.value.ValueBinary
 
ValueBlob - Class in org.h2.value
Implementation of the BINARY LARGE OBJECT data type.
ValueBlob(LobData, long) - Constructor for class org.h2.value.ValueBlob
 
ValueBoolean - Class in org.h2.value
Implementation of the BOOLEAN data type.
ValueBoolean(boolean) - Constructor for class org.h2.value.ValueBoolean
 
ValueBytesBase - Class in org.h2.value
Base implementation of byte array based data types.
ValueBytesBase(byte[]) - Constructor for class org.h2.value.ValueBytesBase
 
ValueChar - Class in org.h2.value
Implementation of the CHARACTER data type.
ValueChar(String) - Constructor for class org.h2.value.ValueChar
 
ValueClob - Class in org.h2.value
Implementation of the CHARACTER LARGE OBJECT data type.
ValueClob(LobData, long, long) - Constructor for class org.h2.value.ValueClob
 
ValueCollectionBase - Class in org.h2.value
Base class for ARRAY and ROW values.
ValueCollectionBase(Value[]) - Constructor for class org.h2.value.ValueCollectionBase
 
valueCount - Variable in class org.h2.mvstore.db.MVSortedTempResult
Count of remaining duplicate rows for the MVSortedTempResult.next() method.
valueDataType - Variable in class org.h2.mvstore.db.RowDataType
 
ValueDataType - Class in org.h2.mvstore.db
A row type.
ValueDataType() - Constructor for class org.h2.mvstore.db.ValueDataType
 
ValueDataType(CastDataProvider, CompareMode, DataHandler, int[]) - Constructor for class org.h2.mvstore.db.ValueDataType
 
ValueDataType(Database, int[]) - Constructor for class org.h2.mvstore.db.ValueDataType
 
ValueDataType.Factory - Class in org.h2.mvstore.db
 
ValueDate - Class in org.h2.value
Implementation of the DATE data type.
ValueDate(long) - Constructor for class org.h2.value.ValueDate
 
ValueDecfloat - Class in org.h2.value
Implementation of the DECFLOAT data type.
ValueDecfloat(BigDecimal) - Constructor for class org.h2.value.ValueDecfloat
 
ValueDouble - Class in org.h2.value
Implementation of the DOUBLE PRECISION data type.
ValueDouble(double) - Constructor for class org.h2.value.ValueDouble
 
ValueEnum - Class in org.h2.value
ENUM value.
ValueEnum(ExtTypeInfoEnum, String, int) - Constructor for class org.h2.value.ValueEnum
 
ValueEnumBase - Class in org.h2.value
Base implementation of the ENUM data type.
ValueEnumBase(String, int) - Constructor for class org.h2.value.ValueEnumBase
 
ValueExpression - Class in org.h2.expression
An expression representing a constant value.
ValueExpression(Value) - Constructor for class org.h2.expression.ValueExpression
 
valueFalse() - Method in class org.h2.util.json.JSONByteArrayTarget
 
valueFalse() - Method in class org.h2.util.json.JSONStringTarget
 
valueFalse() - Method in class org.h2.util.json.JSONTarget
Parse "false".
valueFalse() - Method in class org.h2.util.json.JSONValidationTargetWithoutUniqueKeys
 
valueFalse() - Method in class org.h2.util.json.JSONValidationTargetWithUniqueKeys
 
valueFalse() - Method in class org.h2.util.json.JSONValueTarget
 
ValueGeometry - Class in org.h2.value
Implementation of the GEOMETRY data type.
ValueGeometry(byte[], double[]) - Constructor for class org.h2.value.ValueGeometry
Create a new geometry object.
valueId - Variable in class org.h2.tools.Recover
 
ValueInteger - Class in org.h2.value
Implementation of the INTEGER data type.
ValueInteger(int) - Constructor for class org.h2.value.ValueInteger
 
ValueInterval - Class in org.h2.value
Implementation of the INTERVAL data type.
ValueInterval(int, boolean, long, long) - Constructor for class org.h2.value.ValueInterval
 
ValueJavaObject - Class in org.h2.value
Implementation of the JAVA_OBJECT data type.
ValueJavaObject(byte[]) - Constructor for class org.h2.value.ValueJavaObject
 
ValueJson - Class in org.h2.value
Implementation of the JSON data type.
ValueJson(byte[]) - Constructor for class org.h2.value.ValueJson
 
valueList - Variable in class org.h2.expression.condition.ConditionIn
 
valueList - Variable in class org.h2.expression.condition.ConditionInConstantSet
 
ValueLob - Class in org.h2.value
A implementation of the BINARY LARGE OBJECT and CHARACTER LARGE OBJECT data types.
ValueLob(LobData, long, long) - Constructor for class org.h2.value.ValueLob
 
valueNull() - Method in class org.h2.util.json.JSONByteArrayTarget
 
valueNull() - Method in class org.h2.util.json.JSONStringTarget
 
valueNull() - Method in class org.h2.util.json.JSONTarget
Parse "null".
valueNull() - Method in class org.h2.util.json.JSONValidationTargetWithoutUniqueKeys
 
valueNull() - Method in class org.h2.util.json.JSONValidationTargetWithUniqueKeys
 
valueNull() - Method in class org.h2.util.json.JSONValueTarget
 
ValueNull - Class in org.h2.value
Implementation of NULL.
ValueNull() - Constructor for class org.h2.value.ValueNull
 
valueNumber(BigDecimal) - Method in class org.h2.util.json.JSONByteArrayTarget
 
valueNumber(BigDecimal) - Method in class org.h2.util.json.JSONStringTarget
 
valueNumber(BigDecimal) - Method in class org.h2.util.json.JSONTarget
A number value.
valueNumber(BigDecimal) - Method in class org.h2.util.json.JSONValidationTargetWithoutUniqueKeys
 
valueNumber(BigDecimal) - Method in class org.h2.util.json.JSONValidationTargetWithUniqueKeys
 
valueNumber(BigDecimal) - Method in class org.h2.util.json.JSONValueTarget
 
ValueNumeric - Class in org.h2.value
Implementation of the NUMERIC data type.
ValueNumeric(BigDecimal) - Constructor for class org.h2.value.ValueNumeric
 
valueOf(int) - Static method in enum org.h2.api.IntervalQualifier
Returns the interval qualifier with the specified ordinal value.
valueOf(int) - Static method in enum org.h2.mode.DefaultNullOrdering
Returns default ordering of NULL values for the specified ordinal number.
valueOf(Object) - Static method in class org.h2.engine.GeneratedKeysMode
Determines mode of generated keys' gathering.
valueOf(String) - Static method in enum org.h2.api.IntervalQualifier
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.command.Parser.NullConstraintType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.command.query.SelectUnion.UnionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.constraint.Constraint.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.constraint.ConstraintActionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.engine.IsolationLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.engine.Mode.CharPadding
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.engine.Mode.ExpressionNames
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.engine.Mode.ModeEnum
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.engine.Mode.UniqueIndexNullsHandling
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.engine.Mode.ViewExpressionNames
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.engine.SessionLocal.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.expression.aggregate.AggregateDataCollecting.NullCollectionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.expression.aggregate.AggregateType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.expression.analysis.WindowFrameBoundType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.expression.analysis.WindowFrameExclusion
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.expression.analysis.WindowFrameUnits
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.expression.analysis.WindowFunctionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.expression.BinaryOperation.OpType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.expression.condition.CompareLike.LikeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.expression.Format.FormatEnum
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.expression.function.ToCharFunction.Capitalization
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.expression.IntervalOperation.IntervalOpType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.jdbc.JdbcLob.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.mode.DefaultNullOrdering
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.mode.ToDateParser.ConfigParam
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.mode.ToDateTokenizer.FormatTokenEnum
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.mvstore.db.MVTable.TraceLockEvent
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.mvstore.MVMap.Decision
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.schema.Sequence.Cycle
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.store.FileLockMethod
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.table.DataChangeDeltaTable.ResultOption
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.table.TableType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.h2.util.json.JSONItemType
Returns the enum constant of this type with the specified name.
valueOf(TypeInfo) - Static method in class org.h2.table.InformationSchemaTable.DataTypeInformation
 
ValueReal - Class in org.h2.value
Implementation of the REAL data type.
ValueReal(float) - Constructor for class org.h2.value.ValueReal
 
ValueRow - Class in org.h2.value
Row value.
ValueRow(TypeInfo, Value[]) - Constructor for class org.h2.value.ValueRow
 
values - Variable in class org.h2.command.dml.MergeUsing.WhenNotMatched
 
values - Variable in class org.h2.command.dml.SetClauseList.RowExpression
 
values - Variable in class org.h2.expression.aggregate.AggregateDataCollecting
 
values - Variable in class org.h2.expression.aggregate.AggregateDataDistinctWithCounts
 
values - Variable in class org.h2.index.VirtualTableCursor
 
values - Variable in class org.h2.mvstore.Page.Leaf
The storage for values.
values - Variable in class org.h2.util.CacheLRU
 
values - Variable in class org.h2.value.ValueCollectionBase
Values.
values() - Static method in enum org.h2.api.IntervalQualifier
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.command.Parser.NullConstraintType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.command.query.SelectUnion.UnionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.constraint.Constraint.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.constraint.ConstraintActionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.engine.IsolationLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.engine.Mode.CharPadding
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.engine.Mode.ExpressionNames
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.engine.Mode.ModeEnum
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.engine.Mode.UniqueIndexNullsHandling
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.engine.Mode.ViewExpressionNames
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.engine.SessionLocal.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.expression.aggregate.AggregateDataCollecting.NullCollectionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.expression.aggregate.AggregateType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.expression.analysis.WindowFrameBoundType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.expression.analysis.WindowFrameExclusion
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.expression.analysis.WindowFrameUnits
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.expression.analysis.WindowFunctionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.expression.BinaryOperation.OpType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.expression.condition.CompareLike.LikeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.expression.Format.FormatEnum
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.expression.function.ToCharFunction.Capitalization
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.expression.IntervalOperation.IntervalOpType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.jdbc.JdbcLob.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.mode.DefaultNullOrdering
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.mode.ToDateParser.ConfigParam
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.mode.ToDateTokenizer.FormatTokenEnum
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.h2.mvstore.cache.CacheLongKeyLIRS
Get the values for all resident entries.
values() - Static method in enum org.h2.mvstore.db.MVTable.TraceLockEvent
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.mvstore.MVMap.Decision
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.schema.Sequence.Cycle
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.store.FileLockMethod
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.table.DataChangeDeltaTable.ResultOption
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.table.TableType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.h2.util.json.JSONItemType
Returns an array containing the constants of this enum type, in the order they are declared.
VALUES - Static variable in enum org.h2.mode.DefaultNullOrdering
 
VALUES - Static variable in class org.h2.util.ParserUtil
The token "VALUES".
valuesBuffer - Variable in class org.h2.mvstore.MVMap
 
valueSet - Variable in class org.h2.expression.condition.ConditionInConstantSet
 
valuesExpressionList - Variable in class org.h2.command.dml.CommandWithValues
Expression data for the VALUES clause.
ValueSmallint - Class in org.h2.value
Implementation of the SMALLINT data type.
ValueSmallint(short) - Constructor for class org.h2.value.ValueSmallint
 
valueString(String) - Method in class org.h2.util.json.JSONByteArrayTarget
 
valueString(String) - Method in class org.h2.util.json.JSONStringTarget
 
valueString(String) - Method in class org.h2.util.json.JSONTarget
A string value.
valueString(String) - Method in class org.h2.util.json.JSONValidationTargetWithoutUniqueKeys
 
valueString(String) - Method in class org.h2.util.json.JSONValidationTargetWithUniqueKeys
 
valueString(String) - Method in class org.h2.util.json.JSONValueTarget
 
ValueStringBase - Class in org.h2.value
Base implementation of String based data types.
ValueStringBase(String) - Constructor for class org.h2.value.ValueStringBase
 
ValueTime - Class in org.h2.value
Implementation of the TIME data type.
ValueTime(long) - Constructor for class org.h2.value.ValueTime
 
ValueTimestamp - Class in org.h2.value
Implementation of the TIMESTAMP data type.
ValueTimestamp(long, long) - Constructor for class org.h2.value.ValueTimestamp
 
ValueTimestampTimeZone - Class in org.h2.value
Implementation of the TIMESTAMP WITH TIME ZONE data type.
ValueTimestampTimeZone(long, long, int) - Constructor for class org.h2.value.ValueTimestampTimeZone
 
ValueTimeTimeZone - Class in org.h2.value
Implementation of the TIME WITH TIME ZONE data type.
ValueTimeTimeZone(long, int) - Constructor for class org.h2.value.ValueTimeTimeZone
 
ValueTinyint - Class in org.h2.value
Implementation of the TINYINT data type.
ValueTinyint(byte) - Constructor for class org.h2.value.ValueTinyint
 
valueToArray(Class<?>, Value, JdbcConnection) - Static method in class org.h2.value.ValueToObjectConverter
 
valueToDefaultArray(Value, JdbcConnection, boolean) - Static method in class org.h2.value.ValueToObjectConverter
Converts the specified array value to array of default Java objects for its type.
valueToDefaultObject(Value, JdbcConnection, boolean) - Static method in class org.h2.value.ValueToObjectConverter
Converts the specified value to the default Java object for its type.
valueToDuration(Value) - Static method in class org.h2.util.JSR310Utils
Converts a value to a Duration.
valueToInstant(Value, CastDataProvider) - Static method in class org.h2.util.JSR310Utils
Converts a value to a Instant.
ValueToken(int, Value) - Constructor for class org.h2.command.Token.ValueToken
 
valueToLegacyType(Class<T>, Value, CastDataProvider) - Static method in class org.h2.util.LegacyDateTimeUtils
Converts the specified value to an object of the specified legacy type.
valueToLocalDate(Value, CastDataProvider) - Static method in class org.h2.util.JSR310Utils
Converts a value to a LocalDate.
valueToLocalDateTime(Value, CastDataProvider) - Static method in class org.h2.util.JSR310Utils
Converts a value to a LocalDateTime.
valueToLocalTime(Value, CastDataProvider) - Static method in class org.h2.util.JSR310Utils
Converts a value to a LocalTime.
valueToObject(Class<T>, Value, JdbcConnection) - Static method in class org.h2.value.ValueToObjectConverter
Converts the specified value to an object of the specified type.
ValueToObjectConverter - Class in org.h2.value
Data type conversion methods between values and Java objects.
ValueToObjectConverter() - Constructor for class org.h2.value.ValueToObjectConverter
 
ValueToObjectConverter2 - Class in org.h2.value
Data type conversion methods between values and Java objects to use on the server side on H2 only.
ValueToObjectConverter2() - Constructor for class org.h2.value.ValueToObjectConverter2
 
valueToOffsetDateTime(Value, CastDataProvider) - Static method in class org.h2.util.JSR310Utils
Converts a value to a OffsetDateTime.
valueToOffsetTime(Value, CastDataProvider) - Static method in class org.h2.util.JSR310Utils
Converts a value to a OffsetTime.
valueToOther(Class<?>, Value, JdbcConnection) - Static method in class org.h2.value.ValueToObjectConverter
 
valueToPeriod(Value) - Static method in class org.h2.util.JSR310Utils
Converts a value to a Period.
valueToZonedDateTime(Value, CastDataProvider) - Static method in class org.h2.util.JSR310Utils
Converts a value to a ZonedDateTime.
valueTrue() - Method in class org.h2.util.json.JSONByteArrayTarget
 
valueTrue() - Method in class org.h2.util.json.JSONStringTarget
 
valueTrue() - Method in class org.h2.util.json.JSONTarget
Parse "true".
valueTrue() - Method in class org.h2.util.json.JSONValidationTargetWithoutUniqueKeys
 
valueTrue() - Method in class org.h2.util.json.JSONValidationTargetWithUniqueKeys
 
valueTrue() - Method in class org.h2.util.json.JSONValueTarget
 
valueType - Variable in class org.h2.mvstore.MVMap.BasicBuilder
 
valueType - Variable in class org.h2.mvstore.MVMap
 
valueType - Variable in class org.h2.mvstore.tx.TxDecisionMaker.RepeatableReadLockDecisionMaker
 
valueType - Variable in class org.h2.mvstore.tx.VersionedValueType
 
valueType - Variable in class org.h2.value.TypeInfo
 
valueType - Variable in class org.h2.value.ValueInterval
 
valueType(DataType<? super V>) - Method in class org.h2.mvstore.MVMap.BasicBuilder
Set the value data type.
valueType(DataType<? super V>) - Method in class org.h2.mvstore.MVMap.Builder
 
valueType(DataType<? super V>) - Method in class org.h2.mvstore.rtree.MVRTreeMap.Builder
Set the key data type.
valueTypes - Variable in class org.h2.expression.condition.TypePredicate
 
ValueUuid - Class in org.h2.value
Implementation of the UUID data type.
ValueUuid(long, long) - Constructor for class org.h2.value.ValueUuid
 
ValueVarbinary - Class in org.h2.value
Implementation of the BINARY VARYING data type.
ValueVarbinary(byte[]) - Constructor for class org.h2.value.ValueVarbinary
 
ValueVarchar - Class in org.h2.value
Implementation of the CHARACTER VARYING data type.
ValueVarchar(String) - Constructor for class org.h2.value.ValueVarchar
 
ValueVarcharIgnoreCase - Class in org.h2.value
Implementation of the VARCHAR_IGNORECASE data type.
ValueVarcharIgnoreCase(String) - Constructor for class org.h2.value.ValueVarcharIgnoreCase
 
VAR_ARGS - Static variable in class org.h2.mode.ModeFunction
Constant for variable number of arguments.
VAR_POP - org.h2.expression.aggregate.AggregateType
The aggregate type for VAR_POP(expression).
VAR_SAMP - org.h2.expression.aggregate.AggregateType
The aggregate type for VAR_SAMP(expression).
varArgClass - Variable in class org.h2.schema.FunctionAlias.JavaMethod
 
varArgs - Variable in class org.h2.schema.FunctionAlias.JavaMethod
 
VARBINARY - Static variable in class org.h2.api.H2Type
The BINARY VARYING data type.
VARBINARY - Static variable in class org.h2.mvstore.db.ValueDataType
 
VARBINARY - Static variable in class org.h2.value.Transfer
 
VARBINARY - Static variable in class org.h2.value.Value
The value type for BINARY VARYING values.
VARBINARY_0_31 - Static variable in class org.h2.mvstore.db.ValueDataType
 
VARCHAR - Static variable in class org.h2.api.H2Type
The CHARACTER VARYING data type.
VARCHAR - Static variable in class org.h2.mvstore.db.ValueDataType
 
VARCHAR - Static variable in class org.h2.value.Transfer
 
VARCHAR - Static variable in class org.h2.value.Value
The value type for CHARACTER VARYING values.
VARCHAR_0_31 - Static variable in class org.h2.mvstore.db.ValueDataType
 
VARCHAR_IGNORECASE - Static variable in class org.h2.api.H2Type
The VARCHAR_IGNORECASE data type.
VARCHAR_IGNORECASE - Static variable in class org.h2.mvstore.db.ValueDataType
 
VARCHAR_IGNORECASE - Static variable in class org.h2.value.Transfer
 
VARCHAR_IGNORECASE - Static variable in class org.h2.value.Value
The value type for VARCHAR_IGNORECASE values.
Variable - Class in org.h2.expression
A user-defined variable, for example: @ID.
Variable(SessionLocal, String) - Constructor for class org.h2.expression.Variable
 
VARIABLE - Static variable in class org.h2.command.dml.SetTypes
The type of a SET \@VARIABLE statement.
VARIABLE_BINARY - Static variable in class org.h2.command.dml.SetTypes
The type of a SET VARIABLE_BINARY statement.
variableBinary - Variable in class org.h2.command.dml.RunScriptCommand
 
variableBinary - Variable in class org.h2.command.Parser
 
variableBinary - Variable in class org.h2.engine.SessionLocal
Whether BINARY is parsed as VARBINARY.
variables - Variable in class org.h2.engine.SessionLocal
 
verifyArgs(String...) - Method in class org.h2.tools.Server
 
verifyCount - Variable in class org.h2.store.RecoverTester
 
verifyLobMac(byte[], long) - Method in class org.h2.value.Transfer
Verify the HMAC.
verifyMetaLocked(SessionLocal) - Method in class org.h2.engine.Database
Verify the meta table is locked.
version - Variable in class org.h2.command.dml.ScriptCommand
 
version - Variable in class org.h2.mvstore.Chunk
The version stored in this chunk.
version - Variable in class org.h2.mvstore.MVStore.RemovedPageInfo
 
version - Variable in class org.h2.mvstore.MVStore.TxCounter
Version of a store, this TxCounter is related to
version - Variable in class org.h2.mvstore.RootReference
The version used for writing.
version - Variable in class org.h2.mvstore.tx.VersionedBitSet
 
version - Variable in class org.h2.value.Transfer
 
VERSION - Static variable in class org.h2.engine.Constants
The version of this product, consisting of major version, minor version, and build id.
VERSION - Static variable in class org.h2.mode.FunctionsPostgreSQL
 
VERSION_MAJOR - Static variable in class org.h2.engine.Constants
The major version of this database.
VERSION_MINOR - Static variable in class org.h2.engine.Constants
The minor version of this database.
VersionedBitSet - Class in org.h2.mvstore.tx
Class VersionedBitSet extends standard BitSet to add a version field.
VersionedBitSet() - Constructor for class org.h2.mvstore.tx.VersionedBitSet
 
VersionedValue<T> - Class in org.h2.value
A versioned value (possibly null).
VersionedValue() - Constructor for class org.h2.value.VersionedValue
 
VersionedValueCommitted<T> - Class in org.h2.mvstore.tx
Class CommittedVersionedValue.
VersionedValueCommitted(T) - Constructor for class org.h2.mvstore.tx.VersionedValueCommitted
 
VersionedValueType<T,​D> - Class in org.h2.mvstore.tx
The value type for a versioned value.
VersionedValueType(DataType<T>) - Constructor for class org.h2.mvstore.tx.VersionedValueType
 
VersionedValueType.Factory<D> - Class in org.h2.mvstore.tx
 
VersionedValueUncommitted<T> - Class in org.h2.mvstore.tx
Class VersionedValueUncommitted.
VersionedValueUncommitted(long, T, T) - Constructor for class org.h2.mvstore.tx.VersionedValueUncommitted
 
versions - Variable in class org.h2.mvstore.MVStore
Ordered collection of all version usage counters for all versions starting from oldestVersionToKeep and up to current.
versionsToKeep - Variable in class org.h2.mvstore.MVStore
 
view - Variable in class org.h2.command.ddl.AlterView
 
view - Variable in class org.h2.index.ViewIndex
 
view - Variable in class org.h2.table.TableView.CacheKey
 
VIEW - org.h2.table.TableType
The table type name for views.
VIEW_ALREADY_EXISTS_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90038 is thrown when trying to create a view if a view with this name already exists.
VIEW_COST_CACHE_MAX_AGE - Static variable in class org.h2.engine.Constants
The maximum time in milliseconds to keep the cost of a view.
VIEW_INDEX_CACHE_SIZE - Static variable in class org.h2.engine.Constants
The name of the index cache that is used for temporary view (subqueries used as tables).
VIEW_IS_INVALID_2 - Static variable in class org.h2.api.ErrorCode
The error with code 90109 is thrown when trying to run a query against an invalid view.
VIEW_NOT_FOUND_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90037 is thrown when trying to drop or alter a view that does not exist.
ViewCursor - Class in org.h2.index
The cursor implementation of a view index.
ViewCursor(ViewIndex, ResultInterface, SearchRow, SearchRow) - Constructor for class org.h2.index.ViewCursor
 
viewExpressionNames - Variable in class org.h2.engine.Mode
How column names are generated for views.
ViewExpressionNames() - Constructor for enum org.h2.engine.Mode.ViewExpressionNames
 
ViewIndex - Class in org.h2.index
This object represents a virtual index for a query.
ViewIndex(TableView, String, ArrayList<Parameter>, boolean) - Constructor for class org.h2.index.ViewIndex
Constructor for the original index in TableView.
ViewIndex(TableView, ViewIndex, SessionLocal, int[], TableFilter[], int, SortOrder) - Constructor for class org.h2.index.ViewIndex
Constructor for plan item generation.
viewIndexCache - Variable in class org.h2.engine.SessionLocal
 
viewName - Variable in class org.h2.command.ddl.CreateView
 
viewName - Variable in class org.h2.command.ddl.DropView
 
viewQuery - Variable in class org.h2.table.TableView
 
views(SessionLocal, ArrayList<Row>, String, Table, String) - Method in class org.h2.table.InformationSchemaTable
 
views(SessionLocal, Value, Value, ArrayList<Row>, String) - Method in class org.h2.table.InformationSchemaTable
 
VIEWS - Static variable in class org.h2.table.InformationSchemaTable
 
VIEWS - Static variable in class org.h2.table.InformationSchemaTableLegacy
 
virtualColumnCount - Variable in class org.h2.result.SimpleRowValue
 
VirtualConstructedTable - Class in org.h2.table
A base class for virtual tables that construct all their content at once.
VirtualConstructedTable(Schema, int, String) - Constructor for class org.h2.table.VirtualConstructedTable
 
VirtualConstructedTableIndex - Class in org.h2.index
An index for a virtual table that returns a result set.
VirtualConstructedTableIndex(VirtualConstructedTable, IndexColumn[]) - Constructor for class org.h2.index.VirtualConstructedTableIndex
 
VirtualTable - Class in org.h2.table
A base class for virtual tables.
VirtualTable(Schema, int, String) - Constructor for class org.h2.table.VirtualTable
 
VirtualTableCursor - Class in org.h2.index
A cursor for a virtual table.
VirtualTableCursor(VirtualTableIndex, SearchRow, SearchRow, ResultInterface) - Constructor for class org.h2.index.VirtualTableCursor
 
VirtualTableIndex - Class in org.h2.index
An base class for indexes of virtual tables.
VirtualTableIndex(VirtualTable, String, IndexColumn[]) - Constructor for class org.h2.index.VirtualTableIndex
 
visible - Variable in class org.h2.table.Column
 
visibleColumnCount - Variable in class org.h2.command.query.Query
The visible columns (the ones required in the result).
visibleColumnCount - Variable in class org.h2.mvstore.db.MVTempResult
Count of visible columns.
visibleColumnCount - Variable in class org.h2.result.LocalResult
 
visit(BnfVisitor, String) - Method in class org.h2.bnf.Bnf
Parse the syntax and let the rule call the visitor.
visit(TableFilter.TableFilterVisitor) - Method in class org.h2.table.TableFilter
Visit this and all joined or nested table filters.
visitRuleElement(boolean, String, Rule) - Method in interface org.h2.bnf.BnfVisitor
Visit a rule element.
visitRuleExtension(Rule, boolean) - Method in interface org.h2.bnf.BnfVisitor
Visit a rule with non-standard extension.
visitRuleFixed(int) - Method in interface org.h2.bnf.BnfVisitor
Visit a fixed rule.
visitRuleList(boolean, ArrayList<Rule>) - Method in interface org.h2.bnf.BnfVisitor
Visit a rule list.
visitRuleOptional(ArrayList<Rule>) - Method in interface org.h2.bnf.BnfVisitor
Visit an OR list of optional rules.
visitRuleOptional(Rule) - Method in interface org.h2.bnf.BnfVisitor
Visit an optional rule.
visitRuleRepeat(boolean, Rule) - Method in interface org.h2.bnf.BnfVisitor
Visit a repeat rule.

W

wait(int) - Static method in class org.h2.store.fs.disk.FilePathDisk
 
wait(int) - Static method in class org.h2.tools.Server
 
waitFor(Transaction, String, Object) - Method in class org.h2.mvstore.tx.Transaction
Make this transaction to wait for the specified transaction to be closed, because both of them try to modify the same map entry.
waitForLock - Variable in class org.h2.engine.SessionLocal
 
waitForLockThread - Variable in class org.h2.engine.SessionLocal
 
waitForThisToEnd(int, Transaction) - Method in class org.h2.mvstore.tx.Transaction
 
waitIfExclusiveModeEnabled() - Method in class org.h2.engine.SessionLocal
Wait if the exclusive mode has been enabled for another session.
WAITING_FOR_LOCK - Static variable in class org.h2.mvstore.db.MVTable
The table name this thread is waiting to lock.
waitingSessions - Variable in class org.h2.mvstore.db.MVTable
The queue of sessions waiting to lock the table.
waitUntilOld() - Method in class org.h2.store.FileLock
 
warn(String, Throwable) - Static method in class org.h2.util.MathUtils
Print a message to system output if there was a problem initializing the random number generator.
wasEmpty - Variable in class org.h2.util.geometry.GeoJsonUtils.GeoJsonTarget
 
wasNull - Variable in class org.h2.jdbc.JdbcResultSet
 
wasNull - Variable in class org.h2.tools.SimpleResultSet
 
wasNull() - Method in class org.h2.jdbc.JdbcCallableStatement
Returns whether the last column accessed was null.
wasNull() - Method in class org.h2.jdbc.JdbcResultSet
Returns whether the last column accessed was null.
wasNull() - Method in class org.h2.tools.SimpleResultSet
Returns whether the last column accessed was null.
wasStored - Variable in class org.h2.mvstore.tx.Transaction
Indicates whether this transaction was stored in preparedTransactions map
watchdog - Variable in class org.h2.store.FileLock
 
watcher - Variable in class org.h2.jdbc.JdbcConnection
 
web - Variable in class org.h2.tools.Console
 
web - Variable in class org.h2.tools.Server
 
WebApp - Class in org.h2.server.web
For each connection to a session, an object of this class is created.
WebApp(WebServer) - Constructor for class org.h2.server.web.WebApp
 
WebApp.IndexInfo - Class in org.h2.server.web
This class represents index information for the GUI.
WebServer - Class in org.h2.server.web
The web server is a simple standalone HTTP server that implements the H2 Console application.
WebServer() - Constructor for class org.h2.server.web.WebServer
 
WebServer.TranslateThread - Class in org.h2.server.web
The translate thread reads and writes the file translation.properties once a second.
WebServlet - Class in org.h2.server.web
This servlet lets the H2 Console be used in a standard servlet container such as Tomcat or Jetty.
WebServlet() - Constructor for class org.h2.server.web.WebServlet
 
WebSession - Class in org.h2.server.web
The web session keeps all data of a user session.
WebSession(WebServer) - Constructor for class org.h2.server.web.WebSession
 
WebThread - Class in org.h2.server.web
For each connection to a session, an object of this class is created.
WebThread(Socket, WebServer) - Constructor for class org.h2.server.web.WebThread
 
WEEK - Static variable in class org.h2.expression.function.DateTimeFunction
Week (locale-specific).
WEEK_FIELDS - Static variable in class org.h2.expression.function.DateTimeFunction
Local definitions of day-of-week, week-of-month, and week-of-year.
WEEK_YEAR - Static variable in class org.h2.expression.function.DateTimeFunction
Week-based year (locale-specific).
WEEKDAYS - Static variable in class org.h2.expression.function.ToCharFunction
The weekday field.
weekdiff(long, long, int) - Static method in class org.h2.expression.function.DateTimeFunction
 
when - Variable in class org.h2.command.dml.MergeUsing
 
when - Variable in class org.h2.expression.SimpleCase
 
When() - Constructor for class org.h2.command.dml.MergeUsing.When
 
WHEN - Static variable in class org.h2.util.ParserUtil
The token "WHEN".
WhenMatchedThenDelete() - Constructor for class org.h2.command.dml.MergeUsing.WhenMatchedThenDelete
 
WhenMatchedThenUpdate() - Constructor for class org.h2.command.dml.MergeUsing.WhenMatchedThenUpdate
 
WhenNotMatched(Column[], Boolean, Expression[]) - Constructor for class org.h2.command.dml.MergeUsing.WhenNotMatched
 
whenOperand - Variable in class org.h2.expression.condition.BetweenPredicate
 
whenOperand - Variable in class org.h2.expression.condition.CompareLike
 
whenOperand - Variable in class org.h2.expression.condition.Comparison
 
whenOperand - Variable in class org.h2.expression.condition.ConditionIn
 
whenOperand - Variable in class org.h2.expression.condition.ConditionInConstantSet
 
whenOperand - Variable in class org.h2.expression.condition.ConditionInParameter
 
whenOperand - Variable in class org.h2.expression.condition.ConditionInQuery
 
whenOperand - Variable in class org.h2.expression.condition.IsJsonPredicate
 
whenOperand - Variable in class org.h2.expression.condition.SimplePredicate
Where this is the when operand of the simple case.
WHERE - Static variable in class org.h2.util.ParserUtil
The token "WHERE".
whitespaceChars - Variable in class org.h2.fulltext.FullTextSettings
The whitespace characters.
Wildcard - Class in org.h2.expression
A wildcard expression as in SELECT * FROM TEST.
Wildcard(String, String) - Constructor for class org.h2.expression.Wildcard
 
Window - Class in org.h2.expression.analysis
Window clause.
Window(String, ArrayList<Expression>, ArrayList<QueryOrderBy>, WindowFrame) - Constructor for class org.h2.expression.analysis.Window
Creates a new instance of window clause.
WINDOW - Static variable in class org.h2.util.ParserUtil
The token "WINDOW".
WINDOW_HALF_SIZE - Static variable in class org.h2.util.MemoryEstimator
 
WINDOW_NOT_FOUND_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90136 is thrown when trying to reference a window that does not exist.
WINDOW_SHIFT - Static variable in class org.h2.util.MemoryEstimator
 
WINDOW_SIZE - Static variable in class org.h2.util.MemoryEstimator
 
windowActivated(WindowEvent) - Method in class org.h2.tools.GUIConsole
INTERNAL
windowClosed(WindowEvent) - Method in class org.h2.tools.GUIConsole
INTERNAL
windowClosing(WindowEvent) - Method in class org.h2.tools.GUIConsole
INTERNAL
windowData - Variable in class org.h2.command.query.SelectGroups
Maps an window expression object to its data.
windowDeactivated(WindowEvent) - Method in class org.h2.tools.GUIConsole
INTERNAL
windowDeiconified(WindowEvent) - Method in class org.h2.tools.GUIConsole
INTERNAL
WindowFrame - Class in org.h2.expression.analysis
Window frame clause.
WindowFrame(WindowFrameUnits, WindowFrameBound, WindowFrameBound, WindowFrameExclusion) - Constructor for class org.h2.expression.analysis.WindowFrame
Creates new instance of window frame clause.
WindowFrame.BiItr - Class in org.h2.expression.analysis
 
WindowFrame.BiReverseItr - Class in org.h2.expression.analysis
 
WindowFrame.Itr - Class in org.h2.expression.analysis
 
WindowFrame.PlainItr - Class in org.h2.expression.analysis
 
WindowFrame.PlainReverseItr - Class in org.h2.expression.analysis
 
WindowFrame.TriItr - Class in org.h2.expression.analysis
 
WindowFrame.TriReverseItr - Class in org.h2.expression.analysis
 
WindowFrameBound - Class in org.h2.expression.analysis
Window frame bound.
WindowFrameBound(WindowFrameBoundType, Expression) - Constructor for class org.h2.expression.analysis.WindowFrameBound
Creates new instance of window frame bound.
WindowFrameBoundType - Enum in org.h2.expression.analysis
Window frame bound type.
WindowFrameBoundType(String) - Constructor for enum org.h2.expression.analysis.WindowFrameBoundType
 
WindowFrameExclusion - Enum in org.h2.expression.analysis
Window frame exclusion clause.
WindowFrameExclusion(String) - Constructor for enum org.h2.expression.analysis.WindowFrameExclusion
 
WindowFrameUnits - Enum in org.h2.expression.analysis
Window frame units.
WindowFrameUnits() - Constructor for enum org.h2.expression.analysis.WindowFrameUnits
 
WindowFunction - Class in org.h2.expression.analysis
A window function.
WindowFunction(WindowFunctionType, Select, Expression[]) - Constructor for class org.h2.expression.analysis.WindowFunction
Creates new instance of a window function.
WindowFunctionType - Enum in org.h2.expression.analysis
A type of a window function.
WindowFunctionType() - Constructor for enum org.h2.expression.analysis.WindowFunctionType
 
windowIconified(WindowEvent) - Method in class org.h2.tools.GUIConsole
INTERNAL
windowOpened(WindowEvent) - Method in class org.h2.tools.GUIConsole
INTERNAL
windowPartitionData - Variable in class org.h2.command.query.SelectGroups
Maps an partitioned window expression object to its data.
windows - Variable in class org.h2.command.query.Select
 
WITH - Static variable in class org.h2.util.ParserUtil
The token "WITH".
WITH_PARENTHESES - Static variable in class org.h2.expression.Expression
Wrap expression in parentheses unconditionally.
WITH_STATEMENT_SUPPORTS_LIMITED_SUB_STATEMENTS - Static variable in class org.h2.command.Parser
 
WITH_TIES_WITHOUT_ORDER_BY - Static variable in class org.h2.api.ErrorCode
The error with code 90122 is thrown when WITH TIES clause is used without ORDER BY clause.
WITH_VALUE - org.h2.jdbc.JdbcLob.State
A value is set.
withColumns - Variable in class org.h2.command.dml.ScriptCommand
 
WithKeys(long, ResultInterface) - Constructor for class org.h2.result.ResultWithGeneratedKeys.WithKeys
Creates a result with update count and generated keys.
withNoData - Variable in class org.h2.command.ddl.CreateTable
 
WITHOUT_PARENTHESES - Static variable in class org.h2.expression.Expression
Do not wrap expression in parentheses.
withoutCount - Variable in class org.h2.expression.aggregate.ListaggArguments
 
withTies - Variable in class org.h2.command.query.Query
Whether tied rows should be included in result too.
withTiesSortOrder - Variable in class org.h2.result.LocalResult
 
WithTimeZone(ZoneId) - Constructor for class org.h2.util.TimeZoneProvider.WithTimeZone
 
withUniqueKeys - Variable in class org.h2.expression.condition.IsJsonPredicate
 
words - Variable in class org.h2.fulltext.FullTextSettings
The set of words / terms.
wrap(FileChannel) - Static method in class org.h2.mvstore.cache.FilePathCache
 
wrap(FilePath) - Method in class org.h2.store.fs.FilePathWrapper
Create a wrapped path instance for the given base path.
wrap(Column[]) - Static method in class org.h2.table.IndexColumn
Create an array of index columns from a list of columns.
wrapException(String, Exception) - Static method in class org.h2.table.TableLink
Wrap a SQL exception that occurred while accessing a linked table.
wrapInputStream(InputStream, String, String) - Static method in class org.h2.tools.CompressTool
INTERNAL
wrapOutputStream(OutputStream, String, String) - Static method in class org.h2.tools.CompressTool
INTERNAL
write(byte[]) - Method in class org.h2.server.pg.PgServerThread
 
write(byte[]) - Method in class org.h2.store.FileStoreOutputStream
 
write(byte[], int, int) - Method in class org.h2.compress.LZFOutputStream
 
write(byte[], int, int) - Method in class org.h2.security.SecureFileStore
 
write(byte[], int, int) - Method in class org.h2.store.Data
Append a number of bytes to this buffer.
write(byte[], int, int) - Method in class org.h2.store.FileStore
Write a number of bytes.
write(byte[], int, int) - Method in class org.h2.store.FileStoreOutputStream
 
write(int) - Method in class org.h2.compress.LZFOutputStream
 
write(int) - Method in class org.h2.server.pg.PgServerThread
 
write(int) - Method in class org.h2.store.FileStoreOutputStream
 
write(int, int, String, Throwable) - Method in class org.h2.message.TraceSystem
 
write(int, int, String, Throwable) - Method in interface org.h2.message.TraceWriter
Write a message.
write(int, int, String, Throwable) - Method in class org.h2.message.TraceWriterAdapter
 
write(int, String, String, Throwable) - Method in class org.h2.message.TraceSystem
 
write(int, String, String, Throwable) - Method in interface org.h2.message.TraceWriter
Write a message.
write(int, String, String, Throwable) - Method in class org.h2.message.TraceWriterAdapter
 
write(long, ByteBuffer) - Method in class org.h2.mvstore.MVStore
 
write(ByteArrayOutputStream) - Method in class org.h2.server.pg.PgServerThread
 
write(Writer, ResultSet) - Method in class org.h2.tools.Csv
Writes the result set to a file in the CSV format.
write(String, ResultSet, String) - Method in class org.h2.tools.Csv
Writes the result set to a file in the CSV format.
write(ByteBuffer) - Method in class org.h2.mvstore.cache.FilePathCache.FileCache
 
write(ByteBuffer) - Method in class org.h2.store.fs.FakeFileChannel
 
write(ByteBuffer) - Method in class org.h2.store.fs.FileBaseDefault
 
write(ByteBuffer) - Method in class org.h2.store.fs.rec.FileRec
 
write(ByteBuffer) - Method in class org.h2.store.fs.retry.FileRetryOnInterrupt
 
write(ByteBuffer) - Method in class org.h2.store.fs.zip.FileZip
 
write(ByteBuffer[], int, int) - Method in class org.h2.store.fs.FakeFileChannel
 
write(ByteBuffer[], int, int) - Method in class org.h2.store.fs.FileBase
 
write(ByteBuffer, long) - Method in class org.h2.mvstore.cache.FilePathCache.FileCache
 
write(ByteBuffer, long) - Method in class org.h2.store.fs.async.FileAsync
 
write(ByteBuffer, long) - Method in class org.h2.store.fs.encrypt.FileEncrypt
 
write(ByteBuffer, long) - Method in class org.h2.store.fs.FakeFileChannel
 
write(ByteBuffer, long) - Method in class org.h2.store.fs.FileBase
 
write(ByteBuffer, long) - Method in class org.h2.store.fs.mem.FileMem
 
write(ByteBuffer, long) - Method in class org.h2.store.fs.niomapped.FileNioMapped
 
write(ByteBuffer, long) - Method in class org.h2.store.fs.niomem.FileNioMem
 
write(ByteBuffer, long) - Method in class org.h2.store.fs.rec.FileRec
 
write(ByteBuffer, long) - Method in class org.h2.store.fs.retry.FileRetryOnInterrupt
 
write(ByteBuffer, long) - Method in class org.h2.store.fs.split.FileSplit
 
write(Connection, String, String, String) - Method in class org.h2.tools.Csv
Writes the result set of a query to a file in the CSV format.
write(Chunk, WriteBuffer, List<Long>) - Method in class org.h2.mvstore.Page
Store the page and update the position.
write(WriteBuffer, byte[]) - Method in class org.h2.mvstore.MVStoreTool.GenericDataType
 
write(WriteBuffer, byte[]) - Method in class org.h2.mvstore.type.ByteArrayDataType
 
write(WriteBuffer, Boolean) - Method in class org.h2.mvstore.type.ObjectDataType.BooleanType
 
write(WriteBuffer, Byte) - Method in class org.h2.mvstore.type.ObjectDataType.ByteType
 
write(WriteBuffer, Character) - Method in class org.h2.mvstore.type.ObjectDataType.CharacterType
 
write(WriteBuffer, Double) - Method in class org.h2.mvstore.type.ObjectDataType.DoubleType
 
write(WriteBuffer, Float) - Method in class org.h2.mvstore.type.ObjectDataType.FloatType
 
write(WriteBuffer, Integer) - Method in class org.h2.mvstore.type.ObjectDataType.IntegerType
 
write(WriteBuffer, Long) - Method in class org.h2.mvstore.type.LongDataType
 
write(WriteBuffer, Long) - Method in class org.h2.mvstore.type.ObjectDataType.LongType
 
write(WriteBuffer, Object) - Method in class org.h2.mvstore.type.ObjectDataType.NullType
 
write(WriteBuffer, Object) - Method in class org.h2.mvstore.type.ObjectDataType.ObjectArrayType
 
write(WriteBuffer, Object) - Method in class org.h2.mvstore.type.ObjectDataType.SerializedObjectType
 
write(WriteBuffer, Object) - Method in class org.h2.mvstore.type.ObjectDataType
 
write(WriteBuffer, Object, int) - Method in class org.h2.mvstore.db.NullValueDataType
 
write(WriteBuffer, Object, int) - Method in class org.h2.mvstore.tx.VersionedValueType
 
write(WriteBuffer, Object, int) - Method in class org.h2.mvstore.type.BasicDataType
 
write(WriteBuffer, Object, int) - Method in interface org.h2.mvstore.type.DataType
Write a list of objects.
write(WriteBuffer, Short) - Method in class org.h2.mvstore.type.ObjectDataType.ShortType
 
write(WriteBuffer, String) - Method in class org.h2.mvstore.type.ObjectDataType.StringType
 
write(WriteBuffer, String) - Method in class org.h2.mvstore.type.StringDataType
 
write(WriteBuffer, BigDecimal) - Method in class org.h2.mvstore.type.ObjectDataType.BigDecimalType
 
write(WriteBuffer, BigInteger) - Method in class org.h2.mvstore.type.ObjectDataType.BigIntegerType
 
write(WriteBuffer, Date) - Method in class org.h2.mvstore.type.ObjectDataType.DateType
 
write(WriteBuffer, UUID) - Method in class org.h2.mvstore.type.ObjectDataType.UUIDType
 
write(WriteBuffer, LobStorageMap.BlobMeta) - Method in class org.h2.mvstore.db.LobStorageMap.BlobMeta.Type
 
write(WriteBuffer, LobStorageMap.BlobReference) - Method in class org.h2.mvstore.db.LobStorageMap.BlobReference.Type
 
write(WriteBuffer, Spatial) - Method in class org.h2.mvstore.rtree.SpatialDataType
 
write(WriteBuffer, Record<K, V>) - Method in class org.h2.mvstore.tx.Record.Type
 
write(WriteBuffer, DataType<?>) - Method in class org.h2.mvstore.type.MetaType
 
write(WriteBuffer, SearchRow) - Method in class org.h2.mvstore.db.RowDataType
 
write(WriteBuffer, Value) - Method in class org.h2.mvstore.db.NullValueDataType
 
write(WriteBuffer, Value) - Method in class org.h2.mvstore.db.ValueDataType
 
write(WriteBuffer, VersionedValue<T>) - Method in class org.h2.mvstore.tx.VersionedValueType
 
write(WriteBuffer, T) - Method in class org.h2.mvstore.type.BasicDataType
 
write(WriteBuffer, T) - Method in interface org.h2.mvstore.type.DataType
Write an object.
write(WriteBuffer, T) - Method in class org.h2.mvstore.type.ObjectDataType.AutoDetectDataType
 
WRITE - Static variable in interface org.h2.store.fs.Recorder
Write to the file.
WRITE_DELAY - Static variable in class org.h2.command.dml.SetTypes
The type of a SET WRITE_DELAY statement.
WRITE_LOCK - Static variable in class org.h2.table.Table
Write lock.
writeBack(CacheObject) - Method in interface org.h2.util.CacheWriter
Persist a record.
writeBinary(byte, WriteBuffer, Value) - Static method in class org.h2.mvstore.db.ValueDataType
 
writeBlock(byte[]) - Method in class org.h2.mvstore.StreamStore
 
writeBoolean(boolean) - Method in class org.h2.value.Transfer
Write a boolean.
WriteBuffer - Class in org.h2.mvstore
An auto-resize buffer to write data into a ByteBuffer.
WriteBuffer() - Constructor for class org.h2.mvstore.WriteBuffer
 
WriteBuffer(int) - Constructor for class org.h2.mvstore.WriteBuffer
 
writeBufferPool - Variable in class org.h2.mvstore.MVStore
 
writeByte(byte) - Method in class org.h2.value.Transfer
Write a byte.
writeBytePrecisionWithDefault(long) - Method in class org.h2.value.Transfer
 
writeBytes - Variable in class org.h2.mvstore.FileStore
The number of written bytes.
writeBytes(byte[]) - Method in class org.h2.value.Transfer
Write a byte array.
writeBytes(byte[], int, int) - Method in class org.h2.value.Transfer
Write a number of bytes.
writeByteScaleWithDefault(int) - Method in class org.h2.value.Transfer
 
writeChildren(WriteBuffer, boolean) - Method in class org.h2.mvstore.Page.Leaf
 
writeChildren(WriteBuffer, boolean) - Method in class org.h2.mvstore.Page.NonLeaf
 
writeChildren(WriteBuffer, boolean) - Method in class org.h2.mvstore.Page
Write page children to the buff.
writeChildrenRecursive(Chunk, WriteBuffer, List<Long>) - Method in class org.h2.mvstore.Page.NonLeaf
 
writeChunkHeader(WriteBuffer, int) - Method in class org.h2.mvstore.Chunk
Write the chunk header.
writeColumn(Transfer, ResultInterface, int) - Static method in class org.h2.result.ResultColumn
Write a result column to the given output.
writeColumnHeader - Variable in class org.h2.tools.Csv
 
writeColumns(StringBuilder, Column[], int) - Static method in class org.h2.table.Column
Appends the specified columns to the specified builder.
writeColumns(StringBuilder, Column[], String, String, int) - Static method in class org.h2.table.Column
Appends the specified columns to the specified builder.
writeColumns(StringBuilder, IndexColumn[], int) - Static method in class org.h2.table.IndexColumn
Appends the specified columns to the specified builder.
writeColumns(StringBuilder, IndexColumn[], int, int, int) - Static method in class org.h2.table.IndexColumn
Appends the specified columns to the specified builder.
writeColumns(StringBuilder, IndexColumn[], String, String, int) - Static method in class org.h2.table.IndexColumn
Appends the specified columns to the specified builder.
writeCount - Variable in class org.h2.mvstore.FileStore
The number of write operations.
writeCount - Variable in class org.h2.store.RecoverTester
 
writeDataColumn(Value, int, boolean) - Method in class org.h2.server.pg.PgServerThread
 
writeDirect(byte[], int, int) - Method in class org.h2.security.SecureFileStore
 
writeDirect(byte[], int, int) - Method in class org.h2.store.FileStore
Write a number of bytes without encrypting.
writeDouble(byte[], int, double) - Static method in class org.h2.util.Bits
Writes a double value to the byte array at the given position in big-endian order.
writeDouble(double) - Method in class org.h2.util.geometry.EWKBUtils.EWKBTarget
 
writeDouble(double) - Method in class org.h2.util.geometry.EWKTUtils.EWKTTarget
 
writeDouble(double) - Method in class org.h2.util.geometry.GeoJsonUtils.GeoJsonTarget
 
writeDouble(double) - Method in class org.h2.value.Transfer
Write a double.
writeDoubleLE(byte[], int, double) - Static method in class org.h2.util.Bits
Writes a double value to the byte array at the given position in little-endian order.
writeError(PrintWriter, Throwable) - Method in class org.h2.tools.Recover
 
writeExpressions(StringBuilder, List<? extends Expression>, int) - Static method in class org.h2.expression.Expression
Get the SQL snippet for a list of expressions.
writeExpressions(StringBuilder, Expression[], int) - Static method in class org.h2.expression.Expression
Get the SQL snippet for an array of expressions.
writeFile(String, Throwable) - Method in class org.h2.message.TraceSystem
 
writeFloat(float) - Method in class org.h2.value.Transfer
Write a float.
writeFully(long, ByteBuffer) - Method in class org.h2.mvstore.FileStore
Write to the file.
writeFully(long, ByteBuffer) - Method in class org.h2.mvstore.OffHeapStore
 
writeFully(FileChannel, long, ByteBuffer) - Static method in class org.h2.mvstore.DataUtils
Write to a file channel.
writeFully(FileChannel, long, ByteBuffer) - Static method in class org.h2.store.fs.encrypt.FileEncrypt
 
writeFully(FileChannel, ByteBuffer) - Static method in class org.h2.store.fs.FileUtils
Fully write to the file.
writeHeader(int) - Method in class org.h2.util.geometry.EWKBUtils.EWKBTarget
 
writeHeader(int) - Method in class org.h2.util.geometry.EWKTUtils.EWKTTarget
 
writeHeader(int) - Method in class org.h2.util.geometry.GeoJsonUtils.GeoJsonTarget
 
writeInBackground() - Method in class org.h2.mvstore.MVStore
Commit and save all changes, if there are any, and compact the store if needed.
writeInt(byte[], int, int) - Static method in class org.h2.util.Bits
Writes a int value to the byte array at the given position in big-endian order.
writeInt(int) - Method in class org.h2.compress.LZFOutputStream
 
writeInt(int) - Method in class org.h2.server.pg.PgServerThread
 
writeInt(int) - Method in class org.h2.store.Data
Write an integer at the current position.
writeInt(int) - Method in class org.h2.util.geometry.EWKBUtils.EWKBTarget
 
writeInt(int) - Method in class org.h2.value.Transfer
Write an int.
writeIntArray(WriteBuffer, int[]) - Static method in class org.h2.mvstore.db.RowDataType
 
writeIntArray(WriteBuffer, int[]) - Static method in class org.h2.mvstore.db.ValueDataType
 
writeInternal(ByteBuffer, long, int, XTS) - Method in class org.h2.store.fs.encrypt.FileEncrypt
 
writeIntLE(byte[], int, int) - Static method in class org.h2.util.Bits
Writes a int value to the byte array at the given position in little-endian order.
writeLobStream(Value) - Method in class org.h2.command.dml.ScriptCommand
 
writeLong(byte[], int, long) - Static method in class org.h2.util.Bits
Writes a long value to the byte array at the given position in big-endian order.
writeLong(long) - Method in class org.h2.value.Transfer
Write a long.
writeLong(WriteBuffer, long) - Static method in class org.h2.mvstore.db.ValueDataType
Writes a long.
writeLongLE(byte[], int, long) - Static method in class org.h2.util.Bits
Writes a long value to the byte array at the given position in little-endian order.
writeMetaData(Transfer, ParameterInterface) - Static method in class org.h2.expression.ParameterRemote
Write the parameter meta data to the transfer object.
writeMetaRow(Row) - Method in class org.h2.tools.Recover
 
writeNewEntry(long, ByteBuffer) - Method in class org.h2.mvstore.OffHeapStore
 
writeNumericBinary(BigDecimal) - Method in class org.h2.server.pg.PgServerThread
 
writer - Variable in class org.h2.fulltext.FullTextLucene.IndexAccess
The index writer.
writer - Variable in class org.h2.message.TraceSystem
 
writer - Variable in class org.h2.util.CacheLRU
 
writeResultSet(ResultSet) - Method in class org.h2.tools.Csv
 
writeRow(String[]) - Method in class org.h2.tools.Csv
 
writeRowCount(long) - Method in class org.h2.value.Transfer
Write a row count.
writeSchema(PrintWriter) - Method in class org.h2.tools.Recover
 
writeSchemaSET(PrintWriter) - Method in class org.h2.tools.Recover
 
writeShort(int) - Method in class org.h2.server.pg.PgServerThread
 
writeShort(short) - Method in class org.h2.value.Transfer
Write a short.
writeSimple(String, byte[]) - Method in class org.h2.server.web.WebThread
 
writeSimple(String, String) - Method in class org.h2.server.web.WebThread
 
writeStartObject(int) - Method in class org.h2.util.geometry.GeoJsonUtils.GeoJsonTarget
 
writeStoreHeader() - Method in class org.h2.mvstore.MVStore
 
writeString(String) - Method in class org.h2.server.pg.PgServerThread
 
writeString(String) - Method in class org.h2.value.Transfer
Write a string.
writeString(WriteBuffer, String) - Static method in class org.h2.mvstore.db.ValueDataType
 
writeStringData(ByteBuffer, String, int) - Static method in class org.h2.mvstore.DataUtils
Write characters from a string (without the length).
writeStringPart(String) - Method in class org.h2.server.pg.PgServerThread
 
writeStringWithoutLength(char[], int) - Method in class org.h2.store.Data
 
writeTimeBinary(long, int) - Method in class org.h2.server.pg.PgServerThread
 
writeTimestampBinary(long, long) - Method in class org.h2.server.pg.PgServerThread
 
writeTimestampTime(WriteBuffer, long) - Static method in class org.h2.mvstore.db.ValueDataType
 
writeTimeZone(WriteBuffer, int) - Static method in class org.h2.mvstore.db.ValueDataType
 
writeTypeInfo(TypeInfo) - Method in class org.h2.value.Transfer
Write value type, precision, and scale.
writeTypeInfo19(TypeInfo) - Method in class org.h2.value.Transfer
 
writeTypeInfo20(TypeInfo) - Method in class org.h2.value.Transfer
 
writeTypeInfoEnum(TypeInfo) - Method in class org.h2.value.Transfer
 
writeTypeInfoGeometry(TypeInfo) - Method in class org.h2.value.Transfer
 
writeTypeInfoRow(TypeInfo) - Method in class org.h2.value.Transfer
 
writeUnsavedRecursive(Chunk, WriteBuffer, List<Long>) - Method in class org.h2.mvstore.Page.IncompleteNonLeaf
 
writeUnsavedRecursive(Chunk, WriteBuffer, List<Long>) - Method in class org.h2.mvstore.Page.Leaf
 
writeUnsavedRecursive(Chunk, WriteBuffer, List<Long>) - Method in class org.h2.mvstore.Page.NonLeaf
 
writeUnsavedRecursive(Chunk, WriteBuffer, List<Long>) - Method in class org.h2.mvstore.Page
Store this page and all children that are changed, in reverse order, and update the position and the children.
writeValue(Value) - Method in class org.h2.value.Transfer
Write a value.
writeValues(WriteBuffer) - Method in class org.h2.mvstore.Page.Leaf
 
writeValues(WriteBuffer) - Method in class org.h2.mvstore.Page.NonLeaf
 
writeValues(WriteBuffer) - Method in class org.h2.mvstore.Page
Write values that the buffer contains to the buff.
writeVariableInt(byte[], int, int) - Static method in class org.h2.tools.CompressTool
Write a variable size integer using Rice coding.
writeVarInt(OutputStream, int) - Static method in class org.h2.mvstore.DataUtils
Write a variable size int.
writeVarInt(ByteBuffer, int) - Static method in class org.h2.mvstore.DataUtils
Write a variable size int.
writeVarLong(OutputStream, long) - Static method in class org.h2.mvstore.DataUtils
Write a variable size long.
writeVarLong(ByteBuffer, long) - Static method in class org.h2.mvstore.DataUtils
Write a variable size long.
writeWithMargin - Variable in class org.h2.schema.Sequence
 
writingErrorLogged - Variable in class org.h2.message.TraceSystem
 
WRONG_PASSWORD_DELAY - Static variable in class org.h2.engine.Engine
 
WRONG_PASSWORD_FORMAT - Static variable in class org.h2.api.ErrorCode
The error with code 90050 is thrown when trying to open an encrypted database, but not separating the file password from the user password.
WRONG_USER_OR_PASSWORD - Static variable in class org.h2.api.ErrorCode
The error with code 28000 is thrown when there is no such user registered in the database, when the user password does not match, or when the database encryption password does not match (if database encryption is used).
WRONG_XID_FORMAT_1 - Static variable in class org.h2.api.ErrorCode
The error with code 90101 is thrown when the XA API detected unsupported transaction names.

X

X - Static variable in class org.h2.util.geometry.GeometryUtils
Number of X coordinate.
XA_DATA_SOURCE - Static variable in class org.h2.message.TraceObject
The trace type id for XA data sources.
XID - Static variable in class org.h2.message.TraceObject
The trace type id for transaction ids.
xmlAttr(String, String) - Static method in class org.h2.util.StringUtils
Creates an XML attribute of the form name="value".
XMLATTR - Static variable in class org.h2.expression.function.XMLFunction
XMLATTR() (non-standard).
xmlCData(String) - Static method in class org.h2.util.StringUtils
Converts the data to a CDATA element.
XMLCDATA - Static variable in class org.h2.expression.function.XMLFunction
XMLCDATA() (non-standard).
xmlComment(String) - Static method in class org.h2.util.StringUtils
Escapes a comment.
XMLCOMMENT - Static variable in class org.h2.expression.function.XMLFunction
XMLCOMMENT() (non-standard).
XMLFunction - Class in org.h2.expression.function
An XML function.
XMLFunction(int) - Constructor for class org.h2.expression.function.XMLFunction
 
xmlNode(String, String, String) - Static method in class org.h2.util.StringUtils
Create an XML node with optional attributes and content.
xmlNode(String, String, String, boolean) - Static method in class org.h2.util.StringUtils
Create an XML node with optional attributes and content.
xmlNode(SessionLocal) - Method in class org.h2.expression.function.XMLFunction
 
XMLNODE - Static variable in class org.h2.expression.function.XMLFunction
XMLNODE() (non-standard).
xmlStartDoc() - Static method in class org.h2.util.StringUtils
Returns <?xml version="1.0"?>
XMLSTARTDOC - Static variable in class org.h2.expression.function.XMLFunction
XMLSTARTDOC() (non-standard).
xmlText(String) - Static method in class org.h2.util.StringUtils
Escapes an XML text element.
xmlText(String, boolean) - Static method in class org.h2.util.StringUtils
Escapes an XML text element.
XMLTEXT - Static variable in class org.h2.expression.function.XMLFunction
XMLTEXT() (non-standard).
xorInitVector(byte[], int, int, long) - Method in class org.h2.security.SecureFileStore
 
xorTweak(byte[], int, byte[]) - Static method in class org.h2.store.fs.encrypt.XTS
 
XTEA - Class in org.h2.security
An implementation of the XTEA block cipher algorithm.
XTEA() - Constructor for class org.h2.security.XTEA
 
xtime(int) - Static method in class org.h2.security.AES
 
xts - Variable in class org.h2.store.fs.encrypt.FileEncrypt
 
XTS - Class in org.h2.store.fs.encrypt
An XTS implementation as described in IEEE P1619 (Standard Architecture for Encrypted Shared Storage Media).
XTS(BlockCipher) - Constructor for class org.h2.store.fs.encrypt.XTS
 

Y

Y - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
Y - Static variable in class org.h2.util.geometry.GeometryUtils
Number of Y coordinate.
year - Variable in class org.h2.mode.ToDateParser
 
YEAR - org.h2.api.IntervalQualifier
YEAR
YEAR - Static variable in class org.h2.expression.function.DateTimeFunction
Year.
YEAR - Static variable in class org.h2.util.ParserUtil
The token "YEAR".
YEAR_TO_MONTH - org.h2.api.IntervalQualifier
YEAR TO MONTH
yearForCalendar(int) - Static method in class org.h2.util.TimeZoneProvider.WithTimeZone
Returns a year within the range -999,999,999..999,999,999 for the given year.
yearFromDateValue(long) - Static method in class org.h2.util.DateTimeUtils
Get the year from a date value.
YearParslet() - Constructor for class org.h2.mode.ToDateTokenizer.YearParslet
 
yearsFromInterval(IntervalQualifier, boolean, long, long) - Static method in class org.h2.util.IntervalUtils
Returns years value of interval, if any.
YES - Static variable in class org.h2.jdbc.meta.DatabaseMetaLegacy
 
YES - Static variable in class org.h2.jdbc.meta.DatabaseMetaLocal
 
YMD - Static variable in class org.h2.bnf.RuleFixed
 
YY - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
YYY - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 
YYYY - org.h2.mode.ToDateTokenizer.FormatTokenEnum
 

Z

Z - Static variable in class org.h2.util.geometry.GeometryUtils
Number of Z coordinate.
ZERO - Static variable in class org.h2.value.ValueDecfloat
The value 'zero'.
ZERO - Static variable in class org.h2.value.ValueDouble
The value 0.
ZERO - Static variable in class org.h2.value.ValueJson
0 JSON value.
ZERO - Static variable in class org.h2.value.ValueNumeric
The value 'zero'.
ZERO - Static variable in class org.h2.value.ValueReal
The value 0.
ZERO_BITS - Static variable in class org.h2.value.ValueDouble
Double.doubleToLongBits(0d)
ZERO_BITS - Static variable in class org.h2.value.ValueReal
Float.floatToIntBits(0f).
zeroBasedEnums - Variable in class org.h2.engine.DbSettings
Database setting ZERO_BASED_ENUMS (default: false).
zeroBasedEnums() - Method in interface org.h2.engine.CastDataProvider
Returns are ENUM values 0-based.
zeroBasedEnums() - Method in class org.h2.engine.Database
 
zeroBasedEnums() - Method in class org.h2.engine.SessionLocal
 
zeroBasedEnums() - Method in class org.h2.engine.SessionRemote
 
zeroBasedEnums() - Method in class org.h2.jdbc.JdbcConnection
 
zeroElement - Variable in class org.h2.command.ddl.Analyze.SelectivityData
Whether the zero element is present.
zeroesAfterDecimalSeparator(BigDecimal) - Static method in class org.h2.expression.function.ToCharFunction
 
zeroExLiteralsAreBinaryStrings - Variable in class org.h2.engine.Mode
If true 0x-prefixed numbers are parsed as binary string literals, if false they are parsed as hexadecimal numeric values.
zonedDateTimeToValue(ZonedDateTime) - Static method in class org.h2.util.JSR310Utils
Converts a ZonedDateTime to a Value.
zoneId - Variable in class org.h2.expression.function.DateTimeFormatFunction.CacheValue
 
zoneId - Variable in class org.h2.util.TimeZoneProvider.WithTimeZone
 

_

_ROWID_ - Static variable in class org.h2.util.ParserUtil
The token "_ROWID_".
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 
All Classes All Packages