1. Packages
  2. Oracle Cloud Infrastructure
  3. API Docs
  4. Mysql
  5. MysqlConfiguration
Oracle Cloud Infrastructure v2.28.0 published on Thursday, Mar 27, 2025 by Pulumi

oci.Mysql.MysqlConfiguration

Explore with Pulumi AI

This resource provides the Mysql Configuration resource in Oracle Cloud Infrastructure MySQL Database service.

Creates a new Configuration.

Example Usage

import * as pulumi from "@pulumi/pulumi";
import * as oci from "@pulumi/oci";

const testMysqlConfiguration = new oci.mysql.MysqlConfiguration("test_mysql_configuration", {
    compartmentId: compartmentId,
    shapeName: testShape.name,
    definedTags: {
        "foo-namespace.bar-key": "value",
    },
    description: mysqlConfigurationDescription,
    displayName: mysqlConfigurationDisplayName,
    freeformTags: {
        "bar-key": "value",
    },
    initVariables: {
        lowerCaseTableNames: mysqlConfigurationInitVariablesLowerCaseTableNames,
    },
    parentConfigurationId: testConfiguration.id,
    variables: {
        autoIncrementIncrement: mysqlConfigurationVariablesAutoIncrementIncrement,
        autoIncrementOffset: mysqlConfigurationVariablesAutoIncrementOffset,
        autocommit: mysqlConfigurationVariablesAutocommit,
        bigTables: mysqlConfigurationVariablesBigTables,
        binlogExpireLogsSeconds: mysqlConfigurationVariablesBinlogExpireLogsSeconds,
        binlogGroupCommitSyncDelay: mysqlConfigurationVariablesBinlogGroupCommitSyncDelay,
        binlogGroupCommitSyncNoDelayCount: mysqlConfigurationVariablesBinlogGroupCommitSyncNoDelayCount,
        binlogRowMetadata: mysqlConfigurationVariablesBinlogRowMetadata,
        binlogRowValueOptions: mysqlConfigurationVariablesBinlogRowValueOptions,
        binlogTransactionCompression: mysqlConfigurationVariablesBinlogTransactionCompression,
        blockEncryptionMode: mysqlConfigurationVariablesBlockEncryptionMode,
        characterSetServer: mysqlConfigurationVariablesCharacterSetServer,
        collationServer: mysqlConfigurationVariablesCollationServer,
        completionType: mysqlConfigurationVariablesCompletionType,
        connectTimeout: mysqlConfigurationVariablesConnectTimeout,
        connectionMemoryChunkSize: mysqlConfigurationVariablesConnectionMemoryChunkSize,
        connectionMemoryLimit: mysqlConfigurationVariablesConnectionMemoryLimit,
        cteMaxRecursionDepth: mysqlConfigurationVariablesCteMaxRecursionDepth,
        defaultAuthenticationPlugin: mysqlConfigurationVariablesDefaultAuthenticationPlugin,
        explainFormat: mysqlConfigurationVariablesExplainFormat,
        explicitDefaultsForTimestamp: mysqlConfigurationVariablesExplicitDefaultsForTimestamp,
        foreignKeyChecks: mysqlConfigurationVariablesForeignKeyChecks,
        generatedRandomPasswordLength: mysqlConfigurationVariablesGeneratedRandomPasswordLength,
        globalConnectionMemoryLimit: mysqlConfigurationVariablesGlobalConnectionMemoryLimit,
        globalConnectionMemoryTracking: mysqlConfigurationVariablesGlobalConnectionMemoryTracking,
        groupConcatMaxLen: mysqlConfigurationVariablesGroupConcatMaxLen,
        groupReplicationConsistency: mysqlConfigurationVariablesGroupReplicationConsistency,
        informationSchemaStatsExpiry: mysqlConfigurationVariablesInformationSchemaStatsExpiry,
        innodbAdaptiveHashIndex: mysqlConfigurationVariablesInnodbAdaptiveHashIndex,
        innodbAutoincLockMode: mysqlConfigurationVariablesInnodbAutoincLockMode,
        innodbBufferPoolDumpPct: mysqlConfigurationVariablesInnodbBufferPoolDumpPct,
        innodbBufferPoolInstances: mysqlConfigurationVariablesInnodbBufferPoolInstances,
        innodbBufferPoolSize: mysqlConfigurationVariablesInnodbBufferPoolSize,
        innodbChangeBuffering: mysqlConfigurationVariablesInnodbChangeBuffering,
        innodbDdlBufferSize: mysqlConfigurationVariablesInnodbDdlBufferSize,
        innodbDdlThreads: mysqlConfigurationVariablesInnodbDdlThreads,
        innodbFtEnableStopword: mysqlConfigurationVariablesInnodbFtEnableStopword,
        innodbFtMaxTokenSize: mysqlConfigurationVariablesInnodbFtMaxTokenSize,
        innodbFtMinTokenSize: mysqlConfigurationVariablesInnodbFtMinTokenSize,
        innodbFtNumWordOptimize: mysqlConfigurationVariablesInnodbFtNumWordOptimize,
        innodbFtResultCacheLimit: mysqlConfigurationVariablesInnodbFtResultCacheLimit,
        innodbFtServerStopwordTable: mysqlConfigurationVariablesInnodbFtServerStopwordTable,
        innodbLockWaitTimeout: mysqlConfigurationVariablesInnodbLockWaitTimeout,
        innodbLogWriterThreads: mysqlConfigurationVariablesInnodbLogWriterThreads,
        innodbMaxPurgeLag: mysqlConfigurationVariablesInnodbMaxPurgeLag,
        innodbMaxPurgeLagDelay: mysqlConfigurationVariablesInnodbMaxPurgeLagDelay,
        innodbNumaInterleave: mysqlConfigurationVariablesInnodbNumaInterleave,
        innodbOnlineAlterLogMaxSize: mysqlConfigurationVariablesInnodbOnlineAlterLogMaxSize,
        innodbRedoLogCapacity: mysqlConfigurationVariablesInnodbRedoLogCapacity,
        innodbRollbackOnTimeout: mysqlConfigurationVariablesInnodbRollbackOnTimeout,
        innodbSortBufferSize: mysqlConfigurationVariablesInnodbSortBufferSize,
        innodbStatsPersistentSamplePages: mysqlConfigurationVariablesInnodbStatsPersistentSamplePages,
        innodbStatsTransientSamplePages: mysqlConfigurationVariablesInnodbStatsTransientSamplePages,
        innodbStrictMode: mysqlConfigurationVariablesInnodbStrictMode,
        innodbUndoLogTruncate: mysqlConfigurationVariablesInnodbUndoLogTruncate,
        interactiveTimeout: mysqlConfigurationVariablesInteractiveTimeout,
        joinBufferSize: mysqlConfigurationVariablesJoinBufferSize,
        localInfile: mysqlConfigurationVariablesLocalInfile,
        longQueryTime: mysqlConfigurationVariablesLongQueryTime,
        mandatoryRoles: mysqlConfigurationVariablesMandatoryRoles,
        maxAllowedPacket: mysqlConfigurationVariablesMaxAllowedPacket,
        maxBinlogCacheSize: mysqlConfigurationVariablesMaxBinlogCacheSize,
        maxConnectErrors: mysqlConfigurationVariablesMaxConnectErrors,
        maxConnections: mysqlConfigurationVariablesMaxConnections,
        maxExecutionTime: mysqlConfigurationVariablesMaxExecutionTime,
        maxHeapTableSize: mysqlConfigurationVariablesMaxHeapTableSize,
        maxPreparedStmtCount: mysqlConfigurationVariablesMaxPreparedStmtCount,
        maxSeeksForKey: mysqlConfigurationVariablesMaxSeeksForKey,
        maxUserConnections: mysqlConfigurationVariablesMaxUserConnections,
        mysqlFirewallMode: mysqlConfigurationVariablesMysqlFirewallMode,
        mysqlZstdDefaultCompressionLevel: mysqlConfigurationVariablesMysqlZstdDefaultCompressionLevel,
        mysqlxConnectTimeout: mysqlConfigurationVariablesMysqlxConnectTimeout,
        mysqlxDeflateDefaultCompressionLevel: mysqlConfigurationVariablesMysqlxDeflateDefaultCompressionLevel,
        mysqlxDeflateMaxClientCompressionLevel: mysqlConfigurationVariablesMysqlxDeflateMaxClientCompressionLevel,
        mysqlxDocumentIdUniquePrefix: mysqlConfigurationVariablesMysqlxDocumentIdUniquePrefix,
        mysqlxEnableHelloNotice: mysqlConfigurationVariablesMysqlxEnableHelloNotice,
        mysqlxIdleWorkerThreadTimeout: mysqlConfigurationVariablesMysqlxIdleWorkerThreadTimeout,
        mysqlxInteractiveTimeout: mysqlConfigurationVariablesMysqlxInteractiveTimeout,
        mysqlxLz4defaultCompressionLevel: mysqlConfigurationVariablesMysqlxLz4defaultCompressionLevel,
        mysqlxLz4maxClientCompressionLevel: mysqlConfigurationVariablesMysqlxLz4maxClientCompressionLevel,
        mysqlxMaxAllowedPacket: mysqlConfigurationVariablesMysqlxMaxAllowedPacket,
        mysqlxMinWorkerThreads: mysqlConfigurationVariablesMysqlxMinWorkerThreads,
        mysqlxReadTimeout: mysqlConfigurationVariablesMysqlxReadTimeout,
        mysqlxWaitTimeout: mysqlConfigurationVariablesMysqlxWaitTimeout,
        mysqlxWriteTimeout: mysqlConfigurationVariablesMysqlxWriteTimeout,
        mysqlxZstdDefaultCompressionLevel: mysqlConfigurationVariablesMysqlxZstdDefaultCompressionLevel,
        mysqlxZstdMaxClientCompressionLevel: mysqlConfigurationVariablesMysqlxZstdMaxClientCompressionLevel,
        netReadTimeout: mysqlConfigurationVariablesNetReadTimeout,
        netWriteTimeout: mysqlConfigurationVariablesNetWriteTimeout,
        optimizerSwitch: mysqlConfigurationVariablesOptimizerSwitch,
        parserMaxMemSize: mysqlConfigurationVariablesParserMaxMemSize,
        queryAllocBlockSize: mysqlConfigurationVariablesQueryAllocBlockSize,
        queryPreallocSize: mysqlConfigurationVariablesQueryPreallocSize,
        rangeOptimizerMaxMemSize: mysqlConfigurationVariablesRangeOptimizerMaxMemSize,
        regexpTimeLimit: mysqlConfigurationVariablesRegexpTimeLimit,
        relayLogSpaceLimit: mysqlConfigurationVariablesRelayLogSpaceLimit,
        replicaNetTimeout: mysqlConfigurationVariablesReplicaNetTimeout,
        replicaParallelWorkers: mysqlConfigurationVariablesReplicaParallelWorkers,
        replicaTypeConversions: mysqlConfigurationVariablesReplicaTypeConversions,
        requireSecureTransport: mysqlConfigurationVariablesRequireSecureTransport,
        skipNameResolve: mysqlConfigurationVariablesSkipNameResolve,
        sortBufferSize: mysqlConfigurationVariablesSortBufferSize,
        sqlGenerateInvisiblePrimaryKey: mysqlConfigurationVariablesSqlGenerateInvisiblePrimaryKey,
        sqlMode: mysqlConfigurationVariablesSqlMode,
        sqlRequirePrimaryKey: mysqlConfigurationVariablesSqlRequirePrimaryKey,
        sqlWarnings: mysqlConfigurationVariablesSqlWarnings,
        tableDefinitionCache: mysqlConfigurationVariablesTableDefinitionCache,
        tableOpenCache: mysqlConfigurationVariablesTableOpenCache,
        temptableMaxRam: mysqlConfigurationVariablesTemptableMaxRam,
        threadPoolDedicatedListeners: mysqlConfigurationVariablesThreadPoolDedicatedListeners,
        threadPoolMaxTransactionsLimit: mysqlConfigurationVariablesThreadPoolMaxTransactionsLimit,
        threadPoolQueryThreadsPerGroup: mysqlConfigurationVariablesThreadPoolQueryThreadsPerGroup,
        threadPoolSize: mysqlConfigurationVariablesThreadPoolSize,
        threadPoolTransactionDelay: mysqlConfigurationVariablesThreadPoolTransactionDelay,
        timeZone: mysqlConfigurationVariablesTimeZone,
        tmpTableSize: mysqlConfigurationVariablesTmpTableSize,
        transactionIsolation: mysqlConfigurationVariablesTransactionIsolation,
        waitTimeout: mysqlConfigurationVariablesWaitTimeout,
    },
});
Copy
import pulumi
import pulumi_oci as oci

test_mysql_configuration = oci.mysql.MysqlConfiguration("test_mysql_configuration",
    compartment_id=compartment_id,
    shape_name=test_shape["name"],
    defined_tags={
        "foo-namespace.bar-key": "value",
    },
    description=mysql_configuration_description,
    display_name=mysql_configuration_display_name,
    freeform_tags={
        "bar-key": "value",
    },
    init_variables={
        "lower_case_table_names": mysql_configuration_init_variables_lower_case_table_names,
    },
    parent_configuration_id=test_configuration["id"],
    variables={
        "auto_increment_increment": mysql_configuration_variables_auto_increment_increment,
        "auto_increment_offset": mysql_configuration_variables_auto_increment_offset,
        "autocommit": mysql_configuration_variables_autocommit,
        "big_tables": mysql_configuration_variables_big_tables,
        "binlog_expire_logs_seconds": mysql_configuration_variables_binlog_expire_logs_seconds,
        "binlog_group_commit_sync_delay": mysql_configuration_variables_binlog_group_commit_sync_delay,
        "binlog_group_commit_sync_no_delay_count": mysql_configuration_variables_binlog_group_commit_sync_no_delay_count,
        "binlog_row_metadata": mysql_configuration_variables_binlog_row_metadata,
        "binlog_row_value_options": mysql_configuration_variables_binlog_row_value_options,
        "binlog_transaction_compression": mysql_configuration_variables_binlog_transaction_compression,
        "block_encryption_mode": mysql_configuration_variables_block_encryption_mode,
        "character_set_server": mysql_configuration_variables_character_set_server,
        "collation_server": mysql_configuration_variables_collation_server,
        "completion_type": mysql_configuration_variables_completion_type,
        "connect_timeout": mysql_configuration_variables_connect_timeout,
        "connection_memory_chunk_size": mysql_configuration_variables_connection_memory_chunk_size,
        "connection_memory_limit": mysql_configuration_variables_connection_memory_limit,
        "cte_max_recursion_depth": mysql_configuration_variables_cte_max_recursion_depth,
        "default_authentication_plugin": mysql_configuration_variables_default_authentication_plugin,
        "explain_format": mysql_configuration_variables_explain_format,
        "explicit_defaults_for_timestamp": mysql_configuration_variables_explicit_defaults_for_timestamp,
        "foreign_key_checks": mysql_configuration_variables_foreign_key_checks,
        "generated_random_password_length": mysql_configuration_variables_generated_random_password_length,
        "global_connection_memory_limit": mysql_configuration_variables_global_connection_memory_limit,
        "global_connection_memory_tracking": mysql_configuration_variables_global_connection_memory_tracking,
        "group_concat_max_len": mysql_configuration_variables_group_concat_max_len,
        "group_replication_consistency": mysql_configuration_variables_group_replication_consistency,
        "information_schema_stats_expiry": mysql_configuration_variables_information_schema_stats_expiry,
        "innodb_adaptive_hash_index": mysql_configuration_variables_innodb_adaptive_hash_index,
        "innodb_autoinc_lock_mode": mysql_configuration_variables_innodb_autoinc_lock_mode,
        "innodb_buffer_pool_dump_pct": mysql_configuration_variables_innodb_buffer_pool_dump_pct,
        "innodb_buffer_pool_instances": mysql_configuration_variables_innodb_buffer_pool_instances,
        "innodb_buffer_pool_size": mysql_configuration_variables_innodb_buffer_pool_size,
        "innodb_change_buffering": mysql_configuration_variables_innodb_change_buffering,
        "innodb_ddl_buffer_size": mysql_configuration_variables_innodb_ddl_buffer_size,
        "innodb_ddl_threads": mysql_configuration_variables_innodb_ddl_threads,
        "innodb_ft_enable_stopword": mysql_configuration_variables_innodb_ft_enable_stopword,
        "innodb_ft_max_token_size": mysql_configuration_variables_innodb_ft_max_token_size,
        "innodb_ft_min_token_size": mysql_configuration_variables_innodb_ft_min_token_size,
        "innodb_ft_num_word_optimize": mysql_configuration_variables_innodb_ft_num_word_optimize,
        "innodb_ft_result_cache_limit": mysql_configuration_variables_innodb_ft_result_cache_limit,
        "innodb_ft_server_stopword_table": mysql_configuration_variables_innodb_ft_server_stopword_table,
        "innodb_lock_wait_timeout": mysql_configuration_variables_innodb_lock_wait_timeout,
        "innodb_log_writer_threads": mysql_configuration_variables_innodb_log_writer_threads,
        "innodb_max_purge_lag": mysql_configuration_variables_innodb_max_purge_lag,
        "innodb_max_purge_lag_delay": mysql_configuration_variables_innodb_max_purge_lag_delay,
        "innodb_numa_interleave": mysql_configuration_variables_innodb_numa_interleave,
        "innodb_online_alter_log_max_size": mysql_configuration_variables_innodb_online_alter_log_max_size,
        "innodb_redo_log_capacity": mysql_configuration_variables_innodb_redo_log_capacity,
        "innodb_rollback_on_timeout": mysql_configuration_variables_innodb_rollback_on_timeout,
        "innodb_sort_buffer_size": mysql_configuration_variables_innodb_sort_buffer_size,
        "innodb_stats_persistent_sample_pages": mysql_configuration_variables_innodb_stats_persistent_sample_pages,
        "innodb_stats_transient_sample_pages": mysql_configuration_variables_innodb_stats_transient_sample_pages,
        "innodb_strict_mode": mysql_configuration_variables_innodb_strict_mode,
        "innodb_undo_log_truncate": mysql_configuration_variables_innodb_undo_log_truncate,
        "interactive_timeout": mysql_configuration_variables_interactive_timeout,
        "join_buffer_size": mysql_configuration_variables_join_buffer_size,
        "local_infile": mysql_configuration_variables_local_infile,
        "long_query_time": mysql_configuration_variables_long_query_time,
        "mandatory_roles": mysql_configuration_variables_mandatory_roles,
        "max_allowed_packet": mysql_configuration_variables_max_allowed_packet,
        "max_binlog_cache_size": mysql_configuration_variables_max_binlog_cache_size,
        "max_connect_errors": mysql_configuration_variables_max_connect_errors,
        "max_connections": mysql_configuration_variables_max_connections,
        "max_execution_time": mysql_configuration_variables_max_execution_time,
        "max_heap_table_size": mysql_configuration_variables_max_heap_table_size,
        "max_prepared_stmt_count": mysql_configuration_variables_max_prepared_stmt_count,
        "max_seeks_for_key": mysql_configuration_variables_max_seeks_for_key,
        "max_user_connections": mysql_configuration_variables_max_user_connections,
        "mysql_firewall_mode": mysql_configuration_variables_mysql_firewall_mode,
        "mysql_zstd_default_compression_level": mysql_configuration_variables_mysql_zstd_default_compression_level,
        "mysqlx_connect_timeout": mysql_configuration_variables_mysqlx_connect_timeout,
        "mysqlx_deflate_default_compression_level": mysql_configuration_variables_mysqlx_deflate_default_compression_level,
        "mysqlx_deflate_max_client_compression_level": mysql_configuration_variables_mysqlx_deflate_max_client_compression_level,
        "mysqlx_document_id_unique_prefix": mysql_configuration_variables_mysqlx_document_id_unique_prefix,
        "mysqlx_enable_hello_notice": mysql_configuration_variables_mysqlx_enable_hello_notice,
        "mysqlx_idle_worker_thread_timeout": mysql_configuration_variables_mysqlx_idle_worker_thread_timeout,
        "mysqlx_interactive_timeout": mysql_configuration_variables_mysqlx_interactive_timeout,
        "mysqlx_lz4default_compression_level": mysql_configuration_variables_mysqlx_lz4default_compression_level,
        "mysqlx_lz4max_client_compression_level": mysql_configuration_variables_mysqlx_lz4max_client_compression_level,
        "mysqlx_max_allowed_packet": mysql_configuration_variables_mysqlx_max_allowed_packet,
        "mysqlx_min_worker_threads": mysql_configuration_variables_mysqlx_min_worker_threads,
        "mysqlx_read_timeout": mysql_configuration_variables_mysqlx_read_timeout,
        "mysqlx_wait_timeout": mysql_configuration_variables_mysqlx_wait_timeout,
        "mysqlx_write_timeout": mysql_configuration_variables_mysqlx_write_timeout,
        "mysqlx_zstd_default_compression_level": mysql_configuration_variables_mysqlx_zstd_default_compression_level,
        "mysqlx_zstd_max_client_compression_level": mysql_configuration_variables_mysqlx_zstd_max_client_compression_level,
        "net_read_timeout": mysql_configuration_variables_net_read_timeout,
        "net_write_timeout": mysql_configuration_variables_net_write_timeout,
        "optimizer_switch": mysql_configuration_variables_optimizer_switch,
        "parser_max_mem_size": mysql_configuration_variables_parser_max_mem_size,
        "query_alloc_block_size": mysql_configuration_variables_query_alloc_block_size,
        "query_prealloc_size": mysql_configuration_variables_query_prealloc_size,
        "range_optimizer_max_mem_size": mysql_configuration_variables_range_optimizer_max_mem_size,
        "regexp_time_limit": mysql_configuration_variables_regexp_time_limit,
        "relay_log_space_limit": mysql_configuration_variables_relay_log_space_limit,
        "replica_net_timeout": mysql_configuration_variables_replica_net_timeout,
        "replica_parallel_workers": mysql_configuration_variables_replica_parallel_workers,
        "replica_type_conversions": mysql_configuration_variables_replica_type_conversions,
        "require_secure_transport": mysql_configuration_variables_require_secure_transport,
        "skip_name_resolve": mysql_configuration_variables_skip_name_resolve,
        "sort_buffer_size": mysql_configuration_variables_sort_buffer_size,
        "sql_generate_invisible_primary_key": mysql_configuration_variables_sql_generate_invisible_primary_key,
        "sql_mode": mysql_configuration_variables_sql_mode,
        "sql_require_primary_key": mysql_configuration_variables_sql_require_primary_key,
        "sql_warnings": mysql_configuration_variables_sql_warnings,
        "table_definition_cache": mysql_configuration_variables_table_definition_cache,
        "table_open_cache": mysql_configuration_variables_table_open_cache,
        "temptable_max_ram": mysql_configuration_variables_temptable_max_ram,
        "thread_pool_dedicated_listeners": mysql_configuration_variables_thread_pool_dedicated_listeners,
        "thread_pool_max_transactions_limit": mysql_configuration_variables_thread_pool_max_transactions_limit,
        "thread_pool_query_threads_per_group": mysql_configuration_variables_thread_pool_query_threads_per_group,
        "thread_pool_size": mysql_configuration_variables_thread_pool_size,
        "thread_pool_transaction_delay": mysql_configuration_variables_thread_pool_transaction_delay,
        "time_zone": mysql_configuration_variables_time_zone,
        "tmp_table_size": mysql_configuration_variables_tmp_table_size,
        "transaction_isolation": mysql_configuration_variables_transaction_isolation,
        "wait_timeout": mysql_configuration_variables_wait_timeout,
    })
Copy
package main

import (
	"github.com/pulumi/pulumi-oci/sdk/v2/go/oci/mysql"
	"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
)

func main() {
	pulumi.Run(func(ctx *pulumi.Context) error {
		_, err := mysql.NewMysqlConfiguration(ctx, "test_mysql_configuration", &mysql.MysqlConfigurationArgs{
			CompartmentId: pulumi.Any(compartmentId),
			ShapeName:     pulumi.Any(testShape.Name),
			DefinedTags: pulumi.StringMap{
				"foo-namespace.bar-key": pulumi.String("value"),
			},
			Description: pulumi.Any(mysqlConfigurationDescription),
			DisplayName: pulumi.Any(mysqlConfigurationDisplayName),
			FreeformTags: pulumi.StringMap{
				"bar-key": pulumi.String("value"),
			},
			InitVariables: &mysql.MysqlConfigurationInitVariablesArgs{
				LowerCaseTableNames: pulumi.Any(mysqlConfigurationInitVariablesLowerCaseTableNames),
			},
			ParentConfigurationId: pulumi.Any(testConfiguration.Id),
			Variables: &mysql.MysqlConfigurationVariablesArgs{
				AutoIncrementIncrement:                 pulumi.Any(mysqlConfigurationVariablesAutoIncrementIncrement),
				AutoIncrementOffset:                    pulumi.Any(mysqlConfigurationVariablesAutoIncrementOffset),
				Autocommit:                             pulumi.Any(mysqlConfigurationVariablesAutocommit),
				BigTables:                              pulumi.Any(mysqlConfigurationVariablesBigTables),
				BinlogExpireLogsSeconds:                pulumi.Any(mysqlConfigurationVariablesBinlogExpireLogsSeconds),
				BinlogGroupCommitSyncDelay:             pulumi.Any(mysqlConfigurationVariablesBinlogGroupCommitSyncDelay),
				BinlogGroupCommitSyncNoDelayCount:      pulumi.Any(mysqlConfigurationVariablesBinlogGroupCommitSyncNoDelayCount),
				BinlogRowMetadata:                      pulumi.Any(mysqlConfigurationVariablesBinlogRowMetadata),
				BinlogRowValueOptions:                  pulumi.Any(mysqlConfigurationVariablesBinlogRowValueOptions),
				BinlogTransactionCompression:           pulumi.Any(mysqlConfigurationVariablesBinlogTransactionCompression),
				BlockEncryptionMode:                    pulumi.Any(mysqlConfigurationVariablesBlockEncryptionMode),
				CharacterSetServer:                     pulumi.Any(mysqlConfigurationVariablesCharacterSetServer),
				CollationServer:                        pulumi.Any(mysqlConfigurationVariablesCollationServer),
				CompletionType:                         pulumi.Any(mysqlConfigurationVariablesCompletionType),
				ConnectTimeout:                         pulumi.Any(mysqlConfigurationVariablesConnectTimeout),
				ConnectionMemoryChunkSize:              pulumi.Any(mysqlConfigurationVariablesConnectionMemoryChunkSize),
				ConnectionMemoryLimit:                  pulumi.Any(mysqlConfigurationVariablesConnectionMemoryLimit),
				CteMaxRecursionDepth:                   pulumi.Any(mysqlConfigurationVariablesCteMaxRecursionDepth),
				DefaultAuthenticationPlugin:            pulumi.Any(mysqlConfigurationVariablesDefaultAuthenticationPlugin),
				ExplainFormat:                          pulumi.Any(mysqlConfigurationVariablesExplainFormat),
				ExplicitDefaultsForTimestamp:           pulumi.Any(mysqlConfigurationVariablesExplicitDefaultsForTimestamp),
				ForeignKeyChecks:                       pulumi.Any(mysqlConfigurationVariablesForeignKeyChecks),
				GeneratedRandomPasswordLength:          pulumi.Any(mysqlConfigurationVariablesGeneratedRandomPasswordLength),
				GlobalConnectionMemoryLimit:            pulumi.Any(mysqlConfigurationVariablesGlobalConnectionMemoryLimit),
				GlobalConnectionMemoryTracking:         pulumi.Any(mysqlConfigurationVariablesGlobalConnectionMemoryTracking),
				GroupConcatMaxLen:                      pulumi.Any(mysqlConfigurationVariablesGroupConcatMaxLen),
				GroupReplicationConsistency:            pulumi.Any(mysqlConfigurationVariablesGroupReplicationConsistency),
				InformationSchemaStatsExpiry:           pulumi.Any(mysqlConfigurationVariablesInformationSchemaStatsExpiry),
				InnodbAdaptiveHashIndex:                pulumi.Any(mysqlConfigurationVariablesInnodbAdaptiveHashIndex),
				InnodbAutoincLockMode:                  pulumi.Any(mysqlConfigurationVariablesInnodbAutoincLockMode),
				InnodbBufferPoolDumpPct:                pulumi.Any(mysqlConfigurationVariablesInnodbBufferPoolDumpPct),
				InnodbBufferPoolInstances:              pulumi.Any(mysqlConfigurationVariablesInnodbBufferPoolInstances),
				InnodbBufferPoolSize:                   pulumi.Any(mysqlConfigurationVariablesInnodbBufferPoolSize),
				InnodbChangeBuffering:                  pulumi.Any(mysqlConfigurationVariablesInnodbChangeBuffering),
				InnodbDdlBufferSize:                    pulumi.Any(mysqlConfigurationVariablesInnodbDdlBufferSize),
				InnodbDdlThreads:                       pulumi.Any(mysqlConfigurationVariablesInnodbDdlThreads),
				InnodbFtEnableStopword:                 pulumi.Any(mysqlConfigurationVariablesInnodbFtEnableStopword),
				InnodbFtMaxTokenSize:                   pulumi.Any(mysqlConfigurationVariablesInnodbFtMaxTokenSize),
				InnodbFtMinTokenSize:                   pulumi.Any(mysqlConfigurationVariablesInnodbFtMinTokenSize),
				InnodbFtNumWordOptimize:                pulumi.Any(mysqlConfigurationVariablesInnodbFtNumWordOptimize),
				InnodbFtResultCacheLimit:               pulumi.Any(mysqlConfigurationVariablesInnodbFtResultCacheLimit),
				InnodbFtServerStopwordTable:            pulumi.Any(mysqlConfigurationVariablesInnodbFtServerStopwordTable),
				InnodbLockWaitTimeout:                  pulumi.Any(mysqlConfigurationVariablesInnodbLockWaitTimeout),
				InnodbLogWriterThreads:                 pulumi.Any(mysqlConfigurationVariablesInnodbLogWriterThreads),
				InnodbMaxPurgeLag:                      pulumi.Any(mysqlConfigurationVariablesInnodbMaxPurgeLag),
				InnodbMaxPurgeLagDelay:                 pulumi.Any(mysqlConfigurationVariablesInnodbMaxPurgeLagDelay),
				InnodbNumaInterleave:                   pulumi.Any(mysqlConfigurationVariablesInnodbNumaInterleave),
				InnodbOnlineAlterLogMaxSize:            pulumi.Any(mysqlConfigurationVariablesInnodbOnlineAlterLogMaxSize),
				InnodbRedoLogCapacity:                  pulumi.Any(mysqlConfigurationVariablesInnodbRedoLogCapacity),
				InnodbRollbackOnTimeout:                pulumi.Any(mysqlConfigurationVariablesInnodbRollbackOnTimeout),
				InnodbSortBufferSize:                   pulumi.Any(mysqlConfigurationVariablesInnodbSortBufferSize),
				InnodbStatsPersistentSamplePages:       pulumi.Any(mysqlConfigurationVariablesInnodbStatsPersistentSamplePages),
				InnodbStatsTransientSamplePages:        pulumi.Any(mysqlConfigurationVariablesInnodbStatsTransientSamplePages),
				InnodbStrictMode:                       pulumi.Any(mysqlConfigurationVariablesInnodbStrictMode),
				InnodbUndoLogTruncate:                  pulumi.Any(mysqlConfigurationVariablesInnodbUndoLogTruncate),
				InteractiveTimeout:                     pulumi.Any(mysqlConfigurationVariablesInteractiveTimeout),
				JoinBufferSize:                         pulumi.Any(mysqlConfigurationVariablesJoinBufferSize),
				LocalInfile:                            pulumi.Any(mysqlConfigurationVariablesLocalInfile),
				LongQueryTime:                          pulumi.Any(mysqlConfigurationVariablesLongQueryTime),
				MandatoryRoles:                         pulumi.Any(mysqlConfigurationVariablesMandatoryRoles),
				MaxAllowedPacket:                       pulumi.Any(mysqlConfigurationVariablesMaxAllowedPacket),
				MaxBinlogCacheSize:                     pulumi.Any(mysqlConfigurationVariablesMaxBinlogCacheSize),
				MaxConnectErrors:                       pulumi.Any(mysqlConfigurationVariablesMaxConnectErrors),
				MaxConnections:                         pulumi.Any(mysqlConfigurationVariablesMaxConnections),
				MaxExecutionTime:                       pulumi.Any(mysqlConfigurationVariablesMaxExecutionTime),
				MaxHeapTableSize:                       pulumi.Any(mysqlConfigurationVariablesMaxHeapTableSize),
				MaxPreparedStmtCount:                   pulumi.Any(mysqlConfigurationVariablesMaxPreparedStmtCount),
				MaxSeeksForKey:                         pulumi.Any(mysqlConfigurationVariablesMaxSeeksForKey),
				MaxUserConnections:                     pulumi.Any(mysqlConfigurationVariablesMaxUserConnections),
				MysqlFirewallMode:                      pulumi.Any(mysqlConfigurationVariablesMysqlFirewallMode),
				MysqlZstdDefaultCompressionLevel:       pulumi.Any(mysqlConfigurationVariablesMysqlZstdDefaultCompressionLevel),
				MysqlxConnectTimeout:                   pulumi.Any(mysqlConfigurationVariablesMysqlxConnectTimeout),
				MysqlxDeflateDefaultCompressionLevel:   pulumi.Any(mysqlConfigurationVariablesMysqlxDeflateDefaultCompressionLevel),
				MysqlxDeflateMaxClientCompressionLevel: pulumi.Any(mysqlConfigurationVariablesMysqlxDeflateMaxClientCompressionLevel),
				MysqlxDocumentIdUniquePrefix:           pulumi.Any(mysqlConfigurationVariablesMysqlxDocumentIdUniquePrefix),
				MysqlxEnableHelloNotice:                pulumi.Any(mysqlConfigurationVariablesMysqlxEnableHelloNotice),
				MysqlxIdleWorkerThreadTimeout:          pulumi.Any(mysqlConfigurationVariablesMysqlxIdleWorkerThreadTimeout),
				MysqlxInteractiveTimeout:               pulumi.Any(mysqlConfigurationVariablesMysqlxInteractiveTimeout),
				MysqlxLz4defaultCompressionLevel:       pulumi.Any(mysqlConfigurationVariablesMysqlxLz4defaultCompressionLevel),
				MysqlxLz4maxClientCompressionLevel:     pulumi.Any(mysqlConfigurationVariablesMysqlxLz4maxClientCompressionLevel),
				MysqlxMaxAllowedPacket:                 pulumi.Any(mysqlConfigurationVariablesMysqlxMaxAllowedPacket),
				MysqlxMinWorkerThreads:                 pulumi.Any(mysqlConfigurationVariablesMysqlxMinWorkerThreads),
				MysqlxReadTimeout:                      pulumi.Any(mysqlConfigurationVariablesMysqlxReadTimeout),
				MysqlxWaitTimeout:                      pulumi.Any(mysqlConfigurationVariablesMysqlxWaitTimeout),
				MysqlxWriteTimeout:                     pulumi.Any(mysqlConfigurationVariablesMysqlxWriteTimeout),
				MysqlxZstdDefaultCompressionLevel:      pulumi.Any(mysqlConfigurationVariablesMysqlxZstdDefaultCompressionLevel),
				MysqlxZstdMaxClientCompressionLevel:    pulumi.Any(mysqlConfigurationVariablesMysqlxZstdMaxClientCompressionLevel),
				NetReadTimeout:                         pulumi.Any(mysqlConfigurationVariablesNetReadTimeout),
				NetWriteTimeout:                        pulumi.Any(mysqlConfigurationVariablesNetWriteTimeout),
				OptimizerSwitch:                        pulumi.Any(mysqlConfigurationVariablesOptimizerSwitch),
				ParserMaxMemSize:                       pulumi.Any(mysqlConfigurationVariablesParserMaxMemSize),
				QueryAllocBlockSize:                    pulumi.Any(mysqlConfigurationVariablesQueryAllocBlockSize),
				QueryPreallocSize:                      pulumi.Any(mysqlConfigurationVariablesQueryPreallocSize),
				RangeOptimizerMaxMemSize:               pulumi.Any(mysqlConfigurationVariablesRangeOptimizerMaxMemSize),
				RegexpTimeLimit:                        pulumi.Any(mysqlConfigurationVariablesRegexpTimeLimit),
				RelayLogSpaceLimit:                     pulumi.Any(mysqlConfigurationVariablesRelayLogSpaceLimit),
				ReplicaNetTimeout:                      pulumi.Any(mysqlConfigurationVariablesReplicaNetTimeout),
				ReplicaParallelWorkers:                 pulumi.Any(mysqlConfigurationVariablesReplicaParallelWorkers),
				ReplicaTypeConversions:                 pulumi.Any(mysqlConfigurationVariablesReplicaTypeConversions),
				RequireSecureTransport:                 pulumi.Any(mysqlConfigurationVariablesRequireSecureTransport),
				SkipNameResolve:                        pulumi.Any(mysqlConfigurationVariablesSkipNameResolve),
				SortBufferSize:                         pulumi.Any(mysqlConfigurationVariablesSortBufferSize),
				SqlGenerateInvisiblePrimaryKey:         pulumi.Any(mysqlConfigurationVariablesSqlGenerateInvisiblePrimaryKey),
				SqlMode:                                pulumi.Any(mysqlConfigurationVariablesSqlMode),
				SqlRequirePrimaryKey:                   pulumi.Any(mysqlConfigurationVariablesSqlRequirePrimaryKey),
				SqlWarnings:                            pulumi.Any(mysqlConfigurationVariablesSqlWarnings),
				TableDefinitionCache:                   pulumi.Any(mysqlConfigurationVariablesTableDefinitionCache),
				TableOpenCache:                         pulumi.Any(mysqlConfigurationVariablesTableOpenCache),
				TemptableMaxRam:                        pulumi.Any(mysqlConfigurationVariablesTemptableMaxRam),
				ThreadPoolDedicatedListeners:           pulumi.Any(mysqlConfigurationVariablesThreadPoolDedicatedListeners),
				ThreadPoolMaxTransactionsLimit:         pulumi.Any(mysqlConfigurationVariablesThreadPoolMaxTransactionsLimit),
				ThreadPoolQueryThreadsPerGroup:         pulumi.Any(mysqlConfigurationVariablesThreadPoolQueryThreadsPerGroup),
				ThreadPoolSize:                         pulumi.Any(mysqlConfigurationVariablesThreadPoolSize),
				ThreadPoolTransactionDelay:             pulumi.Any(mysqlConfigurationVariablesThreadPoolTransactionDelay),
				TimeZone:                               pulumi.Any(mysqlConfigurationVariablesTimeZone),
				TmpTableSize:                           pulumi.Any(mysqlConfigurationVariablesTmpTableSize),
				TransactionIsolation:                   pulumi.Any(mysqlConfigurationVariablesTransactionIsolation),
				WaitTimeout:                            pulumi.Any(mysqlConfigurationVariablesWaitTimeout),
			},
		})
		if err != nil {
			return err
		}
		return nil
	})
}
Copy
using System.Collections.Generic;
using System.Linq;
using Pulumi;
using Oci = Pulumi.Oci;

return await Deployment.RunAsync(() => 
{
    var testMysqlConfiguration = new Oci.Mysql.MysqlConfiguration("test_mysql_configuration", new()
    {
        CompartmentId = compartmentId,
        ShapeName = testShape.Name,
        DefinedTags = 
        {
            { "foo-namespace.bar-key", "value" },
        },
        Description = mysqlConfigurationDescription,
        DisplayName = mysqlConfigurationDisplayName,
        FreeformTags = 
        {
            { "bar-key", "value" },
        },
        InitVariables = new Oci.Mysql.Inputs.MysqlConfigurationInitVariablesArgs
        {
            LowerCaseTableNames = mysqlConfigurationInitVariablesLowerCaseTableNames,
        },
        ParentConfigurationId = testConfiguration.Id,
        Variables = new Oci.Mysql.Inputs.MysqlConfigurationVariablesArgs
        {
            AutoIncrementIncrement = mysqlConfigurationVariablesAutoIncrementIncrement,
            AutoIncrementOffset = mysqlConfigurationVariablesAutoIncrementOffset,
            Autocommit = mysqlConfigurationVariablesAutocommit,
            BigTables = mysqlConfigurationVariablesBigTables,
            BinlogExpireLogsSeconds = mysqlConfigurationVariablesBinlogExpireLogsSeconds,
            BinlogGroupCommitSyncDelay = mysqlConfigurationVariablesBinlogGroupCommitSyncDelay,
            BinlogGroupCommitSyncNoDelayCount = mysqlConfigurationVariablesBinlogGroupCommitSyncNoDelayCount,
            BinlogRowMetadata = mysqlConfigurationVariablesBinlogRowMetadata,
            BinlogRowValueOptions = mysqlConfigurationVariablesBinlogRowValueOptions,
            BinlogTransactionCompression = mysqlConfigurationVariablesBinlogTransactionCompression,
            BlockEncryptionMode = mysqlConfigurationVariablesBlockEncryptionMode,
            CharacterSetServer = mysqlConfigurationVariablesCharacterSetServer,
            CollationServer = mysqlConfigurationVariablesCollationServer,
            CompletionType = mysqlConfigurationVariablesCompletionType,
            ConnectTimeout = mysqlConfigurationVariablesConnectTimeout,
            ConnectionMemoryChunkSize = mysqlConfigurationVariablesConnectionMemoryChunkSize,
            ConnectionMemoryLimit = mysqlConfigurationVariablesConnectionMemoryLimit,
            CteMaxRecursionDepth = mysqlConfigurationVariablesCteMaxRecursionDepth,
            DefaultAuthenticationPlugin = mysqlConfigurationVariablesDefaultAuthenticationPlugin,
            ExplainFormat = mysqlConfigurationVariablesExplainFormat,
            ExplicitDefaultsForTimestamp = mysqlConfigurationVariablesExplicitDefaultsForTimestamp,
            ForeignKeyChecks = mysqlConfigurationVariablesForeignKeyChecks,
            GeneratedRandomPasswordLength = mysqlConfigurationVariablesGeneratedRandomPasswordLength,
            GlobalConnectionMemoryLimit = mysqlConfigurationVariablesGlobalConnectionMemoryLimit,
            GlobalConnectionMemoryTracking = mysqlConfigurationVariablesGlobalConnectionMemoryTracking,
            GroupConcatMaxLen = mysqlConfigurationVariablesGroupConcatMaxLen,
            GroupReplicationConsistency = mysqlConfigurationVariablesGroupReplicationConsistency,
            InformationSchemaStatsExpiry = mysqlConfigurationVariablesInformationSchemaStatsExpiry,
            InnodbAdaptiveHashIndex = mysqlConfigurationVariablesInnodbAdaptiveHashIndex,
            InnodbAutoincLockMode = mysqlConfigurationVariablesInnodbAutoincLockMode,
            InnodbBufferPoolDumpPct = mysqlConfigurationVariablesInnodbBufferPoolDumpPct,
            InnodbBufferPoolInstances = mysqlConfigurationVariablesInnodbBufferPoolInstances,
            InnodbBufferPoolSize = mysqlConfigurationVariablesInnodbBufferPoolSize,
            InnodbChangeBuffering = mysqlConfigurationVariablesInnodbChangeBuffering,
            InnodbDdlBufferSize = mysqlConfigurationVariablesInnodbDdlBufferSize,
            InnodbDdlThreads = mysqlConfigurationVariablesInnodbDdlThreads,
            InnodbFtEnableStopword = mysqlConfigurationVariablesInnodbFtEnableStopword,
            InnodbFtMaxTokenSize = mysqlConfigurationVariablesInnodbFtMaxTokenSize,
            InnodbFtMinTokenSize = mysqlConfigurationVariablesInnodbFtMinTokenSize,
            InnodbFtNumWordOptimize = mysqlConfigurationVariablesInnodbFtNumWordOptimize,
            InnodbFtResultCacheLimit = mysqlConfigurationVariablesInnodbFtResultCacheLimit,
            InnodbFtServerStopwordTable = mysqlConfigurationVariablesInnodbFtServerStopwordTable,
            InnodbLockWaitTimeout = mysqlConfigurationVariablesInnodbLockWaitTimeout,
            InnodbLogWriterThreads = mysqlConfigurationVariablesInnodbLogWriterThreads,
            InnodbMaxPurgeLag = mysqlConfigurationVariablesInnodbMaxPurgeLag,
            InnodbMaxPurgeLagDelay = mysqlConfigurationVariablesInnodbMaxPurgeLagDelay,
            InnodbNumaInterleave = mysqlConfigurationVariablesInnodbNumaInterleave,
            InnodbOnlineAlterLogMaxSize = mysqlConfigurationVariablesInnodbOnlineAlterLogMaxSize,
            InnodbRedoLogCapacity = mysqlConfigurationVariablesInnodbRedoLogCapacity,
            InnodbRollbackOnTimeout = mysqlConfigurationVariablesInnodbRollbackOnTimeout,
            InnodbSortBufferSize = mysqlConfigurationVariablesInnodbSortBufferSize,
            InnodbStatsPersistentSamplePages = mysqlConfigurationVariablesInnodbStatsPersistentSamplePages,
            InnodbStatsTransientSamplePages = mysqlConfigurationVariablesInnodbStatsTransientSamplePages,
            InnodbStrictMode = mysqlConfigurationVariablesInnodbStrictMode,
            InnodbUndoLogTruncate = mysqlConfigurationVariablesInnodbUndoLogTruncate,
            InteractiveTimeout = mysqlConfigurationVariablesInteractiveTimeout,
            JoinBufferSize = mysqlConfigurationVariablesJoinBufferSize,
            LocalInfile = mysqlConfigurationVariablesLocalInfile,
            LongQueryTime = mysqlConfigurationVariablesLongQueryTime,
            MandatoryRoles = mysqlConfigurationVariablesMandatoryRoles,
            MaxAllowedPacket = mysqlConfigurationVariablesMaxAllowedPacket,
            MaxBinlogCacheSize = mysqlConfigurationVariablesMaxBinlogCacheSize,
            MaxConnectErrors = mysqlConfigurationVariablesMaxConnectErrors,
            MaxConnections = mysqlConfigurationVariablesMaxConnections,
            MaxExecutionTime = mysqlConfigurationVariablesMaxExecutionTime,
            MaxHeapTableSize = mysqlConfigurationVariablesMaxHeapTableSize,
            MaxPreparedStmtCount = mysqlConfigurationVariablesMaxPreparedStmtCount,
            MaxSeeksForKey = mysqlConfigurationVariablesMaxSeeksForKey,
            MaxUserConnections = mysqlConfigurationVariablesMaxUserConnections,
            MysqlFirewallMode = mysqlConfigurationVariablesMysqlFirewallMode,
            MysqlZstdDefaultCompressionLevel = mysqlConfigurationVariablesMysqlZstdDefaultCompressionLevel,
            MysqlxConnectTimeout = mysqlConfigurationVariablesMysqlxConnectTimeout,
            MysqlxDeflateDefaultCompressionLevel = mysqlConfigurationVariablesMysqlxDeflateDefaultCompressionLevel,
            MysqlxDeflateMaxClientCompressionLevel = mysqlConfigurationVariablesMysqlxDeflateMaxClientCompressionLevel,
            MysqlxDocumentIdUniquePrefix = mysqlConfigurationVariablesMysqlxDocumentIdUniquePrefix,
            MysqlxEnableHelloNotice = mysqlConfigurationVariablesMysqlxEnableHelloNotice,
            MysqlxIdleWorkerThreadTimeout = mysqlConfigurationVariablesMysqlxIdleWorkerThreadTimeout,
            MysqlxInteractiveTimeout = mysqlConfigurationVariablesMysqlxInteractiveTimeout,
            MysqlxLz4defaultCompressionLevel = mysqlConfigurationVariablesMysqlxLz4defaultCompressionLevel,
            MysqlxLz4maxClientCompressionLevel = mysqlConfigurationVariablesMysqlxLz4maxClientCompressionLevel,
            MysqlxMaxAllowedPacket = mysqlConfigurationVariablesMysqlxMaxAllowedPacket,
            MysqlxMinWorkerThreads = mysqlConfigurationVariablesMysqlxMinWorkerThreads,
            MysqlxReadTimeout = mysqlConfigurationVariablesMysqlxReadTimeout,
            MysqlxWaitTimeout = mysqlConfigurationVariablesMysqlxWaitTimeout,
            MysqlxWriteTimeout = mysqlConfigurationVariablesMysqlxWriteTimeout,
            MysqlxZstdDefaultCompressionLevel = mysqlConfigurationVariablesMysqlxZstdDefaultCompressionLevel,
            MysqlxZstdMaxClientCompressionLevel = mysqlConfigurationVariablesMysqlxZstdMaxClientCompressionLevel,
            NetReadTimeout = mysqlConfigurationVariablesNetReadTimeout,
            NetWriteTimeout = mysqlConfigurationVariablesNetWriteTimeout,
            OptimizerSwitch = mysqlConfigurationVariablesOptimizerSwitch,
            ParserMaxMemSize = mysqlConfigurationVariablesParserMaxMemSize,
            QueryAllocBlockSize = mysqlConfigurationVariablesQueryAllocBlockSize,
            QueryPreallocSize = mysqlConfigurationVariablesQueryPreallocSize,
            RangeOptimizerMaxMemSize = mysqlConfigurationVariablesRangeOptimizerMaxMemSize,
            RegexpTimeLimit = mysqlConfigurationVariablesRegexpTimeLimit,
            RelayLogSpaceLimit = mysqlConfigurationVariablesRelayLogSpaceLimit,
            ReplicaNetTimeout = mysqlConfigurationVariablesReplicaNetTimeout,
            ReplicaParallelWorkers = mysqlConfigurationVariablesReplicaParallelWorkers,
            ReplicaTypeConversions = mysqlConfigurationVariablesReplicaTypeConversions,
            RequireSecureTransport = mysqlConfigurationVariablesRequireSecureTransport,
            SkipNameResolve = mysqlConfigurationVariablesSkipNameResolve,
            SortBufferSize = mysqlConfigurationVariablesSortBufferSize,
            SqlGenerateInvisiblePrimaryKey = mysqlConfigurationVariablesSqlGenerateInvisiblePrimaryKey,
            SqlMode = mysqlConfigurationVariablesSqlMode,
            SqlRequirePrimaryKey = mysqlConfigurationVariablesSqlRequirePrimaryKey,
            SqlWarnings = mysqlConfigurationVariablesSqlWarnings,
            TableDefinitionCache = mysqlConfigurationVariablesTableDefinitionCache,
            TableOpenCache = mysqlConfigurationVariablesTableOpenCache,
            TemptableMaxRam = mysqlConfigurationVariablesTemptableMaxRam,
            ThreadPoolDedicatedListeners = mysqlConfigurationVariablesThreadPoolDedicatedListeners,
            ThreadPoolMaxTransactionsLimit = mysqlConfigurationVariablesThreadPoolMaxTransactionsLimit,
            ThreadPoolQueryThreadsPerGroup = mysqlConfigurationVariablesThreadPoolQueryThreadsPerGroup,
            ThreadPoolSize = mysqlConfigurationVariablesThreadPoolSize,
            ThreadPoolTransactionDelay = mysqlConfigurationVariablesThreadPoolTransactionDelay,
            TimeZone = mysqlConfigurationVariablesTimeZone,
            TmpTableSize = mysqlConfigurationVariablesTmpTableSize,
            TransactionIsolation = mysqlConfigurationVariablesTransactionIsolation,
            WaitTimeout = mysqlConfigurationVariablesWaitTimeout,
        },
    });

});
Copy
package generated_program;

import com.pulumi.Context;
import com.pulumi.Pulumi;
import com.pulumi.core.Output;
import com.pulumi.oci.Mysql.MysqlConfiguration;
import com.pulumi.oci.Mysql.MysqlConfigurationArgs;
import com.pulumi.oci.Mysql.inputs.MysqlConfigurationInitVariablesArgs;
import com.pulumi.oci.Mysql.inputs.MysqlConfigurationVariablesArgs;
import java.util.List;
import java.util.ArrayList;
import java.util.Map;
import java.io.File;
import java.nio.file.Files;
import java.nio.file.Paths;

public class App {
    public static void main(String[] args) {
        Pulumi.run(App::stack);
    }

    public static void stack(Context ctx) {
        var testMysqlConfiguration = new MysqlConfiguration("testMysqlConfiguration", MysqlConfigurationArgs.builder()
            .compartmentId(compartmentId)
            .shapeName(testShape.name())
            .definedTags(Map.of("foo-namespace.bar-key", "value"))
            .description(mysqlConfigurationDescription)
            .displayName(mysqlConfigurationDisplayName)
            .freeformTags(Map.of("bar-key", "value"))
            .initVariables(MysqlConfigurationInitVariablesArgs.builder()
                .lowerCaseTableNames(mysqlConfigurationInitVariablesLowerCaseTableNames)
                .build())
            .parentConfigurationId(testConfiguration.id())
            .variables(MysqlConfigurationVariablesArgs.builder()
                .autoIncrementIncrement(mysqlConfigurationVariablesAutoIncrementIncrement)
                .autoIncrementOffset(mysqlConfigurationVariablesAutoIncrementOffset)
                .autocommit(mysqlConfigurationVariablesAutocommit)
                .bigTables(mysqlConfigurationVariablesBigTables)
                .binlogExpireLogsSeconds(mysqlConfigurationVariablesBinlogExpireLogsSeconds)
                .binlogGroupCommitSyncDelay(mysqlConfigurationVariablesBinlogGroupCommitSyncDelay)
                .binlogGroupCommitSyncNoDelayCount(mysqlConfigurationVariablesBinlogGroupCommitSyncNoDelayCount)
                .binlogRowMetadata(mysqlConfigurationVariablesBinlogRowMetadata)
                .binlogRowValueOptions(mysqlConfigurationVariablesBinlogRowValueOptions)
                .binlogTransactionCompression(mysqlConfigurationVariablesBinlogTransactionCompression)
                .blockEncryptionMode(mysqlConfigurationVariablesBlockEncryptionMode)
                .characterSetServer(mysqlConfigurationVariablesCharacterSetServer)
                .collationServer(mysqlConfigurationVariablesCollationServer)
                .completionType(mysqlConfigurationVariablesCompletionType)
                .connectTimeout(mysqlConfigurationVariablesConnectTimeout)
                .connectionMemoryChunkSize(mysqlConfigurationVariablesConnectionMemoryChunkSize)
                .connectionMemoryLimit(mysqlConfigurationVariablesConnectionMemoryLimit)
                .cteMaxRecursionDepth(mysqlConfigurationVariablesCteMaxRecursionDepth)
                .defaultAuthenticationPlugin(mysqlConfigurationVariablesDefaultAuthenticationPlugin)
                .explainFormat(mysqlConfigurationVariablesExplainFormat)
                .explicitDefaultsForTimestamp(mysqlConfigurationVariablesExplicitDefaultsForTimestamp)
                .foreignKeyChecks(mysqlConfigurationVariablesForeignKeyChecks)
                .generatedRandomPasswordLength(mysqlConfigurationVariablesGeneratedRandomPasswordLength)
                .globalConnectionMemoryLimit(mysqlConfigurationVariablesGlobalConnectionMemoryLimit)
                .globalConnectionMemoryTracking(mysqlConfigurationVariablesGlobalConnectionMemoryTracking)
                .groupConcatMaxLen(mysqlConfigurationVariablesGroupConcatMaxLen)
                .groupReplicationConsistency(mysqlConfigurationVariablesGroupReplicationConsistency)
                .informationSchemaStatsExpiry(mysqlConfigurationVariablesInformationSchemaStatsExpiry)
                .innodbAdaptiveHashIndex(mysqlConfigurationVariablesInnodbAdaptiveHashIndex)
                .innodbAutoincLockMode(mysqlConfigurationVariablesInnodbAutoincLockMode)
                .innodbBufferPoolDumpPct(mysqlConfigurationVariablesInnodbBufferPoolDumpPct)
                .innodbBufferPoolInstances(mysqlConfigurationVariablesInnodbBufferPoolInstances)
                .innodbBufferPoolSize(mysqlConfigurationVariablesInnodbBufferPoolSize)
                .innodbChangeBuffering(mysqlConfigurationVariablesInnodbChangeBuffering)
                .innodbDdlBufferSize(mysqlConfigurationVariablesInnodbDdlBufferSize)
                .innodbDdlThreads(mysqlConfigurationVariablesInnodbDdlThreads)
                .innodbFtEnableStopword(mysqlConfigurationVariablesInnodbFtEnableStopword)
                .innodbFtMaxTokenSize(mysqlConfigurationVariablesInnodbFtMaxTokenSize)
                .innodbFtMinTokenSize(mysqlConfigurationVariablesInnodbFtMinTokenSize)
                .innodbFtNumWordOptimize(mysqlConfigurationVariablesInnodbFtNumWordOptimize)
                .innodbFtResultCacheLimit(mysqlConfigurationVariablesInnodbFtResultCacheLimit)
                .innodbFtServerStopwordTable(mysqlConfigurationVariablesInnodbFtServerStopwordTable)
                .innodbLockWaitTimeout(mysqlConfigurationVariablesInnodbLockWaitTimeout)
                .innodbLogWriterThreads(mysqlConfigurationVariablesInnodbLogWriterThreads)
                .innodbMaxPurgeLag(mysqlConfigurationVariablesInnodbMaxPurgeLag)
                .innodbMaxPurgeLagDelay(mysqlConfigurationVariablesInnodbMaxPurgeLagDelay)
                .innodbNumaInterleave(mysqlConfigurationVariablesInnodbNumaInterleave)
                .innodbOnlineAlterLogMaxSize(mysqlConfigurationVariablesInnodbOnlineAlterLogMaxSize)
                .innodbRedoLogCapacity(mysqlConfigurationVariablesInnodbRedoLogCapacity)
                .innodbRollbackOnTimeout(mysqlConfigurationVariablesInnodbRollbackOnTimeout)
                .innodbSortBufferSize(mysqlConfigurationVariablesInnodbSortBufferSize)
                .innodbStatsPersistentSamplePages(mysqlConfigurationVariablesInnodbStatsPersistentSamplePages)
                .innodbStatsTransientSamplePages(mysqlConfigurationVariablesInnodbStatsTransientSamplePages)
                .innodbStrictMode(mysqlConfigurationVariablesInnodbStrictMode)
                .innodbUndoLogTruncate(mysqlConfigurationVariablesInnodbUndoLogTruncate)
                .interactiveTimeout(mysqlConfigurationVariablesInteractiveTimeout)
                .joinBufferSize(mysqlConfigurationVariablesJoinBufferSize)
                .localInfile(mysqlConfigurationVariablesLocalInfile)
                .longQueryTime(mysqlConfigurationVariablesLongQueryTime)
                .mandatoryRoles(mysqlConfigurationVariablesMandatoryRoles)
                .maxAllowedPacket(mysqlConfigurationVariablesMaxAllowedPacket)
                .maxBinlogCacheSize(mysqlConfigurationVariablesMaxBinlogCacheSize)
                .maxConnectErrors(mysqlConfigurationVariablesMaxConnectErrors)
                .maxConnections(mysqlConfigurationVariablesMaxConnections)
                .maxExecutionTime(mysqlConfigurationVariablesMaxExecutionTime)
                .maxHeapTableSize(mysqlConfigurationVariablesMaxHeapTableSize)
                .maxPreparedStmtCount(mysqlConfigurationVariablesMaxPreparedStmtCount)
                .maxSeeksForKey(mysqlConfigurationVariablesMaxSeeksForKey)
                .maxUserConnections(mysqlConfigurationVariablesMaxUserConnections)
                .mysqlFirewallMode(mysqlConfigurationVariablesMysqlFirewallMode)
                .mysqlZstdDefaultCompressionLevel(mysqlConfigurationVariablesMysqlZstdDefaultCompressionLevel)
                .mysqlxConnectTimeout(mysqlConfigurationVariablesMysqlxConnectTimeout)
                .mysqlxDeflateDefaultCompressionLevel(mysqlConfigurationVariablesMysqlxDeflateDefaultCompressionLevel)
                .mysqlxDeflateMaxClientCompressionLevel(mysqlConfigurationVariablesMysqlxDeflateMaxClientCompressionLevel)
                .mysqlxDocumentIdUniquePrefix(mysqlConfigurationVariablesMysqlxDocumentIdUniquePrefix)
                .mysqlxEnableHelloNotice(mysqlConfigurationVariablesMysqlxEnableHelloNotice)
                .mysqlxIdleWorkerThreadTimeout(mysqlConfigurationVariablesMysqlxIdleWorkerThreadTimeout)
                .mysqlxInteractiveTimeout(mysqlConfigurationVariablesMysqlxInteractiveTimeout)
                .mysqlxLz4defaultCompressionLevel(mysqlConfigurationVariablesMysqlxLz4defaultCompressionLevel)
                .mysqlxLz4maxClientCompressionLevel(mysqlConfigurationVariablesMysqlxLz4maxClientCompressionLevel)
                .mysqlxMaxAllowedPacket(mysqlConfigurationVariablesMysqlxMaxAllowedPacket)
                .mysqlxMinWorkerThreads(mysqlConfigurationVariablesMysqlxMinWorkerThreads)
                .mysqlxReadTimeout(mysqlConfigurationVariablesMysqlxReadTimeout)
                .mysqlxWaitTimeout(mysqlConfigurationVariablesMysqlxWaitTimeout)
                .mysqlxWriteTimeout(mysqlConfigurationVariablesMysqlxWriteTimeout)
                .mysqlxZstdDefaultCompressionLevel(mysqlConfigurationVariablesMysqlxZstdDefaultCompressionLevel)
                .mysqlxZstdMaxClientCompressionLevel(mysqlConfigurationVariablesMysqlxZstdMaxClientCompressionLevel)
                .netReadTimeout(mysqlConfigurationVariablesNetReadTimeout)
                .netWriteTimeout(mysqlConfigurationVariablesNetWriteTimeout)
                .optimizerSwitch(mysqlConfigurationVariablesOptimizerSwitch)
                .parserMaxMemSize(mysqlConfigurationVariablesParserMaxMemSize)
                .queryAllocBlockSize(mysqlConfigurationVariablesQueryAllocBlockSize)
                .queryPreallocSize(mysqlConfigurationVariablesQueryPreallocSize)
                .rangeOptimizerMaxMemSize(mysqlConfigurationVariablesRangeOptimizerMaxMemSize)
                .regexpTimeLimit(mysqlConfigurationVariablesRegexpTimeLimit)
                .relayLogSpaceLimit(mysqlConfigurationVariablesRelayLogSpaceLimit)
                .replicaNetTimeout(mysqlConfigurationVariablesReplicaNetTimeout)
                .replicaParallelWorkers(mysqlConfigurationVariablesReplicaParallelWorkers)
                .replicaTypeConversions(mysqlConfigurationVariablesReplicaTypeConversions)
                .requireSecureTransport(mysqlConfigurationVariablesRequireSecureTransport)
                .skipNameResolve(mysqlConfigurationVariablesSkipNameResolve)
                .sortBufferSize(mysqlConfigurationVariablesSortBufferSize)
                .sqlGenerateInvisiblePrimaryKey(mysqlConfigurationVariablesSqlGenerateInvisiblePrimaryKey)
                .sqlMode(mysqlConfigurationVariablesSqlMode)
                .sqlRequirePrimaryKey(mysqlConfigurationVariablesSqlRequirePrimaryKey)
                .sqlWarnings(mysqlConfigurationVariablesSqlWarnings)
                .tableDefinitionCache(mysqlConfigurationVariablesTableDefinitionCache)
                .tableOpenCache(mysqlConfigurationVariablesTableOpenCache)
                .temptableMaxRam(mysqlConfigurationVariablesTemptableMaxRam)
                .threadPoolDedicatedListeners(mysqlConfigurationVariablesThreadPoolDedicatedListeners)
                .threadPoolMaxTransactionsLimit(mysqlConfigurationVariablesThreadPoolMaxTransactionsLimit)
                .threadPoolQueryThreadsPerGroup(mysqlConfigurationVariablesThreadPoolQueryThreadsPerGroup)
                .threadPoolSize(mysqlConfigurationVariablesThreadPoolSize)
                .threadPoolTransactionDelay(mysqlConfigurationVariablesThreadPoolTransactionDelay)
                .timeZone(mysqlConfigurationVariablesTimeZone)
                .tmpTableSize(mysqlConfigurationVariablesTmpTableSize)
                .transactionIsolation(mysqlConfigurationVariablesTransactionIsolation)
                .waitTimeout(mysqlConfigurationVariablesWaitTimeout)
                .build())
            .build());

    }
}
Copy
resources:
  testMysqlConfiguration:
    type: oci:Mysql:MysqlConfiguration
    name: test_mysql_configuration
    properties:
      compartmentId: ${compartmentId}
      shapeName: ${testShape.name}
      definedTags:
        foo-namespace.bar-key: value
      description: ${mysqlConfigurationDescription}
      displayName: ${mysqlConfigurationDisplayName}
      freeformTags:
        bar-key: value
      initVariables:
        lowerCaseTableNames: ${mysqlConfigurationInitVariablesLowerCaseTableNames}
      parentConfigurationId: ${testConfiguration.id}
      variables:
        autoIncrementIncrement: ${mysqlConfigurationVariablesAutoIncrementIncrement}
        autoIncrementOffset: ${mysqlConfigurationVariablesAutoIncrementOffset}
        autocommit: ${mysqlConfigurationVariablesAutocommit}
        bigTables: ${mysqlConfigurationVariablesBigTables}
        binlogExpireLogsSeconds: ${mysqlConfigurationVariablesBinlogExpireLogsSeconds}
        binlogGroupCommitSyncDelay: ${mysqlConfigurationVariablesBinlogGroupCommitSyncDelay}
        binlogGroupCommitSyncNoDelayCount: ${mysqlConfigurationVariablesBinlogGroupCommitSyncNoDelayCount}
        binlogRowMetadata: ${mysqlConfigurationVariablesBinlogRowMetadata}
        binlogRowValueOptions: ${mysqlConfigurationVariablesBinlogRowValueOptions}
        binlogTransactionCompression: ${mysqlConfigurationVariablesBinlogTransactionCompression}
        blockEncryptionMode: ${mysqlConfigurationVariablesBlockEncryptionMode}
        characterSetServer: ${mysqlConfigurationVariablesCharacterSetServer}
        collationServer: ${mysqlConfigurationVariablesCollationServer}
        completionType: ${mysqlConfigurationVariablesCompletionType}
        connectTimeout: ${mysqlConfigurationVariablesConnectTimeout}
        connectionMemoryChunkSize: ${mysqlConfigurationVariablesConnectionMemoryChunkSize}
        connectionMemoryLimit: ${mysqlConfigurationVariablesConnectionMemoryLimit}
        cteMaxRecursionDepth: ${mysqlConfigurationVariablesCteMaxRecursionDepth}
        defaultAuthenticationPlugin: ${mysqlConfigurationVariablesDefaultAuthenticationPlugin}
        explainFormat: ${mysqlConfigurationVariablesExplainFormat}
        explicitDefaultsForTimestamp: ${mysqlConfigurationVariablesExplicitDefaultsForTimestamp}
        foreignKeyChecks: ${mysqlConfigurationVariablesForeignKeyChecks}
        generatedRandomPasswordLength: ${mysqlConfigurationVariablesGeneratedRandomPasswordLength}
        globalConnectionMemoryLimit: ${mysqlConfigurationVariablesGlobalConnectionMemoryLimit}
        globalConnectionMemoryTracking: ${mysqlConfigurationVariablesGlobalConnectionMemoryTracking}
        groupConcatMaxLen: ${mysqlConfigurationVariablesGroupConcatMaxLen}
        groupReplicationConsistency: ${mysqlConfigurationVariablesGroupReplicationConsistency}
        informationSchemaStatsExpiry: ${mysqlConfigurationVariablesInformationSchemaStatsExpiry}
        innodbAdaptiveHashIndex: ${mysqlConfigurationVariablesInnodbAdaptiveHashIndex}
        innodbAutoincLockMode: ${mysqlConfigurationVariablesInnodbAutoincLockMode}
        innodbBufferPoolDumpPct: ${mysqlConfigurationVariablesInnodbBufferPoolDumpPct}
        innodbBufferPoolInstances: ${mysqlConfigurationVariablesInnodbBufferPoolInstances}
        innodbBufferPoolSize: ${mysqlConfigurationVariablesInnodbBufferPoolSize}
        innodbChangeBuffering: ${mysqlConfigurationVariablesInnodbChangeBuffering}
        innodbDdlBufferSize: ${mysqlConfigurationVariablesInnodbDdlBufferSize}
        innodbDdlThreads: ${mysqlConfigurationVariablesInnodbDdlThreads}
        innodbFtEnableStopword: ${mysqlConfigurationVariablesInnodbFtEnableStopword}
        innodbFtMaxTokenSize: ${mysqlConfigurationVariablesInnodbFtMaxTokenSize}
        innodbFtMinTokenSize: ${mysqlConfigurationVariablesInnodbFtMinTokenSize}
        innodbFtNumWordOptimize: ${mysqlConfigurationVariablesInnodbFtNumWordOptimize}
        innodbFtResultCacheLimit: ${mysqlConfigurationVariablesInnodbFtResultCacheLimit}
        innodbFtServerStopwordTable: ${mysqlConfigurationVariablesInnodbFtServerStopwordTable}
        innodbLockWaitTimeout: ${mysqlConfigurationVariablesInnodbLockWaitTimeout}
        innodbLogWriterThreads: ${mysqlConfigurationVariablesInnodbLogWriterThreads}
        innodbMaxPurgeLag: ${mysqlConfigurationVariablesInnodbMaxPurgeLag}
        innodbMaxPurgeLagDelay: ${mysqlConfigurationVariablesInnodbMaxPurgeLagDelay}
        innodbNumaInterleave: ${mysqlConfigurationVariablesInnodbNumaInterleave}
        innodbOnlineAlterLogMaxSize: ${mysqlConfigurationVariablesInnodbOnlineAlterLogMaxSize}
        innodbRedoLogCapacity: ${mysqlConfigurationVariablesInnodbRedoLogCapacity}
        innodbRollbackOnTimeout: ${mysqlConfigurationVariablesInnodbRollbackOnTimeout}
        innodbSortBufferSize: ${mysqlConfigurationVariablesInnodbSortBufferSize}
        innodbStatsPersistentSamplePages: ${mysqlConfigurationVariablesInnodbStatsPersistentSamplePages}
        innodbStatsTransientSamplePages: ${mysqlConfigurationVariablesInnodbStatsTransientSamplePages}
        innodbStrictMode: ${mysqlConfigurationVariablesInnodbStrictMode}
        innodbUndoLogTruncate: ${mysqlConfigurationVariablesInnodbUndoLogTruncate}
        interactiveTimeout: ${mysqlConfigurationVariablesInteractiveTimeout}
        joinBufferSize: ${mysqlConfigurationVariablesJoinBufferSize}
        localInfile: ${mysqlConfigurationVariablesLocalInfile}
        longQueryTime: ${mysqlConfigurationVariablesLongQueryTime}
        mandatoryRoles: ${mysqlConfigurationVariablesMandatoryRoles}
        maxAllowedPacket: ${mysqlConfigurationVariablesMaxAllowedPacket}
        maxBinlogCacheSize: ${mysqlConfigurationVariablesMaxBinlogCacheSize}
        maxConnectErrors: ${mysqlConfigurationVariablesMaxConnectErrors}
        maxConnections: ${mysqlConfigurationVariablesMaxConnections}
        maxExecutionTime: ${mysqlConfigurationVariablesMaxExecutionTime}
        maxHeapTableSize: ${mysqlConfigurationVariablesMaxHeapTableSize}
        maxPreparedStmtCount: ${mysqlConfigurationVariablesMaxPreparedStmtCount}
        maxSeeksForKey: ${mysqlConfigurationVariablesMaxSeeksForKey}
        maxUserConnections: ${mysqlConfigurationVariablesMaxUserConnections}
        mysqlFirewallMode: ${mysqlConfigurationVariablesMysqlFirewallMode}
        mysqlZstdDefaultCompressionLevel: ${mysqlConfigurationVariablesMysqlZstdDefaultCompressionLevel}
        mysqlxConnectTimeout: ${mysqlConfigurationVariablesMysqlxConnectTimeout}
        mysqlxDeflateDefaultCompressionLevel: ${mysqlConfigurationVariablesMysqlxDeflateDefaultCompressionLevel}
        mysqlxDeflateMaxClientCompressionLevel: ${mysqlConfigurationVariablesMysqlxDeflateMaxClientCompressionLevel}
        mysqlxDocumentIdUniquePrefix: ${mysqlConfigurationVariablesMysqlxDocumentIdUniquePrefix}
        mysqlxEnableHelloNotice: ${mysqlConfigurationVariablesMysqlxEnableHelloNotice}
        mysqlxIdleWorkerThreadTimeout: ${mysqlConfigurationVariablesMysqlxIdleWorkerThreadTimeout}
        mysqlxInteractiveTimeout: ${mysqlConfigurationVariablesMysqlxInteractiveTimeout}
        mysqlxLz4defaultCompressionLevel: ${mysqlConfigurationVariablesMysqlxLz4defaultCompressionLevel}
        mysqlxLz4maxClientCompressionLevel: ${mysqlConfigurationVariablesMysqlxLz4maxClientCompressionLevel}
        mysqlxMaxAllowedPacket: ${mysqlConfigurationVariablesMysqlxMaxAllowedPacket}
        mysqlxMinWorkerThreads: ${mysqlConfigurationVariablesMysqlxMinWorkerThreads}
        mysqlxReadTimeout: ${mysqlConfigurationVariablesMysqlxReadTimeout}
        mysqlxWaitTimeout: ${mysqlConfigurationVariablesMysqlxWaitTimeout}
        mysqlxWriteTimeout: ${mysqlConfigurationVariablesMysqlxWriteTimeout}
        mysqlxZstdDefaultCompressionLevel: ${mysqlConfigurationVariablesMysqlxZstdDefaultCompressionLevel}
        mysqlxZstdMaxClientCompressionLevel: ${mysqlConfigurationVariablesMysqlxZstdMaxClientCompressionLevel}
        netReadTimeout: ${mysqlConfigurationVariablesNetReadTimeout}
        netWriteTimeout: ${mysqlConfigurationVariablesNetWriteTimeout}
        optimizerSwitch: ${mysqlConfigurationVariablesOptimizerSwitch}
        parserMaxMemSize: ${mysqlConfigurationVariablesParserMaxMemSize}
        queryAllocBlockSize: ${mysqlConfigurationVariablesQueryAllocBlockSize}
        queryPreallocSize: ${mysqlConfigurationVariablesQueryPreallocSize}
        rangeOptimizerMaxMemSize: ${mysqlConfigurationVariablesRangeOptimizerMaxMemSize}
        regexpTimeLimit: ${mysqlConfigurationVariablesRegexpTimeLimit}
        relayLogSpaceLimit: ${mysqlConfigurationVariablesRelayLogSpaceLimit}
        replicaNetTimeout: ${mysqlConfigurationVariablesReplicaNetTimeout}
        replicaParallelWorkers: ${mysqlConfigurationVariablesReplicaParallelWorkers}
        replicaTypeConversions: ${mysqlConfigurationVariablesReplicaTypeConversions}
        requireSecureTransport: ${mysqlConfigurationVariablesRequireSecureTransport}
        skipNameResolve: ${mysqlConfigurationVariablesSkipNameResolve}
        sortBufferSize: ${mysqlConfigurationVariablesSortBufferSize}
        sqlGenerateInvisiblePrimaryKey: ${mysqlConfigurationVariablesSqlGenerateInvisiblePrimaryKey}
        sqlMode: ${mysqlConfigurationVariablesSqlMode}
        sqlRequirePrimaryKey: ${mysqlConfigurationVariablesSqlRequirePrimaryKey}
        sqlWarnings: ${mysqlConfigurationVariablesSqlWarnings}
        tableDefinitionCache: ${mysqlConfigurationVariablesTableDefinitionCache}
        tableOpenCache: ${mysqlConfigurationVariablesTableOpenCache}
        temptableMaxRam: ${mysqlConfigurationVariablesTemptableMaxRam}
        threadPoolDedicatedListeners: ${mysqlConfigurationVariablesThreadPoolDedicatedListeners}
        threadPoolMaxTransactionsLimit: ${mysqlConfigurationVariablesThreadPoolMaxTransactionsLimit}
        threadPoolQueryThreadsPerGroup: ${mysqlConfigurationVariablesThreadPoolQueryThreadsPerGroup}
        threadPoolSize: ${mysqlConfigurationVariablesThreadPoolSize}
        threadPoolTransactionDelay: ${mysqlConfigurationVariablesThreadPoolTransactionDelay}
        timeZone: ${mysqlConfigurationVariablesTimeZone}
        tmpTableSize: ${mysqlConfigurationVariablesTmpTableSize}
        transactionIsolation: ${mysqlConfigurationVariablesTransactionIsolation}
        waitTimeout: ${mysqlConfigurationVariablesWaitTimeout}
Copy

Create MysqlConfiguration Resource

Resources are created with functions called constructors. To learn more about declaring and configuring resources, see Resources.

Constructor syntax

new MysqlConfiguration(name: string, args: MysqlConfigurationArgs, opts?: CustomResourceOptions);
@overload
def MysqlConfiguration(resource_name: str,
                       args: MysqlConfigurationArgs,
                       opts: Optional[ResourceOptions] = None)

@overload
def MysqlConfiguration(resource_name: str,
                       opts: Optional[ResourceOptions] = None,
                       compartment_id: Optional[str] = None,
                       shape_name: Optional[str] = None,
                       defined_tags: Optional[Mapping[str, str]] = None,
                       description: Optional[str] = None,
                       display_name: Optional[str] = None,
                       freeform_tags: Optional[Mapping[str, str]] = None,
                       init_variables: Optional[_mysql.MysqlConfigurationInitVariablesArgs] = None,
                       parent_configuration_id: Optional[str] = None,
                       variables: Optional[_mysql.MysqlConfigurationVariablesArgs] = None)
func NewMysqlConfiguration(ctx *Context, name string, args MysqlConfigurationArgs, opts ...ResourceOption) (*MysqlConfiguration, error)
public MysqlConfiguration(string name, MysqlConfigurationArgs args, CustomResourceOptions? opts = null)
public MysqlConfiguration(String name, MysqlConfigurationArgs args)
public MysqlConfiguration(String name, MysqlConfigurationArgs args, CustomResourceOptions options)
type: oci:Mysql:MysqlConfiguration
properties: # The arguments to resource properties.
options: # Bag of options to control resource's behavior.

Parameters

name This property is required. string
The unique name of the resource.
args This property is required. MysqlConfigurationArgs
The arguments to resource properties.
opts CustomResourceOptions
Bag of options to control resource's behavior.
resource_name This property is required. str
The unique name of the resource.
args This property is required. MysqlConfigurationArgs
The arguments to resource properties.
opts ResourceOptions
Bag of options to control resource's behavior.
ctx Context
Context object for the current deployment.
name This property is required. string
The unique name of the resource.
args This property is required. MysqlConfigurationArgs
The arguments to resource properties.
opts ResourceOption
Bag of options to control resource's behavior.
name This property is required. string
The unique name of the resource.
args This property is required. MysqlConfigurationArgs
The arguments to resource properties.
opts CustomResourceOptions
Bag of options to control resource's behavior.
name This property is required. String
The unique name of the resource.
args This property is required. MysqlConfigurationArgs
The arguments to resource properties.
options CustomResourceOptions
Bag of options to control resource's behavior.

Constructor example

The following reference example uses placeholder values for all input properties.

var mysqlConfigurationResource = new Oci.Mysql.MysqlConfiguration("mysqlConfigurationResource", new()
{
    CompartmentId = "string",
    ShapeName = "string",
    DefinedTags = 
    {
        { "string", "string" },
    },
    Description = "string",
    DisplayName = "string",
    FreeformTags = 
    {
        { "string", "string" },
    },
    InitVariables = new Oci.Mysql.Inputs.MysqlConfigurationInitVariablesArgs
    {
        LowerCaseTableNames = "string",
    },
    ParentConfigurationId = "string",
    Variables = new Oci.Mysql.Inputs.MysqlConfigurationVariablesArgs
    {
        AutoIncrementIncrement = 0,
        AutoIncrementOffset = 0,
        Autocommit = false,
        BigTables = false,
        BinlogExpireLogsSeconds = 0,
        BinlogGroupCommitSyncDelay = 0,
        BinlogGroupCommitSyncNoDelayCount = 0,
        BinlogRowMetadata = "string",
        BinlogRowValueOptions = "string",
        BinlogTransactionCompression = false,
        BlockEncryptionMode = "string",
        CharacterSetServer = "string",
        CollationServer = "string",
        CompletionType = "string",
        ConnectTimeout = 0,
        ConnectionMemoryChunkSize = 0,
        ConnectionMemoryLimit = "string",
        CteMaxRecursionDepth = "string",
        DefaultAuthenticationPlugin = "string",
        ExplainFormat = "string",
        ExplicitDefaultsForTimestamp = false,
        ForeignKeyChecks = false,
        GlobalConnectionMemoryLimit = "string",
        GlobalConnectionMemoryTracking = false,
        GroupConcatMaxLen = "string",
        GroupReplicationConsistency = "string",
        InformationSchemaStatsExpiry = 0,
        InnodbAdaptiveHashIndex = false,
        InnodbAutoincLockMode = 0,
        InnodbBufferPoolDumpPct = 0,
        InnodbBufferPoolInstances = 0,
        InnodbBufferPoolSize = "string",
        InnodbChangeBuffering = "string",
        InnodbDdlBufferSize = "string",
        InnodbDdlThreads = 0,
        InnodbFtEnableStopword = false,
        InnodbFtMaxTokenSize = 0,
        InnodbFtMinTokenSize = 0,
        InnodbFtNumWordOptimize = 0,
        InnodbFtResultCacheLimit = "string",
        InnodbFtServerStopwordTable = "string",
        InnodbLockWaitTimeout = 0,
        InnodbLogWriterThreads = false,
        InnodbMaxPurgeLag = "string",
        InnodbMaxPurgeLagDelay = 0,
        InnodbNumaInterleave = false,
        InnodbOnlineAlterLogMaxSize = "string",
        InnodbRedoLogCapacity = "string",
        InnodbRollbackOnTimeout = false,
        InnodbSortBufferSize = 0,
        InnodbStatsPersistentSamplePages = "string",
        InnodbStatsTransientSamplePages = "string",
        InnodbStrictMode = false,
        InnodbUndoLogTruncate = false,
        InteractiveTimeout = 0,
        JoinBufferSize = "string",
        LocalInfile = false,
        LongQueryTime = 0,
        MandatoryRoles = "string",
        MaxAllowedPacket = 0,
        MaxBinlogCacheSize = "string",
        MaxConnectErrors = "string",
        MaxConnections = 0,
        MaxExecutionTime = "string",
        MaxHeapTableSize = "string",
        MaxPreparedStmtCount = 0,
        MaxSeeksForKey = "string",
        MaxUserConnections = "string",
        MysqlFirewallMode = false,
        MysqlxConnectTimeout = 0,
        MysqlxDeflateDefaultCompressionLevel = 0,
        MysqlxDeflateMaxClientCompressionLevel = 0,
        MysqlxEnableHelloNotice = false,
        MysqlxInteractiveTimeout = 0,
        MysqlxLz4defaultCompressionLevel = 0,
        MysqlxLz4maxClientCompressionLevel = 0,
        MysqlxMaxAllowedPacket = 0,
        MysqlxReadTimeout = 0,
        MysqlxWaitTimeout = 0,
        MysqlxWriteTimeout = 0,
        MysqlxZstdDefaultCompressionLevel = 0,
        MysqlxZstdMaxClientCompressionLevel = 0,
        NetReadTimeout = 0,
        NetWriteTimeout = 0,
        OptimizerSwitch = "string",
        ParserMaxMemSize = "string",
        QueryPreallocSize = "string",
        RegexpTimeLimit = 0,
        RelayLogSpaceLimit = "string",
        ReplicaNetTimeout = 0,
        ReplicaParallelWorkers = 0,
        ReplicaTypeConversions = "string",
        RequireSecureTransport = false,
        SkipNameResolve = false,
        SortBufferSize = "string",
        SqlGenerateInvisiblePrimaryKey = false,
        SqlMode = "string",
        SqlRequirePrimaryKey = false,
        SqlWarnings = false,
        TableDefinitionCache = 0,
        TableOpenCache = 0,
        TemptableMaxRam = "string",
        ThreadPoolDedicatedListeners = false,
        ThreadPoolMaxTransactionsLimit = 0,
        ThreadPoolQueryThreadsPerGroup = 0,
        ThreadPoolSize = 0,
        ThreadPoolTransactionDelay = 0,
        TimeZone = "string",
        TmpTableSize = "string",
        TransactionIsolation = "string",
        WaitTimeout = 0,
    },
});
Copy
example, err := Mysql.NewMysqlConfiguration(ctx, "mysqlConfigurationResource", &Mysql.MysqlConfigurationArgs{
	CompartmentId: pulumi.String("string"),
	ShapeName:     pulumi.String("string"),
	DefinedTags: pulumi.StringMap{
		"string": pulumi.String("string"),
	},
	Description: pulumi.String("string"),
	DisplayName: pulumi.String("string"),
	FreeformTags: pulumi.StringMap{
		"string": pulumi.String("string"),
	},
	InitVariables: &mysql.MysqlConfigurationInitVariablesArgs{
		LowerCaseTableNames: pulumi.String("string"),
	},
	ParentConfigurationId: pulumi.String("string"),
	Variables: &mysql.MysqlConfigurationVariablesArgs{
		AutoIncrementIncrement:                 pulumi.Int(0),
		AutoIncrementOffset:                    pulumi.Int(0),
		Autocommit:                             pulumi.Bool(false),
		BigTables:                              pulumi.Bool(false),
		BinlogExpireLogsSeconds:                pulumi.Int(0),
		BinlogGroupCommitSyncDelay:             pulumi.Int(0),
		BinlogGroupCommitSyncNoDelayCount:      pulumi.Int(0),
		BinlogRowMetadata:                      pulumi.String("string"),
		BinlogRowValueOptions:                  pulumi.String("string"),
		BinlogTransactionCompression:           pulumi.Bool(false),
		BlockEncryptionMode:                    pulumi.String("string"),
		CharacterSetServer:                     pulumi.String("string"),
		CollationServer:                        pulumi.String("string"),
		CompletionType:                         pulumi.String("string"),
		ConnectTimeout:                         pulumi.Int(0),
		ConnectionMemoryChunkSize:              pulumi.Int(0),
		ConnectionMemoryLimit:                  pulumi.String("string"),
		CteMaxRecursionDepth:                   pulumi.String("string"),
		DefaultAuthenticationPlugin:            pulumi.String("string"),
		ExplainFormat:                          pulumi.String("string"),
		ExplicitDefaultsForTimestamp:           pulumi.Bool(false),
		ForeignKeyChecks:                       pulumi.Bool(false),
		GlobalConnectionMemoryLimit:            pulumi.String("string"),
		GlobalConnectionMemoryTracking:         pulumi.Bool(false),
		GroupConcatMaxLen:                      pulumi.String("string"),
		GroupReplicationConsistency:            pulumi.String("string"),
		InformationSchemaStatsExpiry:           pulumi.Int(0),
		InnodbAdaptiveHashIndex:                pulumi.Bool(false),
		InnodbAutoincLockMode:                  pulumi.Int(0),
		InnodbBufferPoolDumpPct:                pulumi.Int(0),
		InnodbBufferPoolInstances:              pulumi.Int(0),
		InnodbBufferPoolSize:                   pulumi.String("string"),
		InnodbChangeBuffering:                  pulumi.String("string"),
		InnodbDdlBufferSize:                    pulumi.String("string"),
		InnodbDdlThreads:                       pulumi.Int(0),
		InnodbFtEnableStopword:                 pulumi.Bool(false),
		InnodbFtMaxTokenSize:                   pulumi.Int(0),
		InnodbFtMinTokenSize:                   pulumi.Int(0),
		InnodbFtNumWordOptimize:                pulumi.Int(0),
		InnodbFtResultCacheLimit:               pulumi.String("string"),
		InnodbFtServerStopwordTable:            pulumi.String("string"),
		InnodbLockWaitTimeout:                  pulumi.Int(0),
		InnodbLogWriterThreads:                 pulumi.Bool(false),
		InnodbMaxPurgeLag:                      pulumi.String("string"),
		InnodbMaxPurgeLagDelay:                 pulumi.Int(0),
		InnodbNumaInterleave:                   pulumi.Bool(false),
		InnodbOnlineAlterLogMaxSize:            pulumi.String("string"),
		InnodbRedoLogCapacity:                  pulumi.String("string"),
		InnodbRollbackOnTimeout:                pulumi.Bool(false),
		InnodbSortBufferSize:                   pulumi.Int(0),
		InnodbStatsPersistentSamplePages:       pulumi.String("string"),
		InnodbStatsTransientSamplePages:        pulumi.String("string"),
		InnodbStrictMode:                       pulumi.Bool(false),
		InnodbUndoLogTruncate:                  pulumi.Bool(false),
		InteractiveTimeout:                     pulumi.Int(0),
		JoinBufferSize:                         pulumi.String("string"),
		LocalInfile:                            pulumi.Bool(false),
		LongQueryTime:                          pulumi.Int(0),
		MandatoryRoles:                         pulumi.String("string"),
		MaxAllowedPacket:                       pulumi.Int(0),
		MaxBinlogCacheSize:                     pulumi.String("string"),
		MaxConnectErrors:                       pulumi.String("string"),
		MaxConnections:                         pulumi.Int(0),
		MaxExecutionTime:                       pulumi.String("string"),
		MaxHeapTableSize:                       pulumi.String("string"),
		MaxPreparedStmtCount:                   pulumi.Int(0),
		MaxSeeksForKey:                         pulumi.String("string"),
		MaxUserConnections:                     pulumi.String("string"),
		MysqlFirewallMode:                      pulumi.Bool(false),
		MysqlxConnectTimeout:                   pulumi.Int(0),
		MysqlxDeflateDefaultCompressionLevel:   pulumi.Int(0),
		MysqlxDeflateMaxClientCompressionLevel: pulumi.Int(0),
		MysqlxEnableHelloNotice:                pulumi.Bool(false),
		MysqlxInteractiveTimeout:               pulumi.Int(0),
		MysqlxLz4defaultCompressionLevel:       pulumi.Int(0),
		MysqlxLz4maxClientCompressionLevel:     pulumi.Int(0),
		MysqlxMaxAllowedPacket:                 pulumi.Int(0),
		MysqlxReadTimeout:                      pulumi.Int(0),
		MysqlxWaitTimeout:                      pulumi.Int(0),
		MysqlxWriteTimeout:                     pulumi.Int(0),
		MysqlxZstdDefaultCompressionLevel:      pulumi.Int(0),
		MysqlxZstdMaxClientCompressionLevel:    pulumi.Int(0),
		NetReadTimeout:                         pulumi.Int(0),
		NetWriteTimeout:                        pulumi.Int(0),
		OptimizerSwitch:                        pulumi.String("string"),
		ParserMaxMemSize:                       pulumi.String("string"),
		QueryPreallocSize:                      pulumi.String("string"),
		RegexpTimeLimit:                        pulumi.Int(0),
		RelayLogSpaceLimit:                     pulumi.String("string"),
		ReplicaNetTimeout:                      pulumi.Int(0),
		ReplicaParallelWorkers:                 pulumi.Int(0),
		ReplicaTypeConversions:                 pulumi.String("string"),
		RequireSecureTransport:                 pulumi.Bool(false),
		SkipNameResolve:                        pulumi.Bool(false),
		SortBufferSize:                         pulumi.String("string"),
		SqlGenerateInvisiblePrimaryKey:         pulumi.Bool(false),
		SqlMode:                                pulumi.String("string"),
		SqlRequirePrimaryKey:                   pulumi.Bool(false),
		SqlWarnings:                            pulumi.Bool(false),
		TableDefinitionCache:                   pulumi.Int(0),
		TableOpenCache:                         pulumi.Int(0),
		TemptableMaxRam:                        pulumi.String("string"),
		ThreadPoolDedicatedListeners:           pulumi.Bool(false),
		ThreadPoolMaxTransactionsLimit:         pulumi.Int(0),
		ThreadPoolQueryThreadsPerGroup:         pulumi.Int(0),
		ThreadPoolSize:                         pulumi.Int(0),
		ThreadPoolTransactionDelay:             pulumi.Int(0),
		TimeZone:                               pulumi.String("string"),
		TmpTableSize:                           pulumi.String("string"),
		TransactionIsolation:                   pulumi.String("string"),
		WaitTimeout:                            pulumi.Int(0),
	},
})
Copy
var mysqlConfigurationResource = new MysqlConfiguration("mysqlConfigurationResource", MysqlConfigurationArgs.builder()
    .compartmentId("string")
    .shapeName("string")
    .definedTags(Map.of("string", "string"))
    .description("string")
    .displayName("string")
    .freeformTags(Map.of("string", "string"))
    .initVariables(MysqlConfigurationInitVariablesArgs.builder()
        .lowerCaseTableNames("string")
        .build())
    .parentConfigurationId("string")
    .variables(MysqlConfigurationVariablesArgs.builder()
        .autoIncrementIncrement(0)
        .autoIncrementOffset(0)
        .autocommit(false)
        .bigTables(false)
        .binlogExpireLogsSeconds(0)
        .binlogGroupCommitSyncDelay(0)
        .binlogGroupCommitSyncNoDelayCount(0)
        .binlogRowMetadata("string")
        .binlogRowValueOptions("string")
        .binlogTransactionCompression(false)
        .blockEncryptionMode("string")
        .characterSetServer("string")
        .collationServer("string")
        .completionType("string")
        .connectTimeout(0)
        .connectionMemoryChunkSize(0)
        .connectionMemoryLimit("string")
        .cteMaxRecursionDepth("string")
        .defaultAuthenticationPlugin("string")
        .explainFormat("string")
        .explicitDefaultsForTimestamp(false)
        .foreignKeyChecks(false)
        .globalConnectionMemoryLimit("string")
        .globalConnectionMemoryTracking(false)
        .groupConcatMaxLen("string")
        .groupReplicationConsistency("string")
        .informationSchemaStatsExpiry(0)
        .innodbAdaptiveHashIndex(false)
        .innodbAutoincLockMode(0)
        .innodbBufferPoolDumpPct(0)
        .innodbBufferPoolInstances(0)
        .innodbBufferPoolSize("string")
        .innodbChangeBuffering("string")
        .innodbDdlBufferSize("string")
        .innodbDdlThreads(0)
        .innodbFtEnableStopword(false)
        .innodbFtMaxTokenSize(0)
        .innodbFtMinTokenSize(0)
        .innodbFtNumWordOptimize(0)
        .innodbFtResultCacheLimit("string")
        .innodbFtServerStopwordTable("string")
        .innodbLockWaitTimeout(0)
        .innodbLogWriterThreads(false)
        .innodbMaxPurgeLag("string")
        .innodbMaxPurgeLagDelay(0)
        .innodbNumaInterleave(false)
        .innodbOnlineAlterLogMaxSize("string")
        .innodbRedoLogCapacity("string")
        .innodbRollbackOnTimeout(false)
        .innodbSortBufferSize(0)
        .innodbStatsPersistentSamplePages("string")
        .innodbStatsTransientSamplePages("string")
        .innodbStrictMode(false)
        .innodbUndoLogTruncate(false)
        .interactiveTimeout(0)
        .joinBufferSize("string")
        .localInfile(false)
        .longQueryTime(0)
        .mandatoryRoles("string")
        .maxAllowedPacket(0)
        .maxBinlogCacheSize("string")
        .maxConnectErrors("string")
        .maxConnections(0)
        .maxExecutionTime("string")
        .maxHeapTableSize("string")
        .maxPreparedStmtCount(0)
        .maxSeeksForKey("string")
        .maxUserConnections("string")
        .mysqlFirewallMode(false)
        .mysqlxConnectTimeout(0)
        .mysqlxDeflateDefaultCompressionLevel(0)
        .mysqlxDeflateMaxClientCompressionLevel(0)
        .mysqlxEnableHelloNotice(false)
        .mysqlxInteractiveTimeout(0)
        .mysqlxLz4defaultCompressionLevel(0)
        .mysqlxLz4maxClientCompressionLevel(0)
        .mysqlxMaxAllowedPacket(0)
        .mysqlxReadTimeout(0)
        .mysqlxWaitTimeout(0)
        .mysqlxWriteTimeout(0)
        .mysqlxZstdDefaultCompressionLevel(0)
        .mysqlxZstdMaxClientCompressionLevel(0)
        .netReadTimeout(0)
        .netWriteTimeout(0)
        .optimizerSwitch("string")
        .parserMaxMemSize("string")
        .queryPreallocSize("string")
        .regexpTimeLimit(0)
        .relayLogSpaceLimit("string")
        .replicaNetTimeout(0)
        .replicaParallelWorkers(0)
        .replicaTypeConversions("string")
        .requireSecureTransport(false)
        .skipNameResolve(false)
        .sortBufferSize("string")
        .sqlGenerateInvisiblePrimaryKey(false)
        .sqlMode("string")
        .sqlRequirePrimaryKey(false)
        .sqlWarnings(false)
        .tableDefinitionCache(0)
        .tableOpenCache(0)
        .temptableMaxRam("string")
        .threadPoolDedicatedListeners(false)
        .threadPoolMaxTransactionsLimit(0)
        .threadPoolQueryThreadsPerGroup(0)
        .threadPoolSize(0)
        .threadPoolTransactionDelay(0)
        .timeZone("string")
        .tmpTableSize("string")
        .transactionIsolation("string")
        .waitTimeout(0)
        .build())
    .build());
Copy
mysql_configuration_resource = oci.mysql.MysqlConfiguration("mysqlConfigurationResource",
    compartment_id="string",
    shape_name="string",
    defined_tags={
        "string": "string",
    },
    description="string",
    display_name="string",
    freeform_tags={
        "string": "string",
    },
    init_variables={
        "lower_case_table_names": "string",
    },
    parent_configuration_id="string",
    variables={
        "auto_increment_increment": 0,
        "auto_increment_offset": 0,
        "autocommit": False,
        "big_tables": False,
        "binlog_expire_logs_seconds": 0,
        "binlog_group_commit_sync_delay": 0,
        "binlog_group_commit_sync_no_delay_count": 0,
        "binlog_row_metadata": "string",
        "binlog_row_value_options": "string",
        "binlog_transaction_compression": False,
        "block_encryption_mode": "string",
        "character_set_server": "string",
        "collation_server": "string",
        "completion_type": "string",
        "connect_timeout": 0,
        "connection_memory_chunk_size": 0,
        "connection_memory_limit": "string",
        "cte_max_recursion_depth": "string",
        "default_authentication_plugin": "string",
        "explain_format": "string",
        "explicit_defaults_for_timestamp": False,
        "foreign_key_checks": False,
        "global_connection_memory_limit": "string",
        "global_connection_memory_tracking": False,
        "group_concat_max_len": "string",
        "group_replication_consistency": "string",
        "information_schema_stats_expiry": 0,
        "innodb_adaptive_hash_index": False,
        "innodb_autoinc_lock_mode": 0,
        "innodb_buffer_pool_dump_pct": 0,
        "innodb_buffer_pool_instances": 0,
        "innodb_buffer_pool_size": "string",
        "innodb_change_buffering": "string",
        "innodb_ddl_buffer_size": "string",
        "innodb_ddl_threads": 0,
        "innodb_ft_enable_stopword": False,
        "innodb_ft_max_token_size": 0,
        "innodb_ft_min_token_size": 0,
        "innodb_ft_num_word_optimize": 0,
        "innodb_ft_result_cache_limit": "string",
        "innodb_ft_server_stopword_table": "string",
        "innodb_lock_wait_timeout": 0,
        "innodb_log_writer_threads": False,
        "innodb_max_purge_lag": "string",
        "innodb_max_purge_lag_delay": 0,
        "innodb_numa_interleave": False,
        "innodb_online_alter_log_max_size": "string",
        "innodb_redo_log_capacity": "string",
        "innodb_rollback_on_timeout": False,
        "innodb_sort_buffer_size": 0,
        "innodb_stats_persistent_sample_pages": "string",
        "innodb_stats_transient_sample_pages": "string",
        "innodb_strict_mode": False,
        "innodb_undo_log_truncate": False,
        "interactive_timeout": 0,
        "join_buffer_size": "string",
        "local_infile": False,
        "long_query_time": 0,
        "mandatory_roles": "string",
        "max_allowed_packet": 0,
        "max_binlog_cache_size": "string",
        "max_connect_errors": "string",
        "max_connections": 0,
        "max_execution_time": "string",
        "max_heap_table_size": "string",
        "max_prepared_stmt_count": 0,
        "max_seeks_for_key": "string",
        "max_user_connections": "string",
        "mysql_firewall_mode": False,
        "mysqlx_connect_timeout": 0,
        "mysqlx_deflate_default_compression_level": 0,
        "mysqlx_deflate_max_client_compression_level": 0,
        "mysqlx_enable_hello_notice": False,
        "mysqlx_interactive_timeout": 0,
        "mysqlx_lz4default_compression_level": 0,
        "mysqlx_lz4max_client_compression_level": 0,
        "mysqlx_max_allowed_packet": 0,
        "mysqlx_read_timeout": 0,
        "mysqlx_wait_timeout": 0,
        "mysqlx_write_timeout": 0,
        "mysqlx_zstd_default_compression_level": 0,
        "mysqlx_zstd_max_client_compression_level": 0,
        "net_read_timeout": 0,
        "net_write_timeout": 0,
        "optimizer_switch": "string",
        "parser_max_mem_size": "string",
        "query_prealloc_size": "string",
        "regexp_time_limit": 0,
        "relay_log_space_limit": "string",
        "replica_net_timeout": 0,
        "replica_parallel_workers": 0,
        "replica_type_conversions": "string",
        "require_secure_transport": False,
        "skip_name_resolve": False,
        "sort_buffer_size": "string",
        "sql_generate_invisible_primary_key": False,
        "sql_mode": "string",
        "sql_require_primary_key": False,
        "sql_warnings": False,
        "table_definition_cache": 0,
        "table_open_cache": 0,
        "temptable_max_ram": "string",
        "thread_pool_dedicated_listeners": False,
        "thread_pool_max_transactions_limit": 0,
        "thread_pool_query_threads_per_group": 0,
        "thread_pool_size": 0,
        "thread_pool_transaction_delay": 0,
        "time_zone": "string",
        "tmp_table_size": "string",
        "transaction_isolation": "string",
        "wait_timeout": 0,
    })
Copy
const mysqlConfigurationResource = new oci.mysql.MysqlConfiguration("mysqlConfigurationResource", {
    compartmentId: "string",
    shapeName: "string",
    definedTags: {
        string: "string",
    },
    description: "string",
    displayName: "string",
    freeformTags: {
        string: "string",
    },
    initVariables: {
        lowerCaseTableNames: "string",
    },
    parentConfigurationId: "string",
    variables: {
        autoIncrementIncrement: 0,
        autoIncrementOffset: 0,
        autocommit: false,
        bigTables: false,
        binlogExpireLogsSeconds: 0,
        binlogGroupCommitSyncDelay: 0,
        binlogGroupCommitSyncNoDelayCount: 0,
        binlogRowMetadata: "string",
        binlogRowValueOptions: "string",
        binlogTransactionCompression: false,
        blockEncryptionMode: "string",
        characterSetServer: "string",
        collationServer: "string",
        completionType: "string",
        connectTimeout: 0,
        connectionMemoryChunkSize: 0,
        connectionMemoryLimit: "string",
        cteMaxRecursionDepth: "string",
        defaultAuthenticationPlugin: "string",
        explainFormat: "string",
        explicitDefaultsForTimestamp: false,
        foreignKeyChecks: false,
        globalConnectionMemoryLimit: "string",
        globalConnectionMemoryTracking: false,
        groupConcatMaxLen: "string",
        groupReplicationConsistency: "string",
        informationSchemaStatsExpiry: 0,
        innodbAdaptiveHashIndex: false,
        innodbAutoincLockMode: 0,
        innodbBufferPoolDumpPct: 0,
        innodbBufferPoolInstances: 0,
        innodbBufferPoolSize: "string",
        innodbChangeBuffering: "string",
        innodbDdlBufferSize: "string",
        innodbDdlThreads: 0,
        innodbFtEnableStopword: false,
        innodbFtMaxTokenSize: 0,
        innodbFtMinTokenSize: 0,
        innodbFtNumWordOptimize: 0,
        innodbFtResultCacheLimit: "string",
        innodbFtServerStopwordTable: "string",
        innodbLockWaitTimeout: 0,
        innodbLogWriterThreads: false,
        innodbMaxPurgeLag: "string",
        innodbMaxPurgeLagDelay: 0,
        innodbNumaInterleave: false,
        innodbOnlineAlterLogMaxSize: "string",
        innodbRedoLogCapacity: "string",
        innodbRollbackOnTimeout: false,
        innodbSortBufferSize: 0,
        innodbStatsPersistentSamplePages: "string",
        innodbStatsTransientSamplePages: "string",
        innodbStrictMode: false,
        innodbUndoLogTruncate: false,
        interactiveTimeout: 0,
        joinBufferSize: "string",
        localInfile: false,
        longQueryTime: 0,
        mandatoryRoles: "string",
        maxAllowedPacket: 0,
        maxBinlogCacheSize: "string",
        maxConnectErrors: "string",
        maxConnections: 0,
        maxExecutionTime: "string",
        maxHeapTableSize: "string",
        maxPreparedStmtCount: 0,
        maxSeeksForKey: "string",
        maxUserConnections: "string",
        mysqlFirewallMode: false,
        mysqlxConnectTimeout: 0,
        mysqlxDeflateDefaultCompressionLevel: 0,
        mysqlxDeflateMaxClientCompressionLevel: 0,
        mysqlxEnableHelloNotice: false,
        mysqlxInteractiveTimeout: 0,
        mysqlxLz4defaultCompressionLevel: 0,
        mysqlxLz4maxClientCompressionLevel: 0,
        mysqlxMaxAllowedPacket: 0,
        mysqlxReadTimeout: 0,
        mysqlxWaitTimeout: 0,
        mysqlxWriteTimeout: 0,
        mysqlxZstdDefaultCompressionLevel: 0,
        mysqlxZstdMaxClientCompressionLevel: 0,
        netReadTimeout: 0,
        netWriteTimeout: 0,
        optimizerSwitch: "string",
        parserMaxMemSize: "string",
        queryPreallocSize: "string",
        regexpTimeLimit: 0,
        relayLogSpaceLimit: "string",
        replicaNetTimeout: 0,
        replicaParallelWorkers: 0,
        replicaTypeConversions: "string",
        requireSecureTransport: false,
        skipNameResolve: false,
        sortBufferSize: "string",
        sqlGenerateInvisiblePrimaryKey: false,
        sqlMode: "string",
        sqlRequirePrimaryKey: false,
        sqlWarnings: false,
        tableDefinitionCache: 0,
        tableOpenCache: 0,
        temptableMaxRam: "string",
        threadPoolDedicatedListeners: false,
        threadPoolMaxTransactionsLimit: 0,
        threadPoolQueryThreadsPerGroup: 0,
        threadPoolSize: 0,
        threadPoolTransactionDelay: 0,
        timeZone: "string",
        tmpTableSize: "string",
        transactionIsolation: "string",
        waitTimeout: 0,
    },
});
Copy
type: oci:Mysql:MysqlConfiguration
properties:
    compartmentId: string
    definedTags:
        string: string
    description: string
    displayName: string
    freeformTags:
        string: string
    initVariables:
        lowerCaseTableNames: string
    parentConfigurationId: string
    shapeName: string
    variables:
        autoIncrementIncrement: 0
        autoIncrementOffset: 0
        autocommit: false
        bigTables: false
        binlogExpireLogsSeconds: 0
        binlogGroupCommitSyncDelay: 0
        binlogGroupCommitSyncNoDelayCount: 0
        binlogRowMetadata: string
        binlogRowValueOptions: string
        binlogTransactionCompression: false
        blockEncryptionMode: string
        characterSetServer: string
        collationServer: string
        completionType: string
        connectTimeout: 0
        connectionMemoryChunkSize: 0
        connectionMemoryLimit: string
        cteMaxRecursionDepth: string
        defaultAuthenticationPlugin: string
        explainFormat: string
        explicitDefaultsForTimestamp: false
        foreignKeyChecks: false
        globalConnectionMemoryLimit: string
        globalConnectionMemoryTracking: false
        groupConcatMaxLen: string
        groupReplicationConsistency: string
        informationSchemaStatsExpiry: 0
        innodbAdaptiveHashIndex: false
        innodbAutoincLockMode: 0
        innodbBufferPoolDumpPct: 0
        innodbBufferPoolInstances: 0
        innodbBufferPoolSize: string
        innodbChangeBuffering: string
        innodbDdlBufferSize: string
        innodbDdlThreads: 0
        innodbFtEnableStopword: false
        innodbFtMaxTokenSize: 0
        innodbFtMinTokenSize: 0
        innodbFtNumWordOptimize: 0
        innodbFtResultCacheLimit: string
        innodbFtServerStopwordTable: string
        innodbLockWaitTimeout: 0
        innodbLogWriterThreads: false
        innodbMaxPurgeLag: string
        innodbMaxPurgeLagDelay: 0
        innodbNumaInterleave: false
        innodbOnlineAlterLogMaxSize: string
        innodbRedoLogCapacity: string
        innodbRollbackOnTimeout: false
        innodbSortBufferSize: 0
        innodbStatsPersistentSamplePages: string
        innodbStatsTransientSamplePages: string
        innodbStrictMode: false
        innodbUndoLogTruncate: false
        interactiveTimeout: 0
        joinBufferSize: string
        localInfile: false
        longQueryTime: 0
        mandatoryRoles: string
        maxAllowedPacket: 0
        maxBinlogCacheSize: string
        maxConnectErrors: string
        maxConnections: 0
        maxExecutionTime: string
        maxHeapTableSize: string
        maxPreparedStmtCount: 0
        maxSeeksForKey: string
        maxUserConnections: string
        mysqlFirewallMode: false
        mysqlxConnectTimeout: 0
        mysqlxDeflateDefaultCompressionLevel: 0
        mysqlxDeflateMaxClientCompressionLevel: 0
        mysqlxEnableHelloNotice: false
        mysqlxInteractiveTimeout: 0
        mysqlxLz4defaultCompressionLevel: 0
        mysqlxLz4maxClientCompressionLevel: 0
        mysqlxMaxAllowedPacket: 0
        mysqlxReadTimeout: 0
        mysqlxWaitTimeout: 0
        mysqlxWriteTimeout: 0
        mysqlxZstdDefaultCompressionLevel: 0
        mysqlxZstdMaxClientCompressionLevel: 0
        netReadTimeout: 0
        netWriteTimeout: 0
        optimizerSwitch: string
        parserMaxMemSize: string
        queryPreallocSize: string
        regexpTimeLimit: 0
        relayLogSpaceLimit: string
        replicaNetTimeout: 0
        replicaParallelWorkers: 0
        replicaTypeConversions: string
        requireSecureTransport: false
        skipNameResolve: false
        sortBufferSize: string
        sqlGenerateInvisiblePrimaryKey: false
        sqlMode: string
        sqlRequirePrimaryKey: false
        sqlWarnings: false
        tableDefinitionCache: 0
        tableOpenCache: 0
        temptableMaxRam: string
        threadPoolDedicatedListeners: false
        threadPoolMaxTransactionsLimit: 0
        threadPoolQueryThreadsPerGroup: 0
        threadPoolSize: 0
        threadPoolTransactionDelay: 0
        timeZone: string
        tmpTableSize: string
        transactionIsolation: string
        waitTimeout: 0
Copy

MysqlConfiguration Resource Properties

To learn more about resource properties and how to use them, see Inputs and Outputs in the Architecture and Concepts docs.

Inputs

In Python, inputs that are objects can be passed either as argument classes or as dictionary literals.

The MysqlConfiguration resource accepts the following input properties:

CompartmentId
This property is required.
Changes to this property will trigger replacement.
string
The OCID of the compartment.
ShapeName
This property is required.
Changes to this property will trigger replacement.
string
The name of the associated Shape.
DefinedTags Dictionary<string, string>
(Updatable) Defined tags for this resource. Each key is predefined and scoped to a namespace. Example: {"foo-namespace.bar-key": "value"}
Description string
(Updatable) User-provided data about the Configuration.
DisplayName string
(Updatable) The display name of the Configuration.
FreeformTags Dictionary<string, string>
(Updatable) Simple key-value pair that is applied without any predefined name, type or scope. Exists for cross-compatibility only. Example: {"bar-key": "value"}
InitVariables Changes to this property will trigger replacement. MysqlConfigurationInitVariables
User-defined service variables set only at DB system initialization. These variables cannot be changed later at runtime.
ParentConfigurationId Changes to this property will trigger replacement. string
The OCID of the Configuration from which the new Configuration is derived. The values in CreateConfigurationDetails.variables supersede the variables of the parent Configuration.
Variables Changes to this property will trigger replacement. MysqlConfigurationVariables
User-defined service variables.
CompartmentId
This property is required.
Changes to this property will trigger replacement.
string
The OCID of the compartment.
ShapeName
This property is required.
Changes to this property will trigger replacement.
string
The name of the associated Shape.
DefinedTags map[string]string
(Updatable) Defined tags for this resource. Each key is predefined and scoped to a namespace. Example: {"foo-namespace.bar-key": "value"}
Description string
(Updatable) User-provided data about the Configuration.
DisplayName string
(Updatable) The display name of the Configuration.
FreeformTags map[string]string
(Updatable) Simple key-value pair that is applied without any predefined name, type or scope. Exists for cross-compatibility only. Example: {"bar-key": "value"}
InitVariables Changes to this property will trigger replacement. MysqlConfigurationInitVariablesArgs
User-defined service variables set only at DB system initialization. These variables cannot be changed later at runtime.
ParentConfigurationId Changes to this property will trigger replacement. string
The OCID of the Configuration from which the new Configuration is derived. The values in CreateConfigurationDetails.variables supersede the variables of the parent Configuration.
Variables Changes to this property will trigger replacement. MysqlConfigurationVariablesArgs
User-defined service variables.
compartmentId
This property is required.
Changes to this property will trigger replacement.
String
The OCID of the compartment.
shapeName
This property is required.
Changes to this property will trigger replacement.
String
The name of the associated Shape.
definedTags Map<String,String>
(Updatable) Defined tags for this resource. Each key is predefined and scoped to a namespace. Example: {"foo-namespace.bar-key": "value"}
description String
(Updatable) User-provided data about the Configuration.
displayName String
(Updatable) The display name of the Configuration.
freeformTags Map<String,String>
(Updatable) Simple key-value pair that is applied without any predefined name, type or scope. Exists for cross-compatibility only. Example: {"bar-key": "value"}
initVariables Changes to this property will trigger replacement. ConfigurationInitVariables
User-defined service variables set only at DB system initialization. These variables cannot be changed later at runtime.
parentConfigurationId Changes to this property will trigger replacement. String
The OCID of the Configuration from which the new Configuration is derived. The values in CreateConfigurationDetails.variables supersede the variables of the parent Configuration.
variables Changes to this property will trigger replacement. ConfigurationVariables
User-defined service variables.
compartmentId
This property is required.
Changes to this property will trigger replacement.
string
The OCID of the compartment.
shapeName
This property is required.
Changes to this property will trigger replacement.
string
The name of the associated Shape.
definedTags {[key: string]: string}
(Updatable) Defined tags for this resource. Each key is predefined and scoped to a namespace. Example: {"foo-namespace.bar-key": "value"}
description string
(Updatable) User-provided data about the Configuration.
displayName string
(Updatable) The display name of the Configuration.
freeformTags {[key: string]: string}
(Updatable) Simple key-value pair that is applied without any predefined name, type or scope. Exists for cross-compatibility only. Example: {"bar-key": "value"}
initVariables Changes to this property will trigger replacement. MysqlConfigurationInitVariables
User-defined service variables set only at DB system initialization. These variables cannot be changed later at runtime.
parentConfigurationId Changes to this property will trigger replacement. string
The OCID of the Configuration from which the new Configuration is derived. The values in CreateConfigurationDetails.variables supersede the variables of the parent Configuration.
variables Changes to this property will trigger replacement. MysqlConfigurationVariables
User-defined service variables.
compartment_id
This property is required.
Changes to this property will trigger replacement.
str
The OCID of the compartment.
shape_name
This property is required.
Changes to this property will trigger replacement.
str
The name of the associated Shape.
defined_tags Mapping[str, str]
(Updatable) Defined tags for this resource. Each key is predefined and scoped to a namespace. Example: {"foo-namespace.bar-key": "value"}
description str
(Updatable) User-provided data about the Configuration.
display_name str
(Updatable) The display name of the Configuration.
freeform_tags Mapping[str, str]
(Updatable) Simple key-value pair that is applied without any predefined name, type or scope. Exists for cross-compatibility only. Example: {"bar-key": "value"}
init_variables Changes to this property will trigger replacement. mysql.MysqlConfigurationInitVariablesArgs
User-defined service variables set only at DB system initialization. These variables cannot be changed later at runtime.
parent_configuration_id Changes to this property will trigger replacement. str
The OCID of the Configuration from which the new Configuration is derived. The values in CreateConfigurationDetails.variables supersede the variables of the parent Configuration.
variables Changes to this property will trigger replacement. mysql.MysqlConfigurationVariablesArgs
User-defined service variables.
compartmentId
This property is required.
Changes to this property will trigger replacement.
String
The OCID of the compartment.
shapeName
This property is required.
Changes to this property will trigger replacement.
String
The name of the associated Shape.
definedTags Map<String>
(Updatable) Defined tags for this resource. Each key is predefined and scoped to a namespace. Example: {"foo-namespace.bar-key": "value"}
description String
(Updatable) User-provided data about the Configuration.
displayName String
(Updatable) The display name of the Configuration.
freeformTags Map<String>
(Updatable) Simple key-value pair that is applied without any predefined name, type or scope. Exists for cross-compatibility only. Example: {"bar-key": "value"}
initVariables Changes to this property will trigger replacement. Property Map
User-defined service variables set only at DB system initialization. These variables cannot be changed later at runtime.
parentConfigurationId Changes to this property will trigger replacement. String
The OCID of the Configuration from which the new Configuration is derived. The values in CreateConfigurationDetails.variables supersede the variables of the parent Configuration.
variables Changes to this property will trigger replacement. Property Map
User-defined service variables.

Outputs

All input properties are implicitly available as output properties. Additionally, the MysqlConfiguration resource produces the following output properties:

Id string
The provider-assigned unique ID for this managed resource.
State string
The current state of the Configuration.
SystemTags Dictionary<string, string>
Usage of system tag keys. These predefined keys are scoped to namespaces. Example: {"orcl-cloud.free-tier-retained": "true"}
TimeCreated string
The date and time the Configuration was created, as described by RFC 3339.
TimeUpdated string
The date and time the Configuration was last updated, as described by RFC 3339.
Type string
The Configuration type, DEFAULT or CUSTOM.
Id string
The provider-assigned unique ID for this managed resource.
State string
The current state of the Configuration.
SystemTags map[string]string
Usage of system tag keys. These predefined keys are scoped to namespaces. Example: {"orcl-cloud.free-tier-retained": "true"}
TimeCreated string
The date and time the Configuration was created, as described by RFC 3339.
TimeUpdated string
The date and time the Configuration was last updated, as described by RFC 3339.
Type string
The Configuration type, DEFAULT or CUSTOM.
id String
The provider-assigned unique ID for this managed resource.
state String
The current state of the Configuration.
systemTags Map<String,String>
Usage of system tag keys. These predefined keys are scoped to namespaces. Example: {"orcl-cloud.free-tier-retained": "true"}
timeCreated String
The date and time the Configuration was created, as described by RFC 3339.
timeUpdated String
The date and time the Configuration was last updated, as described by RFC 3339.
type String
The Configuration type, DEFAULT or CUSTOM.
id string
The provider-assigned unique ID for this managed resource.
state string
The current state of the Configuration.
systemTags {[key: string]: string}
Usage of system tag keys. These predefined keys are scoped to namespaces. Example: {"orcl-cloud.free-tier-retained": "true"}
timeCreated string
The date and time the Configuration was created, as described by RFC 3339.
timeUpdated string
The date and time the Configuration was last updated, as described by RFC 3339.
type string
The Configuration type, DEFAULT or CUSTOM.
id str
The provider-assigned unique ID for this managed resource.
state str
The current state of the Configuration.
system_tags Mapping[str, str]
Usage of system tag keys. These predefined keys are scoped to namespaces. Example: {"orcl-cloud.free-tier-retained": "true"}
time_created str
The date and time the Configuration was created, as described by RFC 3339.
time_updated str
The date and time the Configuration was last updated, as described by RFC 3339.
type str
The Configuration type, DEFAULT or CUSTOM.
id String
The provider-assigned unique ID for this managed resource.
state String
The current state of the Configuration.
systemTags Map<String>
Usage of system tag keys. These predefined keys are scoped to namespaces. Example: {"orcl-cloud.free-tier-retained": "true"}
timeCreated String
The date and time the Configuration was created, as described by RFC 3339.
timeUpdated String
The date and time the Configuration was last updated, as described by RFC 3339.
type String
The Configuration type, DEFAULT or CUSTOM.

Look up Existing MysqlConfiguration Resource

Get an existing MysqlConfiguration resource’s state with the given name, ID, and optional extra properties used to qualify the lookup.

public static get(name: string, id: Input<ID>, state?: MysqlConfigurationState, opts?: CustomResourceOptions): MysqlConfiguration
@staticmethod
def get(resource_name: str,
        id: str,
        opts: Optional[ResourceOptions] = None,
        compartment_id: Optional[str] = None,
        defined_tags: Optional[Mapping[str, str]] = None,
        description: Optional[str] = None,
        display_name: Optional[str] = None,
        freeform_tags: Optional[Mapping[str, str]] = None,
        init_variables: Optional[_mysql.MysqlConfigurationInitVariablesArgs] = None,
        parent_configuration_id: Optional[str] = None,
        shape_name: Optional[str] = None,
        state: Optional[str] = None,
        system_tags: Optional[Mapping[str, str]] = None,
        time_created: Optional[str] = None,
        time_updated: Optional[str] = None,
        type: Optional[str] = None,
        variables: Optional[_mysql.MysqlConfigurationVariablesArgs] = None) -> MysqlConfiguration
func GetMysqlConfiguration(ctx *Context, name string, id IDInput, state *MysqlConfigurationState, opts ...ResourceOption) (*MysqlConfiguration, error)
public static MysqlConfiguration Get(string name, Input<string> id, MysqlConfigurationState? state, CustomResourceOptions? opts = null)
public static MysqlConfiguration get(String name, Output<String> id, MysqlConfigurationState state, CustomResourceOptions options)
resources:  _:    type: oci:Mysql:MysqlConfiguration    get:      id: ${id}
name This property is required.
The unique name of the resulting resource.
id This property is required.
The unique provider ID of the resource to lookup.
state
Any extra arguments used during the lookup.
opts
A bag of options that control this resource's behavior.
resource_name This property is required.
The unique name of the resulting resource.
id This property is required.
The unique provider ID of the resource to lookup.
name This property is required.
The unique name of the resulting resource.
id This property is required.
The unique provider ID of the resource to lookup.
state
Any extra arguments used during the lookup.
opts
A bag of options that control this resource's behavior.
name This property is required.
The unique name of the resulting resource.
id This property is required.
The unique provider ID of the resource to lookup.
state
Any extra arguments used during the lookup.
opts
A bag of options that control this resource's behavior.
name This property is required.
The unique name of the resulting resource.
id This property is required.
The unique provider ID of the resource to lookup.
state
Any extra arguments used during the lookup.
opts
A bag of options that control this resource's behavior.
The following state arguments are supported:
CompartmentId Changes to this property will trigger replacement. string
The OCID of the compartment.
DefinedTags Dictionary<string, string>
(Updatable) Defined tags for this resource. Each key is predefined and scoped to a namespace. Example: {"foo-namespace.bar-key": "value"}
Description string
(Updatable) User-provided data about the Configuration.
DisplayName string
(Updatable) The display name of the Configuration.
FreeformTags Dictionary<string, string>
(Updatable) Simple key-value pair that is applied without any predefined name, type or scope. Exists for cross-compatibility only. Example: {"bar-key": "value"}
InitVariables Changes to this property will trigger replacement. MysqlConfigurationInitVariables
User-defined service variables set only at DB system initialization. These variables cannot be changed later at runtime.
ParentConfigurationId Changes to this property will trigger replacement. string
The OCID of the Configuration from which the new Configuration is derived. The values in CreateConfigurationDetails.variables supersede the variables of the parent Configuration.
ShapeName Changes to this property will trigger replacement. string
The name of the associated Shape.
State string
The current state of the Configuration.
SystemTags Dictionary<string, string>
Usage of system tag keys. These predefined keys are scoped to namespaces. Example: {"orcl-cloud.free-tier-retained": "true"}
TimeCreated string
The date and time the Configuration was created, as described by RFC 3339.
TimeUpdated string
The date and time the Configuration was last updated, as described by RFC 3339.
Type string
The Configuration type, DEFAULT or CUSTOM.
Variables Changes to this property will trigger replacement. MysqlConfigurationVariables
User-defined service variables.
CompartmentId Changes to this property will trigger replacement. string
The OCID of the compartment.
DefinedTags map[string]string
(Updatable) Defined tags for this resource. Each key is predefined and scoped to a namespace. Example: {"foo-namespace.bar-key": "value"}
Description string
(Updatable) User-provided data about the Configuration.
DisplayName string
(Updatable) The display name of the Configuration.
FreeformTags map[string]string
(Updatable) Simple key-value pair that is applied without any predefined name, type or scope. Exists for cross-compatibility only. Example: {"bar-key": "value"}
InitVariables Changes to this property will trigger replacement. MysqlConfigurationInitVariablesArgs
User-defined service variables set only at DB system initialization. These variables cannot be changed later at runtime.
ParentConfigurationId Changes to this property will trigger replacement. string
The OCID of the Configuration from which the new Configuration is derived. The values in CreateConfigurationDetails.variables supersede the variables of the parent Configuration.
ShapeName Changes to this property will trigger replacement. string
The name of the associated Shape.
State string
The current state of the Configuration.
SystemTags map[string]string
Usage of system tag keys. These predefined keys are scoped to namespaces. Example: {"orcl-cloud.free-tier-retained": "true"}
TimeCreated string
The date and time the Configuration was created, as described by RFC 3339.
TimeUpdated string
The date and time the Configuration was last updated, as described by RFC 3339.
Type string
The Configuration type, DEFAULT or CUSTOM.
Variables Changes to this property will trigger replacement. MysqlConfigurationVariablesArgs
User-defined service variables.
compartmentId Changes to this property will trigger replacement. String
The OCID of the compartment.
definedTags Map<String,String>
(Updatable) Defined tags for this resource. Each key is predefined and scoped to a namespace. Example: {"foo-namespace.bar-key": "value"}
description String
(Updatable) User-provided data about the Configuration.
displayName String
(Updatable) The display name of the Configuration.
freeformTags Map<String,String>
(Updatable) Simple key-value pair that is applied without any predefined name, type or scope. Exists for cross-compatibility only. Example: {"bar-key": "value"}
initVariables Changes to this property will trigger replacement. ConfigurationInitVariables
User-defined service variables set only at DB system initialization. These variables cannot be changed later at runtime.
parentConfigurationId Changes to this property will trigger replacement. String
The OCID of the Configuration from which the new Configuration is derived. The values in CreateConfigurationDetails.variables supersede the variables of the parent Configuration.
shapeName Changes to this property will trigger replacement. String
The name of the associated Shape.
state String
The current state of the Configuration.
systemTags Map<String,String>
Usage of system tag keys. These predefined keys are scoped to namespaces. Example: {"orcl-cloud.free-tier-retained": "true"}
timeCreated String
The date and time the Configuration was created, as described by RFC 3339.
timeUpdated String
The date and time the Configuration was last updated, as described by RFC 3339.
type String
The Configuration type, DEFAULT or CUSTOM.
variables Changes to this property will trigger replacement. ConfigurationVariables
User-defined service variables.
compartmentId Changes to this property will trigger replacement. string
The OCID of the compartment.
definedTags {[key: string]: string}
(Updatable) Defined tags for this resource. Each key is predefined and scoped to a namespace. Example: {"foo-namespace.bar-key": "value"}
description string
(Updatable) User-provided data about the Configuration.
displayName string
(Updatable) The display name of the Configuration.
freeformTags {[key: string]: string}
(Updatable) Simple key-value pair that is applied without any predefined name, type or scope. Exists for cross-compatibility only. Example: {"bar-key": "value"}
initVariables Changes to this property will trigger replacement. MysqlConfigurationInitVariables
User-defined service variables set only at DB system initialization. These variables cannot be changed later at runtime.
parentConfigurationId Changes to this property will trigger replacement. string
The OCID of the Configuration from which the new Configuration is derived. The values in CreateConfigurationDetails.variables supersede the variables of the parent Configuration.
shapeName Changes to this property will trigger replacement. string
The name of the associated Shape.
state string
The current state of the Configuration.
systemTags {[key: string]: string}
Usage of system tag keys. These predefined keys are scoped to namespaces. Example: {"orcl-cloud.free-tier-retained": "true"}
timeCreated string
The date and time the Configuration was created, as described by RFC 3339.
timeUpdated string
The date and time the Configuration was last updated, as described by RFC 3339.
type string
The Configuration type, DEFAULT or CUSTOM.
variables Changes to this property will trigger replacement. MysqlConfigurationVariables
User-defined service variables.
compartment_id Changes to this property will trigger replacement. str
The OCID of the compartment.
defined_tags Mapping[str, str]
(Updatable) Defined tags for this resource. Each key is predefined and scoped to a namespace. Example: {"foo-namespace.bar-key": "value"}
description str
(Updatable) User-provided data about the Configuration.
display_name str
(Updatable) The display name of the Configuration.
freeform_tags Mapping[str, str]
(Updatable) Simple key-value pair that is applied without any predefined name, type or scope. Exists for cross-compatibility only. Example: {"bar-key": "value"}
init_variables Changes to this property will trigger replacement. mysql.MysqlConfigurationInitVariablesArgs
User-defined service variables set only at DB system initialization. These variables cannot be changed later at runtime.
parent_configuration_id Changes to this property will trigger replacement. str
The OCID of the Configuration from which the new Configuration is derived. The values in CreateConfigurationDetails.variables supersede the variables of the parent Configuration.
shape_name Changes to this property will trigger replacement. str
The name of the associated Shape.
state str
The current state of the Configuration.
system_tags Mapping[str, str]
Usage of system tag keys. These predefined keys are scoped to namespaces. Example: {"orcl-cloud.free-tier-retained": "true"}
time_created str
The date and time the Configuration was created, as described by RFC 3339.
time_updated str
The date and time the Configuration was last updated, as described by RFC 3339.
type str
The Configuration type, DEFAULT or CUSTOM.
variables Changes to this property will trigger replacement. mysql.MysqlConfigurationVariablesArgs
User-defined service variables.
compartmentId Changes to this property will trigger replacement. String
The OCID of the compartment.
definedTags Map<String>
(Updatable) Defined tags for this resource. Each key is predefined and scoped to a namespace. Example: {"foo-namespace.bar-key": "value"}
description String
(Updatable) User-provided data about the Configuration.
displayName String
(Updatable) The display name of the Configuration.
freeformTags Map<String>
(Updatable) Simple key-value pair that is applied without any predefined name, type or scope. Exists for cross-compatibility only. Example: {"bar-key": "value"}
initVariables Changes to this property will trigger replacement. Property Map
User-defined service variables set only at DB system initialization. These variables cannot be changed later at runtime.
parentConfigurationId Changes to this property will trigger replacement. String
The OCID of the Configuration from which the new Configuration is derived. The values in CreateConfigurationDetails.variables supersede the variables of the parent Configuration.
shapeName Changes to this property will trigger replacement. String
The name of the associated Shape.
state String
The current state of the Configuration.
systemTags Map<String>
Usage of system tag keys. These predefined keys are scoped to namespaces. Example: {"orcl-cloud.free-tier-retained": "true"}
timeCreated String
The date and time the Configuration was created, as described by RFC 3339.
timeUpdated String
The date and time the Configuration was last updated, as described by RFC 3339.
type String
The Configuration type, DEFAULT or CUSTOM.
variables Changes to this property will trigger replacement. Property Map
User-defined service variables.

Supporting Types

MysqlConfigurationInitVariables
, MysqlConfigurationInitVariablesArgs

LowerCaseTableNames Changes to this property will trigger replacement. string

Represents the MySQL server system variable lower_case_table_names (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_lower_case_table_names).

lowerCaseTableNames controls case-sensitivity of tables and schema names and how they are stored in the DB System.

Valid values are:

  • CASE_SENSITIVE - (default) Table and schema name comparisons are case-sensitive and stored as specified. (lower_case_table_names=0)
  • CASE_INSENSITIVE_LOWERCASE - Table and schema name comparisons are not case-sensitive and stored in lowercase. (lower_case_table_names=1)
LowerCaseTableNames Changes to this property will trigger replacement. string

Represents the MySQL server system variable lower_case_table_names (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_lower_case_table_names).

lowerCaseTableNames controls case-sensitivity of tables and schema names and how they are stored in the DB System.

Valid values are:

  • CASE_SENSITIVE - (default) Table and schema name comparisons are case-sensitive and stored as specified. (lower_case_table_names=0)
  • CASE_INSENSITIVE_LOWERCASE - Table and schema name comparisons are not case-sensitive and stored in lowercase. (lower_case_table_names=1)
lowerCaseTableNames Changes to this property will trigger replacement. String

Represents the MySQL server system variable lower_case_table_names (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_lower_case_table_names).

lowerCaseTableNames controls case-sensitivity of tables and schema names and how they are stored in the DB System.

Valid values are:

  • CASE_SENSITIVE - (default) Table and schema name comparisons are case-sensitive and stored as specified. (lower_case_table_names=0)
  • CASE_INSENSITIVE_LOWERCASE - Table and schema name comparisons are not case-sensitive and stored in lowercase. (lower_case_table_names=1)
lowerCaseTableNames Changes to this property will trigger replacement. string

Represents the MySQL server system variable lower_case_table_names (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_lower_case_table_names).

lowerCaseTableNames controls case-sensitivity of tables and schema names and how they are stored in the DB System.

Valid values are:

  • CASE_SENSITIVE - (default) Table and schema name comparisons are case-sensitive and stored as specified. (lower_case_table_names=0)
  • CASE_INSENSITIVE_LOWERCASE - Table and schema name comparisons are not case-sensitive and stored in lowercase. (lower_case_table_names=1)
lower_case_table_names Changes to this property will trigger replacement. str

Represents the MySQL server system variable lower_case_table_names (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_lower_case_table_names).

lowerCaseTableNames controls case-sensitivity of tables and schema names and how they are stored in the DB System.

Valid values are:

  • CASE_SENSITIVE - (default) Table and schema name comparisons are case-sensitive and stored as specified. (lower_case_table_names=0)
  • CASE_INSENSITIVE_LOWERCASE - Table and schema name comparisons are not case-sensitive and stored in lowercase. (lower_case_table_names=1)
lowerCaseTableNames Changes to this property will trigger replacement. String

Represents the MySQL server system variable lower_case_table_names (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_lower_case_table_names).

lowerCaseTableNames controls case-sensitivity of tables and schema names and how they are stored in the DB System.

Valid values are:

  • CASE_SENSITIVE - (default) Table and schema name comparisons are case-sensitive and stored as specified. (lower_case_table_names=0)
  • CASE_INSENSITIVE_LOWERCASE - Table and schema name comparisons are not case-sensitive and stored in lowercase. (lower_case_table_names=1)

MysqlConfigurationVariables
, MysqlConfigurationVariablesArgs

AutoIncrementIncrement Changes to this property will trigger replacement. int

auto_increment_increment and auto_increment_offset are intended for use with circular (source-to-source) replication, and can be used to control the operation of AUTO_INCREMENT columns. Both variables have global and session values, and each can assume an integer value between 1 and 65,535 inclusive.

autoIncrementIncrement corresponds to the MySQL Replication Source Options variable [auto_increment_increment] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-source.html#sysvar_auto_increment_increment).

AutoIncrementOffset Changes to this property will trigger replacement. int

This variable has a default value of 1. If it is left with its default value, and Group Replication is started on the server in multi-primary mode, it is changed to the server ID.

autoIncrementOffset corresponds to the MySQL Replication Source Options variable [auto_increment_offset] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-source.html#sysvar_auto_increment_offset).

Autocommit Changes to this property will trigger replacement. bool
("autocommit")
BigTables Changes to this property will trigger replacement. bool

If enabled, the server stores all temporary tables on disk rather than in memory.

bigTables corresponds to the MySQL server variable big_tables.

BinlogExpireLogsSeconds Changes to this property will trigger replacement. int
Sets the binary log expiration period in seconds. binlogExpireLogsSeconds corresponds to the MySQL binary logging system variable binlog_expire_logs_seconds.
BinlogGroupCommitSyncDelay Changes to this property will trigger replacement. int

Controls how many microseconds the binary log commit waits before synchronizing the binary log file to disk. There is no delay by default. Setting this variable to a microsecond delay enables more transactions to be synchronized together to disk at once, reducing the overall time to commit a group of transactions because the larger groups required fewer time units per group.

binlogGroupCommitSyncDelay corresponds to the MySQL Replication system variable binlog_group_commit_sync_delay

BinlogGroupCommitSyncNoDelayCount Changes to this property will trigger replacement. int

The maximum number of transactions to wait for before aborting the current delay as specified by binlog_group_commit_sync_delay. If binlog_group_commit_sync_delay is set to 0, then this option has no effect.

binlogGroupCommitSyncNoDelayCount corresponds to the MySQL Replication system variable binlog_group_commit_sync_no_delay_count

BinlogRowMetadata Changes to this property will trigger replacement. string
Configures the amount of table metadata added to the binary log when using row-based logging. binlogRowMetadata corresponds to the MySQL binary logging system variable binlog_row_metadata.
BinlogRowValueOptions Changes to this property will trigger replacement. string
When set to PARTIAL_JSON, this enables use of a space-efficient binary log format for updates that modify only a small portion of a JSON document. binlogRowValueOptions corresponds to the MySQL binary logging system variable binlog_row_value_options.
BinlogTransactionCompression Changes to this property will trigger replacement. bool
Enables compression for transactions that are written to binary log files on this server. binlogTransactionCompression corresponds to the MySQL binary logging system variable binlog_transaction_compression.
BlockEncryptionMode Changes to this property will trigger replacement. string

This variable controls the block encryption mode for block-based algorithms such as AES. It affects encryption for AES_ENCRYPT() and AES_DECRYPT(). block_encryption_mode takes a value in aes-keylen-mode format, where keylen is the key length in bits and mode is the encryption mode. The value is not case-sensitive. Permitted keylen values are 128, 192, and 256. Permitted mode values are ECB, CBC, CFB1, CFB8, CFB128, and OFB.

block_encryption_mode corresponds to the MySQL Server Administration system variable block_encryption_mode

CharacterSetServer Changes to this property will trigger replacement. string

The server's default character set. If you set this variable, you should also set collation_server to specify the collation for the character set.

characterSetServer corresponds to the MySQL server variable character_set_server.

CollationServer Changes to this property will trigger replacement. string

The server's default collation.

collationServer corresponds to the MySQL server variable collation_server.

CompletionType Changes to this property will trigger replacement. string
("completion_type")
ConnectTimeout Changes to this property will trigger replacement. int

The number of seconds that the mysqld server waits for a connect packet before responding with Bad handshake.

connectTimeout corresponds to the MySQL system variable connect_timeout

Increasing the connect_timeout value might help if clients frequently encounter errors of the form "Lost connection to MySQL server at 'XXX', system error: errno".

ConnectionMemoryChunkSize Changes to this property will trigger replacement. int

Set the chunking size for updates to the global memory usage counter Global_connection_memory.

connectionMemoryChunkSize corresponds to the MySQL system variable connection_memory_chunk_size.

ConnectionMemoryLimit Changes to this property will trigger replacement. string

Set the maximum amount of memory that can be used by a single user connection.

connectionMemoryLimit corresponds to the MySQL system variable connection_memory_limit.

CteMaxRecursionDepth Changes to this property will trigger replacement. string
("cte_max_recursion_depth")
DefaultAuthenticationPlugin Changes to this property will trigger replacement. string

The default authentication plugin. This must be a plugin that uses internal credentials storage, so these values are permitted: mysql_native_password, sha256_password, caching_sha2_password.

As of MySQL 8.0.27, which introduces multifactor authentication, default_authentication_plugin is still used, but in conjunction with and at a lower precedence than the authentication_policy system variable. For details, see The Default Authentication Plugin. Because of this diminished role, default_authentication_plugin is deprecated as of MySQL 8.0.27 and subject to removal in a future MySQL version.

defaultAuthenticationPlugin corresponds to the MySQL system variable default_authentication_plugin.

ExplainFormat Changes to this property will trigger replacement. string

This variable determines the default output format used by EXPLAIN in the absence of a FORMAT option when displaying a query execution plan.

explainFormat corresponds to the MySQL system variable explain_format.

ExplicitDefaultsForTimestamp Changes to this property will trigger replacement. bool

This system variable determines whether the server enables certain nonstandard behaviors for default values and NULL-value handling in TIMESTAMP columns. By default, explicit_defaults_for_timestamp is enabled, which disables the nonstandard behaviors. Disabling explicit_defaults_for_timestamp results in a warning.

explicit_defaults_for_timestamp corresponds to the MySQL Server Administration system variable explicit_defaults_for_timestamp

ForeignKeyChecks Changes to this property will trigger replacement. bool
("foreign_key_checks")
GeneratedRandomPasswordLength Changes to this property will trigger replacement. int
("generated_random_password_length") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'generated_random_password_length' field has been deprecated and may be removed in a future version. Do not use this field.

GlobalConnectionMemoryLimit Changes to this property will trigger replacement. string

Set the total amount of memory that can be used by all user connections.

globalConnectionMemoryLimit corresponds to the MySQL system variable global_connection_memory_limit.

GlobalConnectionMemoryTracking Changes to this property will trigger replacement. bool

Determines whether the MySQL server calculates Global_connection_memory.

globalConnectionMemoryTracking corresponds to the MySQL system variable global_connection_memory_tracking.

GroupConcatMaxLen Changes to this property will trigger replacement. string

Specifies the maximum permitted result length in bytes for the GROUP_CONCAT() function.

This is the MySQL variable "group_concat_max_len". For more information, please see the MySQL documentation

GroupReplicationConsistency Changes to this property will trigger replacement. string
  • EVENTUAL: Both RO and RW transactions do not wait for preceding transactions to be applied before executing. A RW transaction does not wait for other members to apply a transaction. This means that a transaction could be externalized on one member before the others. This also means that in the event of a primary failover, the new primary can accept new RO and RW transactions before the previous primary transactions are all applied. RO transactions could result in outdated values, RW transactions could result in a rollback due to conflicts.
  • BEFORE_ON_PRIMARY_FAILOVER: New RO or RW transactions with a newly elected primary that is applying backlog from the old primary are held (not applied) until any backlog has been applied. This ensures that when a primary failover happens, intentionally or not, clients always see the latest value on the primary. This guarantees consistency, but means that clients must be able to handle the delay in the event that a backlog is being applied. Usually this delay should be minimal, but does depend on the size of the backlog.
  • BEFORE: A RW transaction waits for all preceding transactions to complete before being applied. A RO transaction waits for all preceding transactions to complete before being executed. This ensures that this transaction reads the latest value by only affecting the latency of the transaction. This reduces the overhead of synchronization on every RW transaction, by ensuring synchronization is used only on RO transactions. This consistency level also includes the consistency guarantees provided by BEFORE_ON_PRIMARY_FAILOVER.
  • AFTER: A RW transaction waits until its changes have been applied to all of the other members. This value has no effect on RO transactions. This mode ensures that when a transaction is committed on the local member, any subsequent transaction reads the written value or a more recent value on any group member. Use this mode with a group that is used for predominantly RO operations to ensure that applied RW transactions are applied everywhere once they commit. This could be used by your application to ensure that subsequent reads fetch the latest data which includes the latest writes. This reduces the overhead of synchronization on every RO transaction, by ensuring synchronization is used only on RW transactions. This consistency level also includes the consistency guarantees provided by BEFORE_ON_PRIMARY_FAILOVER.
  • BEFORE_AND_AFTER: A RW transaction waits for 1) all preceding transactions to complete before being applied and 2) until its changes have been applied on other members. A RO transaction waits for all preceding transactions to complete before execution takes place. This consistency level also includes the consistency guarantees provided by BEFORE_ON_PRIMARY_FAILOVER.
InformationSchemaStatsExpiry Changes to this property will trigger replacement. int
("information_schema_stats_expiry")
InnodbAdaptiveHashIndex Changes to this property will trigger replacement. bool

Whether the InnoDB adaptive hash index is enabled or disabled. It may be desirable, depending on your workload, to dynamically enable or disable adaptive hash indexing to improve query performance. Because the adaptive hash index may not be useful for all workloads, conduct benchmarks with it both enabled and disabled, using realistic workloads.

innodbAdaptiveHashIndex corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_adaptive_hash_index] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_adaptive_hash_index).

InnodbAutoincLockMode Changes to this property will trigger replacement. int

The lock mode to use for generating auto-increment values. Permissible values are 0, 1, or 2, for traditional, consecutive, or interleaved, respectively.

innodbAutoincLockMode corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_autoinc_lock_mode] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_autoinc_lock_mode).

InnodbBufferPoolDumpPct Changes to this property will trigger replacement. int

Specifies the percentage of the most recently used pages for each buffer pool to read out and dump.

innodbBufferPoolDumpPct corresponds to the MySQL InnoDB system variable innodb_buffer_pool_dump_pct.

The range is 1 to 100. The default value is 25.

For example, if there are 4 buffer pools with 100 pages each, and innodb_buffer_pool_dump_pct is set to 25, the 25 most recently used pages from each buffer pool are dumped.

InnodbBufferPoolInstances Changes to this property will trigger replacement. int
("innodb_buffer_pool_instances")
InnodbBufferPoolSize Changes to this property will trigger replacement. string

The size (in bytes) of the buffer pool, that is, the memory area where InnoDB caches table and index data.

innodbBufferPoolSize corresponds to the MySQL server system variable innodb_buffer_pool_size.

The default and maximum values depend on the amount of RAM provisioned by the shape. See Default User Variables.

InnodbChangeBuffering Changes to this property will trigger replacement. string

Whether InnoDB performs change buffering, an optimization that delays write operations to secondary indexes so that the I/O operations can be performed sequentially. Permitted values are described in the following table. Values may also be specified numerically.

innodbChangeBuffering corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_change_buffering] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_change_buffering).

InnodbDdlBufferSize Changes to this property will trigger replacement. string
innodbDdlBufferSize corresponds to the MySQL system variable [innodb_ddl_buffer_size] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_ddl_buffer_size)
InnodbDdlThreads Changes to this property will trigger replacement. int
innodbDdlThreads corresponds to the MySQL system variable [innodb_ddl_threads] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_ddl_threads)
InnodbFtEnableStopword Changes to this property will trigger replacement. bool
("innodb_ft_enable_stopword")
InnodbFtMaxTokenSize Changes to this property will trigger replacement. int
("innodb_ft_max_token_size")
InnodbFtMinTokenSize Changes to this property will trigger replacement. int
("innodb_ft_min_token_size")
InnodbFtNumWordOptimize Changes to this property will trigger replacement. int
("innodb_ft_num_word_optimize")
InnodbFtResultCacheLimit Changes to this property will trigger replacement. string
("innodb_ft_result_cache_limit")
InnodbFtServerStopwordTable Changes to this property will trigger replacement. string
("innodb_ft_server_stopword_table")
InnodbLockWaitTimeout Changes to this property will trigger replacement. int
("innodb_lock_wait_timeout")
InnodbLogWriterThreads Changes to this property will trigger replacement. bool

Enables dedicated log writer threads for writing redo log records from the log buffer to the system buffers and flushing the system buffers to the redo log files.

This is the MySQL variable "innodb_log_writer_threads". For more information, please see the MySQL documentation

InnodbMaxPurgeLag Changes to this property will trigger replacement. string

The desired maximum purge lag in terms of transactions.

InnoDB maintains a list of transactions that have index records delete-marked by UPDATE or DELETE operations. The length of the list is the purge lag.

If this value is exceeded, a delay is imposed on INSERT, UPDATE, and DELETE operations to allow time for purge to catch up.

The default value is 0, which means there is no maximum purge lag and no delay.

innodbMaxPurgeLag corresponds to the MySQL server system variable innodb_max_purge_lag.

InnodbMaxPurgeLagDelay Changes to this property will trigger replacement. int

The maximum delay in microseconds for the delay imposed when the innodb_max_purge_lag threshold is exceeded.

The specified innodb_max_purge_lag_delay value is an upper limit on the delay period.

innodbMaxPurgeLagDelay corresponds to the MySQL server system variable innodb_max_purge_lag_delay.

InnodbNumaInterleave Changes to this property will trigger replacement. bool

Enables the NUMA interleave memory policy for allocation of the InnoDB buffer pool. When innodb_numa_interleave is enabled, the NUMA memory policy is set to MPOL_INTERLEAVE for the mysqld process. After the InnoDB buffer pool is allocated, the NUMA memory policy is set back to MPOL_DEFAULT. For the innodb_numa_interleave option to be available, MySQL must be compiled on a NUMA-enabled Linux system.

innodbNumaInterleave corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_numa_interleave] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_numa_interleave).

InnodbOnlineAlterLogMaxSize Changes to this property will trigger replacement. string

Specifies an upper limit in bytes on the size of the temporary log files used during online DDL operations for InnoDB tables. There is one such log file for each index being created or table being altered. This log file stores data inserted, updated, or deleted in the table during the DDL operation.

innodbOnlineAlterLogMaxSize corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_online_alter_log_max_size] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_online_alter_log_max_size).

InnodbRedoLogCapacity Changes to this property will trigger replacement. string

Defines the amount of disk space occupied by redo log files. innodb_redo_log_capacity supercedes the innodb_log_files_in_group and innodb_log_file_size variables, which are both ignored if innodb_redo_log_capacity is defined. If innodb_redo_log_capacity is not defined, and if neither innodb_log_file_size or innodb_log_files_in_group are defined, then the default innodb_redo_log_capacity value is used.

innodbRedoLogCapacity corresponds to the InnoDB Startup Options and System Variables innodb_redo_log_capacity

InnodbRollbackOnTimeout Changes to this property will trigger replacement. bool

InnoDB rolls back only the last statement on a transaction timeout by default. If --innodb-rollback-on-timeout is specified, a transaction timeout causes InnoDB to abort and roll back the entire transaction.

innodbRollbackOnTimeout corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_rollback_on_timeout] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_rollback_on_timeout).

InnodbSortBufferSize Changes to this property will trigger replacement. int

This variable defines:

  • The sort buffer size for online DDL operations that create or rebuild secondary indexes. However, as of MySQL 8.0.27, this responsibility is subsumed by the innodb_ddl_buffer_size variable.
  • The amount by which the temporary log file is extended when recording concurrent DML during an online DDL operation, and the size of the temporary log file read buffer and write buffer.

innodbSortBufferSize corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_sort_buffer_size] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_sort_buffer_size).

InnodbStatsPersistentSamplePages Changes to this property will trigger replacement. string

The number of index pages to sample when estimating cardinality and other statistics for an indexed column, such as those calculated by ANALYZE TABLE.

innodbStatsPersistentSamplePages corresponds to the MySQL InnoDB system variable innodb_stats_persistent_sample_pages

innodb_stats_persistent_sample_pages only applies when innodb_stats_persistent is enabled for a table; when innodb_stats_persistent is disabled, innodb_stats_transient_sample_pages applies instead.

InnodbStatsTransientSamplePages Changes to this property will trigger replacement. string

The number of index pages to sample when estimating cardinality and other statistics for an indexed column, such as those calculated by ANALYZE TABLE.

innodbStatsTransientSamplePages corresponds to the MySQL InnoDB system variable innodb_stats_transient_sample_pages

innodb_stats_transient_sample_pages only applies when innodb_stats_persistent is disabled for a table; when innodb_stats_persistent is enabled, innodb_stats_persistent_sample_pages applies instead.

innodb_stats_persistent is ON by default and cannot be changed. It is possible to override it using the STATS_PERSISTENT clause of the CREATE TABLE and ALTER TABLE statements.

InnodbStrictMode Changes to this property will trigger replacement. bool

When you enable innodbStrictMode, the InnoDB storage engine returns errors instead of warnings for invalid or incompatible table options.

innodbStrictMode corresponds to the MySQL InnoDB system variable innodb_strict_mode

InnodbUndoLogTruncate Changes to this property will trigger replacement. bool

When enabled, undo tablespaces that exceed the threshold value defined by innodb_max_undo_log_size are marked for truncation. Only undo tablespaces can be truncated. Truncating undo logs that reside in the system tablespace is not supported. For truncation to occur, there must be at least two undo tablespaces.

innodbUndoLogTruncate corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_undo_log_truncate] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_undo_log_truncate).

InteractiveTimeout Changes to this property will trigger replacement. int

The number of seconds the server waits for activity on an interactive connection before closing it.

interactiveTimeout corresponds to the MySQL system variable. interactive_timeout

JoinBufferSize Changes to this property will trigger replacement. string

The minimum size of the buffer that is used for plain index scans, range index scans, and joins that do not use indexes and thus perform full table scans. In MySQL 8.0.18 and later, this variable also controls the amount of memory used for hash joins. Normally, the best way to get fast joins is to add indexes. Increase the value of join_buffer_size to get a faster full join when adding indexes is not possible. One join buffer is allocated for each full join between two tables. For a complex join between several tables for which indexes are not used, multiple join buffers might be necessary.

joinBufferSize corresponds to the MySQL Server System variable [join_buffer_size] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_join_buffer_size).

LocalInfile Changes to this property will trigger replacement. bool

This variable controls server-side LOCAL capability for LOAD DATA statements. Depending on the local_infile setting, the server refuses or permits local data loading by clients that have LOCAL enabled on the client side.

local_infile corresponds to the MySQL Server system variable local_infile

LongQueryTime Changes to this property will trigger replacement. int

If a query takes longer than this many seconds, the server increments the Slow_queries status variable. If the slow query log is enabled, the query is logged to the slow query log file. This value is measured in real time, not CPU time, so a query that is under the threshold on a lightly loaded system might be above the threshold on a heavily loaded one.

longQueryTime corresponds to the MySQL Server System variable [long_query_time] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_long_query_time).

MandatoryRoles Changes to this property will trigger replacement. string
("mandatory_roles")
MaxAllowedPacket Changes to this property will trigger replacement. int

The maximum size of one packet or any generated/intermediate string.

This is the mysql variable "max_allowed_packet".

MaxBinlogCacheSize Changes to this property will trigger replacement. string

Sets the size of the transaction cache.

maxBinlogCacheSize corresponds to the MySQL server system variable max_binlog_cache_size.

MaxConnectErrors Changes to this property will trigger replacement. string
("max_connect_errors")
MaxConnections Changes to this property will trigger replacement. int
("max_connections")
MaxExecutionTime Changes to this property will trigger replacement. string
("max_execution_time")
MaxHeapTableSize Changes to this property will trigger replacement. string

This variable sets the maximum size to which user-created MEMORY tables are permitted to grow.

maxHeapTableSize corresponds to the MySQL system variable max_heap_table_size

MaxPreparedStmtCount Changes to this property will trigger replacement. int
("max_prepared_stmt_count")
MaxSeeksForKey Changes to this property will trigger replacement. string

Limit the assumed maximum number of seeks when looking up rows based on a key. The MySQL optimizer assumes that no more than this number of key seeks are required when searching for matching rows in a table by scanning an index, regardless of the actual cardinality of the index (see Section 15.7.7.22, “SHOW INDEX Statement”). By setting this to a low value (say, 100), you can force MySQL to prefer indexes instead of table scans.

maxSeeksForKey corresponds to the MySQL Server System variable [max_seeks_for_key] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_max_seeks_for_key).

MaxUserConnections Changes to this property will trigger replacement. string

The maximum number of simultaneous connections permitted to any given MySQL user account. A value of 0 (the default) means “no limit.” This variable has a global value that can be set at server startup or runtime. It also has a read-only session value that indicates the effective simultaneous-connection limit that applies to the account associated with the current session.

maxUserConnections corresponds to the MySQL Server System variable [max_user_connections] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_max_user_connections).

MysqlFirewallMode Changes to this property will trigger replacement. bool
("mysql_firewall_mode")
MysqlZstdDefaultCompressionLevel Changes to this property will trigger replacement. int
DEPRECATED -- typo of mysqlx_zstd_default_compression_level. variable will be ignored.

Deprecated: The 'mysql_zstd_default_compression_level' field has been deprecated and may be removed in a future version. Do not use this field.

MysqlxConnectTimeout Changes to this property will trigger replacement. int

The number of seconds X Plugin waits for the first packet to be received from newly connected clients.

mysqlxConnectTimeout corresponds to the MySQL X Plugin system variable mysqlx_connect_timeout

MysqlxDeflateDefaultCompressionLevel Changes to this property will trigger replacement. int
Set the default compression level for the deflate algorithm. ("mysqlx_deflate_default_compression_level")
MysqlxDeflateMaxClientCompressionLevel Changes to this property will trigger replacement. int
Limit the upper bound of accepted compression levels for the deflate algorithm. ("mysqlx_deflate_max_client_compression_level")
MysqlxDocumentIdUniquePrefix Changes to this property will trigger replacement. int
("mysqlx_document_id_unique_prefix") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'mysqlx_document_id_unique_prefix' field has been deprecated and may be removed in a future version. Do not use this field.

MysqlxEnableHelloNotice Changes to this property will trigger replacement. bool
("mysqlx_enable_hello_notice") DEPRECATED -- variable should not be settable and will be ignored
MysqlxIdleWorkerThreadTimeout Changes to this property will trigger replacement. int
("mysqlx_idle_worker_thread_timeout") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'mysqlx_idle_worker_thread_timeout' field has been deprecated and may be removed in a future version. Do not use this field.

MysqlxInteractiveTimeout Changes to this property will trigger replacement. int

The number of seconds to wait for interactive clients to timeout.

mysqlxInteractiveTimeout corresponds to the MySQL X Plugin system variable. mysqlx_interactive_timeout

MysqlxLz4defaultCompressionLevel Changes to this property will trigger replacement. int
Set the default compression level for the lz4 algorithm. ("mysqlx_lz4_default_compression_level")
MysqlxLz4maxClientCompressionLevel Changes to this property will trigger replacement. int
Limit the upper bound of accepted compression levels for the lz4 algorithm. ("mysqlx_lz4_max_client_compression_level")
MysqlxMaxAllowedPacket Changes to this property will trigger replacement. int

The maximum size of network packets that can be received by X Plugin.

This is the mysql variable "mysqlx_max_allowed_packet".

MysqlxMinWorkerThreads Changes to this property will trigger replacement. int
("mysqlx_min_worker_threads") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'mysqlx_min_worker_threads' field has been deprecated and may be removed in a future version. Do not use this field.

MysqlxReadTimeout Changes to this property will trigger replacement. int

The number of seconds that X Plugin waits for blocking read operations to complete. After this time, if the read operation is not successful, X Plugin closes the connection and returns a warning notice with the error code ER_IO_READ_ERROR to the client application.

mysqlxReadTimeout corresponds to the MySQL X Plugin system variable mysqlx_read_timeout

MysqlxWaitTimeout Changes to this property will trigger replacement. int

The number of seconds that X Plugin waits for activity on a connection.

mysqlxWaitTimeout corresponds to the MySQL X Plugin system variable. mysqlx_wait_timeout

MysqlxWriteTimeout Changes to this property will trigger replacement. int

The number of seconds that X Plugin waits for blocking write operations to complete. After this time, if the write operation is not successful, X Plugin closes the connection.

mysqlxReadmysqlxWriteTimeoutTimeout corresponds to the MySQL X Plugin system variable mysqlx_write_timeout

MysqlxZstdDefaultCompressionLevel Changes to this property will trigger replacement. int
Set the default compression level for the zstd algorithm. ("mysqlx_zstd_default_compression_level")
MysqlxZstdMaxClientCompressionLevel Changes to this property will trigger replacement. int
Limit the upper bound of accepted compression levels for the zstd algorithm. ("mysqlx_zstd_max_client_compression_level")
NetReadTimeout Changes to this property will trigger replacement. int

The number of seconds to wait for more data from a connection before aborting the read.

netReadTimeout corresponds to the MySQL system variable net_read_timeout

NetWriteTimeout Changes to this property will trigger replacement. int

The number of seconds to wait for a block to be written to a connection before aborting the write.

netWriteTimeout corresponds to the MySQL system variable net_write_timeout

OptimizerSwitch Changes to this property will trigger replacement. string

The optimizer_switch system variable enables control over optimizer behavior. The value of this variable is a set of flags, each of which has a value of on or off to indicate whether the corresponding optimizer behavior is enabled or disabled. This variable has global and session values and can be changed at runtime. The global default can be set at server startup.

Setting hypergraph_optimizer=on for cloud builds below 9.0.0 will fail.

optimizerSwitch corresponds to the MySQL Server System variable [optimizer_switch] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_optimizer_switch).

ParserMaxMemSize Changes to this property will trigger replacement. string
("parser_max_mem_size")
QueryAllocBlockSize Changes to this property will trigger replacement. string
("query_alloc_block_size") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'query_alloc_block_size' field has been deprecated and may be removed in a future version. Do not use this field.

QueryPreallocSize Changes to this property will trigger replacement. string
("query_prealloc_size") DEPRECATED -- variable should not be settable and will be ignored
RangeOptimizerMaxMemSize Changes to this property will trigger replacement. string

The limit on memory consumption for the range optimizer. A value of 0 means “no limit.” If an execution plan considered by the optimizer uses the range access method but the optimizer estimates that the amount of memory needed for this method would exceed the limit, it abandons the plan and considers other plans.

rangeOptimizerMaxMemSize corresponds to the MySQL Server System variable [range_optimizer_max_mem_size] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_range_optimizer_max_mem_size).

Deprecated: The 'query_prealloc_size' field has been deprecated and may be removed in a future version. Do not use this field.

RegexpTimeLimit Changes to this property will trigger replacement. int
regexpTimeLimit corresponds to the MySQL system variable [regexp_time_limit] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_regexp_time_limit)
RelayLogSpaceLimit Changes to this property will trigger replacement. string

The maximum amount of space to use for all relay logs.

relayLogSpaceLimit corresponds to the MySQL Replica Server Options variable [relay_log_space_limit] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-replica.html#sysvar_relay_log_space_limit).

ReplicaNetTimeout Changes to this property will trigger replacement. int

Specifies the number of seconds to wait for more data or a heartbeat signal from the source before the replica considers the connection broken, aborts the read, and tries to reconnect. Setting this variable has no immediate effect. The state of the variable applies on all subsequent START REPLICA commands.

replicaNetTimeout corresponds to the MySQL Replica server system variable replica_net_timeout

ReplicaParallelWorkers Changes to this property will trigger replacement. int

Beginning with MySQL 8.0.26, slave_parallel_workers is deprecated, and you should use replica_parallel_workers instead. (Prior to MySQL 8.0.26, you must use slave_parallel_workers to set the number of applier threads.)

replicaParallelWorkers corresponds to the MySQL Replica Server Options variable [replica_parallel_workers] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-replica.html#sysvar_replica_parallel_workers).

ReplicaTypeConversions Changes to this property will trigger replacement. string

From MySQL 8.0.26, use replica_type_conversions in place of slave_type_conversions, which is deprecated from that release. In releases before MySQL 8.0.26, use slave_type_conversions.

replica_type_conversions controls the type conversion mode in effect on the replica when using row-based replication. Its value is a comma-delimited set of zero or more elements from the list: ALL_LOSSY, ALL_NON_LOSSY, ALL_SIGNED, ALL_UNSIGNED. Set this variable to an empty string to disallow type conversions between the source and the replica. Setting this variable takes effect for all replication channels immediately, including running channels.

replica_type_conversions corresponds to the MySQL Replica Server Options variable [replica_type_conversions] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-replica.html#sysvar_replica_type_conversions).

RequireSecureTransport Changes to this property will trigger replacement. bool

Whether client connections to the server are required to use some form of secure transport. When this variable is enabled, the server permits only TCP/IP connections encrypted using TLS/SSL, or connections that use a socket file or shared memory. The server rejects nonsecure connection attempts, which fail with an ER_SECURE_TRANSPORT_REQUIRED error.

require_secure_transport corresponds to the MySQL Server Administration system variable require_secure_transport

SkipNameResolve Changes to this property will trigger replacement. bool

Whether to resolve host names when checking client connections. If this variable is OFF, mysqld resolves host names when checking client connections. If it is ON, mysqld uses only IP numbers; in this case, all Host column values in the grant tables must be IP addresses. See Section 7.1.12.3, “DNS Lookups and the Host Cache”.

skipNameResolve corresponds to the MySQL Server System variable [skip_name_resolve] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_skip_name_resolve).

SortBufferSize Changes to this property will trigger replacement. string

Each session that must perform a sort allocates a buffer of this size.

sortBufferSize corresponds to the MySQL system variable sort_buffer_size

SqlGenerateInvisiblePrimaryKey Changes to this property will trigger replacement. bool

Whether GIPK mode is in effect, in which case a MySQL replication source server adds a generated invisible primary key to any InnoDB table that is created without one.

sqlGenerateInvisiblePrimaryKey corresponds to the MySQL system variable [sql_generate_invisible_primary_key] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_sql_generate_invisible_primary_key).

SqlMode Changes to this property will trigger replacement. string
("sql_mode")
SqlRequirePrimaryKey Changes to this property will trigger replacement. bool
("sql_require_primary_key")
SqlWarnings Changes to this property will trigger replacement. bool
("sql_warnings")
TableDefinitionCache Changes to this property will trigger replacement. int

The number of table definitions that can be stored in the table definition cache. If you use a large number of tables, you can create a large table definition cache to speed up opening of tables. The table definition cache takes less space and does not use file descriptors, unlike the normal table cache.

table_definition_cache corresponds to the MySQL Server Administration system variable table_definition_cache

TableOpenCache Changes to this property will trigger replacement. int

The number of open tables for all threads. Increasing this value increases the number of file descriptors that mysqld requires.

table_open_cache corresponds to the MySQL Server Administration system variable table_open_cache

TemptableMaxRam Changes to this property will trigger replacement. string

Defines the maximum amount of memory that can be occupied by the TempTable storage engine before it starts storing data on disk. The default value is 1073741824 bytes (1GiB). For more information, see Section 10.4.4, “Internal Temporary Table Use in MySQL”.

temptableMaxRam corresponds to the MySQL system variable [temptable_max_ram] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_temptable_max_ram).

ThreadPoolDedicatedListeners Changes to this property will trigger replacement. bool
Controls whether the thread pool uses dedicated listener threads. If enabled, a listener thread in each thread group is dedicated to the task of listening for network events from clients, ensuring that the maximum number of query worker threads is no more than the value specified by threadPoolMaxTransactionsLimit. threadPoolDedicatedListeners corresponds to the MySQL Database Service-specific system variable thread_pool_dedicated_listeners.
ThreadPoolMaxTransactionsLimit Changes to this property will trigger replacement. int
Limits the maximum number of open transactions to the defined value. The default value is 0, which enforces no limit. threadPoolMaxTransactionsLimit corresponds to the MySQL Database Service-specific system variable thread_pool_max_transactions_limit.
ThreadPoolQueryThreadsPerGroup Changes to this property will trigger replacement. int

The maximum number of query threads permitted in a thread group. The maximum value is 4096, but if thread_pool_max_transactions_limit is set, thread_pool_query_threads_per_group must not exceed that value. The default value of 1 means there is one active query thread in each thread group, which works well for many loads. When you are using the high concurrency thread pool algorithm (thread_pool_algorithm = 1), consider increasing the value if you experience slower response times due to long-running transactions.

threadPoolQueryThreadsPerGroup corresponds to the MySQL Server system variable thread_pool_query_threads_per_group

ThreadPoolSize Changes to this property will trigger replacement. int

The number of thread groups in the thread pool. This is the most important parameter controlling thread pool performance. It affects how many statements can execute simultaneously. If a value outside the range of permissible values is specified, the thread pool plugin does not load and the server writes a message to the error log.

threadPoolSize corresponds to the MySQL Server System variable [thread_pool_size] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_thread_pool_size).

ThreadPoolTransactionDelay Changes to this property will trigger replacement. int

The delay period before executing a new transaction, in milliseconds. The maximum value is 300000 (5 minutes). A transaction delay can be used in cases where parallel transactions affect the performance of other operations due to resource contention. For example, if parallel transactions affect index creation or an online buffer pool resizing operation, you can configure a transaction delay to reduce resource contention while those operations are running.

threadPoolTransactionDelay corresponds to the MySQL Server system variable thread_pool_transaction_delay

TimeZone Changes to this property will trigger replacement. string

Initializes the time zone for each client that connects.

This corresponds to the MySQL System Variable "time_zone".

The values can be given in one of the following formats, none of which are case-sensitive:

  • As a string indicating an offset from UTC of the form [H]H:MM, prefixed with a + or -, such as '+10:00', '-6:00', or '+05:30'. The permitted range is '-13:59' to '+14:00', inclusive.
  • As a named time zone, as defined by the "IANA Time Zone database", such as 'Europe/Helsinki', 'US/Eastern', 'MET', or 'UTC'.
TmpTableSize Changes to this property will trigger replacement. string

The maximum size of internal in-memory temporary tables. This variable does not apply to user-created MEMORY tables.

tmp_table_size corresponds to the MySQL system variable tmp_table_size

TransactionIsolation Changes to this property will trigger replacement. string
("transaction_isolation")
WaitTimeout Changes to this property will trigger replacement. int

The number of seconds the server waits for activity on a noninteractive connection before closing it.

waitTimeout corresponds to the MySQL system variable. wait_timeout

** IMPORTANT ** Any change to a property that does not support update will force the destruction and recreation of the resource with the new property values

AutoIncrementIncrement Changes to this property will trigger replacement. int

auto_increment_increment and auto_increment_offset are intended for use with circular (source-to-source) replication, and can be used to control the operation of AUTO_INCREMENT columns. Both variables have global and session values, and each can assume an integer value between 1 and 65,535 inclusive.

autoIncrementIncrement corresponds to the MySQL Replication Source Options variable [auto_increment_increment] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-source.html#sysvar_auto_increment_increment).

AutoIncrementOffset Changes to this property will trigger replacement. int

This variable has a default value of 1. If it is left with its default value, and Group Replication is started on the server in multi-primary mode, it is changed to the server ID.

autoIncrementOffset corresponds to the MySQL Replication Source Options variable [auto_increment_offset] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-source.html#sysvar_auto_increment_offset).

Autocommit Changes to this property will trigger replacement. bool
("autocommit")
BigTables Changes to this property will trigger replacement. bool

If enabled, the server stores all temporary tables on disk rather than in memory.

bigTables corresponds to the MySQL server variable big_tables.

BinlogExpireLogsSeconds Changes to this property will trigger replacement. int
Sets the binary log expiration period in seconds. binlogExpireLogsSeconds corresponds to the MySQL binary logging system variable binlog_expire_logs_seconds.
BinlogGroupCommitSyncDelay Changes to this property will trigger replacement. int

Controls how many microseconds the binary log commit waits before synchronizing the binary log file to disk. There is no delay by default. Setting this variable to a microsecond delay enables more transactions to be synchronized together to disk at once, reducing the overall time to commit a group of transactions because the larger groups required fewer time units per group.

binlogGroupCommitSyncDelay corresponds to the MySQL Replication system variable binlog_group_commit_sync_delay

BinlogGroupCommitSyncNoDelayCount Changes to this property will trigger replacement. int

The maximum number of transactions to wait for before aborting the current delay as specified by binlog_group_commit_sync_delay. If binlog_group_commit_sync_delay is set to 0, then this option has no effect.

binlogGroupCommitSyncNoDelayCount corresponds to the MySQL Replication system variable binlog_group_commit_sync_no_delay_count

BinlogRowMetadata Changes to this property will trigger replacement. string
Configures the amount of table metadata added to the binary log when using row-based logging. binlogRowMetadata corresponds to the MySQL binary logging system variable binlog_row_metadata.
BinlogRowValueOptions Changes to this property will trigger replacement. string
When set to PARTIAL_JSON, this enables use of a space-efficient binary log format for updates that modify only a small portion of a JSON document. binlogRowValueOptions corresponds to the MySQL binary logging system variable binlog_row_value_options.
BinlogTransactionCompression Changes to this property will trigger replacement. bool
Enables compression for transactions that are written to binary log files on this server. binlogTransactionCompression corresponds to the MySQL binary logging system variable binlog_transaction_compression.
BlockEncryptionMode Changes to this property will trigger replacement. string

This variable controls the block encryption mode for block-based algorithms such as AES. It affects encryption for AES_ENCRYPT() and AES_DECRYPT(). block_encryption_mode takes a value in aes-keylen-mode format, where keylen is the key length in bits and mode is the encryption mode. The value is not case-sensitive. Permitted keylen values are 128, 192, and 256. Permitted mode values are ECB, CBC, CFB1, CFB8, CFB128, and OFB.

block_encryption_mode corresponds to the MySQL Server Administration system variable block_encryption_mode

CharacterSetServer Changes to this property will trigger replacement. string

The server's default character set. If you set this variable, you should also set collation_server to specify the collation for the character set.

characterSetServer corresponds to the MySQL server variable character_set_server.

CollationServer Changes to this property will trigger replacement. string

The server's default collation.

collationServer corresponds to the MySQL server variable collation_server.

CompletionType Changes to this property will trigger replacement. string
("completion_type")
ConnectTimeout Changes to this property will trigger replacement. int

The number of seconds that the mysqld server waits for a connect packet before responding with Bad handshake.

connectTimeout corresponds to the MySQL system variable connect_timeout

Increasing the connect_timeout value might help if clients frequently encounter errors of the form "Lost connection to MySQL server at 'XXX', system error: errno".

ConnectionMemoryChunkSize Changes to this property will trigger replacement. int

Set the chunking size for updates to the global memory usage counter Global_connection_memory.

connectionMemoryChunkSize corresponds to the MySQL system variable connection_memory_chunk_size.

ConnectionMemoryLimit Changes to this property will trigger replacement. string

Set the maximum amount of memory that can be used by a single user connection.

connectionMemoryLimit corresponds to the MySQL system variable connection_memory_limit.

CteMaxRecursionDepth Changes to this property will trigger replacement. string
("cte_max_recursion_depth")
DefaultAuthenticationPlugin Changes to this property will trigger replacement. string

The default authentication plugin. This must be a plugin that uses internal credentials storage, so these values are permitted: mysql_native_password, sha256_password, caching_sha2_password.

As of MySQL 8.0.27, which introduces multifactor authentication, default_authentication_plugin is still used, but in conjunction with and at a lower precedence than the authentication_policy system variable. For details, see The Default Authentication Plugin. Because of this diminished role, default_authentication_plugin is deprecated as of MySQL 8.0.27 and subject to removal in a future MySQL version.

defaultAuthenticationPlugin corresponds to the MySQL system variable default_authentication_plugin.

ExplainFormat Changes to this property will trigger replacement. string

This variable determines the default output format used by EXPLAIN in the absence of a FORMAT option when displaying a query execution plan.

explainFormat corresponds to the MySQL system variable explain_format.

ExplicitDefaultsForTimestamp Changes to this property will trigger replacement. bool

This system variable determines whether the server enables certain nonstandard behaviors for default values and NULL-value handling in TIMESTAMP columns. By default, explicit_defaults_for_timestamp is enabled, which disables the nonstandard behaviors. Disabling explicit_defaults_for_timestamp results in a warning.

explicit_defaults_for_timestamp corresponds to the MySQL Server Administration system variable explicit_defaults_for_timestamp

ForeignKeyChecks Changes to this property will trigger replacement. bool
("foreign_key_checks")
GeneratedRandomPasswordLength Changes to this property will trigger replacement. int
("generated_random_password_length") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'generated_random_password_length' field has been deprecated and may be removed in a future version. Do not use this field.

GlobalConnectionMemoryLimit Changes to this property will trigger replacement. string

Set the total amount of memory that can be used by all user connections.

globalConnectionMemoryLimit corresponds to the MySQL system variable global_connection_memory_limit.

GlobalConnectionMemoryTracking Changes to this property will trigger replacement. bool

Determines whether the MySQL server calculates Global_connection_memory.

globalConnectionMemoryTracking corresponds to the MySQL system variable global_connection_memory_tracking.

GroupConcatMaxLen Changes to this property will trigger replacement. string

Specifies the maximum permitted result length in bytes for the GROUP_CONCAT() function.

This is the MySQL variable "group_concat_max_len". For more information, please see the MySQL documentation

GroupReplicationConsistency Changes to this property will trigger replacement. string
  • EVENTUAL: Both RO and RW transactions do not wait for preceding transactions to be applied before executing. A RW transaction does not wait for other members to apply a transaction. This means that a transaction could be externalized on one member before the others. This also means that in the event of a primary failover, the new primary can accept new RO and RW transactions before the previous primary transactions are all applied. RO transactions could result in outdated values, RW transactions could result in a rollback due to conflicts.
  • BEFORE_ON_PRIMARY_FAILOVER: New RO or RW transactions with a newly elected primary that is applying backlog from the old primary are held (not applied) until any backlog has been applied. This ensures that when a primary failover happens, intentionally or not, clients always see the latest value on the primary. This guarantees consistency, but means that clients must be able to handle the delay in the event that a backlog is being applied. Usually this delay should be minimal, but does depend on the size of the backlog.
  • BEFORE: A RW transaction waits for all preceding transactions to complete before being applied. A RO transaction waits for all preceding transactions to complete before being executed. This ensures that this transaction reads the latest value by only affecting the latency of the transaction. This reduces the overhead of synchronization on every RW transaction, by ensuring synchronization is used only on RO transactions. This consistency level also includes the consistency guarantees provided by BEFORE_ON_PRIMARY_FAILOVER.
  • AFTER: A RW transaction waits until its changes have been applied to all of the other members. This value has no effect on RO transactions. This mode ensures that when a transaction is committed on the local member, any subsequent transaction reads the written value or a more recent value on any group member. Use this mode with a group that is used for predominantly RO operations to ensure that applied RW transactions are applied everywhere once they commit. This could be used by your application to ensure that subsequent reads fetch the latest data which includes the latest writes. This reduces the overhead of synchronization on every RO transaction, by ensuring synchronization is used only on RW transactions. This consistency level also includes the consistency guarantees provided by BEFORE_ON_PRIMARY_FAILOVER.
  • BEFORE_AND_AFTER: A RW transaction waits for 1) all preceding transactions to complete before being applied and 2) until its changes have been applied on other members. A RO transaction waits for all preceding transactions to complete before execution takes place. This consistency level also includes the consistency guarantees provided by BEFORE_ON_PRIMARY_FAILOVER.
InformationSchemaStatsExpiry Changes to this property will trigger replacement. int
("information_schema_stats_expiry")
InnodbAdaptiveHashIndex Changes to this property will trigger replacement. bool

Whether the InnoDB adaptive hash index is enabled or disabled. It may be desirable, depending on your workload, to dynamically enable or disable adaptive hash indexing to improve query performance. Because the adaptive hash index may not be useful for all workloads, conduct benchmarks with it both enabled and disabled, using realistic workloads.

innodbAdaptiveHashIndex corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_adaptive_hash_index] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_adaptive_hash_index).

InnodbAutoincLockMode Changes to this property will trigger replacement. int

The lock mode to use for generating auto-increment values. Permissible values are 0, 1, or 2, for traditional, consecutive, or interleaved, respectively.

innodbAutoincLockMode corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_autoinc_lock_mode] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_autoinc_lock_mode).

InnodbBufferPoolDumpPct Changes to this property will trigger replacement. int

Specifies the percentage of the most recently used pages for each buffer pool to read out and dump.

innodbBufferPoolDumpPct corresponds to the MySQL InnoDB system variable innodb_buffer_pool_dump_pct.

The range is 1 to 100. The default value is 25.

For example, if there are 4 buffer pools with 100 pages each, and innodb_buffer_pool_dump_pct is set to 25, the 25 most recently used pages from each buffer pool are dumped.

InnodbBufferPoolInstances Changes to this property will trigger replacement. int
("innodb_buffer_pool_instances")
InnodbBufferPoolSize Changes to this property will trigger replacement. string

The size (in bytes) of the buffer pool, that is, the memory area where InnoDB caches table and index data.

innodbBufferPoolSize corresponds to the MySQL server system variable innodb_buffer_pool_size.

The default and maximum values depend on the amount of RAM provisioned by the shape. See Default User Variables.

InnodbChangeBuffering Changes to this property will trigger replacement. string

Whether InnoDB performs change buffering, an optimization that delays write operations to secondary indexes so that the I/O operations can be performed sequentially. Permitted values are described in the following table. Values may also be specified numerically.

innodbChangeBuffering corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_change_buffering] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_change_buffering).

InnodbDdlBufferSize Changes to this property will trigger replacement. string
innodbDdlBufferSize corresponds to the MySQL system variable [innodb_ddl_buffer_size] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_ddl_buffer_size)
InnodbDdlThreads Changes to this property will trigger replacement. int
innodbDdlThreads corresponds to the MySQL system variable [innodb_ddl_threads] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_ddl_threads)
InnodbFtEnableStopword Changes to this property will trigger replacement. bool
("innodb_ft_enable_stopword")
InnodbFtMaxTokenSize Changes to this property will trigger replacement. int
("innodb_ft_max_token_size")
InnodbFtMinTokenSize Changes to this property will trigger replacement. int
("innodb_ft_min_token_size")
InnodbFtNumWordOptimize Changes to this property will trigger replacement. int
("innodb_ft_num_word_optimize")
InnodbFtResultCacheLimit Changes to this property will trigger replacement. string
("innodb_ft_result_cache_limit")
InnodbFtServerStopwordTable Changes to this property will trigger replacement. string
("innodb_ft_server_stopword_table")
InnodbLockWaitTimeout Changes to this property will trigger replacement. int
("innodb_lock_wait_timeout")
InnodbLogWriterThreads Changes to this property will trigger replacement. bool

Enables dedicated log writer threads for writing redo log records from the log buffer to the system buffers and flushing the system buffers to the redo log files.

This is the MySQL variable "innodb_log_writer_threads". For more information, please see the MySQL documentation

InnodbMaxPurgeLag Changes to this property will trigger replacement. string

The desired maximum purge lag in terms of transactions.

InnoDB maintains a list of transactions that have index records delete-marked by UPDATE or DELETE operations. The length of the list is the purge lag.

If this value is exceeded, a delay is imposed on INSERT, UPDATE, and DELETE operations to allow time for purge to catch up.

The default value is 0, which means there is no maximum purge lag and no delay.

innodbMaxPurgeLag corresponds to the MySQL server system variable innodb_max_purge_lag.

InnodbMaxPurgeLagDelay Changes to this property will trigger replacement. int

The maximum delay in microseconds for the delay imposed when the innodb_max_purge_lag threshold is exceeded.

The specified innodb_max_purge_lag_delay value is an upper limit on the delay period.

innodbMaxPurgeLagDelay corresponds to the MySQL server system variable innodb_max_purge_lag_delay.

InnodbNumaInterleave Changes to this property will trigger replacement. bool

Enables the NUMA interleave memory policy for allocation of the InnoDB buffer pool. When innodb_numa_interleave is enabled, the NUMA memory policy is set to MPOL_INTERLEAVE for the mysqld process. After the InnoDB buffer pool is allocated, the NUMA memory policy is set back to MPOL_DEFAULT. For the innodb_numa_interleave option to be available, MySQL must be compiled on a NUMA-enabled Linux system.

innodbNumaInterleave corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_numa_interleave] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_numa_interleave).

InnodbOnlineAlterLogMaxSize Changes to this property will trigger replacement. string

Specifies an upper limit in bytes on the size of the temporary log files used during online DDL operations for InnoDB tables. There is one such log file for each index being created or table being altered. This log file stores data inserted, updated, or deleted in the table during the DDL operation.

innodbOnlineAlterLogMaxSize corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_online_alter_log_max_size] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_online_alter_log_max_size).

InnodbRedoLogCapacity Changes to this property will trigger replacement. string

Defines the amount of disk space occupied by redo log files. innodb_redo_log_capacity supercedes the innodb_log_files_in_group and innodb_log_file_size variables, which are both ignored if innodb_redo_log_capacity is defined. If innodb_redo_log_capacity is not defined, and if neither innodb_log_file_size or innodb_log_files_in_group are defined, then the default innodb_redo_log_capacity value is used.

innodbRedoLogCapacity corresponds to the InnoDB Startup Options and System Variables innodb_redo_log_capacity

InnodbRollbackOnTimeout Changes to this property will trigger replacement. bool

InnoDB rolls back only the last statement on a transaction timeout by default. If --innodb-rollback-on-timeout is specified, a transaction timeout causes InnoDB to abort and roll back the entire transaction.

innodbRollbackOnTimeout corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_rollback_on_timeout] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_rollback_on_timeout).

InnodbSortBufferSize Changes to this property will trigger replacement. int

This variable defines:

  • The sort buffer size for online DDL operations that create or rebuild secondary indexes. However, as of MySQL 8.0.27, this responsibility is subsumed by the innodb_ddl_buffer_size variable.
  • The amount by which the temporary log file is extended when recording concurrent DML during an online DDL operation, and the size of the temporary log file read buffer and write buffer.

innodbSortBufferSize corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_sort_buffer_size] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_sort_buffer_size).

InnodbStatsPersistentSamplePages Changes to this property will trigger replacement. string

The number of index pages to sample when estimating cardinality and other statistics for an indexed column, such as those calculated by ANALYZE TABLE.

innodbStatsPersistentSamplePages corresponds to the MySQL InnoDB system variable innodb_stats_persistent_sample_pages

innodb_stats_persistent_sample_pages only applies when innodb_stats_persistent is enabled for a table; when innodb_stats_persistent is disabled, innodb_stats_transient_sample_pages applies instead.

InnodbStatsTransientSamplePages Changes to this property will trigger replacement. string

The number of index pages to sample when estimating cardinality and other statistics for an indexed column, such as those calculated by ANALYZE TABLE.

innodbStatsTransientSamplePages corresponds to the MySQL InnoDB system variable innodb_stats_transient_sample_pages

innodb_stats_transient_sample_pages only applies when innodb_stats_persistent is disabled for a table; when innodb_stats_persistent is enabled, innodb_stats_persistent_sample_pages applies instead.

innodb_stats_persistent is ON by default and cannot be changed. It is possible to override it using the STATS_PERSISTENT clause of the CREATE TABLE and ALTER TABLE statements.

InnodbStrictMode Changes to this property will trigger replacement. bool

When you enable innodbStrictMode, the InnoDB storage engine returns errors instead of warnings for invalid or incompatible table options.

innodbStrictMode corresponds to the MySQL InnoDB system variable innodb_strict_mode

InnodbUndoLogTruncate Changes to this property will trigger replacement. bool

When enabled, undo tablespaces that exceed the threshold value defined by innodb_max_undo_log_size are marked for truncation. Only undo tablespaces can be truncated. Truncating undo logs that reside in the system tablespace is not supported. For truncation to occur, there must be at least two undo tablespaces.

innodbUndoLogTruncate corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_undo_log_truncate] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_undo_log_truncate).

InteractiveTimeout Changes to this property will trigger replacement. int

The number of seconds the server waits for activity on an interactive connection before closing it.

interactiveTimeout corresponds to the MySQL system variable. interactive_timeout

JoinBufferSize Changes to this property will trigger replacement. string

The minimum size of the buffer that is used for plain index scans, range index scans, and joins that do not use indexes and thus perform full table scans. In MySQL 8.0.18 and later, this variable also controls the amount of memory used for hash joins. Normally, the best way to get fast joins is to add indexes. Increase the value of join_buffer_size to get a faster full join when adding indexes is not possible. One join buffer is allocated for each full join between two tables. For a complex join between several tables for which indexes are not used, multiple join buffers might be necessary.

joinBufferSize corresponds to the MySQL Server System variable [join_buffer_size] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_join_buffer_size).

LocalInfile Changes to this property will trigger replacement. bool

This variable controls server-side LOCAL capability for LOAD DATA statements. Depending on the local_infile setting, the server refuses or permits local data loading by clients that have LOCAL enabled on the client side.

local_infile corresponds to the MySQL Server system variable local_infile

LongQueryTime Changes to this property will trigger replacement. int

If a query takes longer than this many seconds, the server increments the Slow_queries status variable. If the slow query log is enabled, the query is logged to the slow query log file. This value is measured in real time, not CPU time, so a query that is under the threshold on a lightly loaded system might be above the threshold on a heavily loaded one.

longQueryTime corresponds to the MySQL Server System variable [long_query_time] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_long_query_time).

MandatoryRoles Changes to this property will trigger replacement. string
("mandatory_roles")
MaxAllowedPacket Changes to this property will trigger replacement. int

The maximum size of one packet or any generated/intermediate string.

This is the mysql variable "max_allowed_packet".

MaxBinlogCacheSize Changes to this property will trigger replacement. string

Sets the size of the transaction cache.

maxBinlogCacheSize corresponds to the MySQL server system variable max_binlog_cache_size.

MaxConnectErrors Changes to this property will trigger replacement. string
("max_connect_errors")
MaxConnections Changes to this property will trigger replacement. int
("max_connections")
MaxExecutionTime Changes to this property will trigger replacement. string
("max_execution_time")
MaxHeapTableSize Changes to this property will trigger replacement. string

This variable sets the maximum size to which user-created MEMORY tables are permitted to grow.

maxHeapTableSize corresponds to the MySQL system variable max_heap_table_size

MaxPreparedStmtCount Changes to this property will trigger replacement. int
("max_prepared_stmt_count")
MaxSeeksForKey Changes to this property will trigger replacement. string

Limit the assumed maximum number of seeks when looking up rows based on a key. The MySQL optimizer assumes that no more than this number of key seeks are required when searching for matching rows in a table by scanning an index, regardless of the actual cardinality of the index (see Section 15.7.7.22, “SHOW INDEX Statement”). By setting this to a low value (say, 100), you can force MySQL to prefer indexes instead of table scans.

maxSeeksForKey corresponds to the MySQL Server System variable [max_seeks_for_key] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_max_seeks_for_key).

MaxUserConnections Changes to this property will trigger replacement. string

The maximum number of simultaneous connections permitted to any given MySQL user account. A value of 0 (the default) means “no limit.” This variable has a global value that can be set at server startup or runtime. It also has a read-only session value that indicates the effective simultaneous-connection limit that applies to the account associated with the current session.

maxUserConnections corresponds to the MySQL Server System variable [max_user_connections] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_max_user_connections).

MysqlFirewallMode Changes to this property will trigger replacement. bool
("mysql_firewall_mode")
MysqlZstdDefaultCompressionLevel Changes to this property will trigger replacement. int
DEPRECATED -- typo of mysqlx_zstd_default_compression_level. variable will be ignored.

Deprecated: The 'mysql_zstd_default_compression_level' field has been deprecated and may be removed in a future version. Do not use this field.

MysqlxConnectTimeout Changes to this property will trigger replacement. int

The number of seconds X Plugin waits for the first packet to be received from newly connected clients.

mysqlxConnectTimeout corresponds to the MySQL X Plugin system variable mysqlx_connect_timeout

MysqlxDeflateDefaultCompressionLevel Changes to this property will trigger replacement. int
Set the default compression level for the deflate algorithm. ("mysqlx_deflate_default_compression_level")
MysqlxDeflateMaxClientCompressionLevel Changes to this property will trigger replacement. int
Limit the upper bound of accepted compression levels for the deflate algorithm. ("mysqlx_deflate_max_client_compression_level")
MysqlxDocumentIdUniquePrefix Changes to this property will trigger replacement. int
("mysqlx_document_id_unique_prefix") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'mysqlx_document_id_unique_prefix' field has been deprecated and may be removed in a future version. Do not use this field.

MysqlxEnableHelloNotice Changes to this property will trigger replacement. bool
("mysqlx_enable_hello_notice") DEPRECATED -- variable should not be settable and will be ignored
MysqlxIdleWorkerThreadTimeout Changes to this property will trigger replacement. int
("mysqlx_idle_worker_thread_timeout") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'mysqlx_idle_worker_thread_timeout' field has been deprecated and may be removed in a future version. Do not use this field.

MysqlxInteractiveTimeout Changes to this property will trigger replacement. int

The number of seconds to wait for interactive clients to timeout.

mysqlxInteractiveTimeout corresponds to the MySQL X Plugin system variable. mysqlx_interactive_timeout

MysqlxLz4defaultCompressionLevel Changes to this property will trigger replacement. int
Set the default compression level for the lz4 algorithm. ("mysqlx_lz4_default_compression_level")
MysqlxLz4maxClientCompressionLevel Changes to this property will trigger replacement. int
Limit the upper bound of accepted compression levels for the lz4 algorithm. ("mysqlx_lz4_max_client_compression_level")
MysqlxMaxAllowedPacket Changes to this property will trigger replacement. int

The maximum size of network packets that can be received by X Plugin.

This is the mysql variable "mysqlx_max_allowed_packet".

MysqlxMinWorkerThreads Changes to this property will trigger replacement. int
("mysqlx_min_worker_threads") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'mysqlx_min_worker_threads' field has been deprecated and may be removed in a future version. Do not use this field.

MysqlxReadTimeout Changes to this property will trigger replacement. int

The number of seconds that X Plugin waits for blocking read operations to complete. After this time, if the read operation is not successful, X Plugin closes the connection and returns a warning notice with the error code ER_IO_READ_ERROR to the client application.

mysqlxReadTimeout corresponds to the MySQL X Plugin system variable mysqlx_read_timeout

MysqlxWaitTimeout Changes to this property will trigger replacement. int

The number of seconds that X Plugin waits for activity on a connection.

mysqlxWaitTimeout corresponds to the MySQL X Plugin system variable. mysqlx_wait_timeout

MysqlxWriteTimeout Changes to this property will trigger replacement. int

The number of seconds that X Plugin waits for blocking write operations to complete. After this time, if the write operation is not successful, X Plugin closes the connection.

mysqlxReadmysqlxWriteTimeoutTimeout corresponds to the MySQL X Plugin system variable mysqlx_write_timeout

MysqlxZstdDefaultCompressionLevel Changes to this property will trigger replacement. int
Set the default compression level for the zstd algorithm. ("mysqlx_zstd_default_compression_level")
MysqlxZstdMaxClientCompressionLevel Changes to this property will trigger replacement. int
Limit the upper bound of accepted compression levels for the zstd algorithm. ("mysqlx_zstd_max_client_compression_level")
NetReadTimeout Changes to this property will trigger replacement. int

The number of seconds to wait for more data from a connection before aborting the read.

netReadTimeout corresponds to the MySQL system variable net_read_timeout

NetWriteTimeout Changes to this property will trigger replacement. int

The number of seconds to wait for a block to be written to a connection before aborting the write.

netWriteTimeout corresponds to the MySQL system variable net_write_timeout

OptimizerSwitch Changes to this property will trigger replacement. string

The optimizer_switch system variable enables control over optimizer behavior. The value of this variable is a set of flags, each of which has a value of on or off to indicate whether the corresponding optimizer behavior is enabled or disabled. This variable has global and session values and can be changed at runtime. The global default can be set at server startup.

Setting hypergraph_optimizer=on for cloud builds below 9.0.0 will fail.

optimizerSwitch corresponds to the MySQL Server System variable [optimizer_switch] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_optimizer_switch).

ParserMaxMemSize Changes to this property will trigger replacement. string
("parser_max_mem_size")
QueryAllocBlockSize Changes to this property will trigger replacement. string
("query_alloc_block_size") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'query_alloc_block_size' field has been deprecated and may be removed in a future version. Do not use this field.

QueryPreallocSize Changes to this property will trigger replacement. string
("query_prealloc_size") DEPRECATED -- variable should not be settable and will be ignored
RangeOptimizerMaxMemSize Changes to this property will trigger replacement. string

The limit on memory consumption for the range optimizer. A value of 0 means “no limit.” If an execution plan considered by the optimizer uses the range access method but the optimizer estimates that the amount of memory needed for this method would exceed the limit, it abandons the plan and considers other plans.

rangeOptimizerMaxMemSize corresponds to the MySQL Server System variable [range_optimizer_max_mem_size] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_range_optimizer_max_mem_size).

Deprecated: The 'query_prealloc_size' field has been deprecated and may be removed in a future version. Do not use this field.

RegexpTimeLimit Changes to this property will trigger replacement. int
regexpTimeLimit corresponds to the MySQL system variable [regexp_time_limit] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_regexp_time_limit)
RelayLogSpaceLimit Changes to this property will trigger replacement. string

The maximum amount of space to use for all relay logs.

relayLogSpaceLimit corresponds to the MySQL Replica Server Options variable [relay_log_space_limit] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-replica.html#sysvar_relay_log_space_limit).

ReplicaNetTimeout Changes to this property will trigger replacement. int

Specifies the number of seconds to wait for more data or a heartbeat signal from the source before the replica considers the connection broken, aborts the read, and tries to reconnect. Setting this variable has no immediate effect. The state of the variable applies on all subsequent START REPLICA commands.

replicaNetTimeout corresponds to the MySQL Replica server system variable replica_net_timeout

ReplicaParallelWorkers Changes to this property will trigger replacement. int

Beginning with MySQL 8.0.26, slave_parallel_workers is deprecated, and you should use replica_parallel_workers instead. (Prior to MySQL 8.0.26, you must use slave_parallel_workers to set the number of applier threads.)

replicaParallelWorkers corresponds to the MySQL Replica Server Options variable [replica_parallel_workers] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-replica.html#sysvar_replica_parallel_workers).

ReplicaTypeConversions Changes to this property will trigger replacement. string

From MySQL 8.0.26, use replica_type_conversions in place of slave_type_conversions, which is deprecated from that release. In releases before MySQL 8.0.26, use slave_type_conversions.

replica_type_conversions controls the type conversion mode in effect on the replica when using row-based replication. Its value is a comma-delimited set of zero or more elements from the list: ALL_LOSSY, ALL_NON_LOSSY, ALL_SIGNED, ALL_UNSIGNED. Set this variable to an empty string to disallow type conversions between the source and the replica. Setting this variable takes effect for all replication channels immediately, including running channels.

replica_type_conversions corresponds to the MySQL Replica Server Options variable [replica_type_conversions] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-replica.html#sysvar_replica_type_conversions).

RequireSecureTransport Changes to this property will trigger replacement. bool

Whether client connections to the server are required to use some form of secure transport. When this variable is enabled, the server permits only TCP/IP connections encrypted using TLS/SSL, or connections that use a socket file or shared memory. The server rejects nonsecure connection attempts, which fail with an ER_SECURE_TRANSPORT_REQUIRED error.

require_secure_transport corresponds to the MySQL Server Administration system variable require_secure_transport

SkipNameResolve Changes to this property will trigger replacement. bool

Whether to resolve host names when checking client connections. If this variable is OFF, mysqld resolves host names when checking client connections. If it is ON, mysqld uses only IP numbers; in this case, all Host column values in the grant tables must be IP addresses. See Section 7.1.12.3, “DNS Lookups and the Host Cache”.

skipNameResolve corresponds to the MySQL Server System variable [skip_name_resolve] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_skip_name_resolve).

SortBufferSize Changes to this property will trigger replacement. string

Each session that must perform a sort allocates a buffer of this size.

sortBufferSize corresponds to the MySQL system variable sort_buffer_size

SqlGenerateInvisiblePrimaryKey Changes to this property will trigger replacement. bool

Whether GIPK mode is in effect, in which case a MySQL replication source server adds a generated invisible primary key to any InnoDB table that is created without one.

sqlGenerateInvisiblePrimaryKey corresponds to the MySQL system variable [sql_generate_invisible_primary_key] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_sql_generate_invisible_primary_key).

SqlMode Changes to this property will trigger replacement. string
("sql_mode")
SqlRequirePrimaryKey Changes to this property will trigger replacement. bool
("sql_require_primary_key")
SqlWarnings Changes to this property will trigger replacement. bool
("sql_warnings")
TableDefinitionCache Changes to this property will trigger replacement. int

The number of table definitions that can be stored in the table definition cache. If you use a large number of tables, you can create a large table definition cache to speed up opening of tables. The table definition cache takes less space and does not use file descriptors, unlike the normal table cache.

table_definition_cache corresponds to the MySQL Server Administration system variable table_definition_cache

TableOpenCache Changes to this property will trigger replacement. int

The number of open tables for all threads. Increasing this value increases the number of file descriptors that mysqld requires.

table_open_cache corresponds to the MySQL Server Administration system variable table_open_cache

TemptableMaxRam Changes to this property will trigger replacement. string

Defines the maximum amount of memory that can be occupied by the TempTable storage engine before it starts storing data on disk. The default value is 1073741824 bytes (1GiB). For more information, see Section 10.4.4, “Internal Temporary Table Use in MySQL”.

temptableMaxRam corresponds to the MySQL system variable [temptable_max_ram] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_temptable_max_ram).

ThreadPoolDedicatedListeners Changes to this property will trigger replacement. bool
Controls whether the thread pool uses dedicated listener threads. If enabled, a listener thread in each thread group is dedicated to the task of listening for network events from clients, ensuring that the maximum number of query worker threads is no more than the value specified by threadPoolMaxTransactionsLimit. threadPoolDedicatedListeners corresponds to the MySQL Database Service-specific system variable thread_pool_dedicated_listeners.
ThreadPoolMaxTransactionsLimit Changes to this property will trigger replacement. int
Limits the maximum number of open transactions to the defined value. The default value is 0, which enforces no limit. threadPoolMaxTransactionsLimit corresponds to the MySQL Database Service-specific system variable thread_pool_max_transactions_limit.
ThreadPoolQueryThreadsPerGroup Changes to this property will trigger replacement. int

The maximum number of query threads permitted in a thread group. The maximum value is 4096, but if thread_pool_max_transactions_limit is set, thread_pool_query_threads_per_group must not exceed that value. The default value of 1 means there is one active query thread in each thread group, which works well for many loads. When you are using the high concurrency thread pool algorithm (thread_pool_algorithm = 1), consider increasing the value if you experience slower response times due to long-running transactions.

threadPoolQueryThreadsPerGroup corresponds to the MySQL Server system variable thread_pool_query_threads_per_group

ThreadPoolSize Changes to this property will trigger replacement. int

The number of thread groups in the thread pool. This is the most important parameter controlling thread pool performance. It affects how many statements can execute simultaneously. If a value outside the range of permissible values is specified, the thread pool plugin does not load and the server writes a message to the error log.

threadPoolSize corresponds to the MySQL Server System variable [thread_pool_size] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_thread_pool_size).

ThreadPoolTransactionDelay Changes to this property will trigger replacement. int

The delay period before executing a new transaction, in milliseconds. The maximum value is 300000 (5 minutes). A transaction delay can be used in cases where parallel transactions affect the performance of other operations due to resource contention. For example, if parallel transactions affect index creation or an online buffer pool resizing operation, you can configure a transaction delay to reduce resource contention while those operations are running.

threadPoolTransactionDelay corresponds to the MySQL Server system variable thread_pool_transaction_delay

TimeZone Changes to this property will trigger replacement. string

Initializes the time zone for each client that connects.

This corresponds to the MySQL System Variable "time_zone".

The values can be given in one of the following formats, none of which are case-sensitive:

  • As a string indicating an offset from UTC of the form [H]H:MM, prefixed with a + or -, such as '+10:00', '-6:00', or '+05:30'. The permitted range is '-13:59' to '+14:00', inclusive.
  • As a named time zone, as defined by the "IANA Time Zone database", such as 'Europe/Helsinki', 'US/Eastern', 'MET', or 'UTC'.
TmpTableSize Changes to this property will trigger replacement. string

The maximum size of internal in-memory temporary tables. This variable does not apply to user-created MEMORY tables.

tmp_table_size corresponds to the MySQL system variable tmp_table_size

TransactionIsolation Changes to this property will trigger replacement. string
("transaction_isolation")
WaitTimeout Changes to this property will trigger replacement. int

The number of seconds the server waits for activity on a noninteractive connection before closing it.

waitTimeout corresponds to the MySQL system variable. wait_timeout

** IMPORTANT ** Any change to a property that does not support update will force the destruction and recreation of the resource with the new property values

autoIncrementIncrement Changes to this property will trigger replacement. Integer

auto_increment_increment and auto_increment_offset are intended for use with circular (source-to-source) replication, and can be used to control the operation of AUTO_INCREMENT columns. Both variables have global and session values, and each can assume an integer value between 1 and 65,535 inclusive.

autoIncrementIncrement corresponds to the MySQL Replication Source Options variable [auto_increment_increment] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-source.html#sysvar_auto_increment_increment).

autoIncrementOffset Changes to this property will trigger replacement. Integer

This variable has a default value of 1. If it is left with its default value, and Group Replication is started on the server in multi-primary mode, it is changed to the server ID.

autoIncrementOffset corresponds to the MySQL Replication Source Options variable [auto_increment_offset] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-source.html#sysvar_auto_increment_offset).

autocommit Changes to this property will trigger replacement. Boolean
("autocommit")
bigTables Changes to this property will trigger replacement. Boolean

If enabled, the server stores all temporary tables on disk rather than in memory.

bigTables corresponds to the MySQL server variable big_tables.

binlogExpireLogsSeconds Changes to this property will trigger replacement. Integer
Sets the binary log expiration period in seconds. binlogExpireLogsSeconds corresponds to the MySQL binary logging system variable binlog_expire_logs_seconds.
binlogGroupCommitSyncDelay Changes to this property will trigger replacement. Integer

Controls how many microseconds the binary log commit waits before synchronizing the binary log file to disk. There is no delay by default. Setting this variable to a microsecond delay enables more transactions to be synchronized together to disk at once, reducing the overall time to commit a group of transactions because the larger groups required fewer time units per group.

binlogGroupCommitSyncDelay corresponds to the MySQL Replication system variable binlog_group_commit_sync_delay

binlogGroupCommitSyncNoDelayCount Changes to this property will trigger replacement. Integer

The maximum number of transactions to wait for before aborting the current delay as specified by binlog_group_commit_sync_delay. If binlog_group_commit_sync_delay is set to 0, then this option has no effect.

binlogGroupCommitSyncNoDelayCount corresponds to the MySQL Replication system variable binlog_group_commit_sync_no_delay_count

binlogRowMetadata Changes to this property will trigger replacement. String
Configures the amount of table metadata added to the binary log when using row-based logging. binlogRowMetadata corresponds to the MySQL binary logging system variable binlog_row_metadata.
binlogRowValueOptions Changes to this property will trigger replacement. String
When set to PARTIAL_JSON, this enables use of a space-efficient binary log format for updates that modify only a small portion of a JSON document. binlogRowValueOptions corresponds to the MySQL binary logging system variable binlog_row_value_options.
binlogTransactionCompression Changes to this property will trigger replacement. Boolean
Enables compression for transactions that are written to binary log files on this server. binlogTransactionCompression corresponds to the MySQL binary logging system variable binlog_transaction_compression.
blockEncryptionMode Changes to this property will trigger replacement. String

This variable controls the block encryption mode for block-based algorithms such as AES. It affects encryption for AES_ENCRYPT() and AES_DECRYPT(). block_encryption_mode takes a value in aes-keylen-mode format, where keylen is the key length in bits and mode is the encryption mode. The value is not case-sensitive. Permitted keylen values are 128, 192, and 256. Permitted mode values are ECB, CBC, CFB1, CFB8, CFB128, and OFB.

block_encryption_mode corresponds to the MySQL Server Administration system variable block_encryption_mode

characterSetServer Changes to this property will trigger replacement. String

The server's default character set. If you set this variable, you should also set collation_server to specify the collation for the character set.

characterSetServer corresponds to the MySQL server variable character_set_server.

collationServer Changes to this property will trigger replacement. String

The server's default collation.

collationServer corresponds to the MySQL server variable collation_server.

completionType Changes to this property will trigger replacement. String
("completion_type")
connectTimeout Changes to this property will trigger replacement. Integer

The number of seconds that the mysqld server waits for a connect packet before responding with Bad handshake.

connectTimeout corresponds to the MySQL system variable connect_timeout

Increasing the connect_timeout value might help if clients frequently encounter errors of the form "Lost connection to MySQL server at 'XXX', system error: errno".

connectionMemoryChunkSize Changes to this property will trigger replacement. Integer

Set the chunking size for updates to the global memory usage counter Global_connection_memory.

connectionMemoryChunkSize corresponds to the MySQL system variable connection_memory_chunk_size.

connectionMemoryLimit Changes to this property will trigger replacement. String

Set the maximum amount of memory that can be used by a single user connection.

connectionMemoryLimit corresponds to the MySQL system variable connection_memory_limit.

cteMaxRecursionDepth Changes to this property will trigger replacement. String
("cte_max_recursion_depth")
defaultAuthenticationPlugin Changes to this property will trigger replacement. String

The default authentication plugin. This must be a plugin that uses internal credentials storage, so these values are permitted: mysql_native_password, sha256_password, caching_sha2_password.

As of MySQL 8.0.27, which introduces multifactor authentication, default_authentication_plugin is still used, but in conjunction with and at a lower precedence than the authentication_policy system variable. For details, see The Default Authentication Plugin. Because of this diminished role, default_authentication_plugin is deprecated as of MySQL 8.0.27 and subject to removal in a future MySQL version.

defaultAuthenticationPlugin corresponds to the MySQL system variable default_authentication_plugin.

explainFormat Changes to this property will trigger replacement. String

This variable determines the default output format used by EXPLAIN in the absence of a FORMAT option when displaying a query execution plan.

explainFormat corresponds to the MySQL system variable explain_format.

explicitDefaultsForTimestamp Changes to this property will trigger replacement. Boolean

This system variable determines whether the server enables certain nonstandard behaviors for default values and NULL-value handling in TIMESTAMP columns. By default, explicit_defaults_for_timestamp is enabled, which disables the nonstandard behaviors. Disabling explicit_defaults_for_timestamp results in a warning.

explicit_defaults_for_timestamp corresponds to the MySQL Server Administration system variable explicit_defaults_for_timestamp

foreignKeyChecks Changes to this property will trigger replacement. Boolean
("foreign_key_checks")
generatedRandomPasswordLength Changes to this property will trigger replacement. Integer
("generated_random_password_length") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'generated_random_password_length' field has been deprecated and may be removed in a future version. Do not use this field.

globalConnectionMemoryLimit Changes to this property will trigger replacement. String

Set the total amount of memory that can be used by all user connections.

globalConnectionMemoryLimit corresponds to the MySQL system variable global_connection_memory_limit.

globalConnectionMemoryTracking Changes to this property will trigger replacement. Boolean

Determines whether the MySQL server calculates Global_connection_memory.

globalConnectionMemoryTracking corresponds to the MySQL system variable global_connection_memory_tracking.

groupConcatMaxLen Changes to this property will trigger replacement. String

Specifies the maximum permitted result length in bytes for the GROUP_CONCAT() function.

This is the MySQL variable "group_concat_max_len". For more information, please see the MySQL documentation

groupReplicationConsistency Changes to this property will trigger replacement. String
  • EVENTUAL: Both RO and RW transactions do not wait for preceding transactions to be applied before executing. A RW transaction does not wait for other members to apply a transaction. This means that a transaction could be externalized on one member before the others. This also means that in the event of a primary failover, the new primary can accept new RO and RW transactions before the previous primary transactions are all applied. RO transactions could result in outdated values, RW transactions could result in a rollback due to conflicts.
  • BEFORE_ON_PRIMARY_FAILOVER: New RO or RW transactions with a newly elected primary that is applying backlog from the old primary are held (not applied) until any backlog has been applied. This ensures that when a primary failover happens, intentionally or not, clients always see the latest value on the primary. This guarantees consistency, but means that clients must be able to handle the delay in the event that a backlog is being applied. Usually this delay should be minimal, but does depend on the size of the backlog.
  • BEFORE: A RW transaction waits for all preceding transactions to complete before being applied. A RO transaction waits for all preceding transactions to complete before being executed. This ensures that this transaction reads the latest value by only affecting the latency of the transaction. This reduces the overhead of synchronization on every RW transaction, by ensuring synchronization is used only on RO transactions. This consistency level also includes the consistency guarantees provided by BEFORE_ON_PRIMARY_FAILOVER.
  • AFTER: A RW transaction waits until its changes have been applied to all of the other members. This value has no effect on RO transactions. This mode ensures that when a transaction is committed on the local member, any subsequent transaction reads the written value or a more recent value on any group member. Use this mode with a group that is used for predominantly RO operations to ensure that applied RW transactions are applied everywhere once they commit. This could be used by your application to ensure that subsequent reads fetch the latest data which includes the latest writes. This reduces the overhead of synchronization on every RO transaction, by ensuring synchronization is used only on RW transactions. This consistency level also includes the consistency guarantees provided by BEFORE_ON_PRIMARY_FAILOVER.
  • BEFORE_AND_AFTER: A RW transaction waits for 1) all preceding transactions to complete before being applied and 2) until its changes have been applied on other members. A RO transaction waits for all preceding transactions to complete before execution takes place. This consistency level also includes the consistency guarantees provided by BEFORE_ON_PRIMARY_FAILOVER.
informationSchemaStatsExpiry Changes to this property will trigger replacement. Integer
("information_schema_stats_expiry")
innodbAdaptiveHashIndex Changes to this property will trigger replacement. Boolean

Whether the InnoDB adaptive hash index is enabled or disabled. It may be desirable, depending on your workload, to dynamically enable or disable adaptive hash indexing to improve query performance. Because the adaptive hash index may not be useful for all workloads, conduct benchmarks with it both enabled and disabled, using realistic workloads.

innodbAdaptiveHashIndex corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_adaptive_hash_index] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_adaptive_hash_index).

innodbAutoincLockMode Changes to this property will trigger replacement. Integer

The lock mode to use for generating auto-increment values. Permissible values are 0, 1, or 2, for traditional, consecutive, or interleaved, respectively.

innodbAutoincLockMode corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_autoinc_lock_mode] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_autoinc_lock_mode).

innodbBufferPoolDumpPct Changes to this property will trigger replacement. Integer

Specifies the percentage of the most recently used pages for each buffer pool to read out and dump.

innodbBufferPoolDumpPct corresponds to the MySQL InnoDB system variable innodb_buffer_pool_dump_pct.

The range is 1 to 100. The default value is 25.

For example, if there are 4 buffer pools with 100 pages each, and innodb_buffer_pool_dump_pct is set to 25, the 25 most recently used pages from each buffer pool are dumped.

innodbBufferPoolInstances Changes to this property will trigger replacement. Integer
("innodb_buffer_pool_instances")
innodbBufferPoolSize Changes to this property will trigger replacement. String

The size (in bytes) of the buffer pool, that is, the memory area where InnoDB caches table and index data.

innodbBufferPoolSize corresponds to the MySQL server system variable innodb_buffer_pool_size.

The default and maximum values depend on the amount of RAM provisioned by the shape. See Default User Variables.

innodbChangeBuffering Changes to this property will trigger replacement. String

Whether InnoDB performs change buffering, an optimization that delays write operations to secondary indexes so that the I/O operations can be performed sequentially. Permitted values are described in the following table. Values may also be specified numerically.

innodbChangeBuffering corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_change_buffering] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_change_buffering).

innodbDdlBufferSize Changes to this property will trigger replacement. String
innodbDdlBufferSize corresponds to the MySQL system variable [innodb_ddl_buffer_size] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_ddl_buffer_size)
innodbDdlThreads Changes to this property will trigger replacement. Integer
innodbDdlThreads corresponds to the MySQL system variable [innodb_ddl_threads] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_ddl_threads)
innodbFtEnableStopword Changes to this property will trigger replacement. Boolean
("innodb_ft_enable_stopword")
innodbFtMaxTokenSize Changes to this property will trigger replacement. Integer
("innodb_ft_max_token_size")
innodbFtMinTokenSize Changes to this property will trigger replacement. Integer
("innodb_ft_min_token_size")
innodbFtNumWordOptimize Changes to this property will trigger replacement. Integer
("innodb_ft_num_word_optimize")
innodbFtResultCacheLimit Changes to this property will trigger replacement. String
("innodb_ft_result_cache_limit")
innodbFtServerStopwordTable Changes to this property will trigger replacement. String
("innodb_ft_server_stopword_table")
innodbLockWaitTimeout Changes to this property will trigger replacement. Integer
("innodb_lock_wait_timeout")
innodbLogWriterThreads Changes to this property will trigger replacement. Boolean

Enables dedicated log writer threads for writing redo log records from the log buffer to the system buffers and flushing the system buffers to the redo log files.

This is the MySQL variable "innodb_log_writer_threads". For more information, please see the MySQL documentation

innodbMaxPurgeLag Changes to this property will trigger replacement. String

The desired maximum purge lag in terms of transactions.

InnoDB maintains a list of transactions that have index records delete-marked by UPDATE or DELETE operations. The length of the list is the purge lag.

If this value is exceeded, a delay is imposed on INSERT, UPDATE, and DELETE operations to allow time for purge to catch up.

The default value is 0, which means there is no maximum purge lag and no delay.

innodbMaxPurgeLag corresponds to the MySQL server system variable innodb_max_purge_lag.

innodbMaxPurgeLagDelay Changes to this property will trigger replacement. Integer

The maximum delay in microseconds for the delay imposed when the innodb_max_purge_lag threshold is exceeded.

The specified innodb_max_purge_lag_delay value is an upper limit on the delay period.

innodbMaxPurgeLagDelay corresponds to the MySQL server system variable innodb_max_purge_lag_delay.

innodbNumaInterleave Changes to this property will trigger replacement. Boolean

Enables the NUMA interleave memory policy for allocation of the InnoDB buffer pool. When innodb_numa_interleave is enabled, the NUMA memory policy is set to MPOL_INTERLEAVE for the mysqld process. After the InnoDB buffer pool is allocated, the NUMA memory policy is set back to MPOL_DEFAULT. For the innodb_numa_interleave option to be available, MySQL must be compiled on a NUMA-enabled Linux system.

innodbNumaInterleave corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_numa_interleave] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_numa_interleave).

innodbOnlineAlterLogMaxSize Changes to this property will trigger replacement. String

Specifies an upper limit in bytes on the size of the temporary log files used during online DDL operations for InnoDB tables. There is one such log file for each index being created or table being altered. This log file stores data inserted, updated, or deleted in the table during the DDL operation.

innodbOnlineAlterLogMaxSize corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_online_alter_log_max_size] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_online_alter_log_max_size).

innodbRedoLogCapacity Changes to this property will trigger replacement. String

Defines the amount of disk space occupied by redo log files. innodb_redo_log_capacity supercedes the innodb_log_files_in_group and innodb_log_file_size variables, which are both ignored if innodb_redo_log_capacity is defined. If innodb_redo_log_capacity is not defined, and if neither innodb_log_file_size or innodb_log_files_in_group are defined, then the default innodb_redo_log_capacity value is used.

innodbRedoLogCapacity corresponds to the InnoDB Startup Options and System Variables innodb_redo_log_capacity

innodbRollbackOnTimeout Changes to this property will trigger replacement. Boolean

InnoDB rolls back only the last statement on a transaction timeout by default. If --innodb-rollback-on-timeout is specified, a transaction timeout causes InnoDB to abort and roll back the entire transaction.

innodbRollbackOnTimeout corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_rollback_on_timeout] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_rollback_on_timeout).

innodbSortBufferSize Changes to this property will trigger replacement. Integer

This variable defines:

  • The sort buffer size for online DDL operations that create or rebuild secondary indexes. However, as of MySQL 8.0.27, this responsibility is subsumed by the innodb_ddl_buffer_size variable.
  • The amount by which the temporary log file is extended when recording concurrent DML during an online DDL operation, and the size of the temporary log file read buffer and write buffer.

innodbSortBufferSize corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_sort_buffer_size] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_sort_buffer_size).

innodbStatsPersistentSamplePages Changes to this property will trigger replacement. String

The number of index pages to sample when estimating cardinality and other statistics for an indexed column, such as those calculated by ANALYZE TABLE.

innodbStatsPersistentSamplePages corresponds to the MySQL InnoDB system variable innodb_stats_persistent_sample_pages

innodb_stats_persistent_sample_pages only applies when innodb_stats_persistent is enabled for a table; when innodb_stats_persistent is disabled, innodb_stats_transient_sample_pages applies instead.

innodbStatsTransientSamplePages Changes to this property will trigger replacement. String

The number of index pages to sample when estimating cardinality and other statistics for an indexed column, such as those calculated by ANALYZE TABLE.

innodbStatsTransientSamplePages corresponds to the MySQL InnoDB system variable innodb_stats_transient_sample_pages

innodb_stats_transient_sample_pages only applies when innodb_stats_persistent is disabled for a table; when innodb_stats_persistent is enabled, innodb_stats_persistent_sample_pages applies instead.

innodb_stats_persistent is ON by default and cannot be changed. It is possible to override it using the STATS_PERSISTENT clause of the CREATE TABLE and ALTER TABLE statements.

innodbStrictMode Changes to this property will trigger replacement. Boolean

When you enable innodbStrictMode, the InnoDB storage engine returns errors instead of warnings for invalid or incompatible table options.

innodbStrictMode corresponds to the MySQL InnoDB system variable innodb_strict_mode

innodbUndoLogTruncate Changes to this property will trigger replacement. Boolean

When enabled, undo tablespaces that exceed the threshold value defined by innodb_max_undo_log_size are marked for truncation. Only undo tablespaces can be truncated. Truncating undo logs that reside in the system tablespace is not supported. For truncation to occur, there must be at least two undo tablespaces.

innodbUndoLogTruncate corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_undo_log_truncate] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_undo_log_truncate).

interactiveTimeout Changes to this property will trigger replacement. Integer

The number of seconds the server waits for activity on an interactive connection before closing it.

interactiveTimeout corresponds to the MySQL system variable. interactive_timeout

joinBufferSize Changes to this property will trigger replacement. String

The minimum size of the buffer that is used for plain index scans, range index scans, and joins that do not use indexes and thus perform full table scans. In MySQL 8.0.18 and later, this variable also controls the amount of memory used for hash joins. Normally, the best way to get fast joins is to add indexes. Increase the value of join_buffer_size to get a faster full join when adding indexes is not possible. One join buffer is allocated for each full join between two tables. For a complex join between several tables for which indexes are not used, multiple join buffers might be necessary.

joinBufferSize corresponds to the MySQL Server System variable [join_buffer_size] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_join_buffer_size).

localInfile Changes to this property will trigger replacement. Boolean

This variable controls server-side LOCAL capability for LOAD DATA statements. Depending on the local_infile setting, the server refuses or permits local data loading by clients that have LOCAL enabled on the client side.

local_infile corresponds to the MySQL Server system variable local_infile

longQueryTime Changes to this property will trigger replacement. Integer

If a query takes longer than this many seconds, the server increments the Slow_queries status variable. If the slow query log is enabled, the query is logged to the slow query log file. This value is measured in real time, not CPU time, so a query that is under the threshold on a lightly loaded system might be above the threshold on a heavily loaded one.

longQueryTime corresponds to the MySQL Server System variable [long_query_time] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_long_query_time).

mandatoryRoles Changes to this property will trigger replacement. String
("mandatory_roles")
maxAllowedPacket Changes to this property will trigger replacement. Integer

The maximum size of one packet or any generated/intermediate string.

This is the mysql variable "max_allowed_packet".

maxBinlogCacheSize Changes to this property will trigger replacement. String

Sets the size of the transaction cache.

maxBinlogCacheSize corresponds to the MySQL server system variable max_binlog_cache_size.

maxConnectErrors Changes to this property will trigger replacement. String
("max_connect_errors")
maxConnections Changes to this property will trigger replacement. Integer
("max_connections")
maxExecutionTime Changes to this property will trigger replacement. String
("max_execution_time")
maxHeapTableSize Changes to this property will trigger replacement. String

This variable sets the maximum size to which user-created MEMORY tables are permitted to grow.

maxHeapTableSize corresponds to the MySQL system variable max_heap_table_size

maxPreparedStmtCount Changes to this property will trigger replacement. Integer
("max_prepared_stmt_count")
maxSeeksForKey Changes to this property will trigger replacement. String

Limit the assumed maximum number of seeks when looking up rows based on a key. The MySQL optimizer assumes that no more than this number of key seeks are required when searching for matching rows in a table by scanning an index, regardless of the actual cardinality of the index (see Section 15.7.7.22, “SHOW INDEX Statement”). By setting this to a low value (say, 100), you can force MySQL to prefer indexes instead of table scans.

maxSeeksForKey corresponds to the MySQL Server System variable [max_seeks_for_key] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_max_seeks_for_key).

maxUserConnections Changes to this property will trigger replacement. String

The maximum number of simultaneous connections permitted to any given MySQL user account. A value of 0 (the default) means “no limit.” This variable has a global value that can be set at server startup or runtime. It also has a read-only session value that indicates the effective simultaneous-connection limit that applies to the account associated with the current session.

maxUserConnections corresponds to the MySQL Server System variable [max_user_connections] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_max_user_connections).

mysqlFirewallMode Changes to this property will trigger replacement. Boolean
("mysql_firewall_mode")
mysqlZstdDefaultCompressionLevel Changes to this property will trigger replacement. Integer
DEPRECATED -- typo of mysqlx_zstd_default_compression_level. variable will be ignored.

Deprecated: The 'mysql_zstd_default_compression_level' field has been deprecated and may be removed in a future version. Do not use this field.

mysqlxConnectTimeout Changes to this property will trigger replacement. Integer

The number of seconds X Plugin waits for the first packet to be received from newly connected clients.

mysqlxConnectTimeout corresponds to the MySQL X Plugin system variable mysqlx_connect_timeout

mysqlxDeflateDefaultCompressionLevel Changes to this property will trigger replacement. Integer
Set the default compression level for the deflate algorithm. ("mysqlx_deflate_default_compression_level")
mysqlxDeflateMaxClientCompressionLevel Changes to this property will trigger replacement. Integer
Limit the upper bound of accepted compression levels for the deflate algorithm. ("mysqlx_deflate_max_client_compression_level")
mysqlxDocumentIdUniquePrefix Changes to this property will trigger replacement. Integer
("mysqlx_document_id_unique_prefix") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'mysqlx_document_id_unique_prefix' field has been deprecated and may be removed in a future version. Do not use this field.

mysqlxEnableHelloNotice Changes to this property will trigger replacement. Boolean
("mysqlx_enable_hello_notice") DEPRECATED -- variable should not be settable and will be ignored
mysqlxIdleWorkerThreadTimeout Changes to this property will trigger replacement. Integer
("mysqlx_idle_worker_thread_timeout") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'mysqlx_idle_worker_thread_timeout' field has been deprecated and may be removed in a future version. Do not use this field.

mysqlxInteractiveTimeout Changes to this property will trigger replacement. Integer

The number of seconds to wait for interactive clients to timeout.

mysqlxInteractiveTimeout corresponds to the MySQL X Plugin system variable. mysqlx_interactive_timeout

mysqlxLz4defaultCompressionLevel Changes to this property will trigger replacement. Integer
Set the default compression level for the lz4 algorithm. ("mysqlx_lz4_default_compression_level")
mysqlxLz4maxClientCompressionLevel Changes to this property will trigger replacement. Integer
Limit the upper bound of accepted compression levels for the lz4 algorithm. ("mysqlx_lz4_max_client_compression_level")
mysqlxMaxAllowedPacket Changes to this property will trigger replacement. Integer

The maximum size of network packets that can be received by X Plugin.

This is the mysql variable "mysqlx_max_allowed_packet".

mysqlxMinWorkerThreads Changes to this property will trigger replacement. Integer
("mysqlx_min_worker_threads") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'mysqlx_min_worker_threads' field has been deprecated and may be removed in a future version. Do not use this field.

mysqlxReadTimeout Changes to this property will trigger replacement. Integer

The number of seconds that X Plugin waits for blocking read operations to complete. After this time, if the read operation is not successful, X Plugin closes the connection and returns a warning notice with the error code ER_IO_READ_ERROR to the client application.

mysqlxReadTimeout corresponds to the MySQL X Plugin system variable mysqlx_read_timeout

mysqlxWaitTimeout Changes to this property will trigger replacement. Integer

The number of seconds that X Plugin waits for activity on a connection.

mysqlxWaitTimeout corresponds to the MySQL X Plugin system variable. mysqlx_wait_timeout

mysqlxWriteTimeout Changes to this property will trigger replacement. Integer

The number of seconds that X Plugin waits for blocking write operations to complete. After this time, if the write operation is not successful, X Plugin closes the connection.

mysqlxReadmysqlxWriteTimeoutTimeout corresponds to the MySQL X Plugin system variable mysqlx_write_timeout

mysqlxZstdDefaultCompressionLevel Changes to this property will trigger replacement. Integer
Set the default compression level for the zstd algorithm. ("mysqlx_zstd_default_compression_level")
mysqlxZstdMaxClientCompressionLevel Changes to this property will trigger replacement. Integer
Limit the upper bound of accepted compression levels for the zstd algorithm. ("mysqlx_zstd_max_client_compression_level")
netReadTimeout Changes to this property will trigger replacement. Integer

The number of seconds to wait for more data from a connection before aborting the read.

netReadTimeout corresponds to the MySQL system variable net_read_timeout

netWriteTimeout Changes to this property will trigger replacement. Integer

The number of seconds to wait for a block to be written to a connection before aborting the write.

netWriteTimeout corresponds to the MySQL system variable net_write_timeout

optimizerSwitch Changes to this property will trigger replacement. String

The optimizer_switch system variable enables control over optimizer behavior. The value of this variable is a set of flags, each of which has a value of on or off to indicate whether the corresponding optimizer behavior is enabled or disabled. This variable has global and session values and can be changed at runtime. The global default can be set at server startup.

Setting hypergraph_optimizer=on for cloud builds below 9.0.0 will fail.

optimizerSwitch corresponds to the MySQL Server System variable [optimizer_switch] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_optimizer_switch).

parserMaxMemSize Changes to this property will trigger replacement. String
("parser_max_mem_size")
queryAllocBlockSize Changes to this property will trigger replacement. String
("query_alloc_block_size") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'query_alloc_block_size' field has been deprecated and may be removed in a future version. Do not use this field.

queryPreallocSize Changes to this property will trigger replacement. String
("query_prealloc_size") DEPRECATED -- variable should not be settable and will be ignored
rangeOptimizerMaxMemSize Changes to this property will trigger replacement. String

The limit on memory consumption for the range optimizer. A value of 0 means “no limit.” If an execution plan considered by the optimizer uses the range access method but the optimizer estimates that the amount of memory needed for this method would exceed the limit, it abandons the plan and considers other plans.

rangeOptimizerMaxMemSize corresponds to the MySQL Server System variable [range_optimizer_max_mem_size] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_range_optimizer_max_mem_size).

Deprecated: The 'query_prealloc_size' field has been deprecated and may be removed in a future version. Do not use this field.

regexpTimeLimit Changes to this property will trigger replacement. Integer
regexpTimeLimit corresponds to the MySQL system variable [regexp_time_limit] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_regexp_time_limit)
relayLogSpaceLimit Changes to this property will trigger replacement. String

The maximum amount of space to use for all relay logs.

relayLogSpaceLimit corresponds to the MySQL Replica Server Options variable [relay_log_space_limit] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-replica.html#sysvar_relay_log_space_limit).

replicaNetTimeout Changes to this property will trigger replacement. Integer

Specifies the number of seconds to wait for more data or a heartbeat signal from the source before the replica considers the connection broken, aborts the read, and tries to reconnect. Setting this variable has no immediate effect. The state of the variable applies on all subsequent START REPLICA commands.

replicaNetTimeout corresponds to the MySQL Replica server system variable replica_net_timeout

replicaParallelWorkers Changes to this property will trigger replacement. Integer

Beginning with MySQL 8.0.26, slave_parallel_workers is deprecated, and you should use replica_parallel_workers instead. (Prior to MySQL 8.0.26, you must use slave_parallel_workers to set the number of applier threads.)

replicaParallelWorkers corresponds to the MySQL Replica Server Options variable [replica_parallel_workers] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-replica.html#sysvar_replica_parallel_workers).

replicaTypeConversions Changes to this property will trigger replacement. String

From MySQL 8.0.26, use replica_type_conversions in place of slave_type_conversions, which is deprecated from that release. In releases before MySQL 8.0.26, use slave_type_conversions.

replica_type_conversions controls the type conversion mode in effect on the replica when using row-based replication. Its value is a comma-delimited set of zero or more elements from the list: ALL_LOSSY, ALL_NON_LOSSY, ALL_SIGNED, ALL_UNSIGNED. Set this variable to an empty string to disallow type conversions between the source and the replica. Setting this variable takes effect for all replication channels immediately, including running channels.

replica_type_conversions corresponds to the MySQL Replica Server Options variable [replica_type_conversions] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-replica.html#sysvar_replica_type_conversions).

requireSecureTransport Changes to this property will trigger replacement. Boolean

Whether client connections to the server are required to use some form of secure transport. When this variable is enabled, the server permits only TCP/IP connections encrypted using TLS/SSL, or connections that use a socket file or shared memory. The server rejects nonsecure connection attempts, which fail with an ER_SECURE_TRANSPORT_REQUIRED error.

require_secure_transport corresponds to the MySQL Server Administration system variable require_secure_transport

skipNameResolve Changes to this property will trigger replacement. Boolean

Whether to resolve host names when checking client connections. If this variable is OFF, mysqld resolves host names when checking client connections. If it is ON, mysqld uses only IP numbers; in this case, all Host column values in the grant tables must be IP addresses. See Section 7.1.12.3, “DNS Lookups and the Host Cache”.

skipNameResolve corresponds to the MySQL Server System variable [skip_name_resolve] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_skip_name_resolve).

sortBufferSize Changes to this property will trigger replacement. String

Each session that must perform a sort allocates a buffer of this size.

sortBufferSize corresponds to the MySQL system variable sort_buffer_size

sqlGenerateInvisiblePrimaryKey Changes to this property will trigger replacement. Boolean

Whether GIPK mode is in effect, in which case a MySQL replication source server adds a generated invisible primary key to any InnoDB table that is created without one.

sqlGenerateInvisiblePrimaryKey corresponds to the MySQL system variable [sql_generate_invisible_primary_key] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_sql_generate_invisible_primary_key).

sqlMode Changes to this property will trigger replacement. String
("sql_mode")
sqlRequirePrimaryKey Changes to this property will trigger replacement. Boolean
("sql_require_primary_key")
sqlWarnings Changes to this property will trigger replacement. Boolean
("sql_warnings")
tableDefinitionCache Changes to this property will trigger replacement. Integer

The number of table definitions that can be stored in the table definition cache. If you use a large number of tables, you can create a large table definition cache to speed up opening of tables. The table definition cache takes less space and does not use file descriptors, unlike the normal table cache.

table_definition_cache corresponds to the MySQL Server Administration system variable table_definition_cache

tableOpenCache Changes to this property will trigger replacement. Integer

The number of open tables for all threads. Increasing this value increases the number of file descriptors that mysqld requires.

table_open_cache corresponds to the MySQL Server Administration system variable table_open_cache

temptableMaxRam Changes to this property will trigger replacement. String

Defines the maximum amount of memory that can be occupied by the TempTable storage engine before it starts storing data on disk. The default value is 1073741824 bytes (1GiB). For more information, see Section 10.4.4, “Internal Temporary Table Use in MySQL”.

temptableMaxRam corresponds to the MySQL system variable [temptable_max_ram] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_temptable_max_ram).

threadPoolDedicatedListeners Changes to this property will trigger replacement. Boolean
Controls whether the thread pool uses dedicated listener threads. If enabled, a listener thread in each thread group is dedicated to the task of listening for network events from clients, ensuring that the maximum number of query worker threads is no more than the value specified by threadPoolMaxTransactionsLimit. threadPoolDedicatedListeners corresponds to the MySQL Database Service-specific system variable thread_pool_dedicated_listeners.
threadPoolMaxTransactionsLimit Changes to this property will trigger replacement. Integer
Limits the maximum number of open transactions to the defined value. The default value is 0, which enforces no limit. threadPoolMaxTransactionsLimit corresponds to the MySQL Database Service-specific system variable thread_pool_max_transactions_limit.
threadPoolQueryThreadsPerGroup Changes to this property will trigger replacement. Integer

The maximum number of query threads permitted in a thread group. The maximum value is 4096, but if thread_pool_max_transactions_limit is set, thread_pool_query_threads_per_group must not exceed that value. The default value of 1 means there is one active query thread in each thread group, which works well for many loads. When you are using the high concurrency thread pool algorithm (thread_pool_algorithm = 1), consider increasing the value if you experience slower response times due to long-running transactions.

threadPoolQueryThreadsPerGroup corresponds to the MySQL Server system variable thread_pool_query_threads_per_group

threadPoolSize Changes to this property will trigger replacement. Integer

The number of thread groups in the thread pool. This is the most important parameter controlling thread pool performance. It affects how many statements can execute simultaneously. If a value outside the range of permissible values is specified, the thread pool plugin does not load and the server writes a message to the error log.

threadPoolSize corresponds to the MySQL Server System variable [thread_pool_size] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_thread_pool_size).

threadPoolTransactionDelay Changes to this property will trigger replacement. Integer

The delay period before executing a new transaction, in milliseconds. The maximum value is 300000 (5 minutes). A transaction delay can be used in cases where parallel transactions affect the performance of other operations due to resource contention. For example, if parallel transactions affect index creation or an online buffer pool resizing operation, you can configure a transaction delay to reduce resource contention while those operations are running.

threadPoolTransactionDelay corresponds to the MySQL Server system variable thread_pool_transaction_delay

timeZone Changes to this property will trigger replacement. String

Initializes the time zone for each client that connects.

This corresponds to the MySQL System Variable "time_zone".

The values can be given in one of the following formats, none of which are case-sensitive:

  • As a string indicating an offset from UTC of the form [H]H:MM, prefixed with a + or -, such as '+10:00', '-6:00', or '+05:30'. The permitted range is '-13:59' to '+14:00', inclusive.
  • As a named time zone, as defined by the "IANA Time Zone database", such as 'Europe/Helsinki', 'US/Eastern', 'MET', or 'UTC'.
tmpTableSize Changes to this property will trigger replacement. String

The maximum size of internal in-memory temporary tables. This variable does not apply to user-created MEMORY tables.

tmp_table_size corresponds to the MySQL system variable tmp_table_size

transactionIsolation Changes to this property will trigger replacement. String
("transaction_isolation")
waitTimeout Changes to this property will trigger replacement. Integer

The number of seconds the server waits for activity on a noninteractive connection before closing it.

waitTimeout corresponds to the MySQL system variable. wait_timeout

** IMPORTANT ** Any change to a property that does not support update will force the destruction and recreation of the resource with the new property values

autoIncrementIncrement Changes to this property will trigger replacement. number

auto_increment_increment and auto_increment_offset are intended for use with circular (source-to-source) replication, and can be used to control the operation of AUTO_INCREMENT columns. Both variables have global and session values, and each can assume an integer value between 1 and 65,535 inclusive.

autoIncrementIncrement corresponds to the MySQL Replication Source Options variable [auto_increment_increment] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-source.html#sysvar_auto_increment_increment).

autoIncrementOffset Changes to this property will trigger replacement. number

This variable has a default value of 1. If it is left with its default value, and Group Replication is started on the server in multi-primary mode, it is changed to the server ID.

autoIncrementOffset corresponds to the MySQL Replication Source Options variable [auto_increment_offset] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-source.html#sysvar_auto_increment_offset).

autocommit Changes to this property will trigger replacement. boolean
("autocommit")
bigTables Changes to this property will trigger replacement. boolean

If enabled, the server stores all temporary tables on disk rather than in memory.

bigTables corresponds to the MySQL server variable big_tables.

binlogExpireLogsSeconds Changes to this property will trigger replacement. number
Sets the binary log expiration period in seconds. binlogExpireLogsSeconds corresponds to the MySQL binary logging system variable binlog_expire_logs_seconds.
binlogGroupCommitSyncDelay Changes to this property will trigger replacement. number

Controls how many microseconds the binary log commit waits before synchronizing the binary log file to disk. There is no delay by default. Setting this variable to a microsecond delay enables more transactions to be synchronized together to disk at once, reducing the overall time to commit a group of transactions because the larger groups required fewer time units per group.

binlogGroupCommitSyncDelay corresponds to the MySQL Replication system variable binlog_group_commit_sync_delay

binlogGroupCommitSyncNoDelayCount Changes to this property will trigger replacement. number

The maximum number of transactions to wait for before aborting the current delay as specified by binlog_group_commit_sync_delay. If binlog_group_commit_sync_delay is set to 0, then this option has no effect.

binlogGroupCommitSyncNoDelayCount corresponds to the MySQL Replication system variable binlog_group_commit_sync_no_delay_count

binlogRowMetadata Changes to this property will trigger replacement. string
Configures the amount of table metadata added to the binary log when using row-based logging. binlogRowMetadata corresponds to the MySQL binary logging system variable binlog_row_metadata.
binlogRowValueOptions Changes to this property will trigger replacement. string
When set to PARTIAL_JSON, this enables use of a space-efficient binary log format for updates that modify only a small portion of a JSON document. binlogRowValueOptions corresponds to the MySQL binary logging system variable binlog_row_value_options.
binlogTransactionCompression Changes to this property will trigger replacement. boolean
Enables compression for transactions that are written to binary log files on this server. binlogTransactionCompression corresponds to the MySQL binary logging system variable binlog_transaction_compression.
blockEncryptionMode Changes to this property will trigger replacement. string

This variable controls the block encryption mode for block-based algorithms such as AES. It affects encryption for AES_ENCRYPT() and AES_DECRYPT(). block_encryption_mode takes a value in aes-keylen-mode format, where keylen is the key length in bits and mode is the encryption mode. The value is not case-sensitive. Permitted keylen values are 128, 192, and 256. Permitted mode values are ECB, CBC, CFB1, CFB8, CFB128, and OFB.

block_encryption_mode corresponds to the MySQL Server Administration system variable block_encryption_mode

characterSetServer Changes to this property will trigger replacement. string

The server's default character set. If you set this variable, you should also set collation_server to specify the collation for the character set.

characterSetServer corresponds to the MySQL server variable character_set_server.

collationServer Changes to this property will trigger replacement. string

The server's default collation.

collationServer corresponds to the MySQL server variable collation_server.

completionType Changes to this property will trigger replacement. string
("completion_type")
connectTimeout Changes to this property will trigger replacement. number

The number of seconds that the mysqld server waits for a connect packet before responding with Bad handshake.

connectTimeout corresponds to the MySQL system variable connect_timeout

Increasing the connect_timeout value might help if clients frequently encounter errors of the form "Lost connection to MySQL server at 'XXX', system error: errno".

connectionMemoryChunkSize Changes to this property will trigger replacement. number

Set the chunking size for updates to the global memory usage counter Global_connection_memory.

connectionMemoryChunkSize corresponds to the MySQL system variable connection_memory_chunk_size.

connectionMemoryLimit Changes to this property will trigger replacement. string

Set the maximum amount of memory that can be used by a single user connection.

connectionMemoryLimit corresponds to the MySQL system variable connection_memory_limit.

cteMaxRecursionDepth Changes to this property will trigger replacement. string
("cte_max_recursion_depth")
defaultAuthenticationPlugin Changes to this property will trigger replacement. string

The default authentication plugin. This must be a plugin that uses internal credentials storage, so these values are permitted: mysql_native_password, sha256_password, caching_sha2_password.

As of MySQL 8.0.27, which introduces multifactor authentication, default_authentication_plugin is still used, but in conjunction with and at a lower precedence than the authentication_policy system variable. For details, see The Default Authentication Plugin. Because of this diminished role, default_authentication_plugin is deprecated as of MySQL 8.0.27 and subject to removal in a future MySQL version.

defaultAuthenticationPlugin corresponds to the MySQL system variable default_authentication_plugin.

explainFormat Changes to this property will trigger replacement. string

This variable determines the default output format used by EXPLAIN in the absence of a FORMAT option when displaying a query execution plan.

explainFormat corresponds to the MySQL system variable explain_format.

explicitDefaultsForTimestamp Changes to this property will trigger replacement. boolean

This system variable determines whether the server enables certain nonstandard behaviors for default values and NULL-value handling in TIMESTAMP columns. By default, explicit_defaults_for_timestamp is enabled, which disables the nonstandard behaviors. Disabling explicit_defaults_for_timestamp results in a warning.

explicit_defaults_for_timestamp corresponds to the MySQL Server Administration system variable explicit_defaults_for_timestamp

foreignKeyChecks Changes to this property will trigger replacement. boolean
("foreign_key_checks")
generatedRandomPasswordLength Changes to this property will trigger replacement. number
("generated_random_password_length") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'generated_random_password_length' field has been deprecated and may be removed in a future version. Do not use this field.

globalConnectionMemoryLimit Changes to this property will trigger replacement. string

Set the total amount of memory that can be used by all user connections.

globalConnectionMemoryLimit corresponds to the MySQL system variable global_connection_memory_limit.

globalConnectionMemoryTracking Changes to this property will trigger replacement. boolean

Determines whether the MySQL server calculates Global_connection_memory.

globalConnectionMemoryTracking corresponds to the MySQL system variable global_connection_memory_tracking.

groupConcatMaxLen Changes to this property will trigger replacement. string

Specifies the maximum permitted result length in bytes for the GROUP_CONCAT() function.

This is the MySQL variable "group_concat_max_len". For more information, please see the MySQL documentation

groupReplicationConsistency Changes to this property will trigger replacement. string
  • EVENTUAL: Both RO and RW transactions do not wait for preceding transactions to be applied before executing. A RW transaction does not wait for other members to apply a transaction. This means that a transaction could be externalized on one member before the others. This also means that in the event of a primary failover, the new primary can accept new RO and RW transactions before the previous primary transactions are all applied. RO transactions could result in outdated values, RW transactions could result in a rollback due to conflicts.
  • BEFORE_ON_PRIMARY_FAILOVER: New RO or RW transactions with a newly elected primary that is applying backlog from the old primary are held (not applied) until any backlog has been applied. This ensures that when a primary failover happens, intentionally or not, clients always see the latest value on the primary. This guarantees consistency, but means that clients must be able to handle the delay in the event that a backlog is being applied. Usually this delay should be minimal, but does depend on the size of the backlog.
  • BEFORE: A RW transaction waits for all preceding transactions to complete before being applied. A RO transaction waits for all preceding transactions to complete before being executed. This ensures that this transaction reads the latest value by only affecting the latency of the transaction. This reduces the overhead of synchronization on every RW transaction, by ensuring synchronization is used only on RO transactions. This consistency level also includes the consistency guarantees provided by BEFORE_ON_PRIMARY_FAILOVER.
  • AFTER: A RW transaction waits until its changes have been applied to all of the other members. This value has no effect on RO transactions. This mode ensures that when a transaction is committed on the local member, any subsequent transaction reads the written value or a more recent value on any group member. Use this mode with a group that is used for predominantly RO operations to ensure that applied RW transactions are applied everywhere once they commit. This could be used by your application to ensure that subsequent reads fetch the latest data which includes the latest writes. This reduces the overhead of synchronization on every RO transaction, by ensuring synchronization is used only on RW transactions. This consistency level also includes the consistency guarantees provided by BEFORE_ON_PRIMARY_FAILOVER.
  • BEFORE_AND_AFTER: A RW transaction waits for 1) all preceding transactions to complete before being applied and 2) until its changes have been applied on other members. A RO transaction waits for all preceding transactions to complete before execution takes place. This consistency level also includes the consistency guarantees provided by BEFORE_ON_PRIMARY_FAILOVER.
informationSchemaStatsExpiry Changes to this property will trigger replacement. number
("information_schema_stats_expiry")
innodbAdaptiveHashIndex Changes to this property will trigger replacement. boolean

Whether the InnoDB adaptive hash index is enabled or disabled. It may be desirable, depending on your workload, to dynamically enable or disable adaptive hash indexing to improve query performance. Because the adaptive hash index may not be useful for all workloads, conduct benchmarks with it both enabled and disabled, using realistic workloads.

innodbAdaptiveHashIndex corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_adaptive_hash_index] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_adaptive_hash_index).

innodbAutoincLockMode Changes to this property will trigger replacement. number

The lock mode to use for generating auto-increment values. Permissible values are 0, 1, or 2, for traditional, consecutive, or interleaved, respectively.

innodbAutoincLockMode corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_autoinc_lock_mode] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_autoinc_lock_mode).

innodbBufferPoolDumpPct Changes to this property will trigger replacement. number

Specifies the percentage of the most recently used pages for each buffer pool to read out and dump.

innodbBufferPoolDumpPct corresponds to the MySQL InnoDB system variable innodb_buffer_pool_dump_pct.

The range is 1 to 100. The default value is 25.

For example, if there are 4 buffer pools with 100 pages each, and innodb_buffer_pool_dump_pct is set to 25, the 25 most recently used pages from each buffer pool are dumped.

innodbBufferPoolInstances Changes to this property will trigger replacement. number
("innodb_buffer_pool_instances")
innodbBufferPoolSize Changes to this property will trigger replacement. string

The size (in bytes) of the buffer pool, that is, the memory area where InnoDB caches table and index data.

innodbBufferPoolSize corresponds to the MySQL server system variable innodb_buffer_pool_size.

The default and maximum values depend on the amount of RAM provisioned by the shape. See Default User Variables.

innodbChangeBuffering Changes to this property will trigger replacement. string

Whether InnoDB performs change buffering, an optimization that delays write operations to secondary indexes so that the I/O operations can be performed sequentially. Permitted values are described in the following table. Values may also be specified numerically.

innodbChangeBuffering corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_change_buffering] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_change_buffering).

innodbDdlBufferSize Changes to this property will trigger replacement. string
innodbDdlBufferSize corresponds to the MySQL system variable [innodb_ddl_buffer_size] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_ddl_buffer_size)
innodbDdlThreads Changes to this property will trigger replacement. number
innodbDdlThreads corresponds to the MySQL system variable [innodb_ddl_threads] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_ddl_threads)
innodbFtEnableStopword Changes to this property will trigger replacement. boolean
("innodb_ft_enable_stopword")
innodbFtMaxTokenSize Changes to this property will trigger replacement. number
("innodb_ft_max_token_size")
innodbFtMinTokenSize Changes to this property will trigger replacement. number
("innodb_ft_min_token_size")
innodbFtNumWordOptimize Changes to this property will trigger replacement. number
("innodb_ft_num_word_optimize")
innodbFtResultCacheLimit Changes to this property will trigger replacement. string
("innodb_ft_result_cache_limit")
innodbFtServerStopwordTable Changes to this property will trigger replacement. string
("innodb_ft_server_stopword_table")
innodbLockWaitTimeout Changes to this property will trigger replacement. number
("innodb_lock_wait_timeout")
innodbLogWriterThreads Changes to this property will trigger replacement. boolean

Enables dedicated log writer threads for writing redo log records from the log buffer to the system buffers and flushing the system buffers to the redo log files.

This is the MySQL variable "innodb_log_writer_threads". For more information, please see the MySQL documentation

innodbMaxPurgeLag Changes to this property will trigger replacement. string

The desired maximum purge lag in terms of transactions.

InnoDB maintains a list of transactions that have index records delete-marked by UPDATE or DELETE operations. The length of the list is the purge lag.

If this value is exceeded, a delay is imposed on INSERT, UPDATE, and DELETE operations to allow time for purge to catch up.

The default value is 0, which means there is no maximum purge lag and no delay.

innodbMaxPurgeLag corresponds to the MySQL server system variable innodb_max_purge_lag.

innodbMaxPurgeLagDelay Changes to this property will trigger replacement. number

The maximum delay in microseconds for the delay imposed when the innodb_max_purge_lag threshold is exceeded.

The specified innodb_max_purge_lag_delay value is an upper limit on the delay period.

innodbMaxPurgeLagDelay corresponds to the MySQL server system variable innodb_max_purge_lag_delay.

innodbNumaInterleave Changes to this property will trigger replacement. boolean

Enables the NUMA interleave memory policy for allocation of the InnoDB buffer pool. When innodb_numa_interleave is enabled, the NUMA memory policy is set to MPOL_INTERLEAVE for the mysqld process. After the InnoDB buffer pool is allocated, the NUMA memory policy is set back to MPOL_DEFAULT. For the innodb_numa_interleave option to be available, MySQL must be compiled on a NUMA-enabled Linux system.

innodbNumaInterleave corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_numa_interleave] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_numa_interleave).

innodbOnlineAlterLogMaxSize Changes to this property will trigger replacement. string

Specifies an upper limit in bytes on the size of the temporary log files used during online DDL operations for InnoDB tables. There is one such log file for each index being created or table being altered. This log file stores data inserted, updated, or deleted in the table during the DDL operation.

innodbOnlineAlterLogMaxSize corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_online_alter_log_max_size] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_online_alter_log_max_size).

innodbRedoLogCapacity Changes to this property will trigger replacement. string

Defines the amount of disk space occupied by redo log files. innodb_redo_log_capacity supercedes the innodb_log_files_in_group and innodb_log_file_size variables, which are both ignored if innodb_redo_log_capacity is defined. If innodb_redo_log_capacity is not defined, and if neither innodb_log_file_size or innodb_log_files_in_group are defined, then the default innodb_redo_log_capacity value is used.

innodbRedoLogCapacity corresponds to the InnoDB Startup Options and System Variables innodb_redo_log_capacity

innodbRollbackOnTimeout Changes to this property will trigger replacement. boolean

InnoDB rolls back only the last statement on a transaction timeout by default. If --innodb-rollback-on-timeout is specified, a transaction timeout causes InnoDB to abort and roll back the entire transaction.

innodbRollbackOnTimeout corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_rollback_on_timeout] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_rollback_on_timeout).

innodbSortBufferSize Changes to this property will trigger replacement. number

This variable defines:

  • The sort buffer size for online DDL operations that create or rebuild secondary indexes. However, as of MySQL 8.0.27, this responsibility is subsumed by the innodb_ddl_buffer_size variable.
  • The amount by which the temporary log file is extended when recording concurrent DML during an online DDL operation, and the size of the temporary log file read buffer and write buffer.

innodbSortBufferSize corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_sort_buffer_size] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_sort_buffer_size).

innodbStatsPersistentSamplePages Changes to this property will trigger replacement. string

The number of index pages to sample when estimating cardinality and other statistics for an indexed column, such as those calculated by ANALYZE TABLE.

innodbStatsPersistentSamplePages corresponds to the MySQL InnoDB system variable innodb_stats_persistent_sample_pages

innodb_stats_persistent_sample_pages only applies when innodb_stats_persistent is enabled for a table; when innodb_stats_persistent is disabled, innodb_stats_transient_sample_pages applies instead.

innodbStatsTransientSamplePages Changes to this property will trigger replacement. string

The number of index pages to sample when estimating cardinality and other statistics for an indexed column, such as those calculated by ANALYZE TABLE.

innodbStatsTransientSamplePages corresponds to the MySQL InnoDB system variable innodb_stats_transient_sample_pages

innodb_stats_transient_sample_pages only applies when innodb_stats_persistent is disabled for a table; when innodb_stats_persistent is enabled, innodb_stats_persistent_sample_pages applies instead.

innodb_stats_persistent is ON by default and cannot be changed. It is possible to override it using the STATS_PERSISTENT clause of the CREATE TABLE and ALTER TABLE statements.

innodbStrictMode Changes to this property will trigger replacement. boolean

When you enable innodbStrictMode, the InnoDB storage engine returns errors instead of warnings for invalid or incompatible table options.

innodbStrictMode corresponds to the MySQL InnoDB system variable innodb_strict_mode

innodbUndoLogTruncate Changes to this property will trigger replacement. boolean

When enabled, undo tablespaces that exceed the threshold value defined by innodb_max_undo_log_size are marked for truncation. Only undo tablespaces can be truncated. Truncating undo logs that reside in the system tablespace is not supported. For truncation to occur, there must be at least two undo tablespaces.

innodbUndoLogTruncate corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_undo_log_truncate] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_undo_log_truncate).

interactiveTimeout Changes to this property will trigger replacement. number

The number of seconds the server waits for activity on an interactive connection before closing it.

interactiveTimeout corresponds to the MySQL system variable. interactive_timeout

joinBufferSize Changes to this property will trigger replacement. string

The minimum size of the buffer that is used for plain index scans, range index scans, and joins that do not use indexes and thus perform full table scans. In MySQL 8.0.18 and later, this variable also controls the amount of memory used for hash joins. Normally, the best way to get fast joins is to add indexes. Increase the value of join_buffer_size to get a faster full join when adding indexes is not possible. One join buffer is allocated for each full join between two tables. For a complex join between several tables for which indexes are not used, multiple join buffers might be necessary.

joinBufferSize corresponds to the MySQL Server System variable [join_buffer_size] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_join_buffer_size).

localInfile Changes to this property will trigger replacement. boolean

This variable controls server-side LOCAL capability for LOAD DATA statements. Depending on the local_infile setting, the server refuses or permits local data loading by clients that have LOCAL enabled on the client side.

local_infile corresponds to the MySQL Server system variable local_infile

longQueryTime Changes to this property will trigger replacement. number

If a query takes longer than this many seconds, the server increments the Slow_queries status variable. If the slow query log is enabled, the query is logged to the slow query log file. This value is measured in real time, not CPU time, so a query that is under the threshold on a lightly loaded system might be above the threshold on a heavily loaded one.

longQueryTime corresponds to the MySQL Server System variable [long_query_time] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_long_query_time).

mandatoryRoles Changes to this property will trigger replacement. string
("mandatory_roles")
maxAllowedPacket Changes to this property will trigger replacement. number

The maximum size of one packet or any generated/intermediate string.

This is the mysql variable "max_allowed_packet".

maxBinlogCacheSize Changes to this property will trigger replacement. string

Sets the size of the transaction cache.

maxBinlogCacheSize corresponds to the MySQL server system variable max_binlog_cache_size.

maxConnectErrors Changes to this property will trigger replacement. string
("max_connect_errors")
maxConnections Changes to this property will trigger replacement. number
("max_connections")
maxExecutionTime Changes to this property will trigger replacement. string
("max_execution_time")
maxHeapTableSize Changes to this property will trigger replacement. string

This variable sets the maximum size to which user-created MEMORY tables are permitted to grow.

maxHeapTableSize corresponds to the MySQL system variable max_heap_table_size

maxPreparedStmtCount Changes to this property will trigger replacement. number
("max_prepared_stmt_count")
maxSeeksForKey Changes to this property will trigger replacement. string

Limit the assumed maximum number of seeks when looking up rows based on a key. The MySQL optimizer assumes that no more than this number of key seeks are required when searching for matching rows in a table by scanning an index, regardless of the actual cardinality of the index (see Section 15.7.7.22, “SHOW INDEX Statement”). By setting this to a low value (say, 100), you can force MySQL to prefer indexes instead of table scans.

maxSeeksForKey corresponds to the MySQL Server System variable [max_seeks_for_key] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_max_seeks_for_key).

maxUserConnections Changes to this property will trigger replacement. string

The maximum number of simultaneous connections permitted to any given MySQL user account. A value of 0 (the default) means “no limit.” This variable has a global value that can be set at server startup or runtime. It also has a read-only session value that indicates the effective simultaneous-connection limit that applies to the account associated with the current session.

maxUserConnections corresponds to the MySQL Server System variable [max_user_connections] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_max_user_connections).

mysqlFirewallMode Changes to this property will trigger replacement. boolean
("mysql_firewall_mode")
mysqlZstdDefaultCompressionLevel Changes to this property will trigger replacement. number
DEPRECATED -- typo of mysqlx_zstd_default_compression_level. variable will be ignored.

Deprecated: The 'mysql_zstd_default_compression_level' field has been deprecated and may be removed in a future version. Do not use this field.

mysqlxConnectTimeout Changes to this property will trigger replacement. number

The number of seconds X Plugin waits for the first packet to be received from newly connected clients.

mysqlxConnectTimeout corresponds to the MySQL X Plugin system variable mysqlx_connect_timeout

mysqlxDeflateDefaultCompressionLevel Changes to this property will trigger replacement. number
Set the default compression level for the deflate algorithm. ("mysqlx_deflate_default_compression_level")
mysqlxDeflateMaxClientCompressionLevel Changes to this property will trigger replacement. number
Limit the upper bound of accepted compression levels for the deflate algorithm. ("mysqlx_deflate_max_client_compression_level")
mysqlxDocumentIdUniquePrefix Changes to this property will trigger replacement. number
("mysqlx_document_id_unique_prefix") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'mysqlx_document_id_unique_prefix' field has been deprecated and may be removed in a future version. Do not use this field.

mysqlxEnableHelloNotice Changes to this property will trigger replacement. boolean
("mysqlx_enable_hello_notice") DEPRECATED -- variable should not be settable and will be ignored
mysqlxIdleWorkerThreadTimeout Changes to this property will trigger replacement. number
("mysqlx_idle_worker_thread_timeout") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'mysqlx_idle_worker_thread_timeout' field has been deprecated and may be removed in a future version. Do not use this field.

mysqlxInteractiveTimeout Changes to this property will trigger replacement. number

The number of seconds to wait for interactive clients to timeout.

mysqlxInteractiveTimeout corresponds to the MySQL X Plugin system variable. mysqlx_interactive_timeout

mysqlxLz4defaultCompressionLevel Changes to this property will trigger replacement. number
Set the default compression level for the lz4 algorithm. ("mysqlx_lz4_default_compression_level")
mysqlxLz4maxClientCompressionLevel Changes to this property will trigger replacement. number
Limit the upper bound of accepted compression levels for the lz4 algorithm. ("mysqlx_lz4_max_client_compression_level")
mysqlxMaxAllowedPacket Changes to this property will trigger replacement. number

The maximum size of network packets that can be received by X Plugin.

This is the mysql variable "mysqlx_max_allowed_packet".

mysqlxMinWorkerThreads Changes to this property will trigger replacement. number
("mysqlx_min_worker_threads") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'mysqlx_min_worker_threads' field has been deprecated and may be removed in a future version. Do not use this field.

mysqlxReadTimeout Changes to this property will trigger replacement. number

The number of seconds that X Plugin waits for blocking read operations to complete. After this time, if the read operation is not successful, X Plugin closes the connection and returns a warning notice with the error code ER_IO_READ_ERROR to the client application.

mysqlxReadTimeout corresponds to the MySQL X Plugin system variable mysqlx_read_timeout

mysqlxWaitTimeout Changes to this property will trigger replacement. number

The number of seconds that X Plugin waits for activity on a connection.

mysqlxWaitTimeout corresponds to the MySQL X Plugin system variable. mysqlx_wait_timeout

mysqlxWriteTimeout Changes to this property will trigger replacement. number

The number of seconds that X Plugin waits for blocking write operations to complete. After this time, if the write operation is not successful, X Plugin closes the connection.

mysqlxReadmysqlxWriteTimeoutTimeout corresponds to the MySQL X Plugin system variable mysqlx_write_timeout

mysqlxZstdDefaultCompressionLevel Changes to this property will trigger replacement. number
Set the default compression level for the zstd algorithm. ("mysqlx_zstd_default_compression_level")
mysqlxZstdMaxClientCompressionLevel Changes to this property will trigger replacement. number
Limit the upper bound of accepted compression levels for the zstd algorithm. ("mysqlx_zstd_max_client_compression_level")
netReadTimeout Changes to this property will trigger replacement. number

The number of seconds to wait for more data from a connection before aborting the read.

netReadTimeout corresponds to the MySQL system variable net_read_timeout

netWriteTimeout Changes to this property will trigger replacement. number

The number of seconds to wait for a block to be written to a connection before aborting the write.

netWriteTimeout corresponds to the MySQL system variable net_write_timeout

optimizerSwitch Changes to this property will trigger replacement. string

The optimizer_switch system variable enables control over optimizer behavior. The value of this variable is a set of flags, each of which has a value of on or off to indicate whether the corresponding optimizer behavior is enabled or disabled. This variable has global and session values and can be changed at runtime. The global default can be set at server startup.

Setting hypergraph_optimizer=on for cloud builds below 9.0.0 will fail.

optimizerSwitch corresponds to the MySQL Server System variable [optimizer_switch] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_optimizer_switch).

parserMaxMemSize Changes to this property will trigger replacement. string
("parser_max_mem_size")
queryAllocBlockSize Changes to this property will trigger replacement. string
("query_alloc_block_size") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'query_alloc_block_size' field has been deprecated and may be removed in a future version. Do not use this field.

queryPreallocSize Changes to this property will trigger replacement. string
("query_prealloc_size") DEPRECATED -- variable should not be settable and will be ignored
rangeOptimizerMaxMemSize Changes to this property will trigger replacement. string

The limit on memory consumption for the range optimizer. A value of 0 means “no limit.” If an execution plan considered by the optimizer uses the range access method but the optimizer estimates that the amount of memory needed for this method would exceed the limit, it abandons the plan and considers other plans.

rangeOptimizerMaxMemSize corresponds to the MySQL Server System variable [range_optimizer_max_mem_size] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_range_optimizer_max_mem_size).

Deprecated: The 'query_prealloc_size' field has been deprecated and may be removed in a future version. Do not use this field.

regexpTimeLimit Changes to this property will trigger replacement. number
regexpTimeLimit corresponds to the MySQL system variable [regexp_time_limit] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_regexp_time_limit)
relayLogSpaceLimit Changes to this property will trigger replacement. string

The maximum amount of space to use for all relay logs.

relayLogSpaceLimit corresponds to the MySQL Replica Server Options variable [relay_log_space_limit] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-replica.html#sysvar_relay_log_space_limit).

replicaNetTimeout Changes to this property will trigger replacement. number

Specifies the number of seconds to wait for more data or a heartbeat signal from the source before the replica considers the connection broken, aborts the read, and tries to reconnect. Setting this variable has no immediate effect. The state of the variable applies on all subsequent START REPLICA commands.

replicaNetTimeout corresponds to the MySQL Replica server system variable replica_net_timeout

replicaParallelWorkers Changes to this property will trigger replacement. number

Beginning with MySQL 8.0.26, slave_parallel_workers is deprecated, and you should use replica_parallel_workers instead. (Prior to MySQL 8.0.26, you must use slave_parallel_workers to set the number of applier threads.)

replicaParallelWorkers corresponds to the MySQL Replica Server Options variable [replica_parallel_workers] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-replica.html#sysvar_replica_parallel_workers).

replicaTypeConversions Changes to this property will trigger replacement. string

From MySQL 8.0.26, use replica_type_conversions in place of slave_type_conversions, which is deprecated from that release. In releases before MySQL 8.0.26, use slave_type_conversions.

replica_type_conversions controls the type conversion mode in effect on the replica when using row-based replication. Its value is a comma-delimited set of zero or more elements from the list: ALL_LOSSY, ALL_NON_LOSSY, ALL_SIGNED, ALL_UNSIGNED. Set this variable to an empty string to disallow type conversions between the source and the replica. Setting this variable takes effect for all replication channels immediately, including running channels.

replica_type_conversions corresponds to the MySQL Replica Server Options variable [replica_type_conversions] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-replica.html#sysvar_replica_type_conversions).

requireSecureTransport Changes to this property will trigger replacement. boolean

Whether client connections to the server are required to use some form of secure transport. When this variable is enabled, the server permits only TCP/IP connections encrypted using TLS/SSL, or connections that use a socket file or shared memory. The server rejects nonsecure connection attempts, which fail with an ER_SECURE_TRANSPORT_REQUIRED error.

require_secure_transport corresponds to the MySQL Server Administration system variable require_secure_transport

skipNameResolve Changes to this property will trigger replacement. boolean

Whether to resolve host names when checking client connections. If this variable is OFF, mysqld resolves host names when checking client connections. If it is ON, mysqld uses only IP numbers; in this case, all Host column values in the grant tables must be IP addresses. See Section 7.1.12.3, “DNS Lookups and the Host Cache”.

skipNameResolve corresponds to the MySQL Server System variable [skip_name_resolve] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_skip_name_resolve).

sortBufferSize Changes to this property will trigger replacement. string

Each session that must perform a sort allocates a buffer of this size.

sortBufferSize corresponds to the MySQL system variable sort_buffer_size

sqlGenerateInvisiblePrimaryKey Changes to this property will trigger replacement. boolean

Whether GIPK mode is in effect, in which case a MySQL replication source server adds a generated invisible primary key to any InnoDB table that is created without one.

sqlGenerateInvisiblePrimaryKey corresponds to the MySQL system variable [sql_generate_invisible_primary_key] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_sql_generate_invisible_primary_key).

sqlMode Changes to this property will trigger replacement. string
("sql_mode")
sqlRequirePrimaryKey Changes to this property will trigger replacement. boolean
("sql_require_primary_key")
sqlWarnings Changes to this property will trigger replacement. boolean
("sql_warnings")
tableDefinitionCache Changes to this property will trigger replacement. number

The number of table definitions that can be stored in the table definition cache. If you use a large number of tables, you can create a large table definition cache to speed up opening of tables. The table definition cache takes less space and does not use file descriptors, unlike the normal table cache.

table_definition_cache corresponds to the MySQL Server Administration system variable table_definition_cache

tableOpenCache Changes to this property will trigger replacement. number

The number of open tables for all threads. Increasing this value increases the number of file descriptors that mysqld requires.

table_open_cache corresponds to the MySQL Server Administration system variable table_open_cache

temptableMaxRam Changes to this property will trigger replacement. string

Defines the maximum amount of memory that can be occupied by the TempTable storage engine before it starts storing data on disk. The default value is 1073741824 bytes (1GiB). For more information, see Section 10.4.4, “Internal Temporary Table Use in MySQL”.

temptableMaxRam corresponds to the MySQL system variable [temptable_max_ram] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_temptable_max_ram).

threadPoolDedicatedListeners Changes to this property will trigger replacement. boolean
Controls whether the thread pool uses dedicated listener threads. If enabled, a listener thread in each thread group is dedicated to the task of listening for network events from clients, ensuring that the maximum number of query worker threads is no more than the value specified by threadPoolMaxTransactionsLimit. threadPoolDedicatedListeners corresponds to the MySQL Database Service-specific system variable thread_pool_dedicated_listeners.
threadPoolMaxTransactionsLimit Changes to this property will trigger replacement. number
Limits the maximum number of open transactions to the defined value. The default value is 0, which enforces no limit. threadPoolMaxTransactionsLimit corresponds to the MySQL Database Service-specific system variable thread_pool_max_transactions_limit.
threadPoolQueryThreadsPerGroup Changes to this property will trigger replacement. number

The maximum number of query threads permitted in a thread group. The maximum value is 4096, but if thread_pool_max_transactions_limit is set, thread_pool_query_threads_per_group must not exceed that value. The default value of 1 means there is one active query thread in each thread group, which works well for many loads. When you are using the high concurrency thread pool algorithm (thread_pool_algorithm = 1), consider increasing the value if you experience slower response times due to long-running transactions.

threadPoolQueryThreadsPerGroup corresponds to the MySQL Server system variable thread_pool_query_threads_per_group

threadPoolSize Changes to this property will trigger replacement. number

The number of thread groups in the thread pool. This is the most important parameter controlling thread pool performance. It affects how many statements can execute simultaneously. If a value outside the range of permissible values is specified, the thread pool plugin does not load and the server writes a message to the error log.

threadPoolSize corresponds to the MySQL Server System variable [thread_pool_size] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_thread_pool_size).

threadPoolTransactionDelay Changes to this property will trigger replacement. number

The delay period before executing a new transaction, in milliseconds. The maximum value is 300000 (5 minutes). A transaction delay can be used in cases where parallel transactions affect the performance of other operations due to resource contention. For example, if parallel transactions affect index creation or an online buffer pool resizing operation, you can configure a transaction delay to reduce resource contention while those operations are running.

threadPoolTransactionDelay corresponds to the MySQL Server system variable thread_pool_transaction_delay

timeZone Changes to this property will trigger replacement. string

Initializes the time zone for each client that connects.

This corresponds to the MySQL System Variable "time_zone".

The values can be given in one of the following formats, none of which are case-sensitive:

  • As a string indicating an offset from UTC of the form [H]H:MM, prefixed with a + or -, such as '+10:00', '-6:00', or '+05:30'. The permitted range is '-13:59' to '+14:00', inclusive.
  • As a named time zone, as defined by the "IANA Time Zone database", such as 'Europe/Helsinki', 'US/Eastern', 'MET', or 'UTC'.
tmpTableSize Changes to this property will trigger replacement. string

The maximum size of internal in-memory temporary tables. This variable does not apply to user-created MEMORY tables.

tmp_table_size corresponds to the MySQL system variable tmp_table_size

transactionIsolation Changes to this property will trigger replacement. string
("transaction_isolation")
waitTimeout Changes to this property will trigger replacement. number

The number of seconds the server waits for activity on a noninteractive connection before closing it.

waitTimeout corresponds to the MySQL system variable. wait_timeout

** IMPORTANT ** Any change to a property that does not support update will force the destruction and recreation of the resource with the new property values

auto_increment_increment Changes to this property will trigger replacement. int

auto_increment_increment and auto_increment_offset are intended for use with circular (source-to-source) replication, and can be used to control the operation of AUTO_INCREMENT columns. Both variables have global and session values, and each can assume an integer value between 1 and 65,535 inclusive.

autoIncrementIncrement corresponds to the MySQL Replication Source Options variable [auto_increment_increment] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-source.html#sysvar_auto_increment_increment).

auto_increment_offset Changes to this property will trigger replacement. int

This variable has a default value of 1. If it is left with its default value, and Group Replication is started on the server in multi-primary mode, it is changed to the server ID.

autoIncrementOffset corresponds to the MySQL Replication Source Options variable [auto_increment_offset] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-source.html#sysvar_auto_increment_offset).

autocommit Changes to this property will trigger replacement. bool
("autocommit")
big_tables Changes to this property will trigger replacement. bool

If enabled, the server stores all temporary tables on disk rather than in memory.

bigTables corresponds to the MySQL server variable big_tables.

binlog_expire_logs_seconds Changes to this property will trigger replacement. int
Sets the binary log expiration period in seconds. binlogExpireLogsSeconds corresponds to the MySQL binary logging system variable binlog_expire_logs_seconds.
binlog_group_commit_sync_delay Changes to this property will trigger replacement. int

Controls how many microseconds the binary log commit waits before synchronizing the binary log file to disk. There is no delay by default. Setting this variable to a microsecond delay enables more transactions to be synchronized together to disk at once, reducing the overall time to commit a group of transactions because the larger groups required fewer time units per group.

binlogGroupCommitSyncDelay corresponds to the MySQL Replication system variable binlog_group_commit_sync_delay

binlog_group_commit_sync_no_delay_count Changes to this property will trigger replacement. int

The maximum number of transactions to wait for before aborting the current delay as specified by binlog_group_commit_sync_delay. If binlog_group_commit_sync_delay is set to 0, then this option has no effect.

binlogGroupCommitSyncNoDelayCount corresponds to the MySQL Replication system variable binlog_group_commit_sync_no_delay_count

binlog_row_metadata Changes to this property will trigger replacement. str
Configures the amount of table metadata added to the binary log when using row-based logging. binlogRowMetadata corresponds to the MySQL binary logging system variable binlog_row_metadata.
binlog_row_value_options Changes to this property will trigger replacement. str
When set to PARTIAL_JSON, this enables use of a space-efficient binary log format for updates that modify only a small portion of a JSON document. binlogRowValueOptions corresponds to the MySQL binary logging system variable binlog_row_value_options.
binlog_transaction_compression Changes to this property will trigger replacement. bool
Enables compression for transactions that are written to binary log files on this server. binlogTransactionCompression corresponds to the MySQL binary logging system variable binlog_transaction_compression.
block_encryption_mode Changes to this property will trigger replacement. str

This variable controls the block encryption mode for block-based algorithms such as AES. It affects encryption for AES_ENCRYPT() and AES_DECRYPT(). block_encryption_mode takes a value in aes-keylen-mode format, where keylen is the key length in bits and mode is the encryption mode. The value is not case-sensitive. Permitted keylen values are 128, 192, and 256. Permitted mode values are ECB, CBC, CFB1, CFB8, CFB128, and OFB.

block_encryption_mode corresponds to the MySQL Server Administration system variable block_encryption_mode

character_set_server Changes to this property will trigger replacement. str

The server's default character set. If you set this variable, you should also set collation_server to specify the collation for the character set.

characterSetServer corresponds to the MySQL server variable character_set_server.

collation_server Changes to this property will trigger replacement. str

The server's default collation.

collationServer corresponds to the MySQL server variable collation_server.

completion_type Changes to this property will trigger replacement. str
("completion_type")
connect_timeout Changes to this property will trigger replacement. int

The number of seconds that the mysqld server waits for a connect packet before responding with Bad handshake.

connectTimeout corresponds to the MySQL system variable connect_timeout

Increasing the connect_timeout value might help if clients frequently encounter errors of the form "Lost connection to MySQL server at 'XXX', system error: errno".

connection_memory_chunk_size Changes to this property will trigger replacement. int

Set the chunking size for updates to the global memory usage counter Global_connection_memory.

connectionMemoryChunkSize corresponds to the MySQL system variable connection_memory_chunk_size.

connection_memory_limit Changes to this property will trigger replacement. str

Set the maximum amount of memory that can be used by a single user connection.

connectionMemoryLimit corresponds to the MySQL system variable connection_memory_limit.

cte_max_recursion_depth Changes to this property will trigger replacement. str
("cte_max_recursion_depth")
default_authentication_plugin Changes to this property will trigger replacement. str

The default authentication plugin. This must be a plugin that uses internal credentials storage, so these values are permitted: mysql_native_password, sha256_password, caching_sha2_password.

As of MySQL 8.0.27, which introduces multifactor authentication, default_authentication_plugin is still used, but in conjunction with and at a lower precedence than the authentication_policy system variable. For details, see The Default Authentication Plugin. Because of this diminished role, default_authentication_plugin is deprecated as of MySQL 8.0.27 and subject to removal in a future MySQL version.

defaultAuthenticationPlugin corresponds to the MySQL system variable default_authentication_plugin.

explain_format Changes to this property will trigger replacement. str

This variable determines the default output format used by EXPLAIN in the absence of a FORMAT option when displaying a query execution plan.

explainFormat corresponds to the MySQL system variable explain_format.

explicit_defaults_for_timestamp Changes to this property will trigger replacement. bool

This system variable determines whether the server enables certain nonstandard behaviors for default values and NULL-value handling in TIMESTAMP columns. By default, explicit_defaults_for_timestamp is enabled, which disables the nonstandard behaviors. Disabling explicit_defaults_for_timestamp results in a warning.

explicit_defaults_for_timestamp corresponds to the MySQL Server Administration system variable explicit_defaults_for_timestamp

foreign_key_checks Changes to this property will trigger replacement. bool
("foreign_key_checks")
generated_random_password_length Changes to this property will trigger replacement. int
("generated_random_password_length") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'generated_random_password_length' field has been deprecated and may be removed in a future version. Do not use this field.

global_connection_memory_limit Changes to this property will trigger replacement. str

Set the total amount of memory that can be used by all user connections.

globalConnectionMemoryLimit corresponds to the MySQL system variable global_connection_memory_limit.

global_connection_memory_tracking Changes to this property will trigger replacement. bool

Determines whether the MySQL server calculates Global_connection_memory.

globalConnectionMemoryTracking corresponds to the MySQL system variable global_connection_memory_tracking.

group_concat_max_len Changes to this property will trigger replacement. str

Specifies the maximum permitted result length in bytes for the GROUP_CONCAT() function.

This is the MySQL variable "group_concat_max_len". For more information, please see the MySQL documentation

group_replication_consistency Changes to this property will trigger replacement. str
  • EVENTUAL: Both RO and RW transactions do not wait for preceding transactions to be applied before executing. A RW transaction does not wait for other members to apply a transaction. This means that a transaction could be externalized on one member before the others. This also means that in the event of a primary failover, the new primary can accept new RO and RW transactions before the previous primary transactions are all applied. RO transactions could result in outdated values, RW transactions could result in a rollback due to conflicts.
  • BEFORE_ON_PRIMARY_FAILOVER: New RO or RW transactions with a newly elected primary that is applying backlog from the old primary are held (not applied) until any backlog has been applied. This ensures that when a primary failover happens, intentionally or not, clients always see the latest value on the primary. This guarantees consistency, but means that clients must be able to handle the delay in the event that a backlog is being applied. Usually this delay should be minimal, but does depend on the size of the backlog.
  • BEFORE: A RW transaction waits for all preceding transactions to complete before being applied. A RO transaction waits for all preceding transactions to complete before being executed. This ensures that this transaction reads the latest value by only affecting the latency of the transaction. This reduces the overhead of synchronization on every RW transaction, by ensuring synchronization is used only on RO transactions. This consistency level also includes the consistency guarantees provided by BEFORE_ON_PRIMARY_FAILOVER.
  • AFTER: A RW transaction waits until its changes have been applied to all of the other members. This value has no effect on RO transactions. This mode ensures that when a transaction is committed on the local member, any subsequent transaction reads the written value or a more recent value on any group member. Use this mode with a group that is used for predominantly RO operations to ensure that applied RW transactions are applied everywhere once they commit. This could be used by your application to ensure that subsequent reads fetch the latest data which includes the latest writes. This reduces the overhead of synchronization on every RO transaction, by ensuring synchronization is used only on RW transactions. This consistency level also includes the consistency guarantees provided by BEFORE_ON_PRIMARY_FAILOVER.
  • BEFORE_AND_AFTER: A RW transaction waits for 1) all preceding transactions to complete before being applied and 2) until its changes have been applied on other members. A RO transaction waits for all preceding transactions to complete before execution takes place. This consistency level also includes the consistency guarantees provided by BEFORE_ON_PRIMARY_FAILOVER.
information_schema_stats_expiry Changes to this property will trigger replacement. int
("information_schema_stats_expiry")
innodb_adaptive_hash_index Changes to this property will trigger replacement. bool

Whether the InnoDB adaptive hash index is enabled or disabled. It may be desirable, depending on your workload, to dynamically enable or disable adaptive hash indexing to improve query performance. Because the adaptive hash index may not be useful for all workloads, conduct benchmarks with it both enabled and disabled, using realistic workloads.

innodbAdaptiveHashIndex corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_adaptive_hash_index] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_adaptive_hash_index).

innodb_autoinc_lock_mode Changes to this property will trigger replacement. int

The lock mode to use for generating auto-increment values. Permissible values are 0, 1, or 2, for traditional, consecutive, or interleaved, respectively.

innodbAutoincLockMode corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_autoinc_lock_mode] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_autoinc_lock_mode).

innodb_buffer_pool_dump_pct Changes to this property will trigger replacement. int

Specifies the percentage of the most recently used pages for each buffer pool to read out and dump.

innodbBufferPoolDumpPct corresponds to the MySQL InnoDB system variable innodb_buffer_pool_dump_pct.

The range is 1 to 100. The default value is 25.

For example, if there are 4 buffer pools with 100 pages each, and innodb_buffer_pool_dump_pct is set to 25, the 25 most recently used pages from each buffer pool are dumped.

innodb_buffer_pool_instances Changes to this property will trigger replacement. int
("innodb_buffer_pool_instances")
innodb_buffer_pool_size Changes to this property will trigger replacement. str

The size (in bytes) of the buffer pool, that is, the memory area where InnoDB caches table and index data.

innodbBufferPoolSize corresponds to the MySQL server system variable innodb_buffer_pool_size.

The default and maximum values depend on the amount of RAM provisioned by the shape. See Default User Variables.

innodb_change_buffering Changes to this property will trigger replacement. str

Whether InnoDB performs change buffering, an optimization that delays write operations to secondary indexes so that the I/O operations can be performed sequentially. Permitted values are described in the following table. Values may also be specified numerically.

innodbChangeBuffering corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_change_buffering] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_change_buffering).

innodb_ddl_buffer_size Changes to this property will trigger replacement. str
innodbDdlBufferSize corresponds to the MySQL system variable [innodb_ddl_buffer_size] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_ddl_buffer_size)
innodb_ddl_threads Changes to this property will trigger replacement. int
innodbDdlThreads corresponds to the MySQL system variable [innodb_ddl_threads] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_ddl_threads)
innodb_ft_enable_stopword Changes to this property will trigger replacement. bool
("innodb_ft_enable_stopword")
innodb_ft_max_token_size Changes to this property will trigger replacement. int
("innodb_ft_max_token_size")
innodb_ft_min_token_size Changes to this property will trigger replacement. int
("innodb_ft_min_token_size")
innodb_ft_num_word_optimize Changes to this property will trigger replacement. int
("innodb_ft_num_word_optimize")
innodb_ft_result_cache_limit Changes to this property will trigger replacement. str
("innodb_ft_result_cache_limit")
innodb_ft_server_stopword_table Changes to this property will trigger replacement. str
("innodb_ft_server_stopword_table")
innodb_lock_wait_timeout Changes to this property will trigger replacement. int
("innodb_lock_wait_timeout")
innodb_log_writer_threads Changes to this property will trigger replacement. bool

Enables dedicated log writer threads for writing redo log records from the log buffer to the system buffers and flushing the system buffers to the redo log files.

This is the MySQL variable "innodb_log_writer_threads". For more information, please see the MySQL documentation

innodb_max_purge_lag Changes to this property will trigger replacement. str

The desired maximum purge lag in terms of transactions.

InnoDB maintains a list of transactions that have index records delete-marked by UPDATE or DELETE operations. The length of the list is the purge lag.

If this value is exceeded, a delay is imposed on INSERT, UPDATE, and DELETE operations to allow time for purge to catch up.

The default value is 0, which means there is no maximum purge lag and no delay.

innodbMaxPurgeLag corresponds to the MySQL server system variable innodb_max_purge_lag.

innodb_max_purge_lag_delay Changes to this property will trigger replacement. int

The maximum delay in microseconds for the delay imposed when the innodb_max_purge_lag threshold is exceeded.

The specified innodb_max_purge_lag_delay value is an upper limit on the delay period.

innodbMaxPurgeLagDelay corresponds to the MySQL server system variable innodb_max_purge_lag_delay.

innodb_numa_interleave Changes to this property will trigger replacement. bool

Enables the NUMA interleave memory policy for allocation of the InnoDB buffer pool. When innodb_numa_interleave is enabled, the NUMA memory policy is set to MPOL_INTERLEAVE for the mysqld process. After the InnoDB buffer pool is allocated, the NUMA memory policy is set back to MPOL_DEFAULT. For the innodb_numa_interleave option to be available, MySQL must be compiled on a NUMA-enabled Linux system.

innodbNumaInterleave corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_numa_interleave] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_numa_interleave).

innodb_online_alter_log_max_size Changes to this property will trigger replacement. str

Specifies an upper limit in bytes on the size of the temporary log files used during online DDL operations for InnoDB tables. There is one such log file for each index being created or table being altered. This log file stores data inserted, updated, or deleted in the table during the DDL operation.

innodbOnlineAlterLogMaxSize corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_online_alter_log_max_size] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_online_alter_log_max_size).

innodb_redo_log_capacity Changes to this property will trigger replacement. str

Defines the amount of disk space occupied by redo log files. innodb_redo_log_capacity supercedes the innodb_log_files_in_group and innodb_log_file_size variables, which are both ignored if innodb_redo_log_capacity is defined. If innodb_redo_log_capacity is not defined, and if neither innodb_log_file_size or innodb_log_files_in_group are defined, then the default innodb_redo_log_capacity value is used.

innodbRedoLogCapacity corresponds to the InnoDB Startup Options and System Variables innodb_redo_log_capacity

innodb_rollback_on_timeout Changes to this property will trigger replacement. bool

InnoDB rolls back only the last statement on a transaction timeout by default. If --innodb-rollback-on-timeout is specified, a transaction timeout causes InnoDB to abort and roll back the entire transaction.

innodbRollbackOnTimeout corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_rollback_on_timeout] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_rollback_on_timeout).

innodb_sort_buffer_size Changes to this property will trigger replacement. int

This variable defines:

  • The sort buffer size for online DDL operations that create or rebuild secondary indexes. However, as of MySQL 8.0.27, this responsibility is subsumed by the innodb_ddl_buffer_size variable.
  • The amount by which the temporary log file is extended when recording concurrent DML during an online DDL operation, and the size of the temporary log file read buffer and write buffer.

innodbSortBufferSize corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_sort_buffer_size] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_sort_buffer_size).

innodb_stats_persistent_sample_pages Changes to this property will trigger replacement. str

The number of index pages to sample when estimating cardinality and other statistics for an indexed column, such as those calculated by ANALYZE TABLE.

innodbStatsPersistentSamplePages corresponds to the MySQL InnoDB system variable innodb_stats_persistent_sample_pages

innodb_stats_persistent_sample_pages only applies when innodb_stats_persistent is enabled for a table; when innodb_stats_persistent is disabled, innodb_stats_transient_sample_pages applies instead.

innodb_stats_transient_sample_pages Changes to this property will trigger replacement. str

The number of index pages to sample when estimating cardinality and other statistics for an indexed column, such as those calculated by ANALYZE TABLE.

innodbStatsTransientSamplePages corresponds to the MySQL InnoDB system variable innodb_stats_transient_sample_pages

innodb_stats_transient_sample_pages only applies when innodb_stats_persistent is disabled for a table; when innodb_stats_persistent is enabled, innodb_stats_persistent_sample_pages applies instead.

innodb_stats_persistent is ON by default and cannot be changed. It is possible to override it using the STATS_PERSISTENT clause of the CREATE TABLE and ALTER TABLE statements.

innodb_strict_mode Changes to this property will trigger replacement. bool

When you enable innodbStrictMode, the InnoDB storage engine returns errors instead of warnings for invalid or incompatible table options.

innodbStrictMode corresponds to the MySQL InnoDB system variable innodb_strict_mode

innodb_undo_log_truncate Changes to this property will trigger replacement. bool

When enabled, undo tablespaces that exceed the threshold value defined by innodb_max_undo_log_size are marked for truncation. Only undo tablespaces can be truncated. Truncating undo logs that reside in the system tablespace is not supported. For truncation to occur, there must be at least two undo tablespaces.

innodbUndoLogTruncate corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_undo_log_truncate] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_undo_log_truncate).

interactive_timeout Changes to this property will trigger replacement. int

The number of seconds the server waits for activity on an interactive connection before closing it.

interactiveTimeout corresponds to the MySQL system variable. interactive_timeout

join_buffer_size Changes to this property will trigger replacement. str

The minimum size of the buffer that is used for plain index scans, range index scans, and joins that do not use indexes and thus perform full table scans. In MySQL 8.0.18 and later, this variable also controls the amount of memory used for hash joins. Normally, the best way to get fast joins is to add indexes. Increase the value of join_buffer_size to get a faster full join when adding indexes is not possible. One join buffer is allocated for each full join between two tables. For a complex join between several tables for which indexes are not used, multiple join buffers might be necessary.

joinBufferSize corresponds to the MySQL Server System variable [join_buffer_size] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_join_buffer_size).

local_infile Changes to this property will trigger replacement. bool

This variable controls server-side LOCAL capability for LOAD DATA statements. Depending on the local_infile setting, the server refuses or permits local data loading by clients that have LOCAL enabled on the client side.

local_infile corresponds to the MySQL Server system variable local_infile

long_query_time Changes to this property will trigger replacement. int

If a query takes longer than this many seconds, the server increments the Slow_queries status variable. If the slow query log is enabled, the query is logged to the slow query log file. This value is measured in real time, not CPU time, so a query that is under the threshold on a lightly loaded system might be above the threshold on a heavily loaded one.

longQueryTime corresponds to the MySQL Server System variable [long_query_time] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_long_query_time).

mandatory_roles Changes to this property will trigger replacement. str
("mandatory_roles")
max_allowed_packet Changes to this property will trigger replacement. int

The maximum size of one packet or any generated/intermediate string.

This is the mysql variable "max_allowed_packet".

max_binlog_cache_size Changes to this property will trigger replacement. str

Sets the size of the transaction cache.

maxBinlogCacheSize corresponds to the MySQL server system variable max_binlog_cache_size.

max_connect_errors Changes to this property will trigger replacement. str
("max_connect_errors")
max_connections Changes to this property will trigger replacement. int
("max_connections")
max_execution_time Changes to this property will trigger replacement. str
("max_execution_time")
max_heap_table_size Changes to this property will trigger replacement. str

This variable sets the maximum size to which user-created MEMORY tables are permitted to grow.

maxHeapTableSize corresponds to the MySQL system variable max_heap_table_size

max_prepared_stmt_count Changes to this property will trigger replacement. int
("max_prepared_stmt_count")
max_seeks_for_key Changes to this property will trigger replacement. str

Limit the assumed maximum number of seeks when looking up rows based on a key. The MySQL optimizer assumes that no more than this number of key seeks are required when searching for matching rows in a table by scanning an index, regardless of the actual cardinality of the index (see Section 15.7.7.22, “SHOW INDEX Statement”). By setting this to a low value (say, 100), you can force MySQL to prefer indexes instead of table scans.

maxSeeksForKey corresponds to the MySQL Server System variable [max_seeks_for_key] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_max_seeks_for_key).

max_user_connections Changes to this property will trigger replacement. str

The maximum number of simultaneous connections permitted to any given MySQL user account. A value of 0 (the default) means “no limit.” This variable has a global value that can be set at server startup or runtime. It also has a read-only session value that indicates the effective simultaneous-connection limit that applies to the account associated with the current session.

maxUserConnections corresponds to the MySQL Server System variable [max_user_connections] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_max_user_connections).

mysql_firewall_mode Changes to this property will trigger replacement. bool
("mysql_firewall_mode")
mysql_zstd_default_compression_level Changes to this property will trigger replacement. int
DEPRECATED -- typo of mysqlx_zstd_default_compression_level. variable will be ignored.

Deprecated: The 'mysql_zstd_default_compression_level' field has been deprecated and may be removed in a future version. Do not use this field.

mysqlx_connect_timeout Changes to this property will trigger replacement. int

The number of seconds X Plugin waits for the first packet to be received from newly connected clients.

mysqlxConnectTimeout corresponds to the MySQL X Plugin system variable mysqlx_connect_timeout

mysqlx_deflate_default_compression_level Changes to this property will trigger replacement. int
Set the default compression level for the deflate algorithm. ("mysqlx_deflate_default_compression_level")
mysqlx_deflate_max_client_compression_level Changes to this property will trigger replacement. int
Limit the upper bound of accepted compression levels for the deflate algorithm. ("mysqlx_deflate_max_client_compression_level")
mysqlx_document_id_unique_prefix Changes to this property will trigger replacement. int
("mysqlx_document_id_unique_prefix") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'mysqlx_document_id_unique_prefix' field has been deprecated and may be removed in a future version. Do not use this field.

mysqlx_enable_hello_notice Changes to this property will trigger replacement. bool
("mysqlx_enable_hello_notice") DEPRECATED -- variable should not be settable and will be ignored
mysqlx_idle_worker_thread_timeout Changes to this property will trigger replacement. int
("mysqlx_idle_worker_thread_timeout") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'mysqlx_idle_worker_thread_timeout' field has been deprecated and may be removed in a future version. Do not use this field.

mysqlx_interactive_timeout Changes to this property will trigger replacement. int

The number of seconds to wait for interactive clients to timeout.

mysqlxInteractiveTimeout corresponds to the MySQL X Plugin system variable. mysqlx_interactive_timeout

mysqlx_lz4default_compression_level Changes to this property will trigger replacement. int
Set the default compression level for the lz4 algorithm. ("mysqlx_lz4_default_compression_level")
mysqlx_lz4max_client_compression_level Changes to this property will trigger replacement. int
Limit the upper bound of accepted compression levels for the lz4 algorithm. ("mysqlx_lz4_max_client_compression_level")
mysqlx_max_allowed_packet Changes to this property will trigger replacement. int

The maximum size of network packets that can be received by X Plugin.

This is the mysql variable "mysqlx_max_allowed_packet".

mysqlx_min_worker_threads Changes to this property will trigger replacement. int
("mysqlx_min_worker_threads") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'mysqlx_min_worker_threads' field has been deprecated and may be removed in a future version. Do not use this field.

mysqlx_read_timeout Changes to this property will trigger replacement. int

The number of seconds that X Plugin waits for blocking read operations to complete. After this time, if the read operation is not successful, X Plugin closes the connection and returns a warning notice with the error code ER_IO_READ_ERROR to the client application.

mysqlxReadTimeout corresponds to the MySQL X Plugin system variable mysqlx_read_timeout

mysqlx_wait_timeout Changes to this property will trigger replacement. int

The number of seconds that X Plugin waits for activity on a connection.

mysqlxWaitTimeout corresponds to the MySQL X Plugin system variable. mysqlx_wait_timeout

mysqlx_write_timeout Changes to this property will trigger replacement. int

The number of seconds that X Plugin waits for blocking write operations to complete. After this time, if the write operation is not successful, X Plugin closes the connection.

mysqlxReadmysqlxWriteTimeoutTimeout corresponds to the MySQL X Plugin system variable mysqlx_write_timeout

mysqlx_zstd_default_compression_level Changes to this property will trigger replacement. int
Set the default compression level for the zstd algorithm. ("mysqlx_zstd_default_compression_level")
mysqlx_zstd_max_client_compression_level Changes to this property will trigger replacement. int
Limit the upper bound of accepted compression levels for the zstd algorithm. ("mysqlx_zstd_max_client_compression_level")
net_read_timeout Changes to this property will trigger replacement. int

The number of seconds to wait for more data from a connection before aborting the read.

netReadTimeout corresponds to the MySQL system variable net_read_timeout

net_write_timeout Changes to this property will trigger replacement. int

The number of seconds to wait for a block to be written to a connection before aborting the write.

netWriteTimeout corresponds to the MySQL system variable net_write_timeout

optimizer_switch Changes to this property will trigger replacement. str

The optimizer_switch system variable enables control over optimizer behavior. The value of this variable is a set of flags, each of which has a value of on or off to indicate whether the corresponding optimizer behavior is enabled or disabled. This variable has global and session values and can be changed at runtime. The global default can be set at server startup.

Setting hypergraph_optimizer=on for cloud builds below 9.0.0 will fail.

optimizerSwitch corresponds to the MySQL Server System variable [optimizer_switch] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_optimizer_switch).

parser_max_mem_size Changes to this property will trigger replacement. str
("parser_max_mem_size")
query_alloc_block_size Changes to this property will trigger replacement. str
("query_alloc_block_size") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'query_alloc_block_size' field has been deprecated and may be removed in a future version. Do not use this field.

query_prealloc_size Changes to this property will trigger replacement. str
("query_prealloc_size") DEPRECATED -- variable should not be settable and will be ignored
range_optimizer_max_mem_size Changes to this property will trigger replacement. str

The limit on memory consumption for the range optimizer. A value of 0 means “no limit.” If an execution plan considered by the optimizer uses the range access method but the optimizer estimates that the amount of memory needed for this method would exceed the limit, it abandons the plan and considers other plans.

rangeOptimizerMaxMemSize corresponds to the MySQL Server System variable [range_optimizer_max_mem_size] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_range_optimizer_max_mem_size).

Deprecated: The 'query_prealloc_size' field has been deprecated and may be removed in a future version. Do not use this field.

regexp_time_limit Changes to this property will trigger replacement. int
regexpTimeLimit corresponds to the MySQL system variable [regexp_time_limit] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_regexp_time_limit)
relay_log_space_limit Changes to this property will trigger replacement. str

The maximum amount of space to use for all relay logs.

relayLogSpaceLimit corresponds to the MySQL Replica Server Options variable [relay_log_space_limit] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-replica.html#sysvar_relay_log_space_limit).

replica_net_timeout Changes to this property will trigger replacement. int

Specifies the number of seconds to wait for more data or a heartbeat signal from the source before the replica considers the connection broken, aborts the read, and tries to reconnect. Setting this variable has no immediate effect. The state of the variable applies on all subsequent START REPLICA commands.

replicaNetTimeout corresponds to the MySQL Replica server system variable replica_net_timeout

replica_parallel_workers Changes to this property will trigger replacement. int

Beginning with MySQL 8.0.26, slave_parallel_workers is deprecated, and you should use replica_parallel_workers instead. (Prior to MySQL 8.0.26, you must use slave_parallel_workers to set the number of applier threads.)

replicaParallelWorkers corresponds to the MySQL Replica Server Options variable [replica_parallel_workers] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-replica.html#sysvar_replica_parallel_workers).

replica_type_conversions Changes to this property will trigger replacement. str

From MySQL 8.0.26, use replica_type_conversions in place of slave_type_conversions, which is deprecated from that release. In releases before MySQL 8.0.26, use slave_type_conversions.

replica_type_conversions controls the type conversion mode in effect on the replica when using row-based replication. Its value is a comma-delimited set of zero or more elements from the list: ALL_LOSSY, ALL_NON_LOSSY, ALL_SIGNED, ALL_UNSIGNED. Set this variable to an empty string to disallow type conversions between the source and the replica. Setting this variable takes effect for all replication channels immediately, including running channels.

replica_type_conversions corresponds to the MySQL Replica Server Options variable [replica_type_conversions] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-replica.html#sysvar_replica_type_conversions).

require_secure_transport Changes to this property will trigger replacement. bool

Whether client connections to the server are required to use some form of secure transport. When this variable is enabled, the server permits only TCP/IP connections encrypted using TLS/SSL, or connections that use a socket file or shared memory. The server rejects nonsecure connection attempts, which fail with an ER_SECURE_TRANSPORT_REQUIRED error.

require_secure_transport corresponds to the MySQL Server Administration system variable require_secure_transport

skip_name_resolve Changes to this property will trigger replacement. bool

Whether to resolve host names when checking client connections. If this variable is OFF, mysqld resolves host names when checking client connections. If it is ON, mysqld uses only IP numbers; in this case, all Host column values in the grant tables must be IP addresses. See Section 7.1.12.3, “DNS Lookups and the Host Cache”.

skipNameResolve corresponds to the MySQL Server System variable [skip_name_resolve] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_skip_name_resolve).

sort_buffer_size Changes to this property will trigger replacement. str

Each session that must perform a sort allocates a buffer of this size.

sortBufferSize corresponds to the MySQL system variable sort_buffer_size

sql_generate_invisible_primary_key Changes to this property will trigger replacement. bool

Whether GIPK mode is in effect, in which case a MySQL replication source server adds a generated invisible primary key to any InnoDB table that is created without one.

sqlGenerateInvisiblePrimaryKey corresponds to the MySQL system variable [sql_generate_invisible_primary_key] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_sql_generate_invisible_primary_key).

sql_mode Changes to this property will trigger replacement. str
("sql_mode")
sql_require_primary_key Changes to this property will trigger replacement. bool
("sql_require_primary_key")
sql_warnings Changes to this property will trigger replacement. bool
("sql_warnings")
table_definition_cache Changes to this property will trigger replacement. int

The number of table definitions that can be stored in the table definition cache. If you use a large number of tables, you can create a large table definition cache to speed up opening of tables. The table definition cache takes less space and does not use file descriptors, unlike the normal table cache.

table_definition_cache corresponds to the MySQL Server Administration system variable table_definition_cache

table_open_cache Changes to this property will trigger replacement. int

The number of open tables for all threads. Increasing this value increases the number of file descriptors that mysqld requires.

table_open_cache corresponds to the MySQL Server Administration system variable table_open_cache

temptable_max_ram Changes to this property will trigger replacement. str

Defines the maximum amount of memory that can be occupied by the TempTable storage engine before it starts storing data on disk. The default value is 1073741824 bytes (1GiB). For more information, see Section 10.4.4, “Internal Temporary Table Use in MySQL”.

temptableMaxRam corresponds to the MySQL system variable [temptable_max_ram] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_temptable_max_ram).

thread_pool_dedicated_listeners Changes to this property will trigger replacement. bool
Controls whether the thread pool uses dedicated listener threads. If enabled, a listener thread in each thread group is dedicated to the task of listening for network events from clients, ensuring that the maximum number of query worker threads is no more than the value specified by threadPoolMaxTransactionsLimit. threadPoolDedicatedListeners corresponds to the MySQL Database Service-specific system variable thread_pool_dedicated_listeners.
thread_pool_max_transactions_limit Changes to this property will trigger replacement. int
Limits the maximum number of open transactions to the defined value. The default value is 0, which enforces no limit. threadPoolMaxTransactionsLimit corresponds to the MySQL Database Service-specific system variable thread_pool_max_transactions_limit.
thread_pool_query_threads_per_group Changes to this property will trigger replacement. int

The maximum number of query threads permitted in a thread group. The maximum value is 4096, but if thread_pool_max_transactions_limit is set, thread_pool_query_threads_per_group must not exceed that value. The default value of 1 means there is one active query thread in each thread group, which works well for many loads. When you are using the high concurrency thread pool algorithm (thread_pool_algorithm = 1), consider increasing the value if you experience slower response times due to long-running transactions.

threadPoolQueryThreadsPerGroup corresponds to the MySQL Server system variable thread_pool_query_threads_per_group

thread_pool_size Changes to this property will trigger replacement. int

The number of thread groups in the thread pool. This is the most important parameter controlling thread pool performance. It affects how many statements can execute simultaneously. If a value outside the range of permissible values is specified, the thread pool plugin does not load and the server writes a message to the error log.

threadPoolSize corresponds to the MySQL Server System variable [thread_pool_size] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_thread_pool_size).

thread_pool_transaction_delay Changes to this property will trigger replacement. int

The delay period before executing a new transaction, in milliseconds. The maximum value is 300000 (5 minutes). A transaction delay can be used in cases where parallel transactions affect the performance of other operations due to resource contention. For example, if parallel transactions affect index creation or an online buffer pool resizing operation, you can configure a transaction delay to reduce resource contention while those operations are running.

threadPoolTransactionDelay corresponds to the MySQL Server system variable thread_pool_transaction_delay

time_zone Changes to this property will trigger replacement. str

Initializes the time zone for each client that connects.

This corresponds to the MySQL System Variable "time_zone".

The values can be given in one of the following formats, none of which are case-sensitive:

  • As a string indicating an offset from UTC of the form [H]H:MM, prefixed with a + or -, such as '+10:00', '-6:00', or '+05:30'. The permitted range is '-13:59' to '+14:00', inclusive.
  • As a named time zone, as defined by the "IANA Time Zone database", such as 'Europe/Helsinki', 'US/Eastern', 'MET', or 'UTC'.
tmp_table_size Changes to this property will trigger replacement. str

The maximum size of internal in-memory temporary tables. This variable does not apply to user-created MEMORY tables.

tmp_table_size corresponds to the MySQL system variable tmp_table_size

transaction_isolation Changes to this property will trigger replacement. str
("transaction_isolation")
wait_timeout Changes to this property will trigger replacement. int

The number of seconds the server waits for activity on a noninteractive connection before closing it.

waitTimeout corresponds to the MySQL system variable. wait_timeout

** IMPORTANT ** Any change to a property that does not support update will force the destruction and recreation of the resource with the new property values

autoIncrementIncrement Changes to this property will trigger replacement. Number

auto_increment_increment and auto_increment_offset are intended for use with circular (source-to-source) replication, and can be used to control the operation of AUTO_INCREMENT columns. Both variables have global and session values, and each can assume an integer value between 1 and 65,535 inclusive.

autoIncrementIncrement corresponds to the MySQL Replication Source Options variable [auto_increment_increment] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-source.html#sysvar_auto_increment_increment).

autoIncrementOffset Changes to this property will trigger replacement. Number

This variable has a default value of 1. If it is left with its default value, and Group Replication is started on the server in multi-primary mode, it is changed to the server ID.

autoIncrementOffset corresponds to the MySQL Replication Source Options variable [auto_increment_offset] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-source.html#sysvar_auto_increment_offset).

autocommit Changes to this property will trigger replacement. Boolean
("autocommit")
bigTables Changes to this property will trigger replacement. Boolean

If enabled, the server stores all temporary tables on disk rather than in memory.

bigTables corresponds to the MySQL server variable big_tables.

binlogExpireLogsSeconds Changes to this property will trigger replacement. Number
Sets the binary log expiration period in seconds. binlogExpireLogsSeconds corresponds to the MySQL binary logging system variable binlog_expire_logs_seconds.
binlogGroupCommitSyncDelay Changes to this property will trigger replacement. Number

Controls how many microseconds the binary log commit waits before synchronizing the binary log file to disk. There is no delay by default. Setting this variable to a microsecond delay enables more transactions to be synchronized together to disk at once, reducing the overall time to commit a group of transactions because the larger groups required fewer time units per group.

binlogGroupCommitSyncDelay corresponds to the MySQL Replication system variable binlog_group_commit_sync_delay

binlogGroupCommitSyncNoDelayCount Changes to this property will trigger replacement. Number

The maximum number of transactions to wait for before aborting the current delay as specified by binlog_group_commit_sync_delay. If binlog_group_commit_sync_delay is set to 0, then this option has no effect.

binlogGroupCommitSyncNoDelayCount corresponds to the MySQL Replication system variable binlog_group_commit_sync_no_delay_count

binlogRowMetadata Changes to this property will trigger replacement. String
Configures the amount of table metadata added to the binary log when using row-based logging. binlogRowMetadata corresponds to the MySQL binary logging system variable binlog_row_metadata.
binlogRowValueOptions Changes to this property will trigger replacement. String
When set to PARTIAL_JSON, this enables use of a space-efficient binary log format for updates that modify only a small portion of a JSON document. binlogRowValueOptions corresponds to the MySQL binary logging system variable binlog_row_value_options.
binlogTransactionCompression Changes to this property will trigger replacement. Boolean
Enables compression for transactions that are written to binary log files on this server. binlogTransactionCompression corresponds to the MySQL binary logging system variable binlog_transaction_compression.
blockEncryptionMode Changes to this property will trigger replacement. String

This variable controls the block encryption mode for block-based algorithms such as AES. It affects encryption for AES_ENCRYPT() and AES_DECRYPT(). block_encryption_mode takes a value in aes-keylen-mode format, where keylen is the key length in bits and mode is the encryption mode. The value is not case-sensitive. Permitted keylen values are 128, 192, and 256. Permitted mode values are ECB, CBC, CFB1, CFB8, CFB128, and OFB.

block_encryption_mode corresponds to the MySQL Server Administration system variable block_encryption_mode

characterSetServer Changes to this property will trigger replacement. String

The server's default character set. If you set this variable, you should also set collation_server to specify the collation for the character set.

characterSetServer corresponds to the MySQL server variable character_set_server.

collationServer Changes to this property will trigger replacement. String

The server's default collation.

collationServer corresponds to the MySQL server variable collation_server.

completionType Changes to this property will trigger replacement. String
("completion_type")
connectTimeout Changes to this property will trigger replacement. Number

The number of seconds that the mysqld server waits for a connect packet before responding with Bad handshake.

connectTimeout corresponds to the MySQL system variable connect_timeout

Increasing the connect_timeout value might help if clients frequently encounter errors of the form "Lost connection to MySQL server at 'XXX', system error: errno".

connectionMemoryChunkSize Changes to this property will trigger replacement. Number

Set the chunking size for updates to the global memory usage counter Global_connection_memory.

connectionMemoryChunkSize corresponds to the MySQL system variable connection_memory_chunk_size.

connectionMemoryLimit Changes to this property will trigger replacement. String

Set the maximum amount of memory that can be used by a single user connection.

connectionMemoryLimit corresponds to the MySQL system variable connection_memory_limit.

cteMaxRecursionDepth Changes to this property will trigger replacement. String
("cte_max_recursion_depth")
defaultAuthenticationPlugin Changes to this property will trigger replacement. String

The default authentication plugin. This must be a plugin that uses internal credentials storage, so these values are permitted: mysql_native_password, sha256_password, caching_sha2_password.

As of MySQL 8.0.27, which introduces multifactor authentication, default_authentication_plugin is still used, but in conjunction with and at a lower precedence than the authentication_policy system variable. For details, see The Default Authentication Plugin. Because of this diminished role, default_authentication_plugin is deprecated as of MySQL 8.0.27 and subject to removal in a future MySQL version.

defaultAuthenticationPlugin corresponds to the MySQL system variable default_authentication_plugin.

explainFormat Changes to this property will trigger replacement. String

This variable determines the default output format used by EXPLAIN in the absence of a FORMAT option when displaying a query execution plan.

explainFormat corresponds to the MySQL system variable explain_format.

explicitDefaultsForTimestamp Changes to this property will trigger replacement. Boolean

This system variable determines whether the server enables certain nonstandard behaviors for default values and NULL-value handling in TIMESTAMP columns. By default, explicit_defaults_for_timestamp is enabled, which disables the nonstandard behaviors. Disabling explicit_defaults_for_timestamp results in a warning.

explicit_defaults_for_timestamp corresponds to the MySQL Server Administration system variable explicit_defaults_for_timestamp

foreignKeyChecks Changes to this property will trigger replacement. Boolean
("foreign_key_checks")
generatedRandomPasswordLength Changes to this property will trigger replacement. Number
("generated_random_password_length") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'generated_random_password_length' field has been deprecated and may be removed in a future version. Do not use this field.

globalConnectionMemoryLimit Changes to this property will trigger replacement. String

Set the total amount of memory that can be used by all user connections.

globalConnectionMemoryLimit corresponds to the MySQL system variable global_connection_memory_limit.

globalConnectionMemoryTracking Changes to this property will trigger replacement. Boolean

Determines whether the MySQL server calculates Global_connection_memory.

globalConnectionMemoryTracking corresponds to the MySQL system variable global_connection_memory_tracking.

groupConcatMaxLen Changes to this property will trigger replacement. String

Specifies the maximum permitted result length in bytes for the GROUP_CONCAT() function.

This is the MySQL variable "group_concat_max_len". For more information, please see the MySQL documentation

groupReplicationConsistency Changes to this property will trigger replacement. String
  • EVENTUAL: Both RO and RW transactions do not wait for preceding transactions to be applied before executing. A RW transaction does not wait for other members to apply a transaction. This means that a transaction could be externalized on one member before the others. This also means that in the event of a primary failover, the new primary can accept new RO and RW transactions before the previous primary transactions are all applied. RO transactions could result in outdated values, RW transactions could result in a rollback due to conflicts.
  • BEFORE_ON_PRIMARY_FAILOVER: New RO or RW transactions with a newly elected primary that is applying backlog from the old primary are held (not applied) until any backlog has been applied. This ensures that when a primary failover happens, intentionally or not, clients always see the latest value on the primary. This guarantees consistency, but means that clients must be able to handle the delay in the event that a backlog is being applied. Usually this delay should be minimal, but does depend on the size of the backlog.
  • BEFORE: A RW transaction waits for all preceding transactions to complete before being applied. A RO transaction waits for all preceding transactions to complete before being executed. This ensures that this transaction reads the latest value by only affecting the latency of the transaction. This reduces the overhead of synchronization on every RW transaction, by ensuring synchronization is used only on RO transactions. This consistency level also includes the consistency guarantees provided by BEFORE_ON_PRIMARY_FAILOVER.
  • AFTER: A RW transaction waits until its changes have been applied to all of the other members. This value has no effect on RO transactions. This mode ensures that when a transaction is committed on the local member, any subsequent transaction reads the written value or a more recent value on any group member. Use this mode with a group that is used for predominantly RO operations to ensure that applied RW transactions are applied everywhere once they commit. This could be used by your application to ensure that subsequent reads fetch the latest data which includes the latest writes. This reduces the overhead of synchronization on every RO transaction, by ensuring synchronization is used only on RW transactions. This consistency level also includes the consistency guarantees provided by BEFORE_ON_PRIMARY_FAILOVER.
  • BEFORE_AND_AFTER: A RW transaction waits for 1) all preceding transactions to complete before being applied and 2) until its changes have been applied on other members. A RO transaction waits for all preceding transactions to complete before execution takes place. This consistency level also includes the consistency guarantees provided by BEFORE_ON_PRIMARY_FAILOVER.
informationSchemaStatsExpiry Changes to this property will trigger replacement. Number
("information_schema_stats_expiry")
innodbAdaptiveHashIndex Changes to this property will trigger replacement. Boolean

Whether the InnoDB adaptive hash index is enabled or disabled. It may be desirable, depending on your workload, to dynamically enable or disable adaptive hash indexing to improve query performance. Because the adaptive hash index may not be useful for all workloads, conduct benchmarks with it both enabled and disabled, using realistic workloads.

innodbAdaptiveHashIndex corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_adaptive_hash_index] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_adaptive_hash_index).

innodbAutoincLockMode Changes to this property will trigger replacement. Number

The lock mode to use for generating auto-increment values. Permissible values are 0, 1, or 2, for traditional, consecutive, or interleaved, respectively.

innodbAutoincLockMode corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_autoinc_lock_mode] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_autoinc_lock_mode).

innodbBufferPoolDumpPct Changes to this property will trigger replacement. Number

Specifies the percentage of the most recently used pages for each buffer pool to read out and dump.

innodbBufferPoolDumpPct corresponds to the MySQL InnoDB system variable innodb_buffer_pool_dump_pct.

The range is 1 to 100. The default value is 25.

For example, if there are 4 buffer pools with 100 pages each, and innodb_buffer_pool_dump_pct is set to 25, the 25 most recently used pages from each buffer pool are dumped.

innodbBufferPoolInstances Changes to this property will trigger replacement. Number
("innodb_buffer_pool_instances")
innodbBufferPoolSize Changes to this property will trigger replacement. String

The size (in bytes) of the buffer pool, that is, the memory area where InnoDB caches table and index data.

innodbBufferPoolSize corresponds to the MySQL server system variable innodb_buffer_pool_size.

The default and maximum values depend on the amount of RAM provisioned by the shape. See Default User Variables.

innodbChangeBuffering Changes to this property will trigger replacement. String

Whether InnoDB performs change buffering, an optimization that delays write operations to secondary indexes so that the I/O operations can be performed sequentially. Permitted values are described in the following table. Values may also be specified numerically.

innodbChangeBuffering corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_change_buffering] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_change_buffering).

innodbDdlBufferSize Changes to this property will trigger replacement. String
innodbDdlBufferSize corresponds to the MySQL system variable [innodb_ddl_buffer_size] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_ddl_buffer_size)
innodbDdlThreads Changes to this property will trigger replacement. Number
innodbDdlThreads corresponds to the MySQL system variable [innodb_ddl_threads] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_ddl_threads)
innodbFtEnableStopword Changes to this property will trigger replacement. Boolean
("innodb_ft_enable_stopword")
innodbFtMaxTokenSize Changes to this property will trigger replacement. Number
("innodb_ft_max_token_size")
innodbFtMinTokenSize Changes to this property will trigger replacement. Number
("innodb_ft_min_token_size")
innodbFtNumWordOptimize Changes to this property will trigger replacement. Number
("innodb_ft_num_word_optimize")
innodbFtResultCacheLimit Changes to this property will trigger replacement. String
("innodb_ft_result_cache_limit")
innodbFtServerStopwordTable Changes to this property will trigger replacement. String
("innodb_ft_server_stopword_table")
innodbLockWaitTimeout Changes to this property will trigger replacement. Number
("innodb_lock_wait_timeout")
innodbLogWriterThreads Changes to this property will trigger replacement. Boolean

Enables dedicated log writer threads for writing redo log records from the log buffer to the system buffers and flushing the system buffers to the redo log files.

This is the MySQL variable "innodb_log_writer_threads". For more information, please see the MySQL documentation

innodbMaxPurgeLag Changes to this property will trigger replacement. String

The desired maximum purge lag in terms of transactions.

InnoDB maintains a list of transactions that have index records delete-marked by UPDATE or DELETE operations. The length of the list is the purge lag.

If this value is exceeded, a delay is imposed on INSERT, UPDATE, and DELETE operations to allow time for purge to catch up.

The default value is 0, which means there is no maximum purge lag and no delay.

innodbMaxPurgeLag corresponds to the MySQL server system variable innodb_max_purge_lag.

innodbMaxPurgeLagDelay Changes to this property will trigger replacement. Number

The maximum delay in microseconds for the delay imposed when the innodb_max_purge_lag threshold is exceeded.

The specified innodb_max_purge_lag_delay value is an upper limit on the delay period.

innodbMaxPurgeLagDelay corresponds to the MySQL server system variable innodb_max_purge_lag_delay.

innodbNumaInterleave Changes to this property will trigger replacement. Boolean

Enables the NUMA interleave memory policy for allocation of the InnoDB buffer pool. When innodb_numa_interleave is enabled, the NUMA memory policy is set to MPOL_INTERLEAVE for the mysqld process. After the InnoDB buffer pool is allocated, the NUMA memory policy is set back to MPOL_DEFAULT. For the innodb_numa_interleave option to be available, MySQL must be compiled on a NUMA-enabled Linux system.

innodbNumaInterleave corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_numa_interleave] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_numa_interleave).

innodbOnlineAlterLogMaxSize Changes to this property will trigger replacement. String

Specifies an upper limit in bytes on the size of the temporary log files used during online DDL operations for InnoDB tables. There is one such log file for each index being created or table being altered. This log file stores data inserted, updated, or deleted in the table during the DDL operation.

innodbOnlineAlterLogMaxSize corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_online_alter_log_max_size] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_online_alter_log_max_size).

innodbRedoLogCapacity Changes to this property will trigger replacement. String

Defines the amount of disk space occupied by redo log files. innodb_redo_log_capacity supercedes the innodb_log_files_in_group and innodb_log_file_size variables, which are both ignored if innodb_redo_log_capacity is defined. If innodb_redo_log_capacity is not defined, and if neither innodb_log_file_size or innodb_log_files_in_group are defined, then the default innodb_redo_log_capacity value is used.

innodbRedoLogCapacity corresponds to the InnoDB Startup Options and System Variables innodb_redo_log_capacity

innodbRollbackOnTimeout Changes to this property will trigger replacement. Boolean

InnoDB rolls back only the last statement on a transaction timeout by default. If --innodb-rollback-on-timeout is specified, a transaction timeout causes InnoDB to abort and roll back the entire transaction.

innodbRollbackOnTimeout corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_rollback_on_timeout] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_rollback_on_timeout).

innodbSortBufferSize Changes to this property will trigger replacement. Number

This variable defines:

  • The sort buffer size for online DDL operations that create or rebuild secondary indexes. However, as of MySQL 8.0.27, this responsibility is subsumed by the innodb_ddl_buffer_size variable.
  • The amount by which the temporary log file is extended when recording concurrent DML during an online DDL operation, and the size of the temporary log file read buffer and write buffer.

innodbSortBufferSize corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_sort_buffer_size] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_sort_buffer_size).

innodbStatsPersistentSamplePages Changes to this property will trigger replacement. String

The number of index pages to sample when estimating cardinality and other statistics for an indexed column, such as those calculated by ANALYZE TABLE.

innodbStatsPersistentSamplePages corresponds to the MySQL InnoDB system variable innodb_stats_persistent_sample_pages

innodb_stats_persistent_sample_pages only applies when innodb_stats_persistent is enabled for a table; when innodb_stats_persistent is disabled, innodb_stats_transient_sample_pages applies instead.

innodbStatsTransientSamplePages Changes to this property will trigger replacement. String

The number of index pages to sample when estimating cardinality and other statistics for an indexed column, such as those calculated by ANALYZE TABLE.

innodbStatsTransientSamplePages corresponds to the MySQL InnoDB system variable innodb_stats_transient_sample_pages

innodb_stats_transient_sample_pages only applies when innodb_stats_persistent is disabled for a table; when innodb_stats_persistent is enabled, innodb_stats_persistent_sample_pages applies instead.

innodb_stats_persistent is ON by default and cannot be changed. It is possible to override it using the STATS_PERSISTENT clause of the CREATE TABLE and ALTER TABLE statements.

innodbStrictMode Changes to this property will trigger replacement. Boolean

When you enable innodbStrictMode, the InnoDB storage engine returns errors instead of warnings for invalid or incompatible table options.

innodbStrictMode corresponds to the MySQL InnoDB system variable innodb_strict_mode

innodbUndoLogTruncate Changes to this property will trigger replacement. Boolean

When enabled, undo tablespaces that exceed the threshold value defined by innodb_max_undo_log_size are marked for truncation. Only undo tablespaces can be truncated. Truncating undo logs that reside in the system tablespace is not supported. For truncation to occur, there must be at least two undo tablespaces.

innodbUndoLogTruncate corresponds to the MySQL InnoDB Startup Options and System Variables [innodb_undo_log_truncate] (https://dev.mysql.com/doc/refman/8.0/en/innodb-parameters.html#sysvar_innodb_undo_log_truncate).

interactiveTimeout Changes to this property will trigger replacement. Number

The number of seconds the server waits for activity on an interactive connection before closing it.

interactiveTimeout corresponds to the MySQL system variable. interactive_timeout

joinBufferSize Changes to this property will trigger replacement. String

The minimum size of the buffer that is used for plain index scans, range index scans, and joins that do not use indexes and thus perform full table scans. In MySQL 8.0.18 and later, this variable also controls the amount of memory used for hash joins. Normally, the best way to get fast joins is to add indexes. Increase the value of join_buffer_size to get a faster full join when adding indexes is not possible. One join buffer is allocated for each full join between two tables. For a complex join between several tables for which indexes are not used, multiple join buffers might be necessary.

joinBufferSize corresponds to the MySQL Server System variable [join_buffer_size] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_join_buffer_size).

localInfile Changes to this property will trigger replacement. Boolean

This variable controls server-side LOCAL capability for LOAD DATA statements. Depending on the local_infile setting, the server refuses or permits local data loading by clients that have LOCAL enabled on the client side.

local_infile corresponds to the MySQL Server system variable local_infile

longQueryTime Changes to this property will trigger replacement. Number

If a query takes longer than this many seconds, the server increments the Slow_queries status variable. If the slow query log is enabled, the query is logged to the slow query log file. This value is measured in real time, not CPU time, so a query that is under the threshold on a lightly loaded system might be above the threshold on a heavily loaded one.

longQueryTime corresponds to the MySQL Server System variable [long_query_time] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_long_query_time).

mandatoryRoles Changes to this property will trigger replacement. String
("mandatory_roles")
maxAllowedPacket Changes to this property will trigger replacement. Number

The maximum size of one packet or any generated/intermediate string.

This is the mysql variable "max_allowed_packet".

maxBinlogCacheSize Changes to this property will trigger replacement. String

Sets the size of the transaction cache.

maxBinlogCacheSize corresponds to the MySQL server system variable max_binlog_cache_size.

maxConnectErrors Changes to this property will trigger replacement. String
("max_connect_errors")
maxConnections Changes to this property will trigger replacement. Number
("max_connections")
maxExecutionTime Changes to this property will trigger replacement. String
("max_execution_time")
maxHeapTableSize Changes to this property will trigger replacement. String

This variable sets the maximum size to which user-created MEMORY tables are permitted to grow.

maxHeapTableSize corresponds to the MySQL system variable max_heap_table_size

maxPreparedStmtCount Changes to this property will trigger replacement. Number
("max_prepared_stmt_count")
maxSeeksForKey Changes to this property will trigger replacement. String

Limit the assumed maximum number of seeks when looking up rows based on a key. The MySQL optimizer assumes that no more than this number of key seeks are required when searching for matching rows in a table by scanning an index, regardless of the actual cardinality of the index (see Section 15.7.7.22, “SHOW INDEX Statement”). By setting this to a low value (say, 100), you can force MySQL to prefer indexes instead of table scans.

maxSeeksForKey corresponds to the MySQL Server System variable [max_seeks_for_key] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_max_seeks_for_key).

maxUserConnections Changes to this property will trigger replacement. String

The maximum number of simultaneous connections permitted to any given MySQL user account. A value of 0 (the default) means “no limit.” This variable has a global value that can be set at server startup or runtime. It also has a read-only session value that indicates the effective simultaneous-connection limit that applies to the account associated with the current session.

maxUserConnections corresponds to the MySQL Server System variable [max_user_connections] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_max_user_connections).

mysqlFirewallMode Changes to this property will trigger replacement. Boolean
("mysql_firewall_mode")
mysqlZstdDefaultCompressionLevel Changes to this property will trigger replacement. Number
DEPRECATED -- typo of mysqlx_zstd_default_compression_level. variable will be ignored.

Deprecated: The 'mysql_zstd_default_compression_level' field has been deprecated and may be removed in a future version. Do not use this field.

mysqlxConnectTimeout Changes to this property will trigger replacement. Number

The number of seconds X Plugin waits for the first packet to be received from newly connected clients.

mysqlxConnectTimeout corresponds to the MySQL X Plugin system variable mysqlx_connect_timeout

mysqlxDeflateDefaultCompressionLevel Changes to this property will trigger replacement. Number
Set the default compression level for the deflate algorithm. ("mysqlx_deflate_default_compression_level")
mysqlxDeflateMaxClientCompressionLevel Changes to this property will trigger replacement. Number
Limit the upper bound of accepted compression levels for the deflate algorithm. ("mysqlx_deflate_max_client_compression_level")
mysqlxDocumentIdUniquePrefix Changes to this property will trigger replacement. Number
("mysqlx_document_id_unique_prefix") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'mysqlx_document_id_unique_prefix' field has been deprecated and may be removed in a future version. Do not use this field.

mysqlxEnableHelloNotice Changes to this property will trigger replacement. Boolean
("mysqlx_enable_hello_notice") DEPRECATED -- variable should not be settable and will be ignored
mysqlxIdleWorkerThreadTimeout Changes to this property will trigger replacement. Number
("mysqlx_idle_worker_thread_timeout") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'mysqlx_idle_worker_thread_timeout' field has been deprecated and may be removed in a future version. Do not use this field.

mysqlxInteractiveTimeout Changes to this property will trigger replacement. Number

The number of seconds to wait for interactive clients to timeout.

mysqlxInteractiveTimeout corresponds to the MySQL X Plugin system variable. mysqlx_interactive_timeout

mysqlxLz4defaultCompressionLevel Changes to this property will trigger replacement. Number
Set the default compression level for the lz4 algorithm. ("mysqlx_lz4_default_compression_level")
mysqlxLz4maxClientCompressionLevel Changes to this property will trigger replacement. Number
Limit the upper bound of accepted compression levels for the lz4 algorithm. ("mysqlx_lz4_max_client_compression_level")
mysqlxMaxAllowedPacket Changes to this property will trigger replacement. Number

The maximum size of network packets that can be received by X Plugin.

This is the mysql variable "mysqlx_max_allowed_packet".

mysqlxMinWorkerThreads Changes to this property will trigger replacement. Number
("mysqlx_min_worker_threads") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'mysqlx_min_worker_threads' field has been deprecated and may be removed in a future version. Do not use this field.

mysqlxReadTimeout Changes to this property will trigger replacement. Number

The number of seconds that X Plugin waits for blocking read operations to complete. After this time, if the read operation is not successful, X Plugin closes the connection and returns a warning notice with the error code ER_IO_READ_ERROR to the client application.

mysqlxReadTimeout corresponds to the MySQL X Plugin system variable mysqlx_read_timeout

mysqlxWaitTimeout Changes to this property will trigger replacement. Number

The number of seconds that X Plugin waits for activity on a connection.

mysqlxWaitTimeout corresponds to the MySQL X Plugin system variable. mysqlx_wait_timeout

mysqlxWriteTimeout Changes to this property will trigger replacement. Number

The number of seconds that X Plugin waits for blocking write operations to complete. After this time, if the write operation is not successful, X Plugin closes the connection.

mysqlxReadmysqlxWriteTimeoutTimeout corresponds to the MySQL X Plugin system variable mysqlx_write_timeout

mysqlxZstdDefaultCompressionLevel Changes to this property will trigger replacement. Number
Set the default compression level for the zstd algorithm. ("mysqlx_zstd_default_compression_level")
mysqlxZstdMaxClientCompressionLevel Changes to this property will trigger replacement. Number
Limit the upper bound of accepted compression levels for the zstd algorithm. ("mysqlx_zstd_max_client_compression_level")
netReadTimeout Changes to this property will trigger replacement. Number

The number of seconds to wait for more data from a connection before aborting the read.

netReadTimeout corresponds to the MySQL system variable net_read_timeout

netWriteTimeout Changes to this property will trigger replacement. Number

The number of seconds to wait for a block to be written to a connection before aborting the write.

netWriteTimeout corresponds to the MySQL system variable net_write_timeout

optimizerSwitch Changes to this property will trigger replacement. String

The optimizer_switch system variable enables control over optimizer behavior. The value of this variable is a set of flags, each of which has a value of on or off to indicate whether the corresponding optimizer behavior is enabled or disabled. This variable has global and session values and can be changed at runtime. The global default can be set at server startup.

Setting hypergraph_optimizer=on for cloud builds below 9.0.0 will fail.

optimizerSwitch corresponds to the MySQL Server System variable [optimizer_switch] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_optimizer_switch).

parserMaxMemSize Changes to this property will trigger replacement. String
("parser_max_mem_size")
queryAllocBlockSize Changes to this property will trigger replacement. String
("query_alloc_block_size") DEPRECATED -- variable should not be settable and will be ignored

Deprecated: The 'query_alloc_block_size' field has been deprecated and may be removed in a future version. Do not use this field.

queryPreallocSize Changes to this property will trigger replacement. String
("query_prealloc_size") DEPRECATED -- variable should not be settable and will be ignored
rangeOptimizerMaxMemSize Changes to this property will trigger replacement. String

The limit on memory consumption for the range optimizer. A value of 0 means “no limit.” If an execution plan considered by the optimizer uses the range access method but the optimizer estimates that the amount of memory needed for this method would exceed the limit, it abandons the plan and considers other plans.

rangeOptimizerMaxMemSize corresponds to the MySQL Server System variable [range_optimizer_max_mem_size] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_range_optimizer_max_mem_size).

Deprecated: The 'query_prealloc_size' field has been deprecated and may be removed in a future version. Do not use this field.

regexpTimeLimit Changes to this property will trigger replacement. Number
regexpTimeLimit corresponds to the MySQL system variable [regexp_time_limit] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_regexp_time_limit)
relayLogSpaceLimit Changes to this property will trigger replacement. String

The maximum amount of space to use for all relay logs.

relayLogSpaceLimit corresponds to the MySQL Replica Server Options variable [relay_log_space_limit] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-replica.html#sysvar_relay_log_space_limit).

replicaNetTimeout Changes to this property will trigger replacement. Number

Specifies the number of seconds to wait for more data or a heartbeat signal from the source before the replica considers the connection broken, aborts the read, and tries to reconnect. Setting this variable has no immediate effect. The state of the variable applies on all subsequent START REPLICA commands.

replicaNetTimeout corresponds to the MySQL Replica server system variable replica_net_timeout

replicaParallelWorkers Changes to this property will trigger replacement. Number

Beginning with MySQL 8.0.26, slave_parallel_workers is deprecated, and you should use replica_parallel_workers instead. (Prior to MySQL 8.0.26, you must use slave_parallel_workers to set the number of applier threads.)

replicaParallelWorkers corresponds to the MySQL Replica Server Options variable [replica_parallel_workers] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-replica.html#sysvar_replica_parallel_workers).

replicaTypeConversions Changes to this property will trigger replacement. String

From MySQL 8.0.26, use replica_type_conversions in place of slave_type_conversions, which is deprecated from that release. In releases before MySQL 8.0.26, use slave_type_conversions.

replica_type_conversions controls the type conversion mode in effect on the replica when using row-based replication. Its value is a comma-delimited set of zero or more elements from the list: ALL_LOSSY, ALL_NON_LOSSY, ALL_SIGNED, ALL_UNSIGNED. Set this variable to an empty string to disallow type conversions between the source and the replica. Setting this variable takes effect for all replication channels immediately, including running channels.

replica_type_conversions corresponds to the MySQL Replica Server Options variable [replica_type_conversions] (https://dev.mysql.com/doc/refman/8.0/en/replication-options-replica.html#sysvar_replica_type_conversions).

requireSecureTransport Changes to this property will trigger replacement. Boolean

Whether client connections to the server are required to use some form of secure transport. When this variable is enabled, the server permits only TCP/IP connections encrypted using TLS/SSL, or connections that use a socket file or shared memory. The server rejects nonsecure connection attempts, which fail with an ER_SECURE_TRANSPORT_REQUIRED error.

require_secure_transport corresponds to the MySQL Server Administration system variable require_secure_transport

skipNameResolve Changes to this property will trigger replacement. Boolean

Whether to resolve host names when checking client connections. If this variable is OFF, mysqld resolves host names when checking client connections. If it is ON, mysqld uses only IP numbers; in this case, all Host column values in the grant tables must be IP addresses. See Section 7.1.12.3, “DNS Lookups and the Host Cache”.

skipNameResolve corresponds to the MySQL Server System variable [skip_name_resolve] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_skip_name_resolve).

sortBufferSize Changes to this property will trigger replacement. String

Each session that must perform a sort allocates a buffer of this size.

sortBufferSize corresponds to the MySQL system variable sort_buffer_size

sqlGenerateInvisiblePrimaryKey Changes to this property will trigger replacement. Boolean

Whether GIPK mode is in effect, in which case a MySQL replication source server adds a generated invisible primary key to any InnoDB table that is created without one.

sqlGenerateInvisiblePrimaryKey corresponds to the MySQL system variable [sql_generate_invisible_primary_key] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_sql_generate_invisible_primary_key).

sqlMode Changes to this property will trigger replacement. String
("sql_mode")
sqlRequirePrimaryKey Changes to this property will trigger replacement. Boolean
("sql_require_primary_key")
sqlWarnings Changes to this property will trigger replacement. Boolean
("sql_warnings")
tableDefinitionCache Changes to this property will trigger replacement. Number

The number of table definitions that can be stored in the table definition cache. If you use a large number of tables, you can create a large table definition cache to speed up opening of tables. The table definition cache takes less space and does not use file descriptors, unlike the normal table cache.

table_definition_cache corresponds to the MySQL Server Administration system variable table_definition_cache

tableOpenCache Changes to this property will trigger replacement. Number

The number of open tables for all threads. Increasing this value increases the number of file descriptors that mysqld requires.

table_open_cache corresponds to the MySQL Server Administration system variable table_open_cache

temptableMaxRam Changes to this property will trigger replacement. String

Defines the maximum amount of memory that can be occupied by the TempTable storage engine before it starts storing data on disk. The default value is 1073741824 bytes (1GiB). For more information, see Section 10.4.4, “Internal Temporary Table Use in MySQL”.

temptableMaxRam corresponds to the MySQL system variable [temptable_max_ram] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_temptable_max_ram).

threadPoolDedicatedListeners Changes to this property will trigger replacement. Boolean
Controls whether the thread pool uses dedicated listener threads. If enabled, a listener thread in each thread group is dedicated to the task of listening for network events from clients, ensuring that the maximum number of query worker threads is no more than the value specified by threadPoolMaxTransactionsLimit. threadPoolDedicatedListeners corresponds to the MySQL Database Service-specific system variable thread_pool_dedicated_listeners.
threadPoolMaxTransactionsLimit Changes to this property will trigger replacement. Number
Limits the maximum number of open transactions to the defined value. The default value is 0, which enforces no limit. threadPoolMaxTransactionsLimit corresponds to the MySQL Database Service-specific system variable thread_pool_max_transactions_limit.
threadPoolQueryThreadsPerGroup Changes to this property will trigger replacement. Number

The maximum number of query threads permitted in a thread group. The maximum value is 4096, but if thread_pool_max_transactions_limit is set, thread_pool_query_threads_per_group must not exceed that value. The default value of 1 means there is one active query thread in each thread group, which works well for many loads. When you are using the high concurrency thread pool algorithm (thread_pool_algorithm = 1), consider increasing the value if you experience slower response times due to long-running transactions.

threadPoolQueryThreadsPerGroup corresponds to the MySQL Server system variable thread_pool_query_threads_per_group

threadPoolSize Changes to this property will trigger replacement. Number

The number of thread groups in the thread pool. This is the most important parameter controlling thread pool performance. It affects how many statements can execute simultaneously. If a value outside the range of permissible values is specified, the thread pool plugin does not load and the server writes a message to the error log.

threadPoolSize corresponds to the MySQL Server System variable [thread_pool_size] (https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_thread_pool_size).

threadPoolTransactionDelay Changes to this property will trigger replacement. Number

The delay period before executing a new transaction, in milliseconds. The maximum value is 300000 (5 minutes). A transaction delay can be used in cases where parallel transactions affect the performance of other operations due to resource contention. For example, if parallel transactions affect index creation or an online buffer pool resizing operation, you can configure a transaction delay to reduce resource contention while those operations are running.

threadPoolTransactionDelay corresponds to the MySQL Server system variable thread_pool_transaction_delay

timeZone Changes to this property will trigger replacement. String

Initializes the time zone for each client that connects.

This corresponds to the MySQL System Variable "time_zone".

The values can be given in one of the following formats, none of which are case-sensitive:

  • As a string indicating an offset from UTC of the form [H]H:MM, prefixed with a + or -, such as '+10:00', '-6:00', or '+05:30'. The permitted range is '-13:59' to '+14:00', inclusive.
  • As a named time zone, as defined by the "IANA Time Zone database", such as 'Europe/Helsinki', 'US/Eastern', 'MET', or 'UTC'.
tmpTableSize Changes to this property will trigger replacement. String

The maximum size of internal in-memory temporary tables. This variable does not apply to user-created MEMORY tables.

tmp_table_size corresponds to the MySQL system variable tmp_table_size

transactionIsolation Changes to this property will trigger replacement. String
("transaction_isolation")
waitTimeout Changes to this property will trigger replacement. Number

The number of seconds the server waits for activity on a noninteractive connection before closing it.

waitTimeout corresponds to the MySQL system variable. wait_timeout

** IMPORTANT ** Any change to a property that does not support update will force the destruction and recreation of the resource with the new property values

Import

MysqlConfigurations can be imported using the id, e.g.

$ pulumi import oci:Mysql/mysqlConfiguration:MysqlConfiguration test_mysql_configuration "configurations/{configurationId}"
Copy

To learn more about importing existing cloud resources, see Importing resources.

Package Details

Repository
oci pulumi/pulumi-oci
License
Apache-2.0
Notes
This Pulumi package is based on the oci Terraform Provider.