Class GenericConstantActionFactory

java.lang.Object
org.apache.derby.impl.sql.execute.GenericConstantActionFactory

public class GenericConstantActionFactory extends Object
Factory for creating ConstantActions.

Implemetation note: For most operations, the ResultSetFactory determines if the operation is allowed in a readonly/target database. Because we perform JAR add/drop/replace with a utility rather than using normal language processing we never get a result set for these operations. For this reason, the ConstantActionFactory rather than the ResultSetFactory checks if the these operations are allowed.

  • Constructor Details

    • GenericConstantActionFactory

      public GenericConstantActionFactory()
  • Method Details

    • getSetConstraintsConstantAction

      public ConstantAction getSetConstraintsConstantAction(List<TableName> constraints, boolean initiallyDeferred)
      Get ConstantAction for SET CONSTRAINTS statement.
      Parameters:
      constraints - The constraints to set, if null, set them ALL.
      initiallyDeferred - ncodes IMMEDIATE (false), DEFERRED (true)
    • getAlterTableConstantAction

      public ConstantAction getAlterTableConstantAction(SchemaDescriptor sd, String tableName, UUID tableId, long tableConglomerateId, int tableType, ColumnInfo[] columnInfo, ConstraintConstantAction[] constraintActions, char lockGranularity, boolean compressTable, int behavior, boolean sequential, boolean truncateTable, boolean purge, boolean defragment, boolean truncateEndOfTable, boolean updateStatistics, boolean updateStatisticsAll, boolean dropStatistics, boolean dropStatisticsAll, String indexNameForStatistics)
      Make the AlterAction for an ALTER TABLE statement.
      Parameters:
      sd - descriptor for the schema that table lives in.
      tableName - Name of table.
      tableId - UUID of table.
      tableConglomerateId - heap conglomerate id of table
      tableType - Type of table (e.g., BASE).
      columnInfo - Information on all the columns in the table.
      constraintActions - ConstraintConstantAction[] for constraints
      lockGranularity - The lock granularity.
      compressTable - Whether or not this is a compress table
      behavior - drop behavior of dropping column
      sequential - If compress table/drop column, whether or not sequential
      truncateTable - Whether or not this is a truncate table
      purge - PURGE during INPLACE COMPRESS?
      defragment - DEFRAGMENT during INPLACE COMPRESS?
      truncateEndOfTable - TRUNCATE END during INPLACE COMPRESS?
      updateStatistics - TRUE means we are here to update statistics
      updateStatisticsAll - TRUE means we are here to update statistics of all the indexes. False means we are here to update statistics of only one index.
      dropStatistics - TRUE means we are here to drop statistics
      dropStatisticsAll - TRUE means we are here to drop statistics of all the indexes. False means we are here to drop statistics of only one index.
      indexNameForStatistics - Will name the index whose statistics will be updated/dropped. This param is looked at only if updateStatisticsAll/dropStatisticsAll is set to false and updateStatistics/dropStatistics is set to true. .
    • getCreateConstraintConstantAction

      public CreateConstraintConstantAction getCreateConstraintConstantAction(String constraintName, int constraintType, boolean[] constraintCharacteristics, boolean forCreateTable, String tableName, UUID tableId, String schemaName, String[] columnNames, IndexConstantAction indexAction, String constraintText, ConstraintInfo otherConstraint, ProviderInfo[] providerInfo)
      Make a ConstantAction for a constraint.
      Parameters:
      constraintName - Constraint name.
      constraintType - Constraint type.
      constraintCharacteristics - Constraint characteristics, see ConstraintDefinitionNode.characteristics
      forCreateTable - True if for a CREATE TABLE
      tableName - Table name.
      tableId - UUID of table.
      schemaName - Schema that table lives in.
      columnNames - String[] for column names
      indexAction - IndexConstantAction for constraint (if necessary)
      constraintText - Text for check constraint
      otherConstraint - The referenced constraint, if a foreign key constraint
      providerInfo - Information on all the Providers
    • getCreateIndexConstantAction

      public IndexConstantAction getCreateIndexConstantAction(boolean forCreateTable, boolean unique, boolean uniqueWithDuplicateNulls, boolean hasDeferrableChecking, boolean initiallyDeferred, int constraintType, String indexType, String schemaName, String indexName, String tableName, UUID tableId, String[] columnNames, boolean[] isAscending, boolean isConstraint, UUID conglomerateUUID, Properties properties)
      Make the ConstantAction for a CREATE INDEX statement.
      Parameters:
      forCreateTable - Executed as part of a CREATE TABLE
      unique - True means it will be a unique index
      uniqueWithDuplicateNulls - True means index check and disallow any duplicate key if key has no column with a null value. If any column in the key has a null value, no checking is done and insert will always succeed.
      hasDeferrableChecking - True if the index is used to back a deferrable constraint
      initiallyDeferred - True means the deferrable constraint has deferred mode initially.
      constraintType - The constraint type
      indexType - The type of index (BTREE, for example)
      schemaName - the schema that table (and index) lives in.
      indexName - Name of the index
      tableName - Name of table the index will be on
      tableId - UUID of table.
      columnNames - Names of the columns in the index, in order
      isAscending - Array of booleans telling asc/desc on each column
      isConstraint - TRUE if index is backing up a constraint, else FALSE
      conglomerateUUID - ID of conglomerate
      properties - The optional properties list associated with the index.
    • getCreateAliasConstantAction

      public ConstantAction getCreateAliasConstantAction(String aliasName, String schemaName, String javaClassName, AliasInfo aliasInfo, char aliasType)
      Make the ConstantAction for a CREATE ALIAS statement.
      Parameters:
      aliasName - Name of alias.
      schemaName - Alias's schema.
      javaClassName - Name of java class.
      aliasType - The alias type
    • getCreateSchemaConstantAction

      public ConstantAction getCreateSchemaConstantAction(String schemaName, String aid)
      Make the ConstantAction for a CREATE SCHEMA statement.
      Parameters:
      schemaName - Name of table.
      aid - Authorizaton id
    • getCreateRoleConstantAction

      public ConstantAction getCreateRoleConstantAction(String roleName)
      Make the ConstantAction for a CREATE ROLE statement.
      Parameters:
      roleName - Name of role.
    • getSetRoleConstantAction

      public ConstantAction getSetRoleConstantAction(String roleName, int type)
      Make the ConstantAction for a SET ROLE statement.
      Parameters:
      roleName - Name of role
      type - Literal (== 0) or ? (== StatementType.SET_ROLE_DYNAMIC)
    • getCreateSequenceConstantAction

      public ConstantAction getCreateSequenceConstantAction(TableName sequenceName, DataTypeDescriptor dataType, long initialValue, long stepValue, long maxValue, long minValue, boolean cycle)
      Make the ConstantAction for a CREATE SEQUENCE statement.
      Parameters:
      sequenceName - Name of sequence.
      dataType -
      initialValue -
      stepValue -
      maxValue -
      minValue -
      cycle -
    • getCreateTableConstantAction

      public ConstantAction getCreateTableConstantAction(String schemaName, String tableName, int tableType, ColumnInfo[] columnInfo, CreateConstraintConstantAction[] constraintActions, Properties properties, char lockGranularity, boolean onCommitDeleteRows, boolean onRollbackDeleteRows)
      Make the ConstantAction for a CREATE TABLE statement.
      Parameters:
      schemaName - name for the schema that table lives in.
      tableName - Name of table.
      tableType - Type of table (e.g., BASE, global temporary table).
      columnInfo - Information on all the columns in the table. (REMIND tableDescriptor ignored)
      constraintActions - CreateConstraintConstantAction[] for constraints
      properties - Optional table properties
      lockGranularity - The lock granularity.
      onCommitDeleteRows - If true, on commit delete rows else on commit preserve rows of temporary table.
      onRollbackDeleteRows - If true, on rollback, delete rows from temp tables which were logically modified. true is the only supported value
    • getSavepointConstantAction

      public ConstantAction getSavepointConstantAction(String savepointName, int statementType)
      Make the ConstantAction for a savepoint statement (ROLLBACK savepoint, RELASE savepoint and SAVEPOINT).
      Parameters:
      savepointName - name for the savepoint.
      statementType - Type of savepoint statement ie rollback, release or set savepoint
    • getCreateViewConstantAction

      public ConstantAction getCreateViewConstantAction(String schemaName, String tableName, int tableType, String viewText, int checkOption, ColumnInfo[] columnInfo, ProviderInfo[] providerInfo, UUID compSchemaId)
      Make the ConstantAction for a CREATE VIEW statement.
      Parameters:
      schemaName - Name of the schema that table lives in.
      tableName - Name of table.
      tableType - Type of table (in this case TableDescriptor.VIEW_TYPE).
      viewText - Text of query expression for view definition
      checkOption - Check option type
      columnInfo - Information on all the columns in the table.
      providerInfo - Information on all the Providers
      compSchemaId - ID of schema in which the view is to be bound when accessed in the future. (REMIND tableDescriptor ignored)
    • getDeleteConstantAction

      public ConstantAction getDeleteConstantAction(long conglomId, int tableType, StaticCompiledOpenConglomInfo heapSCOCI, IndexRowGenerator[] irgs, long[] indexCIDS, StaticCompiledOpenConglomInfo[] indexSCOCIs, boolean deferred, boolean tableIsPublished, UUID tableID, int lockMode, Object deleteToken, Object keySignature, int[] keyPositions, long keyConglomId, String schemaName, String tableName, ResultDescription resultDescription, FKInfo[] fkInfo, TriggerInfo triggerInfo, FormatableBitSet baseRowReadList, int[] baseRowReadMap, int[] streamStorableHeapColIds, int numColumns, UUID dependencyId, boolean singleRowSource, ConstantAction[] dependentConstantActions, boolean underMerge) throws StandardException
      Make the ConstantAction for a Replicated DELETE statement.
      Parameters:
      conglomId - Conglomerate ID.
      tableType - type of this table
      heapSCOCI - StaticCompiledOpenConglomInfo for heap.
      irgs - Index descriptors
      indexCIDS - Conglomerate IDs of indices
      indexSCOCIs - StaticCompiledOpenConglomInfos for indexes.
      deferred - True means deferred delete
      tableIsPublished - true if table is published
      tableID - table id
      lockMode - The lock mode to use (row or table, see TransactionController)
      keySignature - signature for the key(null for source)
      keyPositions - positions of primary key columns in base row
      keyConglomId - conglomerate id for the key (-1 for the souce)
      schemaName - schemaName(null for source)
      tableName - tableName(null for source)
      resultDescription - A description of the columns in the row to be deleted. Only set in replication or during cascade Delete.
      fkInfo - Array of structures containing foreign key info, if any (may be null)
      triggerInfo - Array of structures containing trigger info, if any (may be null)
      baseRowReadList - Map of columns read in. 1 based.
      baseRowReadMap - BaseRowReadMap[heapColId]->ReadRowColumnId.
      streamStorableHeapColIds - Null for non rep. (0 based)
      numColumns - Number of columns to read
      dependencyId - UUID for dependency system
      singleRowSource - Whether or not source is a single row source
      underMerge - True if this is an action of a MERGE statement.
      Throws:
      StandardException - Thrown on failure
    • getDropConstraintConstantAction

      public ConstraintConstantAction getDropConstraintConstantAction(String constraintName, String constraintSchemaName, String tableName, UUID tableId, String tableSchemaName, IndexConstantAction indexAction, int behavior, int verifyType)
      Make ConstantAction to drop a constraint.
      Parameters:
      constraintName - Constraint name.
      constraintSchemaName - Constraint Schema Name
      tableName - Table name.
      tableId - UUID of table.
      tableSchemaName - the schema that table lives in.
      indexAction - IndexConstantAction for constraint (if necessary)
      behavior - The drop behavior (e.g. StatementType.RESTRICT)
      verifyType - Verify that the constraint is of this type.
    • getAlterConstraintConstantAction

      public ConstraintConstantAction getAlterConstraintConstantAction(String constraintName, String constraintSchemaName, boolean[] characteristics, String tableName, UUID tableId, String tableSchemaName, IndexConstantAction indexAction)
      Make ConstantAction to drop a constraint.
      Parameters:
      constraintName - Constraint name.
      constraintSchemaName - Constraint Schema Name
      characteristics - The presumably altered characteristics
      tableName - Table name.
      tableId - UUID of table.
      tableSchemaName - The schema that table lives in.
      indexAction - IndexConstantAction for constraint (if necessary)
    • getDropIndexConstantAction

      public IndexConstantAction getDropIndexConstantAction(String fullIndexName, String indexName, String tableName, String schemaName, UUID tableId, long tableConglomerateId)
      Make the ConstantAction for a DROP INDEX statement.
      Parameters:
      fullIndexName - Fully qualified index name
      indexName - Index name.
      tableName - The table name
      schemaName - Schema that index lives in.
      tableId - UUID for table
      tableConglomerateId - heap conglomerate ID for table
    • getDropAliasConstantAction

      public ConstantAction getDropAliasConstantAction(SchemaDescriptor sd, String aliasName, char aliasType)
      Make the ConstantAction for a DROP ALIAS statement.
      Parameters:
      aliasName - Alias name.
      aliasType - Alias type.
    • getDropRoleConstantAction

      public ConstantAction getDropRoleConstantAction(String roleName)
      Make the ConstantAction for a DROP ROLE statement.
      Parameters:
      roleName - role name to be dropped
    • getDropSequenceConstantAction

      public ConstantAction getDropSequenceConstantAction(SchemaDescriptor sd, String seqName)
      Make the ConstantAction for a DROP SEQUENCE statement.
      Parameters:
      sd - the schema the sequence object belongs to
      seqName - name of sequence to be dropped
    • getDropSchemaConstantAction

      public ConstantAction getDropSchemaConstantAction(String schemaName)
      Make the ConstantAction for a DROP SCHEMA statement.
      Parameters:
      schemaName - Table name.
    • getDropTableConstantAction

      public ConstantAction getDropTableConstantAction(String fullTableName, String tableName, SchemaDescriptor sd, long conglomerateNumber, UUID tableId, int behavior)
      Make the ConstantAction for a DROP TABLE statement.
      Parameters:
      fullTableName - Fully qualified table name
      tableName - Table name.
      sd - Schema that table lives in.
      conglomerateNumber - Conglomerate number for heap
      tableId - UUID for table
      behavior - drop behavior, CASCADE, RESTRICT or DEFAULT
    • getDropViewConstantAction

      public ConstantAction getDropViewConstantAction(String fullTableName, String tableName, SchemaDescriptor sd)
      Make the ConstantAction for a DROP VIEW statement.
      Parameters:
      fullTableName - Fully qualified table name
      tableName - Table name.
      sd - Schema that view lives in.
    • getRenameConstantAction

      public ConstantAction getRenameConstantAction(String fullTableName, String tableName, String oldObjectName, String newObjectName, SchemaDescriptor sd, UUID tableId, boolean usedAlterTable, int renamingWhat)
      Make the ConstantAction for a RENAME TABLE/COLUMN/INDEX statement.
      Parameters:
      fullTableName - Fully qualified table name
      tableName - Table name.
      oldObjectName - Old object name
      newObjectName - New object name.
      sd - Schema that table lives in.
      tableId - UUID for table
      usedAlterTable - True if used Alter Table command, false if used Rename
      renamingWhat - Value indicates if Rename Column/Index.
    • getInsertConstantAction

      public ConstantAction getInsertConstantAction(TableDescriptor tableDescriptor, long conglomId, StaticCompiledOpenConglomInfo heapSCOCI, IndexRowGenerator[] irgs, long[] indexCIDS, StaticCompiledOpenConglomInfo[] indexSCOCIs, String[] indexNames, boolean deferred, boolean tableIsPublished, boolean hasDeferrableChecks, UUID tableID, int lockMode, Object insertToken, Object rowSignature, Properties targetProperties, FKInfo[] fkInfo, TriggerInfo triggerInfo, int[] streamStorableHeapColIds, boolean[] indexedCols, UUID dependencyId, Object[] stageControl, Object[] ddlList, boolean singleRowSource, RowLocation[] autoincRowLocation, boolean underMerge, String identitySequenceUUIDString) throws StandardException
      Make the ConstantAction for a INSERT statement.
      Parameters:
      conglomId - Conglomerate ID.
      heapSCOCI - StaticCompiledOpenConglomInfo for target heap.
      irgs - Index descriptors
      indexCIDS - Conglomerate IDs of indices
      indexSCOCIs - StaticCompiledOpenConglomInfos for indexes.
      indexNames - Names of indices on this table for error reporting.
      deferred - True means deferred insert
      tableIsPublished - true if table is published, false otherwise
      hasDeferrableChecks - The target table has deferrable CHECK constraints
      tableID - table id
      targetProperties - Properties on the target table
      fkInfo - Array of structures containing foreign key info, if any (may be null)
      triggerInfo - Array of structures containing trigger info,
      streamStorableHeapColIds - Null for non rep. (0 based) if any (may be null)
      indexedCols - boolean[] of which (0-based) columns are indexed.
      dependencyId - UUID for dependency system
      stageControl - Stage Control Tokens
      ddlList - List of DDL to log. This is for BULK INSERT into a published table at the Source.
      singleRowSource - Whether or not source is a single row source
      autoincRowLocation - array of row locations into syscolumns for autoincrement columns
      underMerge - True if this is an INSERT action of a MERGE statement.
      identitySequenceUUIDString - For 10.11 and higher, the handle on the sequence for the identity column
      Throws:
      StandardException - Thrown on failure
    • getUpdatableVTIConstantAction

      public ConstantAction getUpdatableVTIConstantAction(int statementType, boolean deferred) throws StandardException
      Make the ConstantAction for an updatable VTI statement.
      Parameters:
      statementType - Statement type, cf. DeferModification.INSERT_STATEMENT etc.
      deferred - Deferred processing mode?
      Throws:
      StandardException - Thrown on failure
    • getUpdatableVTIConstantAction

      public ConstantAction getUpdatableVTIConstantAction(int statementType, boolean deferred, int[] changedColumnIds) throws StandardException
      Make the ConstantAction for an updatable VTI statement.
      Parameters:
      statementType - Statement type, cf. DeferModification.INSERT_STATEMENT etc.
      deferred - Deferred processing mode?
      changedColumnIds - Array of ids of changed columns
      Throws:
      StandardException - Thrown on failure
    • getLockTableConstantAction

      public ConstantAction getLockTableConstantAction(String fullTableName, long conglomerateNumber, boolean exclusiveMode)
      Make the ConstantAction for a LOCK TABLE statement.
      Parameters:
      fullTableName - Full name of the table.
      conglomerateNumber - Conglomerate number for the heap
      exclusiveMode - Whether or not to get an exclusive lock.
    • getSetSchemaConstantAction

      public ConstantAction getSetSchemaConstantAction(String schemaName, int type)
      Make the ConstantAction for a SET SCHEMA statement.
      Parameters:
      schemaName - Name of schema.
      type - Literal, USER or ?
    • getSetTransactionIsolationConstantAction

      public ConstantAction getSetTransactionIsolationConstantAction(int isolationLevel)
      Make the ConstantAction for a SET TRANSACTION ISOLATION statement.
      Parameters:
      isolationLevel - The new isolation level.
    • getUpdateConstantAction

      public UpdateConstantAction getUpdateConstantAction(TableDescriptor targetTableDesc, StaticCompiledOpenConglomInfo heapSCOCI, IndexRowGenerator[] irgs, long[] indexCIDS, StaticCompiledOpenConglomInfo[] indexSCOCIs, String[] indexNames, boolean deferred, UUID targetUUID, int lockMode, boolean tableIsPublished, int[] changedColumnIds, int[] keyPositions, Object updateToken, FKInfo[] fkInfo, TriggerInfo triggerInfo, FormatableBitSet baseRowReadList, int[] baseRowReadMap, int[] streamStorableHeapColIds, int numColumns, boolean positionedUpdate, boolean singleRowSource, RowLocation[] autoincRowLocation, boolean underMerge, String identitySequenceUUIDString) throws StandardException
      Make the ConstantAction for an UPDATE statement.
      Parameters:
      targetTableDesc - Descriptor for the updated table
      heapSCOCI - StaticCompiledOpenConglomInfo for heap.
      irgs - Index descriptors
      indexCIDS - Conglomerate IDs of indices
      indexSCOCIs - StaticCompiledOpenConglomInfos for indexes.
      indexNames -
      deferred - True means deferred update
      targetUUID - UUID of target table
      lockMode - The lock mode to use (row or table, see TransactionController)
      tableIsPublished - true if table is published, false otherwise
      changedColumnIds - Array of ids of changes columns
      keyPositions - positions of primary key columns in base row
      updateToken -
      fkInfo - Array of structures containing foreign key info, if any (may be null)
      triggerInfo - Array of structures containing trigger info,
      baseRowReadList - Map of columns read in. 1 based.
      baseRowReadMap - map of columns to be selected from the base row (partial row). 1 based.
      streamStorableHeapColIds - Null for non rep. (0 based)
      numColumns - The number of columns being read.
      positionedUpdate - is this a positioned update
      singleRowSource - Whether or not source is a single row source
      autoincRowLocation - array of row locations into syscolumns for autoincrement columns
      underMerge - True if this is an action of a MERGE statement.
      identitySequenceUUIDString - For 10.11 and higher, the handle on the sequence for the identity column
      Returns:
      The constant action constructed
      Throws:
      StandardException - Thrown on failure
    • getAuthorizer

      protected static Authorizer getAuthorizer()
    • getCreateTriggerConstantAction

      public ConstantAction getCreateTriggerConstantAction(String triggerSchemaName, String triggerName, int eventMask, boolean isBefore, boolean isRow, boolean isEnabled, TableDescriptor triggerTable, UUID whenSPSId, String whenText, UUID actionSPSId, String actionText, UUID spsCompSchemaId, int[] referencedCols, int[] referencedColsInTriggerAction, String originalWhenText, String originalActionText, boolean referencingOld, boolean referencingNew, String oldReferencingName, String newReferencingName, ProviderInfo[] providerInfo)
      Make the ConstantAction for a CREATE TRIGGER statement.
      Parameters:
      triggerSchemaName - Name of the schema that trigger lives in.
      triggerName - Name of trigger
      eventMask - TriggerDescriptor.TRIGGER_EVENT_XXXX
      isBefore - is this a before (as opposed to after) trigger
      isRow - is this a row trigger or statement trigger
      isEnabled - is this trigger enabled or disabled
      triggerTable - the table upon which this trigger is defined
      whenSPSId - the sps id for the when clause (may be null)
      whenText - the text of the when clause (may be null)
      actionSPSId - the spsid for the trigger action (may be null)
      actionText - the text of the trigger action (may be null)
      spsCompSchemaId - the compilation schema for the action and when spses. If null, will be set to the current default schema
      referencedCols - what columns does this trigger reference (may be null)
      referencedColsInTriggerAction - what columns does the trigger action reference through old/new transition variables (may be null)
      originalWhenText - The original user text of the WHEN clause (may be null)
      originalActionText - The original user text of the trigger action
      referencingOld - whether or not OLD appears in REFERENCING clause
      referencingNew - whether or not NEW appears in REFERENCING clause
      oldReferencingName - old referencing table name, if any, that appears in REFERCING clause
      newReferencingName - new referencing table name, if any, that appears in REFERCING clause
      providerInfo - array of providers that the trigger depends on
    • getDropTriggerConstantAction

      public ConstantAction getDropTriggerConstantAction(SchemaDescriptor sd, String triggerName, UUID tableId)
      Make the ConstantAction for a DROP TRIGGER statement.
      Parameters:
      sd - Schema that stored prepared statement lives in.
      triggerName - Name of the Trigger
      tableId - The table this trigger is defined upon
    • getDropStatisticsConstantAction

      public ConstantAction getDropStatisticsConstantAction(SchemaDescriptor sd, String fullTableName, String objectName, boolean forTable)
      Make the constant action for Drop Statistics statement.
      Parameters:
      sd - Schema Descriptor of the schema in which the object resides.
      fullTableName - full name of the object for which statistics are being dropped.
      objectName - object name for which statistics are being dropped.
      forTable - is it an index or table whose statistics aer being consigned to the garbage heap?
    • getGrantConstantAction

      public ConstantAction getGrantConstantAction(PrivilegeInfo privileges, List grantees)
      Make the constant action for a Grant statement
      Parameters:
      privileges - The list of privileges to be granted
      grantees - The list of grantees
    • getGrantRoleConstantAction

      public ConstantAction getGrantRoleConstantAction(List roleNames, List grantees)
      Make the ConstantAction for a GRANT role statement.
      Parameters:
      roleNames - list of roles to be granted
      grantees - list of authentication ids (user or roles) to which roles(s) are to be granted
    • getRevokeConstantAction

      public ConstantAction getRevokeConstantAction(PrivilegeInfo privileges, List grantees)
      Make the constant action for a Revoke statement
      Parameters:
      privileges - The list of privileges to be revokeed
      grantees - The list of grantees
    • getRevokeRoleConstantAction

      public ConstantAction getRevokeRoleConstantAction(List roleNames, List grantees)
      Make the ConstantAction for a REVOKE role statement.
      Parameters:
      roleNames - list of roles to be revoked
      grantees - list of authentication ids (user or roles) for whom roles are to be revoked
    • getMatchingClauseConstantAction

      public ConstantAction getMatchingClauseConstantAction(int clauseType, String matchRefinementName, ResultDescription thenColumnSignature, String rowMakingMethodName, String resultSetFieldName, String actionMethodName, ConstantAction thenAction)
      Make the ConstantAction for a WHEN [ NOT ] MATCHED clause.
    • getMergeConstantAction

      public MergeConstantAction getMergeConstantAction(ConstantAction[] matchingClauses)
      Make the ConstantAction for a MERGE statement.
    • getContext

      private static Context getContext(String contextID)
      Privileged lookup of a Context. Must be private so that user code can't call this entry point.