Underscore (_) parameters in 21c:
SELECT /*+ use_hash(x y) */
ksppinm name,
ksppstvl value,
ksppdesc description
FROM
x$ksppi x,
x$ksppcv y
WHERE
( x.indx = y.indx )
AND bitand(ksppiflg, 268435456) = 0
AND ksppinm not like '\_\_%' escape '\'
ORDER BY ksppinm;
| name | value | description |
|---|---|---|
| DBFIPS_140 | FALSE | Enable use of crypographic libraries in FIPS mode, public |
| _4030_dump_bitvec | 4095 | bitvec to specify dumps prior to 4030 error |
| _4031_dump_bitvec | 67194879 | bitvec to specify dumps prior to 4031 error |
| _4031_dump_interval | 300 | Dump 4031 error once for each n-second interval |
| _4031_max_dumps | 100 | Maximum number of 4031 dumps for this process |
| _4031_sga_dump_interval | 3600 | Dump 4031 SGA heapdump error once for each n-second interval |
| _4031_sga_max_dumps | 10 | Maximum number of SGA heapdumps |
| _AllowMultInsteadofDDLTrigger | 0 | Oracle internal parameter to allow multiple instead of DDL triggers |
| _EnableDDLTtriggerTracing | FALSE | enable ddl trigger tracing |
| _EnableShadowTypes | FALSE | enable shadow types |
| _ILM_FILTER_TIME | 0 | Upper filter time for ILM block compression |
| _ILM_FILTER_TIME_LOWER | 0 | Lower filter time for ILM block compression |
| _ILM_POLICY_NAME | FALSE | User specified ILM policy name |
| _NUMA_bind_mode | default | Numa bind mode |
| _NUMA_float_spawner | FALSE | float process spawner |
| _NUMA_instance_mapping | Not specified | Set of nodes that this instance should run on |
| _NUMA_pool_size | Not specified | aggregate size in bytes of NUMA pool |
| _PX_use_large_pool | FALSE | Use Large Pool as source of PX buffers |
| _REMOVE_INACTIVE_STANDBY_TDE_MASTER_KEY | FALSE | Remove Inactive Standby TDE Master Key |
| _REMOVE_STDBY_OLD_KEY_AFTER_CHECKPOINT_SCN | TRUE | Remove standby old key after checkpoint SCN |
| _STFForceTranslateOracleSQL | FALSE | if TRUE translation profile will translate Oracle SQL statements |
| _STFTranslateDynamicSQL | FALSE | if TRUE translation profile will translate dynamic SQL statements |
| _VIEW_DICTIONARY_ACCESSIBILITY | FALSE | View Dictionary Accessibility Support |
| _abort_on_mrp_crash | FALSE | abort database instance when MRP crashes |
| _abort_recovery_on_join | FALSE | if TRUE, abort recovery on join reconfigurations |
| _ac_enable_dscn_in_rac | FALSE | Enable Dependent Commit SCN tracking |
| _ac_strict_SCN_check | FALSE | enforce strict SCN check for AC replay across DG failover |
| _accept_versions | List of parameters for rolling operation | |
| _actgrp_spawn_offload | TRUE | action group spawn offload |
| _active_instance_count | 1024 | number of active instances in the cluster database |
| _active_session_idle_limit | 5 | active session idle limit |
| _active_session_legacy_behavior | FALSE | active session legacy behavior |
| _active_standby_fast_reconfiguration | TRUE | if TRUE optimize dlm reconfiguration for active/standby OPS |
| _adaptive_direct_read | TRUE | Adaptive Direct Read |
| _adaptive_direct_write | TRUE | Adaptive Direct Write |
| _adaptive_fetch_enabled | TRUE | enable/disable adaptive fetch in parallel group by |
| _adaptive_log_file_sync_high_switch_freq_threshold | 3 | Threshold for frequent log file sync mode switches (per minute) |
| _adaptive_log_file_sync_poll_aggressiveness | 0 | Polling interval selection bias (conservative=0, aggressive=100) |
| _adaptive_log_file_sync_sampling_count | 128 | Evaluate post/wait versus polling every N writes |
| _adaptive_log_file_sync_sampling_time | 3 | Evaluate post/wait versus polling every N seconds |
| _adaptive_log_file_sync_sched_delay_window | 60 | Window (in seconds) for measuring average scheduling delay |
| _adaptive_log_file_sync_use_polling_threshold | 200 | Ratio of redo synch time to expected poll time as a percentage |
| _adaptive_log_file_sync_use_postwait_threshold | 50 | Percentage of foreground load from when post/wait was last used |
| _adaptive_log_file_sync_use_postwait_threshold_aging | 1001 | Permille of foreground load from when post/wait was last used |
| _adaptive_scalable_log_writer_disable_worker_threshold | 50 | Percentage of overlap across multiple outstanding writes |
| _adaptive_scalable_log_writer_enable_worker_aging | 999900 | Per million of redo gen rate when LGWR workers were last used |
| _adaptive_scalable_log_writer_enable_worker_threshold | 200 | Increase in redo generation rate as a percentage |
| _adaptive_scalable_log_writer_evaluation_fraction | 100 | Serial/parallel log writer evaluation fraction (in 10000ths) |
| _adaptive_scalable_log_writer_evaluation_interval | 60 | Serial/parallel log writer evaluation interval (in seconds) |
| _adaptive_scalable_log_writer_sampling_count | 128 | Evaluate single versus scalable LGWR every N writes |
| _adaptive_scalable_log_writer_sampling_time | 3 | Evaluate single versus scalable LGWR every N seconds |
| _adaptive_window_consolidator_enabled | TRUE | enable/disable adaptive window consolidator PX plan |
| _add_col_optim_enabled | TRUE | Allows new add column optimization |
| _add_nullable_column_with_default_optim | TRUE | Allows add of a nullable column with default optimization |
| _add_stale_mv_to_dependency_list | TRUE | add stale mv to dependency list |
| _add_trim_for_nlssort | TRUE | add trimming for fixed char semantics |
| _addm_auto_actions_enabled | TRUE | determines if ADDM can automatically implement its recommendations |
| _addm_auto_enable | TRUE | governs whether ADDM gets run automatically after every AWR snapshot |
| _addm_skiprules | comma-separated list of ADDM nodes to skip | |
| _addm_version_check | TRUE | governs whether ADDM checks the input AWR snapshot version |
| _adg_adt_redirect_apply_lag_threshold | 12000 | Maximum centi-secends of apply lag threshold |
| _adg_adt_redirect_catchup_wait_time | 12000 | Maximum centi-secends for standby to catch up |
| _adg_auto_close_pdb | TRUE | ADG recovery auto close PDB upon PDB drop/unplug/rename marker |
| _adg_count_beyond_limit | 0 | Count the total number of objects if beyond redo marker length. |
| _adg_defer_segstat | TRUE | Defer the segment statistics update on standby. |
| _adg_distributed_lockmaster | FALSE | standby runs under ADG distributed lockmaster mode |
| _adg_influx_qscn_gap | 0 | maximium time gap between influx scn and qscn update in seconds |
| _adg_instance_recovery | TRUE | enable ADG instance recovery |
| _adg_objectlock_attempts | 2 | Maximum attemps for objectlock get on ADG |
| _adg_objectlock_maxnum | 1000 | The maximum limit of the objectlock number on ADG |
| _adg_objectlock_timeout | 0 | timeout for objectlock get on ADG in centiseconds |
| _adg_parselock_timeout | 0 | timeout for parselock get on ADG in centiseconds |
| _adg_parselock_timeout_sleep | 100 | sleep duration after a parselock timeout on ADG in milliseconds |
| _adg_redirect_upd_to_primary_max_retries | 500 | max retries for ADT redirect to Primary from ADG |
| _adjust_literal_replacement | FALSE | If TRUE, we will adjust the SQL/PLUS output |
| _adr_migrate_runonce | TRUE | Enable/disable ADR Migrate Runonce action |
| _advanced_index_compression_cmp_options | 0 | advanced index compression cmp options |
| _advanced_index_compression_opt_options | 0 | advanced index compression opt options |
| _advanced_index_compression_options | 0 | advanced index compression options |
| _advanced_index_compression_options_value | 0 | advanced index compression options2 |
| _advanced_index_compression_recmp_crsz | 10 | advanced index compression limit recomp cr |
| _advanced_index_compression_recmp_cusz | 90 | advanced index compression limit recomp cu |
| _advanced_index_compression_recmp_nprg | 10 | advanced index compression limit recomp pu |
| _advanced_index_compression_trace | 0 | advanced index compression trace |
| _advanced_index_compression_tst_options | 0 | advanced index compression tst options |
| _advanced_index_compression_umem_options | 2147483647 | advanced index compression umem options |
| _afd_disable_fence | FALSE | Disable AFD fencing |
| _affinity_on | TRUE | enable/disable affinity at run time |
| _age_block_batch_timeout_ms | 1000 | timeout before shipping out the batched age blockmessages in milliseconds |
| _aged_out_cursor_cache_time | 300 | number of seconds an aged out session cached cursor stay in cache |
| _aggregation_optimization_settings | 0 | settings for aggregation optimizations |
| _aiowait_timeouts | 100 | Number of aiowait timeouts before error is reported |
| _alert_expiration | 604800 | seconds before an alert message is moved to exception queue |
| _alert_message_cleanup | 1 | Enable Alert Message Cleanup |
| _alert_message_purge | 1 | Enable Alert Message Purge |
| _alert_post_background | 1 | Enable Background Alert Posting |
| _alert_segment_size | 10 | Alert-log segment size in MBs (1024*1024) |
| _alert_segment_textfile | FALSE | Alert-log text-file also to be segmented |
| _alert_segments_max | 0 | Alert-log max segments to retain, 0 for unlimited |
| _all_shared_dblinks | treat all dblinks as shared | |
| _alloc_perm_as_free | FALSE | allocate permanent chunks as freeable |
| _allocate_creation_order | FALSE | should files be examined in creation order during allocation |
| _allocate_flashback_buffer | FALSE | Allocate flashback buffer at mount time even if flashback is off |
| _allocation_update_interval | 3 | interval at which successful search in L1 should be updated |
| _allow_cell_smart_scan_attr | TRUE | Allow checking smart_scan_capable Attr |
| _allow_commutativity | TRUE | allow for commutativity of +, * when comparing expressions |
| _allow_compatibility_adv_w_grp | FALSE | allow advancing DB compatibility with guaranteed restore points |
| _allow_convert_to_standby | FALSE | allow convert to standby to go through |
| _allow_cross_endian_dictionary | FALSE | Allow cross-endian data dictionary |
| _allow_cross_version_chunk_move | FALSE | Oracle internal parameter |
| _allow_drop_snapshot_standby_grsp | FALSE | Allow dropping snapshot standby guaranteed restore point |
| _allow_drop_ts_with_grp | FALSE | Allow drop Tablespace with guaranteed restore points |
| _allow_error_simulation | FALSE | Allow error simulation for testing |
| _allow_fallback_to_dbkey | FALSE | if TRUE, allow fallback to dbkey |
| _allow_file_1_offline_error_1245 | FALSE | don't signal ORA-1245 due to file 1 being offline |
| _allow_insert_with_update_check | FALSE | Allow INSERT as statement_types when update_check is FALSE |
| _allow_level_without_connect_by | FALSE | allow level without connect by |
| _allow_privileged_session_dblink_conn | FALSE | Allow privileged session for dblink connection |
| _allow_read_only_corruption | FALSE | allow read-only open even if database is corrupt |
| _allow_resetlogs_corruption | FALSE | allow resetlogs even if it will cause corruption |
| _allow_synonym_for_credential | TRUE | Allow public/private synonym for scheduler credential |
| _allow_terminal_recovery_corruption | FALSE | Finish terminal recovery even if it may cause corruption |
| _allow_triggers_on_vpd_table | FALSE | Allow triggers on VPD protected table in DML |
| _allow_xdb_anonymous_logon | FALSE | Allow XDB anonymous logon |
| _allowed_pvf_owners | List of schemas allowed to own password verification function | |
| _alter_adg_redirect_behavior | none | Alter ADG's Redirection behavior |
| _alter_upgrade_signature_only | FALSE | alter table upgrade only sets signature |
| _alternate_iot_leaf_block_split_points | TRUE | enable alternate index-organized table leaf-block split-points |
| _always_anti_join | CHOOSE | always use this method for anti-join when possible |
| _always_semi_join | CHOOSE | always use this method for semi-join when possible |
| _always_star_transformation | FALSE | always favor use of star transformation |
| _always_vector_transformation | FALSE | always favor use of vector transformation |
| _analyze_comprehensive | FALSE | Analyze comprehensive mode |
| _and_pruning_enabled | TRUE | allow partition pruning based on multiple mechanisms |
| _app_container_debug | 0 | Enable Debug tracing in Application container |
| _app_default_containers | FALSE | containers_default and container_map enabled by default on MDL application object |
| _app_ignore_errors | TRUE | ignore errors during containers() on application object |
| _app_replay_silent_errors | FALSE | silently ignore all errors during application sync |
| _application_purge_enabled | TRUE | Is an application purge allowed |
| _application_script | FALSE | Running an application script |
| _apppdb_multi_slave_sync | FALSE | Multiple slaves used during Application sync |
| _appqos_cdb_setting | 0 | QoSM CDB Performance Class Setting |
| _appqos_po_multiplier | 1000 | Multiplier for PC performance objective value |
| _appqos_qt | 10 | System Queue time retrieval interval |
| _approx_cnt_distinct_gby_pushdown | choose | perform group-by pushdown for approximate distinct count query |
| _approx_cnt_distinct_optimization | 0 | settings for approx_count_distinct optimizations |
| _approx_perc_sampling_err_rate | 2 | error rate percentage of approximate percentile using sampling |
| _approx_percentile_optimization | 0 | settings for approx_percentile optimization |
| _apx_root_directory | APX | APX default root directory |
| _aq_Txn_ht_sz | 1024 | Message cache Txn Hash table size |
| _aq_addpt_batch_size | 1 | Add PT batch Size |
| _aq_dly_bkt | 2 | Delay Bucket Size |
| _aq_dq_prefetch_Siz | 5 | AQ PT DQ prefech Size |
| _aq_dqblocks_in_cache | 0 | deq blocks in cache |
| _aq_droppt_batch_size | 5 | Drop PT batch Size |
| _aq_free_list_pools | 10 | state object and transaction memory pools |
| _aq_init_shards | 5 | Minimum enqueue shards per queue at an instance |
| _aq_ipc_max_slave | 10 | maximum number of slaves for knlpipcm |
| _aq_latency_absolute_threshold | 300 | Absolute threshold greater than average latency |
| _aq_latency_relative_threshold | 100 | Relative threshold of average latency |
| _aq_lb_cycle | 120 | Time(seconds) between consecutive AQ load balancing efforts |
| _aq_lb_garbage_col_interval | 600 | AQ LB garbage collect interval |
| _aq_lb_stats_collect_cycle | 45 | Time(seconds) between consecutive AQ load statistics collection |
| _aq_lb_subht_bkt_ltch | 32 | AQ LB subscriber ht bucket latches |
| _aq_lb_subht_elm_ltch | 128 | AQ LB subscriber ht element latches |
| _aq_lookback_size | 60 | AQ PT Look Back Size |
| _aq_max_pdb_close_msg | 1 | Max Number of AQ Recovery Messages when pdb is closed |
| _aq_max_scan_delay | 1500 | Maximum allowable scan delay for AQ indexes and IOTs |
| _aq_opt_background_enabled | TRUE | AQ: OPT Operations Background enabled |
| _aq_opt_enabled | TRUE | AQ: OPT Operations enabled |
| _aq_opt_fudge_factor | 500 | AQ: OPT Fudge Factor for pre-fretching |
| _aq_opt_min_evict_memory | 0 | AQ: OPT LWM memory for eviction to stop |
| _aq_opt_preevict_dop | 3 | AQ: OPT Background: PreEvict Degree Of Parallelism |
| _aq_opt_prefetch_dop | 3 | AQ: OPT Background: Prefetch Degree Of Parallelism |
| _aq_opt_prefetch_horizon | 60 | AQ: OPT horizon for pre-fretching |
| _aq_opt_stat_window | 21600 | AQ: OPT Subscriber Statistics Window Size |
| _aq_opt_stop_stat | FALSE | AQ: OPT Stop Collection of Subscriber Statistics |
| _aq_pt_processes | 10 | Partition background processes |
| _aq_pt_shrink_frequency | 1450 | PT shrink window Size |
| _aq_pt_statistics_window | 60 | PT statistics sample window Size |
| _aq_qt_prefetch_Size | 5 | AQ PT QT prefech Size |
| _aq_queue_global_service | AQ queue global service | |
| _aq_retry_timeouts | 0 | retry timeouts |
| _aq_scrambled_deqlog | 1 | scrambled deqlog |
| _aq_shard_bitmap_child_latches | 32 | Bitmap child latches |
| _aq_shard_child_latches | 512 | Shard child latches |
| _aq_shard_prty_latches | 16 | Shard priority child latches |
| _aq_shard_retry_child_latches | 32 | Retry child latches |
| _aq_shard_sub_child_Elem_latches | 1024 | Subscriber Element child latches |
| _aq_shard_sub_child_latches | 512 | Subscriber child latches |
| _aq_shard_txn_child_latches | 128 | Txn child latches |
| _aq_stop_backgrounds | FALSE | Stop all AQ background processes |
| _aq_streaming_threshold | 10485760 | large payload threshold size |
| _aq_subshard_Size | 20000 | Sub Shard Size |
| _aq_subshards_per_dqpartition | 1 | SubShards Per Deq Partition |
| _aq_subshards_per_qpartition | 1 | SubShards Per Q Partition |
| _aq_tm_deqcountinterval | 0 | dequeue count interval for Time Managers to cleanup DEQ IOT BLOCKS |
| _aq_tm_processes_dump_interval | 12 | Time(minutes) between consecutive Dumps in alert log |
| _aq_tm_scanlimit | 0 | scan limit for Time Managers to clean up IOT |
| _aq_tm_statistics_duration | 0 | statistics collection window duration |
| _aq_truncpt_batch_size | 1 | Trunc PT batch Size |
| _aq_uncached_stats | 0 | Uncached Stats |
| _aq_x_mode | 1 | AQ - cross mode |
| _aq_x_msg_size | 32768 | AQ cross single message buffer size |
| _aqsharded_cache_limit | 0 | Limit for cached enqueue/dequeue operations |
| _aqsharded_cached_hint | 0 | sharded queue cached hint |
| _aqsharded_enq_fresh_ptn_reload | TRUE | start enqueueing to a fresh partition on reload |
| _aqsharded_lowmem_timeout | 1000 | sharded queue low mem timeout (in centiseconds) |
| _aqsharded_reload_tune | 2 | sharded queue tune reload behaviour |
| _arch_comp_dbg_scan | 0 | archive compression scan debug |
| _arch_comp_dec_block_check_dump | 1 | decompress archive compression blocks for checking and dumping |
| _arch_compress_checksums | FALSE | enable/disable row checksums for archive compressed blocks |
| _arch_compression | TRUE | archive compression enabled |
| _arch_io_slaves | 0 | ARCH I/O slaves |
| _array_cdb_view_enabled | TRUE | array mode enabled for CDB views |
| _array_update_vector_read_enabled | FALSE | Enable array update vector read |
| _ash_compression_enable | FALSE | To enable or disable string compression in ASH |
| _ash_disk_filter_ratio | 10 | Ratio of the number of in-memory samples to the number of samples actually written to disk |
| _ash_disk_write_enable | TRUE | To enable or disable Active Session History flushing |
| _ash_dummy_test_param | 0 | Oracle internal dummy ASH parameter used ONLY for testing! |
| _ash_eflush_trigger | 66 | The percentage above which if the in-memory ASH is full the emergency flusher will be triggered |
| _ash_enable | TRUE | To enable or disable Active Session sampling and flushing |
| _ash_min_mmnl_dump | 90 | Minimum Time interval passed to consider MMNL Dump |
| _ash_progressive_flush_interval | 300 | ASH Progressive Flush interval in secs |
| _ash_sample_all | FALSE | To enable or disable sampling every connected session including ones waiting for idle waits |
| _ash_sampling_interval | 1000 | Time interval between two successive Active Session samples in millisecs |
| _ash_size | 1048618 | To set the size of the in-memory Active Session History buffers |
| _asm_access | auto | ASM File access mechanism |
| _asm_access_assume_local | FALSE | Assume IOS client is in the same cluster as IOS |
| _asm_acd_chunks | 1 | initial ACD chunks created |
| _asm_admin_with_sysdba | FALSE | Does the sysdba role have administrative privileges on ASM? |
| _asm_allow_appliance_dropdisk_noforce | FALSE | Allow DROP DISK/FAILUREGROUP NOFORCE on ASM Appliances |
| _asm_allow_appliance_offlineonline | FALSE | Allow OFFLINE/ONLINE DISK/FAILUREGROUP on ASM Appliances |
| _asm_allow_dangerous_unprotected_volumes | FALSE | Disable checking for unprotected volumes in mirrored disk groups |
| _asm_allow_dgname_special_chars | FALSE | Enable the use of special characters in diskgroup names |
| _asm_allow_foreign_siteguids | Disable checking for foreign siteguid on a given node | |
| _asm_allow_lvm_resilvering | TRUE | Enable disk resilvering for external redundancy |
| _asm_allow_older_clients | FALSE | Allow older clients to connect to the ASM server |
| _asm_allow_only_raw_disks | TRUE | Discovery only raw devices |
| _asm_allow_prepare_split | TRUE | Allow database prepare and split in non-appliance mode |
| _asm_allow_small_memory_target | FALSE | Allow a small memory_target for ASM instances |
| _asm_allow_system_alias_rename | FALSE | if system alias renaming is allowed |
| _asm_allow_unsafe_reconnect | TRUE | attempt unsafe reconnect to ASM |
| _asm_allowdegeneratemounts | FALSE | Allow force-mounts of DGs w/o proper quorum |
| _asm_appliance_config_file | Appliance configuration file name | |
| _asm_appliance_disable_fg_check | FALSE | Disable failure group check |
| _asm_appliance_ignore_oak | FALSE | Ignore OAK appliance library |
| _asm_appliance_slot_from_path | FALSE | Get appliance disk slot from disk path |
| _asm_asmb_max_wait_timeout | 6 | timeout before processes are signaled with network interrupt |
| _asm_asmb_rcvto | 10 | Receive timeout for ASMB in seconds |
| _asm_async_scrub_reap_wait | 100000 | Async scrubbing reaping IO wait in microseconds |
| _asm_audit_sp_param | ASM audit spare parameter | |
| _asm_ausize | 1048576 | allocation unit size |
| _asm_auto_online_interval | auto online interval | |
| _asm_automatic_rezone | TRUE | automatically rebalance free space across zones |
| _asm_avoid_pst_scans | TRUE | Avoid PST Scans |
| _asm_blksize | 4096 | metadata block size |
| _asm_br_listener_port | 51521 | Bitrotter listener port for testing purpose |
| _asm_brfuzz_ios_lsnrport | 0 | IOS listener port for fuzzing with Bitrotter |
| _asm_buffer_overlap_tracer | FALSE | Enables kfioBufOverlapTracer |
| _asm_cancel_alert_time | 600 | Wait time for I/O cancel alert message (in seconds) |
| _asm_cancel_delta | 75000 | Delta timeout for blocking big writes in milliseconds |
| _asm_cclient_cleanup_timeout | 300 | timeout before cleaning up remote cluster clients |
| _asm_check_for_misbehaving_cf_clients | FALSE | check for misbehaving CF-holding clients |
| _asm_compatibility | 11.2.0.2 | default ASM compatibility level |
| _asm_dba_batch | 500000 | ASM Disk Based Allocation Max Batch Size |
| _asm_dba_spcchk_thld | 100000 | ASM Disk Based Allocation Space Check Threshold |
| _asm_dba_threshold | 0 | ASM Disk Based Allocation Threshold |
| _asm_dbmsdg_nohdrchk | FALSE | dbms_diskgroup.checkfile does not check block headers |
| _asm_dependency_under_cfenqueue | TRUE | Send dependency request if holding CF enqueue |
| _asm_diag_dead_clients | FALSE | diagnostics for dead clients |
| _asm_direct_con_expire_time | 120 | Expire time for idle direct connection to ASM instance |
| _asm_disable_amdu_dump | FALSE | Disable AMDU dump |
| _asm_disable_async_msgs | FALSE | disable async intra-instance messaging |
| _asm_disable_dangerous_failgroup_checking | FALSE | Disable checking for dubious failgroup configurations |
| _asm_disable_failgroup_count_checking | FALSE | Disable checking for failure group count |
| _asm_disable_failgroup_size_checking | FALSE | Disable checking for failure group size |
| _asm_disable_multiple_instance_check | FALSE | Disable checking for multiple ASM instances on a given node |
| _asm_disable_patch_compat | FALSE | disable DG patch compatibility checks |
| _asm_disable_proact_client_cleanup | FALSE | disable proactive client cleanup |
| _asm_disable_profilediscovery | FALSE | disable profile query for discovery |
| _asm_disable_request_tracer | TRUE | Disable kfioRqTracer |
| _asm_disable_smr_creation | FALSE | Do Not create smr |
| _asm_disable_ufg_dump | FALSE | disable terminated umbilicus diagnostic |
| _asm_disable_ufgmemberkill | FALSE | disable ufg member kill |
| _asm_disable_vtoc_check | FALSE | Disable vtoc/sector 0 check |
| _asm_disable_vxn_map_messages | FALSE | disable using vxn map messages |
| _asm_disk_repair_time | 14400 | seconds to wait before dropping a failing disk |
| _asm_diskerr_traces | 2 | Number of read/write errors per disk a process can trace |
| _asm_diskgroup_renew_timeout | 20 | timeout FENC will give former ASMB group owner to renew |
| _asm_diskgroups2 | disk groups to mount automatically set 2 | |
| _asm_diskgroups3 | disk groups to mount automatically set 3 | |
| _asm_diskgroups4 | disk groups to mount automatically set 4 | |
| _asm_dump_split_pw | 10 | Seconds to wait before requesting dump of split pending writes |
| _asm_emulate_nfs_disk | FALSE | Emulate NFS disk test event |
| _asm_emulmax | 10000 | max number of concurrent disks to emulate I /O errors |
| _asm_emultimeout | 0 | timeout before emulation begins (in 3s ticks) |
| _asm_enable_batch_scrub | FALSE | Allow scrubbing verification to run in batch mode |
| _asm_enable_kfios | FALSE | Enable KFIOS module |
| _asm_enable_kfks | FALSE | Enable KFKS module |
| _asm_enable_lostwrite_scrub | FALSE | Allow lost write detection in scrubbing |
| _asm_enable_map_share | TRUE | Enable ASM extent map share |
| _asm_enable_multiple_asmb | TRUE | Allow the ASM client to have multiple ASMB background processes |
| _asm_enable_parity_scrub | FALSE | Allow scrubbing parity files |
| _asm_enable_parityfile_creation | TRUE | Enable parity files creation |
| _asm_enable_repair_lostwrite_scrub | FALSE | Allow repairing lost write in scrubbing |
| _asm_enable_vfreloc_on_rm | FALSE | Enable voting file relocation on rolling migration |
| _asm_enable_xrov | FALSE | Enable XROV capability |
| _asm_evenread | 2 | ASM Even Read level |
| _asm_evenread_alpha | 0 | ASM Even Read Alpha |
| _asm_evenread_alpha2 | 0 | ASM Even Read Second Alpha |
| _asm_evenread_faststart | 0 | ASM Even Read Fast Start Threshold |
| _asm_fail_random_rx | FALSE | Randomly fail some RX enqueue gets |
| _asm_fd_cln_idle_sess_twait | 60000000 | Idle session time wait to run ASM FD cleanup |
| _asm_fd_cln_on_fg | TRUE | ASM stale FD cleanup on foregrounds |
| _asm_fob_tac_frequency | 9 | Timeout frequency for FOB cleanup |
| _asm_force_parity_extent_check | FALSE | Force parity extent integrity check |
| _asm_force_paritycheck_rebalance | FALSE | Force parity extent integrity check during rebalance |
| _asm_force_quiesce | FALSE | Force diskgroup quiescing |
| _asm_force_vam | FALSE | force VAM for external redundancy |
| _asm_frag_threshold | 50 | Percentage threshold before disk/diskgroup is deemed fragmented |
| _asm_global_dump_level | 267 | System state dump level for ASM asserts |
| _asm_hard_check | TRUE | H.A.R.D. check buffer before write operation |
| _asm_hbeatiowait | 120 | number of secs to wait for PST Async Hbeat IO return |
| _asm_hbeatwaitquantum | 2 | quantum used to compute time-to-wait for a PST Hbeat check |
| _asm_healthcheck_timeout | 180 | seconds until health check takes action |
| _asm_idn_processes | 0 | number of global open processes |
| _asm_imbalance_tolerance | 3 | hundredths of a percentage of inter-disk imbalance to tolerate |
| _asm_instlock_quota | 0 | ASM Instance Lock Quota |
| _asm_ios_network_domains | 0 | number of domains in ASM IOSERVER instance |
| _asm_ios_network_processes | 0 | number network processes per domain in ASM IOSERVER instance |
| _asm_iosconnect_timeout | 0 | Time (in 3secs multiples) before db gives up on connecting to IOS |
| _asm_iosfailover_freq | 3 | Frequency limit after which db gives up on failing over to IOS |
| _asm_iosfailover_timeout | 5 | Time window within which db tries to failover to IOS |
| _asm_iostat_latch_count | 31 | ASM I/O statistics latch count |
| _asm_iowp_max_async | 0 | maximum async IOs per IO worker process |
| _asm_kfdpevent | 0 | KFDP event |
| _asm_kill_unresponsive_clients | TRUE | kill unresponsive ASM clients |
| _asm_libraries | ufs | library search order for discovery |
| _asm_log_scale_rebalance | FALSE | Rebalance power uses logarithmic scale |
| _asm_lsod_bucket_size | 67 | ASM lsod bucket size |
| _asm_max_aux_cods | 5 | maximum number of auxiliary cods in sparse disk groups |
| _asm_max_clients | 1000 | maximum number of clients this IOS instance can service |
| _asm_max_cod_strides | 10 | maximum number of COD strides |
| _asm_max_connected_clients | 3 | The high water mark value for connected clients |
| _asm_max_kfsg_free_heap_perc | 10 | Max percentage of SGA memory reserved for kfsga free heap |
| _asm_max_kfsg_free_heap_size | 524288000 | Max buffer size reserved for kfsga free heap |
| _asm_max_occupied | 90 | Maximum percentage of disk occupied to check for fragmentation |
| _asm_max_parallelios | 256 | Maximum simultaneous outstanding IOs |
| _asm_max_redo_buffer_size | 2097152 | asm maximum redo buffer size |
| _asm_maxio | 1048576 | Maximum size of individual I/O request |
| _asm_min_compatibility | 11.2.0.2 | default mininum ASM compatibility level |
| _asm_min_occupied | 50 | Minimum percentage of disk occupied to check for fragmentation |
| _asm_netp_factor | 0 | number of network processes per net |
| _asm_netp_iosize | 0 | maximum io size |
| _asm_network_timeout | 1 | Keepalive timeout for ASM network connections |
| _asm_networks | ASM network subnet addresses | |
| _asm_node_number | ASM node number | |
| _asm_node_site_guid | ASM site GUID of node | |
| _asm_nodekill_escalate_time | 180 | secs until escalating to nodekill if fence incomplete |
| _asm_noevenread_diskgroups | List of disk groups having even read disabled | |
| _asm_oda_type | ODA Type | |
| _asm_odapremchk | TRUE | Check premature storage for ODA |
| _asm_offline_wait_timeout | 300 | Timeout for offline wait |
| _asm_offload_all | FALSE | Offload all write operations to Exadata cells, when supported |
| _asm_ownerid_trace_timeout | 600 | ownerid tracing threshold in seconds |
| _asm_partner_target_disk_part | 8 | target maximum number of disk partners for repartnering |
| _asm_partner_target_fg_rel | 4 | target maximum number of failure group relationships for repartnering |
| _asm_primary_load | 1 | Number of cycles/extents to load for non-mirrored files |
| _asm_primary_load_cycles | TRUE | True if primary load is in cycles, false if extent counts |
| _asm_procs_trace_diskerr | 5 | Number of processes allowed to trace a disk failure |
| _asm_proxy_online_restart | 0 | Allow patching while ADVM volumes are online |
| _asm_proxy_startwait | 60 | Maximum time to wait for ASM proxy connection |
| _asm_pst_rsinfo | 0 | file redundancies to consider during PST liveness checks |
| _asm_pstonpartners | TRUE | Select ideal PST disks following partnership |
| _asm_random_zone | FALSE | Random zones for new files |
| _asm_read_cancel | AUTO | Read cancel timeout in milliseconds |
| _asm_read_cancel_back_out | 5000 | Time period in milliseconds when no reads are issued to a disk after a read is cancelled |
| _asm_rebalance_estimates_process | TRUE | Perform rebalance estimates in ARB-A process |
| _asm_rebalance_plan_size | 120 | maximum rebalance work unit |
| _asm_rebalance_space_errors | 1000 | number of out of space errors allowed before aborting rebalance |
| _asm_reloc_cic | FALSE | Allow relocation during rolling migration |
| _asm_relocation_async_lock_count | 128 | limit of asynchronous map locks during relocation |
| _asm_relocation_ignore_hard_failure | 0 | ignore HARD for relocation |
| _asm_relocation_scheme | alloc_p2 alloc_s3 reb_p2 reb_s1 bal_p2 bal_s3 prep_p2 prep_s3 | ASM allocation / relocation scheme |
| _asm_relocation_trace | FALSE | enable extent relocation tracing |
| _asm_remote_client_timeout | 300 | timeout before killing disconnected remote clients |
| _asm_repairquantum | 60 | quantum (in 3s) used to compute elapsed time for disk drop |
| _asm_reserve_slaves | TRUE | reserve ASM slaves for CF txns |
| _asm_resyncCkpt | 1024 | number of extents to resync before flushing checkpoint |
| _asm_root_directory | ASM | ASM default root directory |
| _asm_runtime_capability_volume_support | FALSE | runtime capability for volume support returns supported |
| _asm_scrub_async | TRUE | Enable asynchronous scrubbing |
| _asm_scrub_disable_cod | FALSE | Disable scrubbing COD |
| _asm_scrub_limit | AUTO | ASM disk scrubbing power |
| _asm_scrub_max_cod_wait | 5 | Number of minutes to delay scrub COD recovery |
| _asm_scrub_strict | FALSE | Enable strict scrubbing mode |
| _asm_scrub_unmatched_dba | 1024 | Scrub maximum number of blocks with unmatched DBA |
| _asm_secondary_load | 10000 | Number of cycles/extents to load for mirrored files |
| _asm_secondary_load_cycles | FALSE | True if secondary load is in cycles, false if extent counts |
| _asm_serialize_volume_rebalance | FALSE | Serialize volume rebalance |
| _asm_shadow_cycle | 3 | Inverse shadow cycle requirement |
| _asm_shared_pool_latch_timeout | 30 | seconds before terminating inst if ASMB is waiting for shared pool latch during shutdown |
| _asm_showpdb_asmtbl | FALSE | Allow asm table values to be shown in pdb |
| _asm_skip_dbfile_ios | FALSE | Skip I/Os to database files (do only ASM metadata I/O) |
| _asm_skip_diskval_check | FALSE | skip client side discovery for disk revalidate |
| _asm_skip_rename_check | FALSE | skip the checking of the clients for s/w compatibility for rename |
| _asm_skip_resize_check | FALSE | skip the checking of the clients for s/w compatibility for resize |
| _asm_slow_client_timeout_percentage | 50 | Percentage of the write cancel timeout to detect slow client. |
| _asm_storagemaysplit | FALSE | PST Split Possible |
| _asm_stripesize | 131072 | ASM file stripe size |
| _asm_stripewidth | 8 | ASM file stripe width |
| _asm_sync_rebalance | FALSE | Rebalance uses sync I/O |
| _asm_tcp_user_timeout | 1 | TCP_USER_TIMEOUT in minutes |
| _asm_trace_limit_timeout | 30000 | Time-out in milliseconds to reset the number of traces per disk and the number of processes allowed to trace |
| _asm_ufg_nw_wait_timeout | 10 | seconds to start health check on unresponsive clients |
| _asm_usd_batch | 64 | ASM USD Update Max Batch Size |
| _asm_wait_time | 18 | Max/imum time to wait before asmb exits |
| _asm_write_badfdata_in_contentcheck | FALSE | Write BADFDA7A in content check |
| _asm_write_cancel | AUTO | Write timeout in milliseconds |
| _asm_write_cancel_timeout_percentage | 30 | Percentage of the write timeout to wait before optional offline |
| _asm_xrov_cachelgio | 1 | ADVM cache large IO |
| _asm_xrov_nstats | 0 | Specify number of IOs before stats |
| _asm_xrov_nvios | 24 | Specify number of VIO processes |
| _asm_xrov_rsnmod | 2 | Specify 'reason' mode |
| _asm_xrov_single | FALSE | Enable single issues of IOs |
| _asm_zero_power_limit | allow setting zero power limit | |
| _asmsid | asm | ASM instance id |
| _assert_encrypted_tablespace_blocks | TRUE | if TRUE, assert encrypted tablespace blocks must be encrypted |
| _assert_single_current_buffer | FALSE | if TRUE, check and assert only one current buffer |
| _assm_auto_tracing_threshold | 10000 | ASSM threshold to start space search tracing |
| _assm_default | TRUE | ASSM default |
| _assm_examination_blocks_threshold | 8196 | ASSM get space number of fuzzy blocks to examine |
| _assm_examination_enable_sla | FALSE | ASSM get space enable examination limits |
| _assm_examination_time_threshold | 60 | ASSM get space examination time threshold in seconds |
| _assm_force_fetchmeta | FALSE | enable metadata block fetching in ASSM segment scan |
| _assm_high_gsp_threshold | 11024 | Number of blocks rejected before growing segment |
| _assm_l1cleanout_throttle_time | 3 | L1 bitmap block cleanout throttle time in seconds |
| _assm_latency_sampling_frequency | 0 | ASSM Latency sampling frequency in seconds |
| _assm_low_gsp_threshold | 10000 | Number of blocks rejected before collecting stats |
| _assm_segment_extension_percent | 100 | Percent of full blocks after which segment is extended |
| _assm_segment_repair_bg | TRUE | ASSM Segment repair: bg enable |
| _assm_segment_repair_fg | 0 | ASSM Segment repair: fg |
| _assm_segment_repair_maxblks | 4294967294 | ASSM Segment repair: Max blocks per slave |
| _assm_segment_repair_timelimit | 60 | ASSM Segment repair: Max time in seconds per slave |
| _assm_space_cache_hb_expire | 3 | Seconds after which higher order bitmaps expire from space cache |
| _assm_space_cache_max_segments | 1024 | ASSM Maximum Segments to Track |
| _assm_test_force_rej | 0 | assm min number of blocks to cbk-reject |
| _assm_test_force_rej2 | 0 | assm min number of blocks to kdt-reject |
| _assm_test_reentrant_gsp | FALSE | assm test reentrant gsp |
| _async_recovery_claims | TRUE | if TRUE, issue recovery claims asynchronously |
| _async_recovery_reads | TRUE | if TRUE, issue recovery reads asynchronously |
| _async_rta_broadcast | FALSE | asynchronously broadcast RTA boundary |
| _async_scn_sync | OFF | Asynchronous SCN Sync Setting |
| _async_ts_threshold | 1 | check tablespace thresholds asynchronously |
| _atp_block_size_default | TRUE | ATP setting block size to 8K |
| _auto_assign_cg_for_sessions | FALSE | auto assign CGs for sessions |
| _auto_bmr | enabled | enable/disable Auto BMR |
| _auto_bmr_bg_time | 3600 | Auto BMR Process Run Time |
| _auto_bmr_fc_time | 60 | Auto BMR Flood Control Time |
| _auto_bmr_file_header | TRUE | Enable Auto BMR for file header fix |
| _auto_bmr_max_rowno | 1024 | x$krbabrstat Max number of rows |
| _auto_bmr_noretry_window | 1800 | Auto BMR NoRetry Window |
| _auto_bmr_pub_timeout | 10 | Auto BMR Publish Timeout |
| _auto_bmr_req_timeout | 60 | Auto BMR Requester Timeout |
| _auto_bmr_sess_threshold | 30 | Auto BMR Request Session Threshold |
| _auto_bmr_sys_threshold | 100 | Auto BMR Request System Threshold |
| _auto_dismount_on_pdb_close | FALSE | Enable implicit PDB dismount on PDB close |
| _auto_export_preplugin_backup | TRUE | auto export pre-plugin backup |
| _auto_manage_enable_offline_check | TRUE | perodically check for OFFLINE disks and attempt to ONLINE |
| _auto_manage_enable_smart_rebalance | TRUE | OFFLINE instead of DROP disk(s) when free space is not enough for rebalance |
| _auto_manage_exadata_disks | TRUE | Automate Exadata disk management |
| _auto_manage_infreq_tout | 0 | TEST: Set infrequent timeout action to run at this interval, unit is seconds |
| _auto_manage_ioctl_bufsz | 8192 | oss_ioctl buffer size, to read and respond to cell notifications |
| _auto_manage_max_online_tries | 3 | Max. attempts to auto ONLINE an ASM disk |
| _auto_manage_num_pipe_msgs | 1000 | Max. number of out-standing msgs in the KXDAM pipe |
| _auto_manage_num_tries | 2 | Num. tries before giving up on a automation operation |
| _auto_manage_online_tries_expire_time | 86400 | Allow Max. attempts to auto ONLINE an ASM disk after lapsing this time (unit in seconds) |
| _auto_manage_smart_rebalance_grace_period_in_min | 0 | Number of minutes waited after ASM diskgroup free space increases and becomes sufficient for rebalance before dropping an ASM disk offlined due to insufficient free space |
| _auto_manage_smart_rebalance_space_threshold | 0 | Percentage of ASM diskgroup free space required for rebalance |
| _auto_mv_enabled | FALSE | enable/disable Auto MV logic in the sql access advisor |
| _auto_rcv_pdb_open | 1 | enable automatic recovery during pdb open |
| _auto_rekey_during_mrcv | TRUE | enable automatic rekey during media recovery |
| _automatic_maintenance_test | 0 | Enable AUTOTASK Test Mode |
| _automemory_broker_interval | 3 | memory broker statistics gathering interval for auto memory |
| _autoptn_costing | FALSE | DBMS_AUTO_PARTITION is compiling query for cost estimates |
| _autoptn_flags | 0 | DBMS_AUTO_PARTITION flags |
| _autoptn_translate_table_name | DBMS_AUTO_PARTITION table name translation | |
| _autoptn_workload_id | 0 | DBMS_AUTO_PARTITION workload id |
| _autosts_capture_control | 3 | internal controls for auto STS capture |
| _autosts_long_interval | 0 | Auto STS long flush interval |
| _autosts_retention_interval | 31 | Auto STS retention interval |
| _autosts_short_interval | 300 | Auto STS short flush interval |
| _autotask_max_window | 480 | Maximum Logical Maintenance Window Length in minutes |
| _autotask_min_window | 15 | Minimum Maintenance Window Length in minutes |
| _autotask_test_action | 0 | test action parameter for AUTOTASK |
| _autotask_test_name | N/A | Name of current Autotask Test (or test step) |
| _autotbs_management_enabled | FALSE | allow automatic tablespace management |
| _autotune_gtx_idle_time | 600 | idle time to trigger auto-shutdown a gtx background process |
| _autotune_gtx_interval | 5 | interval to autotune global transaction background processes |
| _autotune_gtx_threshold | 60 | auto-tune threshold for degree of global transaction concurrency |
| _aux_dfc_keep_time | 1440 | auxiliary datafile copy keep time in minutes |
| _aux_storage_size | 0 | Auxillary storage for PDB. |
| _available_core_count | 0 | number of cores for this instance |
| _avoid_scn_growth | 1 | enable scn growth optimizations |
| _awr_cdbperf_threshold | 21 | Setting for AWR CDBPERF Threshold |
| _awr_corrupt_mode | FALSE | AWR Corrupt Mode |
| _awr_data_masking | FALSE | Enable/Disable AWR data masking functionality |
| _awr_disabled_flush_tables | Disable flushing of specified AWR tables | |
| _awr_disabled_purge_tables | Disable purging of specified AWR tables | |
| _awr_enable_pdb_snapshots | TRUE | Enable/Disable AWR PDB level snapshots |
| _awr_flush_threshold_metrics | TRUE | Enable/Disable Flushing AWR Threshold Metrics |
| _awr_flush_workload_metrics | FALSE | Enable/Disable Flushing AWR Workload Metrics |
| _awr_incremental_flush_enabled | TRUE | Enable/Disable AWR automatic incremental flushing |
| _awr_metrics_use_mmnl | FALSE | Use MMNL or other background process for AWR metrics |
| _awr_mmon_cpuusage | TRUE | Enable/disable AWR MMON CPU Usage Tracking |
| _awr_mmon_deep_purge_all_expired | FALSE | Allows deep purge to purge AWR data for all expired snapshots |
| _awr_mmon_deep_purge_extent | 7 | Set extent of rows to check each deep purge run |
| _awr_mmon_deep_purge_interval | 7 | Set interval for deep purge of AWR contents |
| _awr_mmon_deep_purge_numrows | 5000 | Set max number of rows per table to delete each deep purge run |
| _awr_partition_interval | 0 | Setting for AWR Partition Interval |
| _awr_pdb_registration_enabled | FALSE | Parameter to enable/disable AWR PDB Registration |
| _awr_restrict_mode | FALSE | AWR Restrict Mode |
| _awr_snapshot_level | BESTFIT | Set Default AWR snapshot level |
| _awr_sql_child_limit | 200 | Setting for AWR SQL Child Limit |
| _awr_warehouse_enabled | TRUE | Enable/Disable AWR warehouse functionality |
| _b_tree_bitmap_plans | TRUE | enable the use of bitmap plans for tables w. only B-tree indexes |
| _ba_cf_trace_buffer_size | 131072 | size of per-process I/O KBC trace buffer |
| _ba_container_filesystem_ausize | 4194304 | allocation unit size for Backup Appliance containers |
| _ba_max_containers | 0 | maximum number of Backup Appliance containers |
| _ba_max_groups | 0 | maximum number of Backup Appliance container groups |
| _ba_max_seg_bytes | 4000 | maximum number of bytes per array segment |
| _ba_timeouts_enabled | TRUE | enable timeouts |
| _background_process_opts | 0 | Misc BG procs parameter |
| _backup_align_write_io | TRUE | align backup write I/Os |
| _backup_appliance_enabled | FALSE | Backup Appliance Enabled |
| _backup_automatic_retry | 10 | automatic retry on backup write errors |
| _backup_block0 | default | backup block0 |
| _backup_bool_spare1 | FALSE | backup bool spare1 |
| _backup_bool_spare2 | FALSE | backup bool spare2 |
| _backup_bool_spare3 | FALSE | backup bool spare3 |
| _backup_bool_spare4 | FALSE | backup bool spare4 |
| _backup_compress | FALSE | turn on backup compression always |
| _backup_disk_bufcnt | 0 | number of buffers used for DISK channels |
| _backup_disk_bufsz | 0 | size of buffers used for DISK channels |
| _backup_disk_io_slaves | 0 | BACKUP Disk I/O slaves |
| _backup_dynamic_buffers | TRUE | dynamically compute backup/restore buffer sizes |
| _backup_encrypt_opt_mode | 4294967294 | specifies encryption block optimization mode |
| _backup_file_bufcnt | 0 | number of buffers used for file access |
| _backup_file_bufsz | 0 | size of buffers used for file access |
| _backup_int_spare1 | 4294967294 | backup int spare1 |
| _backup_int_spare2 | 4294967294 | backup int spare2 |
| _backup_int_spare3 | 4294967294 | backup int spare3 |
| _backup_int_spare4 | 4294967294 | backup int spare4 |
| _backup_interrupt_wait_time | 1000 | specifies interrupt wait time in centi seconds |
| _backup_io_pool_size | 1048576 | memory to reserve from the large pool |
| _backup_kgc_bz2_bufsz | 0 | specifies buffer size to be used by BZ2 compression |
| _backup_kgc_bz2_niters | 0 | specifies number of iterations done by BZ2 compression |
| _backup_kgc_bz2_type | 0 | specifies type used by BZ2 compression |
| _backup_kgc_bzip2_blksiz | 9 | specifies buffer size to be used by BZIP2 compression |
| _backup_kgc_lzo_bufsz | 262144 | specifies buffer size to be used by LZO compression |
| _backup_kgc_medium_scheme | DEFAULT | specifies medium compression scheme |
| _backup_kgc_scheme | ZLIB | specifies compression scheme |
| _backup_kgc_zlib_complevel | 1 | specifies compression (performance) level for ZLIB compression |
| _backup_kgc_zlib_memlevel | 8 | specifies memory level for ZLIB compression |
| _backup_kgc_zlib_windowbits | 15 | specifies window size for ZLIB compression |
| _backup_kgc_zstd_bufsz | 262144 | specifies buffer size to be used by ZSTD compression |
| _backup_kgc_zstd_complevel | 3 | specifies compression (performance) level for ZSTD compression |
| _backup_ksfq_bufcnt | 0 | number of buffers used for backup/restore |
| _backup_ksfq_bufmem_max | 268435456 | maximum amount of memory (in bytes) used for buffers for backup/restore |
| _backup_ksfq_bufsz | 0 | size of buffers used for backup/restore |
| _backup_max_gap_size | 4294967294 | largest gap in an incremental/optimized backup buffer, in bytes |
| _backup_max_wallet_session | 50 | specifies maximum wallet session for backup |
| _backup_min_ct_unused_optim | 2097152 | mimimun size in bytes of change tracking to apply unused space optimuzation |
| _backup_seq_bufcnt | 0 | number of buffers used for non-DISK channels |
| _backup_seq_bufsz | 0 | size of buffers used for non-DISK channels |
| _backup_text_spare1 | backup text spare1 | |
| _backup_text_spare2 | backup text spare2 | |
| _backup_text_spare3 | backup text spare3 | |
| _backup_text_spare4 | backup text spare4 | |
| _bct_bitmaps_per_file | 8 | number of bitmaps to store for each datafile |
| _bct_buffer_allocation_max | 1073741824 | maximum size of all change tracking buffer allocations, in bytes |
| _bct_buffer_allocation_min_extents | 1 | mininum number of extents to allocate per buffer allocation |
| _bct_buffer_allocation_size | 2097152 | size of one change tracking buffer allocation, in bytes |
| _bct_chunk_size | 0 | change tracking datafile chunk size, in bytes |
| _bct_crash_reserve_size | 262144 | change tracking reserved crash recovery SGA space, in bytes |
| _bct_file_block_size | 0 | block size of change tracking file, in bytes |
| _bct_file_extent_size | 0 | extent size of change tracking file, in bytes |
| _bct_fixtab_file | change tracking file for fixed tables | |
| _bct_health_check_interval | 60 | CTWR health check interval (seconds), zero to disable |
| _bct_initial_private_dba_buffer_size | 0 | initial number of entries in the private change tracking dba buffers |
| _bct_mrp_timeout | 5 | CTWR MRP wait timeout (seconds), zero to wait forever |
| _bct_public_dba_buffer_dynresize | 2 | allow dynamic resizing of public dba buffers, zero to disable |
| _bct_public_dba_buffer_dynresize_delay | 3600 | control frequency of dynamic resizing of public dba buffers |
| _bct_public_dba_buffer_maxsize | 0 | max buffer size permitted for public dba buffers, in bytes |
| _bct_public_dba_buffer_size | 0 | total size of all public change tracking dba buffers, in bytes |
| _bequeath_via_broker | FALSE | Bequeath connections via broker |
| _bg_spawn_diag_opts | 0 | background processes spawn diagnostic options |
| _big_scn_test_mode | 2 | testing mode for BigSCN |
| _bigdata_external_table | TRUE | enables use of ORACLE_HIVE and ORACLE_HDFS access drivers |
| _bigdata_offload_flag | FALSE | BigDataSQL offload flag |
| _bigram_dependency_percentage | 5 | Bigram dependency percentage |
| _bitmap_or_improvement_enabled | TRUE | controls extensions to partition pruning for general predicates |
| _block_change_tracking_file | file location for broker to reenable BCT | |
| _block_dump_assert | FALSE | Encrypted block dump assert |
| _block_level_offload_high_lat_thresh | 40000 | High Latency Threshold for Block Level Offload operations |
| _block_sample_readahead_prob_threshold | 10 | controls readahead value during block sampling |
| _blockchainHeapSize | 0 | Set the heap size in bytes for blockchain |
| _blockchainTracing | 0 | Set tracing for blockchain |
| _blockchain_forced_off | NOT_SET | force off blockchain |
| _blockchain_txn_apis_enabled | TRUE | If true, the txn layer blockchain API'S kick in |
| _blockchain_txn_test_lvl | 0 | blockchain txn test lvl |
| _blockhm_flush_period | 3600 | Block heat map background flush period |
| _blocking_sess_graph_cache_size | blocking session graph cache size in bytes | |
| _blocks_per_cache_server | 16 | number of consecutive blocks per global cache server |
| _bloom_extent_size | 0 | bloom filter extent size in bytes |
| _bloom_filter_debug | 0 | debug level for bloom filtering |
| _bloom_filter_enabled | TRUE | enables or disables bloom filter |
| _bloom_filter_ratio | 35 | bloom filter filtering ratio |
| _bloom_filter_setops_enabled | TRUE | Allow bloom filter to be pushed through set operations |
| _bloom_filter_size | 0 | bloom filter vector size (in KB) |
| _bloom_folding_density | 16 | bloom filter folding density lower bound |
| _bloom_folding_enabled | TRUE | Enable folding of bloom filter |
| _bloom_folding_min | 0 | bloom filter folding size lower bound (in KB) |
| _bloom_max_size | 262144 | maximum bloom filter size (in KB) |
| _bloom_max_wait_time | 50 | bloom filter wait time upper bound (in ms) |
| _bloom_minmax_enabled | TRUE | enable or disable bloom min max filtering |
| _bloom_predicate_enabled | TRUE | enables or disables bloom filter predicate pushdown |
| _bloom_predicate_offload | TRUE | enables or disables bloom filter predicate offload to cells |
| _bloom_pruning_enabled | TRUE | Enable partition pruning using bloom filtering |
| _bloom_pruning_setops_enabled | TRUE | Allow bloom pruning to be pushed through set operations |
| _bloom_pushing_max | 512 | bloom filter pushing size upper bound (in KB) |
| _bloom_pushing_total_max | 262144 | bloom filter combined pushing size upper bound (in KB) |
| _bloom_rm_filter | FALSE | remove bloom predicate in favor of zonemap join pruning predicate |
| _bloom_serial_filter | ON | enable serial bloom filter on exadata |
| _bloom_sm_enabled | TRUE | enable bloom filter optimization using slave mapping |
| _bloom_use_shared_pool | FALSE | use shared pool for bloom filter |
| _bloom_wait_on_rac | FALSE | enables bloom filter (with hash hash distribution) wait on RAC |
| _boc_mode | AUTO | Broadcast-on-commit mode |
| _boc_rdma_wait_time | 0 | BOC RDMA busy wait time (microseconds) |
| _bps_sanity_checks | FALSE | enable BPS sanity checks |
| _branch_tagging | TRUE | enable branch tagging for distributed transaction |
| _broadcast_scn_mode | 1 | broadcast-on-commit scn mode |
| _broadcast_scn_wait_timeout | 10 | broadcast-on-commit scn wait timeout in centiseconds |
| _bsln_adaptive_thresholds_enabled | TRUE | Adaptive Thresholds Enabled |
| _bt_mmv_query_rewrite_enabled | TRUE | allow rewrites with multiple MVs and base tables |
| _buddy_instance | 1 | buddy instance control |
| _buddy_instance_num_read_buffers | 4 | Num of Read Buffers to scan everytime in Buddy Instance feature |
| _buddy_instance_scan_phase_threshold | 3 | Threshold (in secs) to let RMS0 construct the recovery set |
| _buddy_instance_start_rba_timeout | 9 | Time-out for re-computing Start RBA in Buddy Instance feature |
| _buffer_busy_wait_timeout | 100 | buffer busy wait time in centiseconds |
| _buffer_requests_to_drain | 5 | Buffer for requests to drain before planned failover |
| _buffered_message_spill_age | 300 | Buffered message spill age |
| _buffered_publisher_flow_control_threshold | 0 | Flow control threshold for buffered publishers except capture |
| _bufq_stop_flow_control | FALSE | Stop enforcing flow control for buffered queues |
| _bug30932330_forceopen_bind_undotbs | FALSE | one-hundred-and-forty-fifth spare parameter - boolean |
| _bug31789178_asm_quorum_hb | FALSE | Allow Quorum Disk Heartbeat |
| _bug31828999_lm_nodrm_service_pct | 95 | minimum nonsingleton service access percentage to disable drm |
| _bug31897178_kspdgctrl | eighty-fourth spare parameter - string | |
| _bug31918168_keusp_stream_batch_size | DEFAULT | Number of KEUSP buffers to flush in a stream batch |
| _bug31990919_keusp_max_num_alloc_buf | DEFAULT | Maximum number of KEUSP buffers in shared memory |
| _bug32093558_j0_deq_maxwait_time | 0 | eighth spare parameter - integer |
| _bug32093558_srvntfn_max_job_time | 180 | seventh spare parameter - integer |
| _bug32171622_asm_reloc_restart_timeout | 900 | csecs before signaling ORA-15424 when waiting for orphans |
| _bug32183142_hang_fast_track_progressing_sessions | FALSE | Hang Management fast-track progressing sessions enabled |
| _bug32498459_max_small_page_sga_size | 34359738368 | Maximum SGA size with small pages |
| _bug32533019_DON_for_update_enabled | FALSE | Default on null for update feature enabled |
| _bug32823692_hang_parsing_hangs_resolution_interval | 0 | Hang Manager parsing hangs resolution interval |
| _build_deferred_mv_skipping_mvlog_update | TRUE | DEFERRED MV creation skipping MV log setup update |
| _bump_highwater_mark_count | 0 | how many blocks should we allocate per free list on advancing HWM |
| _bwr_for_flushed_pi | TRUE | if TRUE, generate a BWR for a flushed PI |
| _bypass_sensitive_context | FALSE | bypass sensitive handling for specific SYS_CONTEXT() parameters |
| _bypass_srl_for_so_eor | FALSE | bypass SRL for S/O EOR logs |
| _bypass_xplatform_error | FALSE | bypass datafile header cross-platform-compliance errors |
| _c3_external_scn_rejection_threshold_hours | 4464 | Lag in hours between max allowed SCN and an external SCN |
| _cache_fusion_pipelined_updates | TRUE | Configure smart fusion block transfer |
| _cache_fusion_pipelined_updates_enable | Enable smart fusion block transfer | |
| _cache_orl_during_open | ALL | cache online logs |
| _cache_stats_monitor | FALSE | if TRUE, enable cache stats monitoring |
| _capability_simulate | Simulate the capabilities for testing | |
| _capture_buffer_size | 65536 | To set the size of the PGA I/O recording buffers |
| _capture_pgadep | 0 | capture statements at this pgadep |
| _capture_publisher_flow_control_threshold | 0 | Flow control threshold for capture publishers |
| _case_sensitive_logon | TRUE | case sensitive logon enabled |
| _catalog_foreign_restore | FALSE | catalog foreign file restore |
| _causal_standby_wait_timeout | 20 | Causal standby wait timeout |
| _cdb_compatible | TRUE | CDB Compatible |
| _cdb_cross_container | 65535 | Debug flag for cross container operations |
| _cdb_disable_pdb_limit | FALSE | CDB Compatible |
| _cdb_fleet_sync_timeout | 10 | Time in minutes to wait for sync of stub entry in CDB Fleet |
| _cdb_init_batch_size | 100 | Batch size for reading pdb info during CDB mount |
| _cdb_port | 0 | Port number for CDB Servlet |
| _cdb_rac_affinity | TRUE | rac affinity for parallel cdb operations |
| _cdb_special_old_xplan | TRUE | display old-style plan for CDB special fixed table |
| _cdb_spfile_inherit | FALSE | Inherit CDB Spfile enabled/disabled in a PDB |
| _cdb_svlt_use_tcps | FALSE | Use TCPS for CDB Servlet |
| _cdb_view_no_skip_migrate | FALSE | do not skip OPEN MIGRATE PDBs from results of CONTAINERS() |
| _cdb_view_no_skip_restricted | FALSE | do not skip RESTRICTED mode PDBs from results of CONTAINERS() |
| _cdb_view_parallel_degree | 65535 | Parallel degree for a CDB view query |
| _cdb_view_prefetch_batch_size | 200 | Batch Size for Prefetch for a CDB view query |
| _cdb_view_rc_shelflife | 30 | Result Cache Shelflife for a CDB view query |
| _cdb_view_recursive_px_enabled | TRUE | enable parallelism of recursive SQL under CONTAINERS() |
| _cdc_subscription_owner | Change Data Capture subscription_owner | |
| _cdmp_diagnostic_level | 2 | cdmp directory diagnostic level |
| _cell_fast_file_create | TRUE | Allow optimized file creation path for Cells |
| _cell_fast_file_restore | TRUE | Allow optimized rman restore for Cells |
| _cell_file_format_chunk_size | 0 | Cell file format chunk size in MB |
| _cell_index_scan_enabled | TRUE | enable CELL processing of index FFS |
| _cell_materialize_all_expressions | FALSE | Force materialization of all offloadable expressions on the cells |
| _cell_materialize_virtual_columns | TRUE | enable offload of expressions underlying virtual columns to cells |
| _cell_metadata_compression | AUTO | Cell metadata compression strategy |
| _cell_object_expiration_hours | 24 | flashcache object expiration timeout |
| _cell_offload_backup_compression | TRUE | enable offload of backup compression to cells |
| _cell_offload_capabilities_enabled | 1 | specifies capability table to load |
| _cell_offload_complex_processing | TRUE | enable complex SQL processing offload to cells |
| _cell_offload_expressions | TRUE | enable offload of expressions to cells |
| _cell_offload_grand_total | TRUE | allow offload of grand total aggregations |
| _cell_offload_hybrid_processing | TRUE | enable hybrid SQL processing offload to cells |
| _cell_offload_hybridcolumnar | TRUE | Query offloading of hybrid columnar compressed tables to exadata |
| _cell_offload_predicate_reordering_enabled | FALSE | enable out-of-order SQL processing offload to cells |
| _cell_offload_sys_context | TRUE | enable offload of SYS_CONTEXT evaluation to cells |
| _cell_offload_timezone | TRUE | enable timezone related SQL processing offload to cells |
| _cell_offload_vector_groupby | TRUE | enable SQL processing offload of vector group by |
| _cell_offload_vector_groupby_external | TRUE | enable cell offload of vector group by with external tables |
| _cell_offload_vector_groupby_fact_key | TRUE | enable cell offload of vector group by with fact grouping keys |
| _cell_offload_vector_groupby_force | FALSE | force offload of vector group by |
| _cell_offload_vector_groupby_withnojoin | TRUE | allow offload of vector group by without joins |
| _cell_offload_virtual_columns | TRUE | enable offload of predicates on virtual columns to cells |
| _cell_range_scan_enabled | TRUE | enable CELL processing of index range scans |
| _cell_storidx_minmax_enabled | TRUE | enable Storage Index Min/Max optimization on the cells |
| _cell_storidx_mode | EVA | Cell Storage Index mode |
| _cellcache_clause_default | Default cellcache clause for new tables | |
| _cellcache_default_flags | 2 | Default flags based on cellcache_clause_default |
| _cellcache_default_new | FALSE | Force cellcache on new tables |
| _cgs_allgroup_poll_time | 20000 | CGS DBALL group polling interval in milli-seconds |
| _cgs_big_group_enabled | FALSE | big group membership support |
| _cgs_clscevents_dumpinterval | 600 | cgs clsce events statistics dump interval in seconds |
| _cgs_combine_css_events | 31 | CGS registration flags for CSS event combining |
| _cgs_comm_readiness_check | 1 | CGS communication readiness check |
| _cgs_dball_group_registration | local | CGS DBALL group registration type |
| _cgs_dbgroup_poll_time | 600 | CGS DB group polling interval in milli-seconds |
| _cgs_health_check_in_reconfig | FALSE | CGS health check during reconfiguration |
| _cgs_memberkill_from_rim_instance | FALSE | allow a RIM instance to issue a CSS member kill |
| _cgs_msg_batch_size | 4096 | CGS message batch size in bytes |
| _cgs_msg_batching | TRUE | CGS message batching |
| _cgs_node_kill_escalation | TRUE | CGS node kill escalation to CSS |
| _cgs_node_kill_escalation_wait | 0 | CGS wait time to escalate node kill to CSS in seconds |
| _cgs_os_level_connection_check | 1 | allow OS level connection and interface check |
| _cgs_os_level_connection_dynamicthread | TRUE | allow oraping to spawn more threads than the default. |
| _cgs_os_level_connection_reqno | 0 | number of ping rqst to process at once, threads created |
| _cgs_publish_netinfo_collect_event_chm | rcfg-half-timeout,rcfg-timeout,rcfg-done,idleconn-half-timeout,idleconn-timeout-imr,idleconn-cln,rcfg-begin,rcfg-pngchkdone,rcfg-memchg | enable cgs publish collect_netinfo event to event stream for CHM |
| _cgs_publish_netinfo_collect_event_chmjf | TRUE | enable cgs publish collect_netinfo event to event stream for CHM with CHM'S JASON format |
| _cgs_publish_netinfo_collect_event_chmjf_batchsz | 0 | batch size of cgs events publishing to CHM in json format via clsce event stream |
| _cgs_publish_netinfo_collect_event_haip | TRUE | enable cgs publish collect_netinfo event to event stream for HAIP |
| _cgs_query_net_interface | SCLSI | api to query network interface |
| _cgs_reconfig_extra_wait | 3 | CGS reconfiguration extra wait time for CSS in seconds |
| _cgs_reconfig_timeout | 0 | CGS reconfiguration timeout interval |
| _cgs_send_timeout | 300 | CGS send timeout value |
| _cgs_support_rim_disc | TRUE | rim instance disconnect and reconnect event support |
| _cgs_ticket_sendback | 50 | CGS ticket active sendback percentage threshold |
| _cgs_tickets | 1000 | CGS messaging tickets |
| _cgs_zombie_member_kill_wait | 20 | CGS zombie member kill wait time in seconds |
| _change_vector_buffers | 1 | Number of change vector buffers for media recovery |
| _change_vector_read_sample_ratio | 0 | Sample ratio of change vector read timestamp on ADG |
| _check_block_after_checksum | FALSE | check block before write irrespective of db_block_checking |
| _check_block_new_invariant_for_flashback | FALSE | check block new invariant for flashback |
| _check_column_length | TRUE | check column length |
| _check_pdbid_in_redo | FALSE | Enable checking of pluggable database ID in redo |
| _check_ts_threshold | 0 | check tablespace thresholds |
| _child_read_ahead_dba_check | FALSE | if TRUE, assert child read ahead dba to be continuous of parent |
| _cleanout_shrcur_buffers | TRUE | if TRUE, cleanout shrcur buffers |
| _cleanup_rollback_entries | 100 | no. of undo entries to apply per transaction cleanup |
| _cleanup_timeout | 150 | timeout value for PMON cleanup |
| _cleanup_timeout_flags | 0 | flags for PMON cleanup timeout |
| _clear_buffer_before_reuse | FALSE | Always zero-out buffer before reuse for security |
| _clear_preserved_buffers | TRUE | Clear preserved buffers before DB reopen after switchover |
| _cli_cachebktalloc | 100 | Percentage of memory to allocate |
| _client_enable_auto_unregister | FALSE | enable automatic unregister after a send fails with timeout |
| _client_features_tracking_enable | TRUE | track client feature uage |
| _client_ntfn_cleanup_interval | 2400 | interval after which dead client registration cleanup task repeats |
| _client_ntfn_pinginterval | 75 | time between pings to unreachable notification clients |
| _client_ntfn_pingretries | 6 | number of times to ping unreachable notification clients |
| _client_ntfn_pingtimeout | 30000 | timeout to connect to unreachable notification clients |
| _client_result_cache_bypass | FALSE | bypass the client result cache |
| _client_result_cache_ramthreshold | client_result_cache_ramthreshold | |
| _client_result_set_threshold | client_result_set_threshold | |
| _client_tstz_error_check | TRUE | Should Client give error for suspect Timestamp with Timezone operations |
| _clone_during_split | TRUE | if TRUE, clone buffer during index split |
| _clone_one_pdb_recovery | FALSE | Recover ROOT and only one PDB in clone database |
| _close_cached_open_cursors | FALSE | close cursors cached by PL/SQL at each commit |
| _close_deq_by_cond_curs | FALSE | Close Dequeue By Condition Cursors |
| _cloud_mandatory_profile_setup | FALSE | Mandatory Profile Setup for Multitenant Cloud Environment |
| _cloud_name | gsm cloud name | |
| _cloud_service_sim | 0 | simulate cloud services in Database |
| _cloud_service_type | cloud service type | |
| _cloudsql_offload_enabled | FALSE | enable CloudSQL cell offload support |
| _cluster_database_instances | 1 | number of instances to use for sizing cluster db SGA structures |
| _cluster_flash_cache_slave_file | cluster flash cache slave file for default block size | |
| _cluster_flash_cache_slave_size | 0 | cluster flash cache slave file size for default block size |
| _cluster_instances_number | 4 | number of instances to calculate number of resource buckets |
| _cluster_library | clss | cluster library selection |
| _clusterwide_global_transactions | TRUE | enable/disable clusterwide global transactions |
| _collapse_wait_history | FALSE | collapse wait history |
| _collect_tempundo_stats | TRUE | Collect Statistics v$tempundostat |
| _collect_undo_stats | TRUE | Collect Statistics v$undostat |
| _column_compression_factor | 0 | Column compression ratio |
| _column_elimination_off | FALSE | turn off predicate-only column elimination |
| _column_level_stats | OFF | Turn column statistics collection on or off |
| _column_stats_flush_interval | 60 | column-level statistics flush to disk interval |
| _column_stats_max_entries_per_stat | 5 | column-level statistics max entries saved per stat type |
| _column_stats_mem_limit | 10 | percentage of the max shared pool column-level statistics can use - internal |
| _column_tracking_level | 53 | column usage tracking |
| _common_data_view_enabled | TRUE | common objects returned through dictionary views |
| _common_user_prefix | C## | Enforce restriction on a prefix of a Common User/Role/Profile name |
| _compilation_call_heap_extent_size | 16384 | Size of the compilation call heaps extents |
| _complex_view_merging | TRUE | enable complex view merging |
| _component_timing | Oracle parameter used for component tracking and timing | |
| _composite_interval_partition_creation_opt_enabled | TRUE | when creating interval/auto list partitions, defer subpartition segment creation until a row for the subpartition is inserted |
| _compression_above_cache | 0 | number of recompression above cache for sanity check |
| _compression_advisor | 0 | Compression advisor |
| _compression_chain | 90 | percentage of chained rows allowed for Compression |
| _compression_compatibility | 21.0.0 | Compression compatibility |
| _con_map_sql_enforcement | TRUE | disable container map SQL enforcement |
| _concurrency_chosen | 10 | what is the chosen value of concurrency |
| _connect_by_use_union_all | TRUE | use union all for connect by |
| _connect_string_settings_after_logon_triggers | 0 | set connect string session settings after logon triggers |
| _connect_string_settings_unalterable | 0 | make connect string session settings unalterable |
| _connection_broker_handout_accept | FALSE | connection broker accepts prior to handout |
| _connection_broker_host | localhost | connection broker host for listen address |
| _connstr_test_param | 0 | connect string workload behavior spare param |
| _consensus_follower_election_timeout | 12000 | consensus follower's election timeout |
| _consensus_leader_heartbeat_interval | 6000 | consensus leader's heartbeat interval |
| _consensus_leader_maximum_heartbeats | consensus leader's maximum heartbeats | |
| _consensus_queue_maximum_elements | 10 | consensus queue maximum elements |
| _consensus_slaves_maximum_count | 5 | consensus slaves maximum count |
| _containers_multiple_ptn_key | TRUE | enable multiple partition keys for container views |
| _controlfile_auto_convert_behaviour | AUTO_CONVERT | controlfile auto convert behavior for a mixed platform dataguard. |
| _controlfile_autobackup_delay | 300 | time delay (in seconds) for performing controlfile autobackups |
| _controlfile_backup_copy_check | TRUE | enable check of the copied blocks during controlfile backup copy |
| _controlfile_block_size | 0 | control file block size in bytes |
| _controlfile_cell_flash_caching | 3 | Flash cache hint for control file accesses |
| _controlfile_enqueue_dump | FALSE | dump the system states after controlfile enqueue timeout |
| _controlfile_enqueue_holding_time | 120 | control file enqueue max holding time in seconds |
| _controlfile_enqueue_holding_time_tracking_size | 0 | control file enqueue holding time tracking size |
| _controlfile_enqueue_timeout | 900 | control file enqueue timeout in seconds |
| _controlfile_section_init_size | control file initial section size | |
| _controlfile_section_max_expand | control file max expansion rate | |
| _controlfile_split_brain_check | FALSE | Check for a split-brain in distributed lock manager domain |
| _controlfile_update_check | OFF | controlfile update sanity check |
| _controlfile_verify_on_mount | FALSE | Verify control file blocks on header error during mount |
| _convert_set_to_join | FALSE | enables conversion of set operator to join |
| _coord_message_buffer | 0 | parallel recovery coordinator side extra message buffer size |
| _corrupted_rollback_segments | corrupted undo segment list | |
| _cost_equality_semi_join | TRUE | enables costing of equality semi-join |
| _cp_del_free_sess | TRUE | connection pool: delete free sessions when at PDB limit |
| _cp_del_free_sess_limit_secs | 1 | connection pool: delete free sessions time limit (in seconds) |
| _cp_num_hash_latches | connection pool number of hash latches | |
| _cpu_count_startup | 0 | Startup number of CPUs for this instance |
| _cpu_eff_thread_multiplier | CPU effective thread multiplier | |
| _cpu_to_io | 0 | divisor for converting CPU cost to I/O cost |
| _cpu_util_adj_force | 1 | force cpu util adjustment |
| _cpu_util_adj_target | 0 | cpu utilization adjustment target |
| _cputime_limit_parallel_fptr | 60 | CPU-time limit for for parallel first-pass recovery |
| _cr_grant_global_role | TRUE | if TRUE, grant lock for CR requests when block is in global role |
| _cr_grant_local_role | AUTO | turn 3-way CR grants off, make it automatic, or turn it on |
| _cr_grant_only | FALSE | if TRUE, grant locks when possible and do not send the block |
| _cr_multiblock_grant_only | FALSE | if TRUE, grant locks for multiblock read when possible and do not send the block |
| _cr_server_log_flush | TRUE | if TRUE, flush redo log before serving a CR buffer |
| _cr_trc_buf_size | 8192 | size of cr trace buffer |
| _crash_domain_on_exception | 0 | allow domain to exit for exceptions in any thread |
| _create_idx_from_constraint | FALSE | allow trigger to create index from constraint |
| _create_pdb_disable_mirror_reads | FALSE | Disable mirror reads during create pdb |
| _create_pdb_flashback_barrier | FALSE | force flashback barrier for create pdb |
| _create_stat_segment | 0 | create ilm statistics segment |
| _create_table_in_any_cluster | FALSE | allow creation of table in a cluster not owned by the user |
| _cross_con_collection | FALSE | enable cross container collection |
| _cross_con_remove_pushed_preds | FALSE | remove pushed predicates from query fetching across containers |
| _cross_con_row_count | FALSE | use actual row count for cross container views |
| _crs_2phase | bypass | crs 2phase |
| _cstats_enabled | FALSE | Core stat monitoring enabled |
| _ctas_numfrags_hint | 0 | Hint for number of partition fragments to be loaded in a CTAS |
| _ctex_fk_copy_mode | 1 | Create table for exchange Copy mode for referential constraints |
| _ctx_doc_policy_stems | FALSE | enable ctx_doc.policy_stems api |
| _cu_row_locking | 0 | CU row level locking |
| _cursor_bind_capture_area_size | 400 | maximum size of the cursor bind capture area |
| _cursor_bind_capture_interval | 900 | interval (in seconds) between two bind capture for a cursor |
| _cursor_cache_time | 900 | number of seconds a session cached cursor stay in cache. |
| _cursor_db_buffers_pinned | 407 | additional number of buffers a cursor can pin at once |
| _cursor_diagnostic_node_agedout_count | 100 | Number of cursor-sharing diagnostic nodes to retain before reuse |
| _cursor_features_enabled | 2 | Shared cursor features enabled bits. |
| _cursor_obsolete_threshold | 8192 | Number of cursors per parent before obsoletion. |
| _cursor_plan_enabled | TRUE | enable collection and display of cursor plans |
| _cursor_plan_hash_version | 1 | version of cursor plan hash value |
| _cursor_plan_unparse_enabled | TRUE | enables/disables using unparse to build projection/predicates |
| _cursor_reload_failure_threshold | 0 | Number of failed reloads before marking cursor unusable |
| _cursor_runtimeheap_memlimit | 5242880 | Shared cursor runtime heap memory limit |
| _cursor_stats_enabled | TRUE | Enable cursor stats |
| _cvw_enable_weak_checking | TRUE | enable weak view checking |
| _cvw_examine_tables_in_from_list_subqry | TRUE | examine tables in from list subqueries |
| _data_transfer_cache_bc_perc_x100 | 500 | Percentange * 100 of buffer cache to transfer to data transfer cache |
| _data_warehousing_scan_buffers | TRUE | if TRUE, enable data warehousing scan buffers |
| _data_warehousing_scan_flash_buffers | FALSE | if TRUE, enable data warehousing scan flash buffers |
| _data_warehousing_serial_scan | TRUE | if TRUE, enable data warehousing serial scans |
| _datafile_cow | FALSE | Use copy on write snapshot for the renamed file |
| _datafile_create_min_wait_time | 0 | Minimum wait time for standby during data file creation |
| _datafile_create_wait_time | 0 | Wait time for standby during data file creation |
| _datafile_open_errors_crash_instance | TRUE | datafile open errors crash instance |
| _datafile_write_errors_crash_instance | TRUE | datafile write errors crash instance |
| _datapump_bypass_tstz_check | FALSE | Bypass Data Pump TSTZ version checking during import. |
| _datapump_compressbas_buffer_size | 0 | specifies buffer size for BASIC compression algorithm |
| _datapump_conv_pga_lim | 0 | pga limit for Data Pump conventional path bind array size |
| _datapump_gather_stats_on_load | FALSE | Gather table statistics during Data Pump load rather thanimporting statistics from the dump file. This should be set to TRUE in the lockdown profile in a DWCS environment. |
| _datapump_hide_cdb_warning | FALSE | Hide Data Pump warning for CDBSEED |
| _datapump_inherit_svcname | TRUE | Inherit and propagate service name throughout job |
| _datapump_metadata_buffer_size | 131072 | specifies buffer size for metadata file I/O |
| _datapump_tabledata_buffer_size | 262144 | specifies buffer size for table data file I/O |
| _db_16k_cache_xmem_size | 0 | Size of 16k buffer pool on extended cache |
| _db_16k_flash_cache_file | flash cache file for 16k block size | |
| _db_16k_flash_cache_size | 0 | flash cache size for _db_16k_flash_cache_file |
| _db_2k_cache_xmem_size | 0 | Size of 2k buffer pool on extended memory |
| _db_2k_flash_cache_file | flash cache file for 2k block size | |
| _db_2k_flash_cache_size | 0 | flash cache size for _db_2k_flash_cache_file |
| _db_32k_cache_xmem_size | 0 | Size of 32k buffer pool on extended memory |
| _db_32k_flash_cache_file | flash cache file for 32k block size | |
| _db_32k_flash_cache_size | 0 | flash cache size for _db_32k_flash_cache_file |
| _db_4k_cache_xmem_size | 0 | Size of 4k buffer pool on extended cache |
| _db_4k_flash_cache_file | flash cache file for 4k block size | |
| _db_4k_flash_cache_size | 0 | flash cache size for _db_4k_flash_cache_file |
| _db_8k_cache_xmem_size | 0 | Size of 8k buffer pool on extended cache |
| _db_8k_flash_cache_file | flash cache file for 8k block size | |
| _db_8k_flash_cache_size | 0 | flash cache size for _db_8k_flash_cache_file |
| _db_aging_cool_count | 1 | Touch count set when buffer cooled |
| _db_aging_freeze_cr | FALSE | Make CR buffers always be too cold to keep in cache |
| _db_aging_hot_criteria | 2 | Touch count which sends a buffer to head of replacement list |
| _db_aging_stay_count | 0 | Touch count set when buffer moved to head of replacement list |
| _db_aging_touch_time | 3 | Touch count which sends a buffer to head of replacement list |
| _db_always_check_system_ts | TRUE | Always perform block check and checksum for System tablespace |
| _db_block_adjcheck | TRUE | adjacent cache buffer checks - low blkchk overwrite parameter |
| _db_block_adjchk_level | 0 | adjacent cache buffer check level |
| _db_block_align_direct_read | TRUE | Align Direct Reads |
| _db_block_bad_write_check | FALSE | enable bad write checks |
| _db_block_buffers | 131186 | Number of database blocks cached in memory: hidden parameter |
| _db_block_cache_history_lru | FALSE | buffer header tracing for lru operations |
| _db_block_cache_protect | false | protect database blocks (for debugging only) |
| _db_block_cache_protect_internal | 0 | protect database blocks (for internal use only) |
| _db_block_check_for_debug | FALSE | Check more and dump block before image for debugging |
| _db_block_check_objtyp | TRUE | check objd and typ on cache disk read |
| _db_block_chunkify_ncmbr | FALSE | chunkify noncontig multi block reads |
| _db_block_corruption_recovery_threshold | 5 | threshold number of block recovery attempts |
| _db_block_do_full_mbreads | FALSE | do full block read even if some blocks are in cache |
| _db_block_hash_buckets | 524288 | Number of database block hash buckets |
| _db_block_hash_latches | 4096 | Number of database block hash latches |
| _db_block_header_guard_level | 0 | number of extra buffer headers to use as guard pages |
| _db_block_hi_priority_batch_size | 0 | Fraction of writes for high priority reasons |
| _db_block_iterations_for_rm | 2000 | number of blocks to reduce every iteration for RM |
| _db_block_known_clean_pct | 2 | Initial Percentage of buffers to maintain known clean |
| _db_block_lru_latches | 36 | number of lru latches |
| _db_block_max_cr_dba | 6 | Maximum Allowed Number of CR buffers per dba |
| _db_block_max_scan_pct | 40 | Percentage of buffers to inspect when looking for free |
| _db_block_med_priority_batch_size | 0 | Fraction of writes for medium priority reasons |
| _db_block_numa | 1 | Number of NUMA nodes |
| _db_block_prefetch_fast_longjumps_enabled | TRUE | Batched IO enable fast longjumps |
| _db_block_prefetch_limit | 0 | Prefetch limit in blocks |
| _db_block_prefetch_override | 0 | Prefetch force override in blocks |
| _db_block_prefetch_private_cache_enabled | TRUE | Batched IO enable private cache |
| _db_block_prefetch_quota | 10 | Prefetch quota as a percent of cache size |
| _db_block_prefetch_skip_reading_enabled | TRUE | Batched IO enable skip reading buffers |
| _db_block_prefetch_wasted_threshold_perc | 2 | Allowed wasted percent threshold of prefetched size |
| _db_block_scandepth_for_rm | 20 | number of blocks to reduce every iteration for RM |
| _db_block_table_scan_buffer_size | 4194304 | Size of shared table scan read buffer |
| _db_block_temp_redo | FALSE | generate redo for temp blocks |
| _db_block_trace_protect | FALSE | trace buffer protect calls |
| _db_block_vlm_check | FALSE | check for mapping leaks (debugging only) |
| _db_block_vlm_leak_threshold | 4 | threshold for allowable mapping leaks |
| _db_blocks_per_hash_latch | Number of blocks per hash latch | |
| _db_bt_cache_only_readmostly_obj_on_roi | FALSE | if TRUE, ABTC only caches read mostly objects on ROI |
| _db_cache_advice_hash_latch_multiple | 16 | cache advisory hash latch multiple |
| _db_cache_advice_max_size_factor | 2 | cache advisory maximum multiple of current size to similate |
| _db_cache_advice_sample_factor | 4 | cache advisory sampling factor |
| _db_cache_advice_sanity_check | FALSE | cache simulation sanity check |
| _db_cache_advice_size_submultiple | 10 | cache advisory size submultiple |
| _db_cache_block_read_stack_trace | 0 | dump short call stack for block reads |
| _db_cache_block_read_stack_trace_where1 | 0 | dump short call stack for block reads just for where1 |
| _db_cache_block_read_stack_trace_where2 | 0 | dump short call stack for block reads just for where2 |
| _db_cache_block_read_stack_trace_where3 | 0 | dump short call stack for block reads just for where3 |
| _db_cache_crx_check | FALSE | check for costly crx examination functions |
| _db_cache_max_sz | 0 | |
| _db_cache_miss_check_les | FALSE | check LEs after cache miss |
| _db_cache_mman_latch_check | FALSE | check for wait latch get under MMAN ops in kcb |
| _db_cache_pmem_confidence_try | 0 | DB Cache PMEM buffer promote attempts for greater confidence |
| _db_cache_pmem_promotion_touch_rate_reset_interval | 300 | DB Cache PMEM promotion touch rate reset interval in sec |
| _db_cache_pmem_promotion_touch_rate_threshold_time | 30 | DB Cache PMEM promotion touch rate threshold time in sec |
| _db_cache_pmem_touch_rate_compare_per | 95 | DB Cache PMEM buffer touch rate additive percentage when comparingagainst dram touch rate |
| _db_cache_pmemp_len | 10000 | DB Cache PMEM promotion list max length |
| _db_cache_pre_warm | TRUE | Buffer Cache Pre-Warm Enabled : hidden parameter |
| _db_cache_process_cr_pin_max | 2147483647 | maximum number of cr pins a process may have |
| _db_cache_silicon_secured_memory | TRUE | enable silicon secured memory |
| _db_cache_wait_debug | 0 | trace new kslwaits |
| _db_cache_xmem_promotion_algo_chosen | 38 | DB Cache Xmem/Pmem promotion algo |
| _db_cache_xmem_size | 0 | Size of extended memory data area for buffer cache DEFAULT pool |
| _db_change_notification_enable | TRUE | enable db change notification |
| _db_check_cell_hints | FALSE | |
| _db_disable_temp_encryption | FALSE | Disable Temp Encryption for Spills |
| _db_discard_lost_masterkey | FALSE | discard lost masterkey handles |
| _db_dump_from_disk_and_efc | 0 | dump contents from disk and efc |
| _db_dw_scan_adaptive_cooling | FALSE | if TRUE, enable adaptive DW scan cooling |
| _db_dw_scan_max_shadow_count | 5 | DW Scan adaptive cooling max shadow count |
| _db_dw_scan_obj_cooling_factor | 500 | DW Scan object cooling factor to cool all temperatures |
| _db_dw_scan_obj_cooling_interval | 100 | DW Scan object cooling interval in number of scans, seconds, or pct of cache size |
| _db_dw_scan_obj_cooling_policy | CACHE_SIZE | DW scan objtect cooling policy |
| _db_dw_scan_obj_warming_increment | 1000 | DW Scan object warming increment when an object is scanned |
| _db_fast_obj_check | FALSE | enable fast object drop sanity check |
| _db_fast_obj_ckpt | TRUE | enable fast object checkpoint |
| _db_fast_obj_truncate | TRUE | enable fast object truncate |
| _db_file_direct_io_count | 1048576 | Sequential I/O buf size |
| _db_file_exec_read_count | 128 | multiblock read count for regular clients |
| _db_file_format_io_buffers | 4 | Block formatting I/O buf count |
| _db_file_noncontig_mblock_read_count | 11 | number of noncontiguous db blocks to be prefetched |
| _db_file_optimizer_read_count | 8 | multiblock read count for regular clients |
| _db_flash_cache_disable_write_batchsize | 4096 | Flash cache disable writes processing batchsize |
| _db_flash_cache_encryption | FALSE | Set _db_flash_cache_encryption to enable flash cache encryption |
| _db_flash_cache_force_replenish_limit | 8 | Flash cache force replenish lower limit in buffers |
| _db_flash_cache_keep_limit | 80 | Flash cache keep buffer upper limit in percentage |
| _db_flash_cache_max_latency | 400 | Flash cache maximum latency allowed in 10 milliseconds |
| _db_flash_cache_max_outstanding_writes | 32 | Flash cache maximum outstanding writes allowed |
| _db_flash_cache_max_read_retry | 10 | Flash cache max read retry |
| _db_flash_cache_max_slow_io | 3 | Flash cache maximum slow io allowed |
| _db_flash_cache_slow_io_adjustment_interval | 3600 | Decrement interval |
| _db_flash_cache_write_limit | 1 | Flash cache write buffer upper limit in percentage |
| _db_flashback_iobuf_size | 1 | Flashback IO Buffer Size |
| _db_flashback_log_min_size | 16777216 | Minimum flashback database log size in bytes |
| _db_flashback_log_min_total_space | 0 | Minimum flashback database log total space in bytes |
| _db_flashback_num_iobuf | 64 | Flashback Number of IO buffers |
| _db_full_caching | TRUE | enable full db implicit caching |
| _db_full_db_cache_diff_pct | 5 | Cache at least this % larger than DB size for full db caching |
| _db_generate_dummy_masterkey | FALSE | if TRUE, use old havior and generate dummy master key |
| _db_handles | 3200 | System-wide simultaneous buffer operations |
| _db_handles_cached | 10 | Buffer handles cached each process |
| _db_hot_block_tracking | FALSE | track hot blocks for hash latch contention |
| _db_imoltp_hashidx_force_nonctg | 0 | kcbw imoltp hash index force non contig granules |
| _db_index_block_checking | TRUE | index block checking override parameter |
| _db_initial_cachesize_create_mb | 256 | size of cache created at startup |
| _db_keep_cache_xmem_size | 0 | Size of KEEP buffer pool for standard block size buffers on extended memory |
| _db_l2_tracing | 0 | flash cache debug tracing |
| _db_large_dirty_queue | 25 | Number of buffers which force dirty queue to be written |
| _db_link_sources_tracking | TRUE | enable/disable database link source tracking |
| _db_lost_write_checking | 2 | Enable scn based lost write detection mechanism |
| _db_lost_write_corrupt_block | FALSE | allow corruption for lost write |
| _db_lost_write_tracing | FALSE | Enable _db_lost_write_checking tracing |
| _db_minimum_auxsize_percent | 0 | min percent of aux buffers to be maintained before using aux2 |
| _db_mttr_advice | ON | MTTR advisory |
| _db_mttr_partitions | 0 | number of partitions for MTTR advisory |
| _db_mttr_sample_factor | 64 | MTTR simulation sampling factor |
| _db_mttr_sim_target | MTTR simulation targets | |
| _db_mttr_sim_trace_size | 256 | MTTR simulation trace size |
| _db_mttr_trace_to_alert | FALSE | dump trace entries to alert file |
| _db_noarch_disble_optim | FALSE | Image redo logging (NOARCHIVEMODE) |
| _db_num_evict_waitevents | 16384 | number of evict wait events |
| _db_num_gsm | 0 | database number in gsm dbpool |
| _db_nvm_promotion_deferred_tchcnt | 195 | touch count threshold which allows deferred background based nvm buffer promotion |
| _db_obj_enable_ksr | TRUE | enable ksr in object checkpoint/reuse |
| _db_percent_hot_default | 50 | Percent of default buffer pool considered hot |
| _db_percent_hot_keep | 0 | Percent of keep buffer pool considered hot |
| _db_percent_hot_recycle | 0 | Percent of recycle buffer pool considered hot |
| _db_percpu_create_cachesize | 2 | size of cache created per cpu in deferred cache create |
| _db_pmem_auto_resize_interval | 10 | PMEM auto resize interval in minutes |
| _db_pmem_direct_map_size | 0 | Size of direct mappable PMEM buffer cache |
| _db_prefetch_histogram_statistics | FALSE | maintain prefetch histogram statistics in x$kcbprfhs |
| _db_recovery_temporal_file_dest | default database recovery temporal file location | |
| _db_recycle_cache_xmem_size | 0 | Size of Recycle buffer pool for standard block size buffers on extended memory |
| _db_replay_security_config | Database Replay Security Configuration | |
| _db_required_percent_fairshare_usage | 10 | percent of fairshare a processor group should always use |
| _db_row_overlap_checking | TRUE | row overlap checking override parameter for data/index blocks |
| _db_shadow_lost_write_protect | NOT_SET | alter shadow lost write detection for PDB |
| _db_todefer_cache_create | TRUE | buffer cache deferred create |
| _db_writer_chunk_writes | 0 | Number of writes DBWR should wait for |
| _db_writer_coalesce_area_size | 4194304 | Size of memory allocated to dbwriter for coalescing writes |
| _db_writer_coalesce_encrypted_buffers | TRUE | Coalecsing for encrypted buffers |
| _db_writer_coalesce_write_limit | 131072 | Limit on size of coalesced write |
| _db_writer_flush_imu | TRUE | If FALSE, DBWR will not downgrade IMU txns for AGING |
| _db_writer_histogram_statistics | FALSE | maintain dbwr histogram statistics in x$kcbbhs |
| _db_writer_max_writes | 0 | Max number of outstanding DB Writer IOs |
| _db_writer_nomemcopy_coalesce | FALSE | Enable DBWR no-memcopy coalescing |
| _db_writer_verify_writes | FALSE | Enable lost write detection mechanism |
| _db_xmem_cache_encryption | TRUE | Set _db_xmem_cache_encryption to enable XMEM cache encryption |
| _db_xmem_hot_switch_criteria | 195 | Xmem/Pmem buffer touch count which makes this buffer candidate of switching to DRAM buffer |
| _dbcomp_maxdump | 100 | Maximum # of dumped blocks per datafile |
| _dbcomp_msg_ver | 1 | database block compare message version |
| _dbfs_modify_implicit_fetch | TRUE | DBFS Link allows implicit fetch on modify - only on SecureFiles |
| _dbfs_symlink_path_prefix | TRUE | disallow symbolic link creation in dbfs outside path_prefix |
| _dbg_proc_startup | FALSE | debug process startup |
| _dbg_scan | 0 | generic scan debug |
| _dbms_sql_security_level | 1 | Security level in DBMS_SQL |
| _dbmsumf$$1x | UMF Configuration | |
| _dbmsumf$$2x | UMF Configuration | |
| _dbmsumf$$3x | UMF Configuration | |
| _dbmsumf$$nn | UMF Configuration | |
| _dbmsumf$$p | UMF Configuration | |
| _dbnest_enable | NONE | dbNest enable |
| _dbnest_pdb_fs_conf | PDB Filesystem configuration | |
| _dbnest_pdb_fs_type | DEFAULT | PDB FS Type |
| _dbnest_pdb_scm_conf | PDB SCM configuration | |
| _dbnest_pdb_scm_level | STRICT1 | PDB SCM Level |
| _dbnest_resource_opts | 0 | dbNest - resource options |
| _dbnest_skip_fed_root | TRUE | Fed root is skipped so CDB nest is root of all pdbs |
| _dbnest_stage_dir | Staging directory configuration | |
| _dbop_enabled | 1 | Any positive number enables automatic DBOP monitoring. 0 is disabled |
| _dbopen_breakpoint | none | ALTER DATABASE OPEN codepath breakpoint |
| _dbpool_name | gsm database pool name | |
| _dbreplay_feature_control | Database Replay Feature Control | |
| _dbreplay_mpk_key | Database Replay Package Key | |
| _dbrm_dynamic_threshold | 17302504 | DBRM dynamic threshold setting |
| _dbrm_num_runnable_list | 0 | Resource Manager number of runnable list per NUMA node |
| _dbrm_quantum | DBRM quantum | |
| _dbrm_runchk | 32798000 | DBRM kskrunstatechk thresholds |
| _dbrm_short_wait_us | 300 | Resource Manager short wait length |
| _dbwr_async_io | TRUE | Enable dbwriter asynchronous writes |
| _dbwr_flashlock_shrink_limit | 0 | limit to shrink le to flash lock per dbwr iteration |
| _dbwr_nowrite_assert_interval | 7200 | dbwriter assert interval after no write seconds |
| _dbwr_nwp_assert_interval | 1800 | dbwriter no write permission assert interval after no write seconds |
| _dbwr_scan_interval | 300 | dbwriter scan interval |
| _dbwr_stall_write_detection_interval | 900 | dbwriter stall write detection interval |
| _dbwr_tracing | 0 | Enable dbwriter tracing |
| _dd_validate_remote_locks | TRUE | GES deadlock detection validate remote locks |
| _dde_flood_control_init | TRUE | Initialize Flood Control at database open |
| _ddlapply_enable | FALSE | DDL VIA APPLY Enable |
| _dead_process_scan_interval | 60 | PMON dead process scan interval (in seconds) |
| _deadlock_diagnostic_level | 2 | automatic deadlock resolution diagnostics level |
| _deadlock_record_to_alert_log | TRUE | record resolved deadlocks to the alert log |
| _deadlock_resolution_incidents_always | FALSE | create incidents when resolving any deadlock? |
| _deadlock_resolution_incidents_enabled | TRUE | create incidents during deadlock resolution |
| _deadlock_resolution_level | 1 | automatic deadlock resolution level |
| _deadlock_resolution_min_wait_timeout_secs | 60 | the minimum wait timeout required for deadlock resolution |
| _deadlock_resolution_signal_process_thresh_secs | 60 | the amount of time given to process a deadlock resolution signal |
| _dedicated_server_poll_count | 10 | dedicated server poll count |
| _dedicated_server_post_wait | FALSE | dedicated server post/wait |
| _dedicated_server_post_wait_call | FALSE | dedicated server post/wait call |
| _default_encrypt_alg | 0 | default encryption algorithm |
| _default_ini_trans_index | 0 | Default value of INI_TRANS enforced by DWCS lockdown for indexes |
| _default_ini_trans_table | 0 | Default value of INI_TRANS enforced by DWCS lockdown for tables |
| _default_non_equality_sel_check | TRUE | sanity check on default selectivity for like/range predicate |
| _default_oracle_fs_type | ofs | default file system type for an oracle file system |
| _default_pct_free | 0 | Default value of PCT_FREE enforced by DWCS lockdown |
| _default_service | TRUE | Run default service |
| _defer_eor_orl_arch_for_so | TRUE | defer EOR ORL archival for switchover |
| _defer_log_boundary_ckpt | TRUE | defer media recovery checkpoint at log boundary |
| _defer_log_count | 100 | Number of log boundaries media recovery checkpoint lags behind |
| _defer_rcv_during_sw_to_sby | FALSE | Defer recovery during switchover to standby |
| _defer_rcv_pdb_attach | TRUE | Defer PDB domain attach in instance recovery |
| _defer_rewrap_controlfile_key_history | FALSE | if TRUE, defer rewrap control file TS keys under next PDB open |
| _defer_sga_alloc_chunk_size | 1073741824 | Chunk size for defer sga allocation |
| _defer_sga_enabled | FALSE | Enable deferred shared memory allocation for SGA |
| _defer_sga_min_spsz_at_startup | 53687091200 | Minimum shared pool size at startup with deferred sga enabled |
| _defer_sga_min_total_defer_segs_sz | 107374182400 | Minimum total deferred segs size for defer sga allocation |
| _defer_sga_test_alloc_intv | 0 | SA** sleeps for N secs before allocating a deferred segment |
| _defer_while_patching | 0 | Session should be deferred if patching is secheduled |
| _deferred_constant_folding_mode | DEFAULT | Deferred constant folding mode |
| _deferred_log_dest_is_valid | TRUE | consider deferred log dest as valid for log deletion (TRUE/FALSE) |
| _deferred_seg_in_seed | TRUE | Enable Deferred Segment Creation in Seed |
| _delay_index_maintain | TRUE | delays index maintenance until after MV is refreshed |
| _delete_ghost_data | FALSE | Test delete ghost data |
| _deq_execute_reset_time | 30 | deq execute reset time |
| _deq_ht_child_latches | 8 | deq ht child latches |
| _deq_ht_max_elements | 100000 | deq ht max elements |
| _deq_large_txn_size | 25000 | deq large txn size |
| _deq_log_array_size | 10000 | deq log array size |
| _deq_max_fetch_count | 10 | deq max fetch count |
| _deq_maxwait_time | 0 | Change wait times between dequeue calls |
| _desired_readmem_rate | 90 | The desired percentage of redo reading from memory |
| _df_hist_offl_override | FALSE | Allow update of keep offline bit in datafile history record |
| _dg_broker_trace_level | data guard broker trace level | |
| _dg_cf_check_timer | 15 | Data Guard controlfile check timer |
| _dg_corrupt_redo_log | 0 | Corrupt redo log validation during archivals |
| _dgb_dgpdb_appst | DGPDBs with apply state off | |
| _dgpdb_file_name_convert | datafile name convert patterns and strings for per PDB standby | |
| _dgpdb_standby_controlfile_name | dgpdb_temp_copy_cf_%u_stby_%u_%u.cf | a name template with three %u's for DGPDB standby controlfile |
| _diag_adl_dyn_alloc | TRUE | Enable Diag Alert Dynamic Allocation |
| _diag_adr_auto_purge | TRUE | Enable/disable ADR MMON Auto Purging |
| _diag_adr_enabled | TRUE | Parameter to enable/disable Diag ADR |
| _diag_adr_test_param | 0 | Test parameter for Diagnosability |
| _diag_adr_trace_dest | /u01/app/oracle/diag/rdbms/orcl21c/orcl21c/trace | diagnosability trace directory path |
| _diag_alert_root_annotate | FALSE | Enable annotation for alert log entries from root |
| _diag_arb_before_kill | FALSE | dump diagnostics before killing unresponsive ARBs |
| _diag_attn_log_format_error | Attention Log Error Entry format | |
| _diag_attn_log_format_standard | Attention Log Standard Entry format | |
| _diag_backward_compat | TRUE | Backward Compatibility for Diagnosability |
| _diag_cc_enabled | TRUE | Parameter to enable/disable Diag Call Context |
| _diag_cdb_logging | short | Format for CDB Annotation |
| _diag_conf_cap_enabled | TRUE | Parameter to enable/disable Diag Configuration Capture |
| _diag_crashdump_level | 10 | parameter for systemstate dump level, used by DIAG during crash |
| _diag_daemon | TRUE | start DIAG daemon |
| _diag_dde_async_age_limit | 300 | diag dde async actions: message age limit (in seconds) |
| _diag_dde_async_cputime_limit | 300 | diag dde async actions: action cputime limit (in seconds) |
| _diag_dde_async_mode | 1 | diag dde async actions: dispatch mode |
| _diag_dde_async_msg_capacity | 1024 | diag dde async actions: message buffer capacity |
| _diag_dde_async_msgs | 50 | diag dde async actions: number of preallocated message buffers |
| _diag_dde_async_process_rate | 5 | diag dde async actions: message processing rate - per loop |
| _diag_dde_async_runtime_limit | 900 | diag dde async actions: action runtime limit (in seconds) |
| _diag_dde_async_slaves | 5 | diag dde async actions: max number of concurrent slave processes |
| _diag_dde_enabled | TRUE | enable DDE handling of critical errors |
| _diag_dde_fc_enabled | TRUE | Parameter to enable/disable Diag Flood Control |
| _diag_dde_fc_implicit_time | 0 | Override Implicit Error Flood Control time parameter |
| _diag_dde_fc_macro_time | 0 | Override Macro Error Flood Control time parameter |
| _diag_dde_inc_proc_delay | 1 | The minimum delay between two MMON incident sweeps (minutes) |
| _diag_diagnostics | TRUE | Turn off diag diagnostics |
| _diag_dump_request_debug_level | 1 | DIAG dump request debug level (0-2) |
| _diag_dump_timeout | 30 | timeout parameter for SYNC dump |
| _diag_enable_startup_events | FALSE | enable events in instance startup notifiers |
| _diag_hm_rc_enabled | TRUE | Parameter to enable/disable Diag HM Reactive Checks |
| _diag_hm_tc_enabled | FALSE | Parameter to enable/disable Diag HM Test(dummy) Checks |
| _diag_large_packets | TRUE | DIA* large packets support |
| _diag_patch_cap_enabled | TRUE | Parameter to enable/disable Diag Patch Configuration Capture |
| _diag_pdb_control | 0 | DIAG PDB Space Management Control Parameter |
| _diag_pdb_purge_target | 90 | Controls target percentage for ADR PDB Auto Purge Operation |
| _diag_pdb_purge_threshold | 97 | Controls threshold for ADR PDB Auto Purge Operation |
| _diag_proc_enabled | TRUE | enable hung process diagnostic API |
| _diag_proc_max_time_ms | 30000 | hung process diagnostic API max wait time in milliseconds |
| _diag_proc_stack_capture_type | 1 | hung process diagnostic API stack capture type |
| _diag_test_seg_reinc_mode | FALSE | Sets trace segmentation to be in reincarnation mode |
| _diag_uts_control | 0 | UTS control parameter |
| _diag_verbose_error_on_init | 0 | Allow verbose error tracing on diag init |
| _diag_xm_enabled | FALSE | If TRUE, DIAG allows message exchanges across DB/ASM boundary |
| _dimension_skip_null | TRUE | control dimension skip when null feature |
| _direct_io_skip_cur_slot_on_error | TRUE | Skip current slot on error |
| _direct_io_slots | 0 | number of slots for direct path I/O |
| _direct_io_via_mapped_pmem | TRUE | if TRUE, direct path I/O will attempt to memory map files on PMEM |
| _direct_io_wslots | 0 | number of write slots for direct path I/O |
| _direct_path_insert_features | 0 | disable direct path insert features |
| _direct_read_decision_statistics_driven | TRUE | enable direct read decision based on optimizer statistics |
| _dirty_appliance_mode | FALSE | Enable appliance mode even on non-appliance |
| _disable_12751 | FALSE | disable policy timeout error (ORA-12751) |
| _disable_12cbigfile | FALSE | DIsable Storing ILM Statistics in 12cBigFiles |
| _disable_active_influx_move | FALSE | disable active influx move during parallel media recovery |
| _disable_actualization_for_grant | FALSE | disable actualization of editioned objects on grant |
| _disable_adaptive_shrunk_aggregation | FALSE | adaptive shrunk aggregation |
| _disable_adp_adj_buf_check | FALSE | No adjacent buffer check for ADP |
| _disable_appliance_check | FALSE | Disable appliance-specific code |
| _disable_appliance_partnering | FALSE | Disable appliance partnering algorithms |
| _disable_asm_audit_feat | 0 | disable ASM audit features |
| _disable_autotune_gtx | FALSE | disable autotune global transaction background processes |
| _disable_block_checking | FALSE | disable block checking at the session level |
| _disable_block_corruption_track | FALSE | disable block corruption tracking |
| _disable_cdb_view_rc_invalidation | FALSE | disable Result Cache invalidation for CDB View results |
| _disable_cell_optimized_backups | FALSE | disable cell optimized backups |
| _disable_con_recurse_queuing | TRUE | disable parallel statement queuing for containers() recursive SQL |
| _disable_cpu_check | FALSE | disable cpu_count check |
| _disable_cursor_sharing | FALSE | disable cursor sharing |
| _disable_data_block_check_after_decrypt | FALSE | if TRUE, disable data block check after decryption |
| _disable_datalayer_sampling | FALSE | disable datalayer sampling |
| _disable_dblink_optim | TRUE | disable intra CDB dblink optimizations |
| _disable_def_seg_update | 0 | Disable deferred seg$ update |
| _disable_destructive_patch_operation | TRUE | Is destructive operation allowed in a patch |
| _disable_dict_check_pdb_open | FALSE | disable PDB pseudo open for dictionary check purpose |
| _disable_directory_link_check | FALSE | Disable directory link checking |
| _disable_duplex_link | TRUE | Turn off connection duplexing |
| _disable_duplicate_service_warning | FALSE | disable listener warning for duplicate service |
| _disable_fast_aggregation | FALSE | fast aggregation |
| _disable_fast_validate | FALSE | disable PL/SQL fast validation |
| _disable_fastopen | FALSE | Do Not Use Fastopen |
| _disable_fba_qrw | 0 | disable flashback archiver query rewrite |
| _disable_fba_wpr | 0 | disable flashback archiver wait for prepared transactions |
| _disable_file_locks | FALSE | disable file locks for control, data, redo log files |
| _disable_file_resize_logging | FALSE | disable file resize logging to alert log |
| _disable_flashback_archiver | 0 | disable flashback archiver |
| _disable_flashback_recyclebin_opt | TRUE | Don't use the Flashback Recyclebin optimization |
| _disable_flashback_wait_callback | FALSE | Disable flashback wait callback |
| _disable_foreign_scn_adjust | FALSE | Disable foreign SCN adjustment |
| _disable_function_based_index | FALSE | disable function-based index matching |
| _disable_gvaq_cache | FALSE | Disable cache |
| _disable_hcc_array_insert | FALSE | TRUE - enable conventional inserts into HCC CUs |
| _disable_health_check | FALSE | Disable Health Check |
| _disable_highres_ticks | FALSE | disable high-res tick counter |
| _disable_ilm_internal | FALSE | Force disable internal ilm stats and drop ilm segment |
| _disable_image_check | FALSE | Disable Oracle executable image checking |
| _disable_implicit_row_movement | FALSE | disable implicit row movement |
| _disable_incremental_checkpoints | FALSE | Disable incremental checkpoints for thread recovery |
| _disable_incremental_recovery_ckpt | FALSE | Disable incremental recovery checkpoint mechanism |
| _disable_index_block_prefetching | FALSE | disable index block prefetching |
| _disable_inheritpriv_grant_public | FALSE | Disable inherit privilege grant to PUBLIC for newly created users |
| _disable_initial_block_compression | FALSE | disable initial block compression |
| _disable_instance_params_check | FALSE | disable instance type check for ksp |
| _disable_interface_checking | FALSE | disable interface checking at startup |
| _disable_kcb_flashback_blocknew_opt | FALSE | Disable KCB flashback block new optimization |
| _disable_kcbhxor_osd | FALSE | disable kcbh(c)xor OSD functionality |
| _disable_kcbl_flashback_blocknew_opt | FALSE | Disable KCBL flashback block new optimization |
| _disable_kgghshcrc32_osd | FALSE | disable kgghshcrc32chk OSD functionality |
| _disable_last_successful_login_time | FALSE | Disable writing Last Successful Login Time to USER$ |
| _disable_logging | FALSE | Disable logging |
| _disable_lostwrite_tablespace_alerts | FALSE | disable tablespace alerts for LOSTWRITE tablespaces |
| _disable_mandatory_profile_onclone | FALSE | Disable Mandatory Profile check on clone of a PDB |
| _disable_marking_noops | FALSE | Don't mark any captured statements as no-ops. |
| _disable_metrics_group | 0 | Disable Metrics Group (or all Metrics Groups) |
| _disable_modsvc_refresh | disable modify service cache refresh | |
| _disable_multiple_block_sizes | FALSE | disable multiple block size support (for debugging) |
| _disable_odm | FALSE | disable odm feature |
| _disable_oradebug_commands | restricted | disable execution of certain categories of oradebug commands |
| _disable_orphan_pdb_recovery | FALSE | Disable PDB PITR/FB to orphan PDB incarnation |
| _disable_os_time_page | FALSE | disable OS time page |
| _disable_parallel_conventional_load | FALSE | Disable parallel conventional loads |
| _disable_pdb_space_check | FALSE | Disable pdb storage usage check in the session |
| _disable_primary_bitmap_switch | FALSE | disable primary bitmap switch |
| _disable_ptl_replay | FALSE | Is PTL replay disabled during Application Sync |
| _disable_read_only_open_dict_check | FALSE | Disable read-only open dictionary check |
| _disable_rebalance_space_check | FALSE | disable space usage checks for storage reconfiguration |
| _disable_recovery_read_skip | FALSE | Disable the read optimization during media recovery |
| _disable_rolling_patch | 0 | Disable Rolling Patch Feature |
| _disable_sample_io_optim | FALSE | disable row sampling IO optimization |
| _disable_savepoint_reset | FALSE | disable the fix for bug 1402161 |
| _disable_selftune_checkpointing | FALSE | Disable self-tune checkpointing |
| _disable_sensitive_internal | FALSE | disable internal SQL from showing sensitive information |
| _disable_sga_filedel | FALSE | disable deletion of files used for SGA |
| _disable_storage_type | FALSE | Disable storage type checks |
| _disable_streams_diagnostics | 0 | streams diagnostics |
| _disable_streams_pool_auto_tuning | FALSE | disable streams pool auto tuning |
| _disable_sun_rsm | TRUE | Disable IPC OSD support for Sun RSMAPI |
| _disable_system_state | 4294967294 | disable system state dump |
| _disable_system_state_wait_samples | FALSE | Disable system state dump - wait samples |
| _disable_system_tablespaces_enc_enforcement | FALSE | if TRUE, disable system tablespaces encryption enforcement |
| _disable_temp_tablespace_alerts | FALSE | disable tablespace alerts for TEMPORARY tablespaces |
| _disable_thread_internal_disable | FALSE | Disable thread internal disable feature |
| _disable_txn_alert | 0 | disable txn layer alert |
| _disable_undo_tablespace_alerts | FALSE | disable tablespace alerts for UNDO tablespaces |
| _disable_wait_state | Disable wait state | |
| _discard_cmn_ddl_in_pdb_err | FALSE | Discard error when Common DDL is attempted in PDB |
| _discrete_transactions_enabled | FALSE | enable OLTP mode |
| _disk_sector_size_override | FALSE | if TRUE, OSD sector size could be overridden |
| _diskmon_pipe_name | DiSKMon skgznp pipe name | |
| _disksize_binary_search | FALSE | if set, perform binary search to get disk size if IOCTL fails |
| _dispatcher_listen_on_vip | FALSE | Determines if dispatcher listens on VIP if no HOST is supplied |
| _dispatcher_rate_scale | scale to display rate statistic (100ths of a second) | |
| _dispatcher_rate_ttl | time-to-live for rate statistic (100ths of a second) | |
| _distinct_agg_optimization_gsets | CHOOSE | Use Distinct Aggregate Optimization for Grouping Sets |
| _distinct_view_unnesting | FALSE | enables unnesting of in subquery into distinct view |
| _distributed_recovery_connection_hold_time | 200 | number of seconds RECO holds outbound connections open |
| _disttxn_for_queries | TRUE | remote queries start distributed transaction |
| _dlm_cache_warmup_slaves | 2 | Number of DLM cache warm up slaves |
| _dlm_stats_collect | 1 | DLM statistics collection(0 = disable, 1 = enable (default)) |
| _dlm_stats_collect_du_limit | 3000 | DLM statistics collection disk updates per slot |
| _dlm_stats_collect_mode | 6 | DLM statistics collection mode |
| _dlm_stats_collect_slot_interval | 60 | DLM statistics collection slot interval (in seconds) |
| _dlmtrace | Trace string of global enqueue type(s) | |
| _dm_dmf_details_compatibility | 12.1.0 | set dm dmf details compatibility version |
| _dm_enable_legacy_dmf_output_types | FALSE | revert dmf output types to pre-12.1.0.1 |
| _dm_inmemory_threshold | 1000000 | In-memory cardinality threshold |
| _dm_max_chunk_size | 2000 | Data Mining Max Chunk Size |
| _dm_max_shared_pool_pct | 5 | max percentage of the shared pool to use for a mining model |
| _dml_batch_error_limit | 0 | number or error handles allocated for DML in batch mode |
| _dml_frequency_tracking | FALSE | Control DML frequency tracking |
| _dml_frequency_tracking_advance | TRUE | Control automatic advance and broadcast of DML frequencies |
| _dml_frequency_tracking_slot_time | 15 | Time length of each slot for DML frequency tracking |
| _dml_frequency_tracking_slots | 4 | Number of slots to use for DML frequency tracking |
| _dml_monitoring_enabled | TRUE | enable modification monitoring |
| _dmm_auto_max_features | 500 | Auto Max Features |
| _dmm_blas_library | Control which BLAS/LAPACK dynamic library to load | |
| _dmm_cnt_arr_size_threshold | 500000 | Counts Array Size Threshold |
| _dmm_details_filter_weight | 1 | Filter details based on weight |
| _dmm_force_treetop_merge | 0 | Force Treetop Merge |
| _dmm_inc_cholesky_rows | 50000 | Incomplete Cholesky number of rows |
| _dmm_ipp_cutoff | 0 | Intra-Partition Parallel size cutoff |
| _dmm_kmean_dense_threshold | 500 | Kmean densify threshold |
| _dmm_max_memory_size | 1000000 | Maximum Memory Size |
| _dmm_memory_size | 64000000 | Memory Size |
| _dmm_nobin_threshold | 200 | No Binning Row Count Threshold |
| _dmm_pga_load_threshold | 3 | Model size less than threshold are loaded into PGA |
| _dmm_reduction_rate | 4 | Reduction rate in reduction tree |
| _dmm_sample_lower_threshold | 10000 | Minimum Sample Size |
| _dmm_sample_upper_threshold | 500000 | Maximum Sample Size |
| _dmm_ser_test | 0 | Stress testing for serialized models |
| _dmm_ts_lapack | 1 | Enable usage of BLAS/LAPACK for Tall Skinny SVD |
| _dmm_xgboost_max_memory | 1000000000 | xgboost maximum memory |
| _dmsqr_qr_chunk_rows | 10000 | QR maximum chunk rows |
| _dnfs_rdma_enable | rman | Enable dNFS RDMA transfers |
| _dnfs_rdma_max | 1048576 | Maximum size of dNFS RDMA transfer |
| _dnfs_rdma_min | 8192 | Minimum size of dNFS RDMA transfer |
| _domain_index_batch_size | 2000 | maximum number of rows from one call to domain index fetch routine |
| _domain_index_dml_batch_size | 200 | maximum number of rows for one call to domain index dml routines |
| _dp_force_length_semantics | NONE | Force nls length semantics |
| _dra_bmr_number_threshold | 1000 | Maximum number of BMRs that can be done to a file |
| _dra_bmr_percent_threshold | 10 | Maximum percentage of blocks in a file that can be BMR-ed |
| _dra_enable_offline_dictionary | FALSE | Enable the periodic creation of the offline dictionary for DRA |
| _drm_parallel_freeze | TRUE | if TRUE enables parallel drm freeze |
| _drop_flashback_logical_operations_enq | FALSE | Drop logical operations enqueue immediately during flashback marker generation |
| _drop_stat_segment | 0 | drop ilm statistics segment |
| _drop_table_granule | 256 | drop_table_granule |
| _drop_table_optimization_enabled | TRUE | reduce SGA memory use during drop of a partitioned table |
| _drop_tablespace_objects | 0 | GDR: drop all tablespace objects |
| _ds_enable_auto_txn | FALSE | Dynamic Sampling Service Autonomous Transaction control parameter |
| _ds_enable_view_sampling | TRUE | Use sampling for views in Dynamic Sampling |
| _ds_iocount_iosize | 6553664 | Dynamic Sampling Service defaults: #IOs and IO Size |
| _ds_parse_model | 2 | Dynamic Sampling Service Parse Model control parameter |
| _ds_progressive_initial_samples | 2 | Number of initial samples used for progressive sampling |
| _ds_progressive_no_matches_min_sample_size | 50 | Minimum sample size at which progressive sampling report no match |
| _ds_sampling_method | PROGRESSIVE | Dynamic sampling method used |
| _ds_xt_split_count | 1 | Dynamic Sampling Service: split count for external tables |
| _dsc_feature_level | 0 | controls the feature level for deferred segment creation |
| _dskm_health_check_cnt | 20 | DiSKMon health check counter |
| _dskm_single_instance | FALSE | DSKM and Diskmon operating in Single Instance mode |
| _dss_cache_flush | FALSE | enable full cache flush for parallel execution |
| _dss_cache_flush_threshold | 1 | threshold when thread ckpt considered over obj ckpt |
| _dtree_area_size | 131072 | size of Decision Tree Classification work area |
| _dtree_binning_enabled | TRUE | Decision Tree Binning Enabled |
| _dtree_max_surrogates | 1 | maximum number of surrogates |
| _dtree_pruning_enabled | TRUE | Decision Tree Pruning Enabled |
| _dummy_instance | FALSE | dummy instance started by RMAN |
| _dump_10261_level | 0 | Dump level for event 10261, 1=>minimal dump 2=>top pga dump |
| _dump_common_subexpressions | FALSE | dump common subexpressions |
| _dump_connect_by_loop_data | FALSE | dump connect by loop error message into trc file |
| _dump_cursor_heap_sizes | FALSE | dump comp/exec heap sizes to tryace file |
| _dump_interval_limit | 120 | trace dump time interval limit (in seconds) |
| _dump_max_limit | 5 | max number of dump within dump interval |
| _dump_qbc_tree | 0 | dump top level query parse tree to trace |
| _dump_rcvr_ipc | TRUE | if TRUE enables IPC dump at instance eviction time |
| _dump_scn_increment_stack | Dumps scn increment stack per session | |
| _dump_system_state_scope | local | scope of sysstate dump during instance termination |
| _dump_trace_scope | global | scope of trace dump during a process crash |
| _duplicated_table_complete_refresh_percent | 50 | percent threshold for duplicated table to do complete refresh |
| _dupt_noupdate | 0 | disable duplicated table updates |
| _dynamic_hash_bucket_array | TRUE | dynamic hash bucket array |
| _dynamic_processes_force_timeout | 6 | dynamic process force timeout |
| _dynamic_processes_max_oom_timeout | 300 | dynamic process max timeout for out of memory |
| _dynamic_processes_wait_timeout | 100 | dynamic process wait timeout for new process |
| _dynamic_rls_policies | TRUE | rls policies are dynamic |
| _dynamic_sequence_cache | TRUE | Enable/disable sequence dynamic cache sizing |
| _dynamic_sequence_cache_max | 1000000 | Sequence dynamic cache maximum size |
| _dynamic_sequence_cache_scale | 10 | Max scale factor for dynamic sequence cache size |
| _dynamic_sessions_force_timeout | 30 | dynamic session force timeout |
| _dynamic_sessions_inc_count | 1000 | dynamic session increment count |
| _dynamic_sessions_max_oom_timeout | 300 | dynamic session max timeout for out of memory |
| _dynamic_sessions_min_force_timeout | 5 | dynamic min session force timeout |
| _dynamic_sessions_wait_timeout | 100 | dynamic session wait timeout for new session |
| _dynamic_share_range_factor | 2 | dynamic share range factor |
| _dynamic_stats_threshold | 30 | delay threshold (in seconds) between sending statistics messages |
| _early_flush_delta | 0 | SCN delta to trigger early log flush |
| _edition_enable_oracle_users | Edition enable Oracle supplied users | |
| _eighteenth_spare_parameter | eighteenth spare parameter - integer | |
| _eighteenth_spare_pdb_parameter | eighteenth spare pdb parameter - integer | |
| _eighth_spare_pdb_parameter | eighth spare pdb parameter - integer | |
| _eightieth_spare_parameter | eightieth spare parameter - integer | |
| _eighty-eighth_spare_parameter | eighty-eighth spare parameter - string | |
| _eighty-fifth_spare_parameter | eighty-fifth spare parameter - string | |
| _eighty-ninth_spare_parameter | eighty-ninth spare parameter - string | |
| _eighty-seventh_spare_parameter | eighty-seventh spare parameter - string | |
| _eighty-sixth_spare_parameter | eighty-sixth spare parameter - string | |
| _eighty-third_spare_parameter | eighty-third spare parameter - string | |
| _eleventh_spare_parameter | eleventh spare parameter - integer | |
| _eleventh_spare_pdb_parameter | eleventh spare pdb parameter - integer | |
| _eliminate_common_subexpr | TRUE | enables elimination of common sub-expressions |
| _emon_max_active_connections | 256 | maximum open connections to clients per emon |
| _emon_outbound_connect_timeout | 7200000 | timeout for completing connection set up to clients |
| _emon_pool_inc | 4 | increment in EMON slaves per pool type |
| _emon_pool_max | 16 | maximum number of EMON slaves per pool type |
| _emon_pool_min | 4 | minimum number of EMON slaves per pool type |
| _emon_regular_ntfn_slaves | 4 | number of EMON slaves doing regular database notifications |
| _emon_send_timeout | 7200000 | send timeout after which the client is unregistered |
| _emx_control | 0 | EM Express control (internal use only) |
| _emx_max_sessions | 128 | Maximum number of sessions in the EM Express cache |
| _emx_session_timeout | 3600 | Session timeout (sec) in the EM Express cache |
| _ena_storage_lmt | DEFAULT | Enable storage clause for LMT |
| _enable_12g_bft | TRUE | enable 12g bigfile tablespace |
| _enable_Front_End_View_Optimization | 1 | enable front end view optimization |
| _enable_NUMA_interleave | TRUE | Enable NUMA interleave mode |
| _enable_NUMA_optimization | FALSE | Enable NUMA specific optimizations |
| _enable_NUMA_support | FALSE | Enable NUMA support and optimizations |
| _enable_asyncvio | FALSE | enable asynch vectored I/O |
| _enable_automatic_maintenance | 1 | if 1, Automated Maintenance Is Enabled |
| _enable_automatic_sqltune | TRUE | Automatic SQL Tuning Advisory enabled parameter |
| _enable_block_level_transaction_recovery | TRUE | enable block level recovery |
| _enable_buffer_header_history | TRUE | if TRUE, records operation history in buffer headers |
| _enable_bug_29838374 | 0 | enable/disable bug fix 29838374 |
| _enable_cdb_all_sync | FALSE | Is CDB-wide ALL sync enabled |
| _enable_cdb_upgrade_capture | FALSE | Enable capture of CDB upgrade |
| _enable_check_truncate | TRUE | enable checking of corruption caused by canceled truncate |
| _enable_columnar_cache | 1 | Enable Columnar Flash Cache Rewrite |
| _enable_containers_subquery | TRUE | enable transformation to containers() sub query |
| _enable_cscn_caching | FALSE | enable commit SCN caching for all transactions |
| _enable_dbwr_auto_tracing | 0 | enable dbwriter auto-tracing |
| _enable_dbwr_parallel_invalidations | TRUE | if TRUE, enables flush and invalidate by DBWRs |
| _enable_ddl_wait_lock | TRUE | use this to turn off ddls with wait semantics |
| _enable_default_affinity | 0 | enable default implementation of hard affinity osds |
| _enable_default_temp_threshold | TRUE | Enable Default Tablespace Utilization Threshold for UNDO Tablespaces |
| _enable_default_undo_threshold | TRUE | Enable Default Tablespace Utilization Threshold for TEMPORARY Tablespaces |
| _enable_dml_lock_escalation | TRUE | enable dml lock escalation against partitioned tables if TRUE |
| _enable_drop_clone | FALSE | Is drop of a Root Clone allowed |
| _enable_dynamic_processes | FALSE | dynamic process SOs |
| _enable_dynamic_sessions | FALSE | dynamic session SOs |
| _enable_editions_for_users | FALSE | enable editions for all users |
| _enable_event_ports | TRUE | Enable/Disable event ports |
| _enable_exchange_validation_using_check | TRUE | use check constraints on the table for validation |
| _enable_fast_file_zero | TRUE | enable fast file zero code path |
| _enable_fast_ref_after_mv_tbs | FALSE | enable fast refresh after move tablespace |
| _enable_ffw | TRUE | FAL FORWARDING |
| _enable_flash_logging | TRUE | Enable Exadata Smart Flash Logging |
| _enable_fsdirect_odmlib | TRUE | enable or disable FsDirect static ODM library |
| _enable_fsdirect_pin | TRUE | enable direct pin of FsDirect blocks |
| _enable_fsdirect_rac | FALSE | enable FsDirect in RAC |
| _enable_gsm_listener_networks | TRUE | gsm listener in listener networks |
| _enable_guid_endpoint_service | TRUE | Enable service functionality for GUID service |
| _enable_hash_overflow | FALSE | TRUE - enable hash cluster overflow based on SIZE |
| _enable_heatmap_internal | FALSE | heatmap related - to be used by oracle dev only |
| _enable_http_digest_generation | TRUE | generation of the HTTP Digest verifier is enabled |
| _enable_hwm_sync | TRUE | enable HWM synchronization |
| _enable_iee_stats | TRUE | enables IEE stats gathering |
| _enable_ignorable_error_capture | FALSE | Capture statement if error is ignorable |
| _enable_ilm_flush_stats | TRUE | Enable ILM Stats Flush |
| _enable_ilm_testflush_stats | FALSE | Enable Test ILM Stats Flush |
| _enable_increase_lms_process | TRUE | set to true to allow _increase_lms_process changes |
| _enable_ios_spm | FALSE | Allow Split Mirror operations via IOServer |
| _enable_kernel_io_outliers | FALSE | enable kernel I/O outlier feature |
| _enable_kqf_purge | TRUE | Enable KQF fixed runtime table purge |
| _enable_list_io | FALSE | Enable List I/O |
| _enable_load_from_clone | TRUE | Is load from a Root Clone allowed |
| _enable_log_memory_protection_key | FALSE | enable memory protection keys (log) |
| _enable_memory_protection_keys | FALSE | Enable memory protection keys usage |
| _enable_metrics_allpdb | TRUE | Enable/Disable Metrics for Root and all PDBs if applicable |
| _enable_metrics_pdb | FALSE | Enable/Disable Metrics for this Non-Root PDB |
| _enable_midtier_affinity | TRUE | enable midtier affinity metrics processing |
| _enable_minscn_cr | TRUE | enable/disable minscn optimization for CR |
| _enable_mle | TRUE | enable MLE |
| _enable_module_match | TRUE | Is match of module name enforced |
| _enable_multiple_fgprepares | FALSE | Allow concurrent PREPAREs on the same database |
| _enable_nativenet_tcpip | FALSE | Enable skgxp driver usage for native net |
| _enable_nvm_dispatcher | 0 | Enable NVM Dispatcher and/or DMPROC |
| _enable_obj_queues | TRUE | enable object queues |
| _enable_offloaded_writes | FALSE | Enable offloaded writes for Unit Test |
| _enable_online_index_without_s_locking | TRUE | Allow online index creation algorithm without S DML lock |
| _enable_os_cpu_rm | FALSE | enable internal OSCPURM testing |
| _enable_parallel_dml | FALSE | enables or disables parallel dml |
| _enable_partial_sync | FALSE | Is partial sync of a Federation allowed |
| _enable_pdb_close_abort | TRUE | Enable PDB shutdown abort (close abort) |
| _enable_pdb_close_noarchivelog | FALSE | Enable PDB close abort with no archive logging |
| _enable_pdb_isolation | FALSE | Enables Pluggable Database isolation inside a CDB |
| _enable_pdb_process_limit | TRUE | Enable process limit as the number of sessions in the PDB. |
| _enable_pdb_skiplist_recovery | TRUE | Enable pdb skip list setup during media recovery. |
| _enable_pdb_skiplist_redogen | TRUE | Enable pdb skip list setup during redo generation. |
| _enable_per_container_acl | FALSE | Enable Per Container ACL |
| _enable_perpdb_suplog | FALSE | per pdb supplemental logging |
| _enable_plcmnt_pol_usage | FALSE | enable placement policy usage |
| _enable_pluggable_database | TRUE | Enable Pluggable Database |
| _enable_pmem_direct_cache | TRUE | if TRUE, enable PMEM direct mapped buffers |
| _enable_pmem_exchange | TRUE | if TRUE, enable PMEM exchange during promotion |
| _enable_pmem_prefetch | FALSE | if TRUE, enable prefecting from PMEM |
| _enable_pmo_outside_begin_end | TRUE | Enable PMO outside begin-end block |
| _enable_proxy_distr_txn | TRUE | Enable Distributed Transaction in Proxy PDB |
| _enable_ptime_update_for_sys | FALSE | Enable/Disable update of user$ for sys |
| _enable_query_rewrite_on_remote_objs | TRUE | mv rewrite on remote table/view |
| _enable_redo_global_post | FALSE | LGWR post globally on write |
| _enable_refresh_schedule | TRUE | enable or disable MV refresh scheduling (revert to 9.2 behavior) |
| _enable_rejection_cache | TRUE | Enable ASSM rejection cache |
| _enable_reliable_latch_waits | TRUE | Enable reliable latch waits |
| _enable_rename_user | FALSE | enable RENAME-clause using ALTER USER statement |
| _enable_replay_upgrade_diag | TRUE | Enable diagnostics for Replay Upgrade |
| _enable_rlb | TRUE | enable RLB metrics processing |
| _enable_row_shipping | TRUE | use the row shipping optimization for wide table selects |
| _enable_schema_synonyms | FALSE | enable DDL operations (e.g. creation) involving schema synonyms |
| _enable_scn_wait_interface | TRUE | use this to turn off scn wait interface in kta |
| _enable_secure_sub_role | FALSE | Disallow enabling of secure sub roles |
| _enable_securefile_flashback_opt | FALSE | Enable securefile flashback optimization |
| _enable_sensitive_trace | FALSE | enable traces to contain sensitive information |
| _enable_separable_transactions | FALSE | enable/disable separable transactions |
| _enable_shared_pool_durations | TRUE | temporary to disable/enable kgh policy |
| _enable_shared_server_sizing | TRUE | Enable sizing manager for shared servers |
| _enable_shared_server_sizing_slope | FALSE | Enable utility slope in sizing manager for shared servers |
| _enable_shared_server_vector_io | FALSE | Enable shared server vector I/O |
| _enable_single_dgprepare | FALSE | Disable concurrent PREPAREs in same disk group |
| _enable_space_preallocation | 3 | enable space pre-allocation |
| _enable_spacebg | TRUE | enable space management background task |
| _enable_sysaux_gdr | FALSE | GDR: Enable on SYSAUX |
| _enable_system_app | 2 | Enable System app for CDB-wide common users |
| _enable_tablespace_alerts | TRUE | enable tablespace alerts |
| _enable_tcpinfo_statistics | 238 | Enable TCP Info Statistics |
| _enable_tenant_id_check | FALSE | Enable Tenant Id check for database link |
| _enable_tenant_id_transfer | FALSE | Enable Tenant Id transfer |
| _enable_thr_kill | TRUE | Enable/Disable thread directed signalling |
| _enable_type_dep_selectivity | TRUE | enable type dependent selectivity estimates |
| _enable_unified_memory | FALSE | Enable use of unified PGA pool |
| _enable_verbose_gdr | FALSE | GDR: Enable verbose |
| _enable_view_pdb | TRUE | Enable Proxy PDB support |
| _endprot_chunk_comment | chk 10235 dflt | chunk comment for selective overrun protection |
| _endprot_heap_comment | hp 10235 dflt | heap comment for selective overrun protection |
| _endprot_stack_segments | FALSE | overrun protection for kgh stack segments |
| _endprot_subheaps | TRUE | selective overrun protection for subeheaps |
| _enforce_minimum_password_rollover_time | TRUE | Enforce minimum PASSWORD_ROLLOVER_TIME of one hour |
| _enqueue_deadlock_detect_all_global_locks | FALSE | enable deadlock detection on all global enqueues |
| _enqueue_deadlock_scan_secs | 0 | deadlock scan interval |
| _enqueue_deadlock_time_sec | 5 | requests with timeout <= this will not have deadlock detection |
| _enqueue_debug_multi_instance | FALSE | debug enqueue multi instance |
| _enqueue_hash | 1043 | enqueue hash table length |
| _enqueue_hash_chain_latches | 4 | enqueue hash chain latches |
| _enqueue_locks | 6060 | locks for managed enqueues |
| _enqueue_paranoia_mode_enabled | FALSE | enable enqueue layer advanced debugging checks |
| _enqueue_resources | 2436 | resources for enqueues |
| _enqueue_scan_interval | 0 | enqueue scan interval |
| _enqueue_sync_retry_attempts | 15 | max number of times the bg process to retry synchronous enqueue open if it failed because master could not allocate memory |
| _enqueue_sync_sim_mem_error | FALSE | simulate master instance running out of memory when synchronously getting a remotely mastered enqueue |
| _enqueue_wall_clock_time | FALSE | if TRUE, use KSUFTIME timer |
| _error_row_predicate_evaluation | AUTO | skip predicate evaluation for error rows |
| _event_port_opts | Options for event ports | |
| _evt_system_event_propagation | TRUE | disable system event propagation |
| _exa_pmemlog_threshold_usec | 100 | maximum i/o time (usecs) for enabled Exadata PMEMLog |
| _exadata_feature_on | FALSE | Exadata Feature On |
| _exclude_seed_cdb_view | TRUE | exclude PDB$SEED from CDB View Result |
| _expand_aggregates | TRUE | expand aggregates |
| _explain_rewrite_mode | FALSE | allow additional messages to be generated during explain rewrite |
| _expression_tracking_elem_per_bucket | 30 | Number of expression usage statistics elements per hash bucket |
| _expression_tracking_latch_count | 16 | Number of latches for tracking expression usage statistics |
| _extended_pruning_enabled | TRUE | do runtime pruning in iterator if set to TRUE |
| _external_scn_activity_tracking | TRUE | enable/disable external scn activity tracking |
| _external_scn_logging_threshold_seconds | 86400 | High delta SCN threshold in seconds |
| _external_scn_rejection_delta_threshold_minutes | 0 | external SCN rejection delta threshold in minutes |
| _external_scn_rejection_threshold_hours | 24 | Lag in hours between max allowed SCN and an external SCN |
| _external_table_hive_partition_restricted | TRUE | restrict external tabel hive partition methods to Hive supported |
| _external_table_smart_scan | HADOOP_ONLY | External Table Smart Scan |
| _extra_lmn_enabled | TRUE | suppl logging for extra record enabled |
| _failover_svrcsum | FALSE | enable server checksum to optimize failover |
| _fair_remote_cvt | FALSE | if TRUE enables fair remote convert |
| _fairness_threshold | 2 | number of times to CR serve before downgrading lock |
| _fast_cr_clone | TRUE | enable fast cr clone feature |
| _fast_cursor_reexecute | FALSE | use more memory in order to get faster execution |
| _fast_dual_enabled | TRUE | enable/disable fast dual |
| _fast_full_scan_enabled | TRUE | enable/disable index fast full scan |
| _fast_index_maintenance | TRUE | fast global index maintenance during PMOPs |
| _fast_psby_conversion | TRUE | Enable fast physical standby conversion |
| _fastpin_enable | 1 | enable reference count based fast pins |
| _fatalprocess_redo_dump_time_limit | 0 | time limit, in secs, for diagnostic redo dumps by a fatal process |
| _fb_log_max_rereads | 100 | Maximum number of rereads after reading a corrupt flashback block |
| _fb_recovery_slave_count | 0 | Number of recovery slaves to be used by the FLASHBACK DATABASE |
| _fbda_adv_gbl_bscn_bcast_interval | 0 | flashback archiver broadcast interval to advance global barrier SCN |
| _fbda_busy_percentage | 0 | flashback archiver busy percentage |
| _fbda_debug_assert | 0 | flashback archiver debug assert for testing |
| _fbda_debug_mode | 0 | flashback archiver debug event for testing |
| _fbda_global_bscn_lag | 0 | flashback archiver global barrier scn lag |
| _fbda_inline_percentage | 0 | flashback archiver inline percentage |
| _fbda_rac_inactive_limit | 0 | flashback archiver rac inactive limit |
| _fbda_tcrv_cleanup_lag | 3600 | flashback archiver tcrv cleanup lag in secs |
| _federation_max_root_clones | 4000 | Maximum number of Root Clones per Root |
| _federation_script | FALSE | Running a Federation script |
| _ffs_in_range_scan_threshold | 50 | threshold of min percentage of block read to use ffs in rs |
| _fg_fast_sync_slack_usecs | 1 | DAX log file sync sleep slack time |
| _fg_fast_sync_sleep_target_pct | 50 | DAX log file sync sleep target pct |
| _fg_fast_sync_sleep_usecs | 0 | DAX log file sync sleep time |
| _fg_fast_sync_spin_usecs | 100 | DAX log file sync spin time |
| _fg_iorm_slaves | 1 | ForeGround I/O slaves for IORM |
| _fg_log_checksum | TRUE | Checksum redo in foreground process |
| _fg_sync_sleep_usecs | 0 | Log file sync via usleep |
| _fic_algorithm_set | automatic | Set Frequent Itemset Counting Algorithm |
| _fic_area_size | 131072 | size of Frequent Itemset Counting work area |
| _fic_min_bmsize | 1024 | Frequent Itemset Counting Minimum BITMAP Size |
| _fifteenth_spare_parameter | fifteenth spare parameter - integer | |
| _fifteenth_spare_pdb_parameter | fifteenth spare pdb parameter - integer | |
| _fifth_spare_parameter | fifth spare parameter - integer | |
| _fifth_spare_pdb_parameter | fifth spare pdb parameter - integer | |
| _fiftieth_spare_parameter | fiftieth spare parameter - integer | |
| _fiftieth_spare_pdb_parameter | fiftieth spare pdb parameter - string list | |
| _fifty-eighth_spare_parameter | fifty-eighth spare parameter - integer | |
| _fifty-eighth_spare_pdb_parameter | fifty-eighth spare pdb parameter - boolean | |
| _fifty-fifth_spare_parameter | fifty-fifth spare parameter - integer | |
| _fifty-fifth_spare_pdb_parameter | fifty-fifth spare pdb parameter - boolean | |
| _fifty-first_spare_parameter | fifty-first spare parameter - integer | |
| _fifty-fourth_spare_parameter | fifty-fourth spare parameter - integer | |
| _fifty-fourth_spare_pdb_parameter | fifty-fourth spare pdb parameter - boolean | |
| _fifty-ninth_spare_parameter | fifty-ninth spare parameter - integer | |
| _fifty-ninth_spare_pdb_parameter | fifty-ninth spare pdb parameter - boolean | |
| _fifty-second_spare_parameter | fifty-second spare parameter - integer | |
| _fifty-seventh_spare_parameter | fifty-seventh spare parameter - integer | |
| _fifty-seventh_spare_pdb_parameter | fifty-seventh spare pdb parameter - boolean | |
| _fifty-sixth_spare_parameter | fifty-sixth spare parameter - integer | |
| _fifty-sixth_spare_pdb_parameter | fifty-sixth spare pdb parameter - boolean | |
| _fifty-third_spare_parameter | fifty-third spare parameter - integer | |
| _fifty-third_spare_pdb_parameter | fifty-third spare pdb parameter - boolean | |
| _file_offline_sync_timeout | 900 | Timeout to sync file offline enqueue (secs) |
| _file_set_enqueue_timeout | 1200 | Timeout to acquire file set enqueue (secs) |
| _file_size_increase_increment | 67108864 | Amount of file size increase increment, in bytes |
| _filemap_dir | FILEMAP directory | |
| _first_k_rows_dynamic_proration | TRUE | enable the use of dynamic proration of join cardinalities |
| _first_spare_pdb_parameter | first spare pdb parameter - integer | |
| _fix_control | bug fix control parameter | |
| _fix_fuzzy_scn | FALSE | fix fuzzy SCN |
| _fixup_all_apps | FALSE | Callback to fix up replay state of all applications |
| _fixup_app_pdb_status_in_root | application name whose PDB application status should be fixed up | |
| _fixup_cdb_apps | FALSE | Callback to fix up replay state of CDB-wide applications |
| _flashback_11_1_block_new_opt | FALSE | use 11.1 flashback block new optimization scheme |
| _flashback_allow_noarchivelog | FALSE | Allow enabling flashback on noarchivelog database |
| _flashback_archiver_partition_size | 0 | flashback archiver table partition size |
| _flashback_barrier_interval | 1800 | Flashback barrier interval in seconds |
| _flashback_copy_latches | 10 | Number of flashback copy latches |
| _flashback_database_test_only | FALSE | Run Flashback Database in test mode |
| _flashback_delete_chunk_MB | 128 | Amount of flashback log (in MB) to delete in one attempt |
| _flashback_dynamic_enable | TRUE | enable flashback enable code path |
| _flashback_dynamic_enable_failure | 0 | Simulate failures during dynamic enable |
| _flashback_enable_ra | TRUE | Flashback enable read ahead |
| _flashback_format_chunk_mb | 4 | Chunk mega-bytes for formatting flashback logs using sync write |
| _flashback_format_chunk_mb_dwrite | 16 | Chunk mega-bytes for formatting flashback logs using delayed write |
| _flashback_fuzzy_barrier | TRUE | Use flashback fuzzy barrier |
| _flashback_generation_buffer_size | 16777216 | flashback generation buffer size |
| _flashback_hint_barrier_percent | 20 | Flashback hint barrier percent |
| _flashback_log_io_error_behavior | 0 | Specify Flashback log I/O error behavior |
| _flashback_log_min_size | 100 | Minimum flashback log size |
| _flashback_log_rac_balance_factor | 10 | flashback log rac balance factor |
| _flashback_log_size | 1000 | Flashback log size |
| _flashback_logfile_enqueue_timeout | 600 | flashback logfile enqueue timeout for opens |
| _flashback_marker_cache_enabled | TRUE | Enable flashback database marker cache |
| _flashback_marker_cache_size | 328 | Size of flashback database marker cache |
| _flashback_marker_for_every_grp | FALSE | generate a new flashback marker for every GRP |
| _flashback_max_log_size | 0 | Maximum flashback log size in bytes (OS limit) |
| _flashback_max_n_log_per_thread | 2048 | Maximum number of flashback logs per flashback thread |
| _flashback_max_standby_sync_span | 300 | Maximum time span between standby recovery sync for flashback |
| _flashback_n_log_per_thread | 128 | Desired number of flashback logs per flashback thread |
| _flashback_prepare_log | TRUE | Prepare Flashback logs in the background |
| _flashback_reclaim_monitor_window | 7 | Proactive flashback logs reclaimation window |
| _flashback_reclaim_speed_up | FALSE | Proactive flashback logs reclaimation speed up |
| _flashback_size_based_on_redo | TRUE | Size new flashback logs based on average redo log size |
| _flashback_standby_barrier_interval | 1 | Flashback standby barrier interval in seconds |
| _flashback_standby_check_barrier_MIRA | 20 | Flashback standby check barrier generation in seconds |
| _flashback_standby_check_minpfh_MIRA | 15 | Flashback standby check minimum high fuzzy scn in seconds |
| _flashback_stby_support_mira | TRUE | Flashback database on standby supports MIRA |
| _flashback_validate_controlfile | FALSE | validate flashback pointers in controlfile for 11.2.0.2 database |
| _flashback_verbose_info | FALSE | Print verbose information about flashback database |
| _flashback_write_max_loop_limit | 10 | Flashback writer loop limit before it returns |
| _flush_ilm_stats | 0 | flush ilm stats |
| _flush_log_buffer_force | FALSE | Flush log buffer force |
| _flush_log_buffer_timeout | 0 | Flush log buffer wait time in seconds |
| _flush_plan_in_awr_sql | 0 | Plan is being flushed from an AWR flush SQL |
| _flush_redo_to_standby | 0 | Flush redo to standby test parameter |
| _flush_undo_after_tx_recovery | TRUE | if TRUE, flush undo buffers after TX recovery |
| _fob_dgaalloc | TRUE | Fob structure allocation from Domain Global Area memory |
| _fob_ospshare | TRUE | Fob structure and file descriptor sharing between threads with-in an OSP in MPMT environment |
| _force_arch_compress | 0 | Archive Compress all newly created compressed tables |
| _force_cloud_on | FALSE | simulate EHCC code path enable in Cloud Database |
| _force_containers_subquery | FALSE | force transformation to containers() sub query |
| _force_datefold_trunc | FALSE | force use of trunc for datefolding rewrite |
| _force_dax_io_err | 0 | Force I/O error on online/standby redo log |
| _force_hash_join_spill | FALSE | force hash join to spill to disk |
| _force_hsc_compress | FALSE | compress all newly created tables |
| _force_java_pool_zero | FALSE | force java pool size to be zero bytes |
| _force_local_temp | FALSE | For testing only Forces temporary tablespaces to be LOCAL |
| _force_logging_in_upgrade | TRUE | force logging during upgrade mode |
| _force_oltp_compress | FALSE | OLTP Compress all newly created compressed tables |
| _force_oltp_update_opt | TRUE | OLTP Compressed row optimization on update |
| _force_partial_compress | FALSE | Force using OLTP Partial Compression |
| _force_pmem_direct_mapped_cache_scan | TRUE | if TRUE, force PMEM mapped direct path scan to cache path scan |
| _force_rewrite_enable | FALSE | control new query rewrite features |
| _force_slave_mapping_intra_part_loads | FALSE | Force slave mapping for intra partition loads |
| _force_standard_compile | FALSE | force compilation of STANDARD |
| _force_sys_compress | TRUE | Sys compress |
| _force_temp_space_cleanup | TRUE | Force temp space cleanup after PDB close |
| _force_temptables_for_gsets | FALSE | executes concatenation of rollups using temp tables |
| _force_tmp_segment_loads | FALSE | Force tmp segment loads |
| _forced_endian_type | UNKNOWN | Forced endian type of data dictionary |
| _fortieth_spare_parameter | fortieth spare parameter - integer | |
| _fortieth_spare_pdb_parameter | fortieth spare pdb parameter - string | |
| _forty-eighth_spare_parameter | forty-eighth spare parameter - integer | |
| _forty-eighth_spare_pdb_parameter | forty-eighth spare pdb parameter - string list | |
| _forty-fifth_spare_parameter | forty-fifth spare parameter - integer | |
| _forty-fifth_spare_pdb_parameter | forty-fifth spare pdb parameter - string list | |
| _forty-first_spare_parameter | forty-first spare parameter - integer | |
| _forty-first_spare_pdb_parameter | forty-first spare pdb parameter - string list | |
| _forty-fourth_spare_parameter | forty-fourth spare parameter - integer | |
| _forty-fourth_spare_pdb_parameter | forty-fourth spare pdb parameter - string list | |
| _forty-ninth_spare_parameter | forty-ninth spare parameter - integer | |
| _forty-ninth_spare_pdb_parameter | forty-ninth spare pdb parameter - string list | |
| _forty-second_spare_parameter | forty-second spare parameter - integer | |
| _forty-second_spare_pdb_parameter | forty-second spare pdb parameter - string list | |
| _forty-seventh_spare_parameter | forty-seventh spare parameter - integer | |
| _forty-seventh_spare_pdb_parameter | forty-seventh spare pdb parameter - string list | |
| _forty-sixth_spare_parameter | forty-sixth spare parameter - integer | |
| _forty-sixth_spare_pdb_parameter | forty-sixth spare pdb parameter - string list | |
| _forty-third_spare_parameter | forty-third spare parameter - integer | |
| _forty-third_spare_pdb_parameter | forty-third spare pdb parameter - string list | |
| _forwarded_2pc_threshold | 10 | auto-tune threshold for two-phase commit rate across RAC instances |
| _fourteenth_spare_pdb_parameter | fourteenth spare pdb parameter - integer | |
| _fourth_spare_pdb_parameter | fourth spare pdb parameter - integer | |
| _frame_cache_time | 0 | number of seconds a cached frame page stay in cache. |
| _freeze_kgh_timestamp | FALSE | prevent heap manager timestamp from advancing |
| _fsdirect_fast_file_create | TRUE | Allow optimized file creation path for FsDirects |
| _full_diag_on_rim | FALSE | rim nodes have full DIA* function |
| _full_pwise_join_enabled | TRUE | enable full partition-wise join when TRUE |
| _fusion_security | TRUE | Fusion Security |
| _gas_partition_size | 0 | Global Address Space Partition Size for each instance |
| _gby_hash_aggregation_enabled | TRUE | enable group-by and aggregation using hash scheme |
| _gby_onekey_enabled | TRUE | enable use of one comparison of all group by keys |
| _gby_vector_aggregation_enabled | TRUE | enable group-by and aggregation using vector scheme |
| _gc_affinity_locking | TRUE | if TRUE, enable object affinity |
| _gc_affinity_locks | TRUE | if TRUE, get affinity locks |
| _gc_affinity_ratio | 50 | dynamic object affinity ratio |
| _gc_anti_lock_ratio | 66 | dynamic object anti-lock ratio |
| _gc_async_send | TRUE | if TRUE, send blocks asynchronously |
| _gc_bg_merge | TRUE | if TRUE, merge pi buffers in the background |
| _gc_blocking_pins | FALSE | if TRUE, record a histogram of blocking pins |
| _gc_buckets_per_latch | 0 | number of hash buckets per latch |
| _gc_bypass_readers | TRUE | if TRUE, modifications bypass readers |
| _gc_check_bscn | TRUE | if TRUE, check for stale blocks |
| _gc_coalesce_recovery_reads | TRUE | if TRUE, coalesce recovery reads |
| _gc_cr_server_read_wait | TRUE | if TRUE, cr server waits for a read to complete |
| _gc_defer_ping_index_only | TRUE | if TRUE, restrict deferred ping to index blocks only |
| _gc_defer_time | 0 | how long to defer pings for hot buffers in microseconds |
| _gc_delay_ping | TRUE | if TRUE, delay pings to hot blocks |
| _gc_disable_cell_populate | FALSE | if TRUE, disable cell ram cache populate |
| _gc_disable_s_lock_brr_ping_check | TRUE | if TRUE, disable S lock BRR ping check for lost write protect |
| _gc_down_convert_after_keep | TRUE | if TRUE, down-convert lock after recovery |
| _gc_down_convert_after_write | TRUE | if TRUE, down-convert lock after a write |
| _gc_drm_windows | 8 | number of DRM windows |
| _gc_dump_remote_lock | TRUE | if TRUE, dump remote lock |
| _gc_element_percent | 105 | global cache element percent |
| _gc_enable_cr_bypass | TRUE | if TRUE, enable CR bypass mechanism |
| _gc_fast_index_split_timeout | 100 | fast index split wait timeout |
| _gc_fast_index_split_wait | 0 | fast index split wait usn array size |
| _gc_fg_merge | TRUE | if TRUE, merge pi buffers in the foreground |
| _gc_fg_spin_time | 0 | foreground msgq spin time |
| _gc_first_dirty_merge | TRUE | if TRUE, merge with a pi after first dirty |
| _gc_flush_during_affinity | TRUE | if TRUE, flush during affinity |
| _gc_fusion_compression | 1024 | compress fusion blocks if there is free space |
| _gc_global_checkpoint_scn | TRUE | if TRUE, enable global checkpoint scn |
| _gc_global_lru | AUTO | turn global lru off, make it automatic, or turn it on |
| _gc_global_lru_touch_count | 5 | global lru touch count |
| _gc_global_lru_touch_time | 60 | global lru touch time in seconds |
| _gc_integrity_checks | 1 | set the integrity check level |
| _gc_interconnect_checksum | FALSE | if TRUE, checksum interconnect blocks |
| _gc_keep_recovery_buffers | TRUE | if TRUE, make recovery buffers current |
| _gc_keep_undo_recovery_buffers | TRUE | if TRUE, make recovery undo buffers current |
| _gc_latches | 32 | number of latches per LMS process |
| _gc_lease_time | 10000 | lease time for memoptimize reads |
| _gc_log_flush | TRUE | if TRUE, flush redo log before a current block transfer |
| _gc_max_downcvt | 4096 | maximum downconverts to process at one time |
| _gc_max_reg_sz | 68719476736 | maximum length for memory registration |
| _gc_msgq_buffers | 0 | set number of MSGQ buffers |
| _gc_no_fairness_for_clones | TRUE | if TRUE, no fairness if we serve a clone |
| _gc_numa_lock_elements | FALSE | if TRUE, numa aware lock element distribution |
| _gc_object_queue_max_length | 0 | maximum length for an object queue |
| _gc_override_force_cr | TRUE | if TRUE, try to override force-cr requests |
| _gc_partial_cleanout | TRUE | if TRUE, partial cleanout is enabled |
| _gc_persistent_read_mostly | TRUE | if TRUE, enable persistent read-mostly locking |
| _gc_policy_minimum | 1500 | dynamic object policy minimum activity per minute |
| _gc_policy_rm_dirty_percent | 1 | percent of cache which can be dirty for readmostly |
| _gc_policy_time | 20 | how often to make object policy decisions in minutes |
| _gc_rdma_connections | 8000 | maximum number of buffer cache RDMA connections |
| _gc_read_mostly_flush_check | FALSE | if TRUE, optimize flushes for read mostly objects |
| _gc_read_mostly_locking | TRUE | if TRUE, enable read-mostly locking |
| _gc_sanity_check_cr_buffers | FALSE | if TRUE, sanity check CR buffers |
| _gc_save_cleanout | FALSE | if TRUE, save cleanout to apply later |
| _gc_serve_from_flash_cache | FALSE | if TRUE, try to serve a flash cache buffer |
| _gc_skip_undo_disk_read | TRUE | if TRUE, skip the disk read for undo blocks |
| _gc_spin_time | 32 | rdma spin time |
| _gc_statistics | TRUE | global cache statistics level |
| _gc_temp_affinity | FALSE | if TRUE, enable global temporary affinity |
| _gc_trace_blocking_pins | FALSE | if TRUE, trace blocking pins |
| _gc_trace_freelist_empty | FALSE | if TRUE, dump a trace when we run out of lock elements |
| _gc_transfer_ratio | 75 | dynamic object read-mostly transfer ratio |
| _gc_try_to_skip_imc_flush | TRUE | if TRUE, try to skip an imc populate flush |
| _gc_undo_affinity | TRUE | if TRUE, enable undo affinity |
| _gc_undo_block_disk_reads | TRUE | if TRUE, enable undo block disk reads |
| _gc_undo_header_rdma_read | TRUE | if TRUE, rdma read of undo headers is enabled |
| _gc_undo_rdma_read | FALSE | if TRUE, rdma read of undo blocks is enabled |
| _gc_vector_read | TRUE | if TRUE, vector read current buffers |
| _gc_xmem_rdma | FALSE | if TRUE, xmem blocks rdma read is enabled |
| _gcr_cpu_consumer_dump_level | 0 | level of process dump performed for CPU consumers |
| _gcr_cpu_min_free | 10 | minimum amount of free CPU to flag an anomaly |
| _gcr_cpu_min_hard_limit | 0 | hard limit for min free CPU to flag high CPU |
| _gcr_css_group_large | size of large CSS group above which query/update disabled | |
| _gcr_css_group_query_boost | allowed number of serial multiple queries | |
| _gcr_css_group_try_lock_delay | minimum delay between group locking attempts, secs | |
| _gcr_css_group_update2_interval | interval between CSS group updates when busy, secs | |
| _gcr_css_group_update_interval | interval between CSS group updates, secs | |
| _gcr_css_use_2group_lock | TRUE | if FALSE, GCR will not try to lock 2 CSS groups at the same time |
| _gcr_disabled_actions | gcr disabled actions list | |
| _gcr_disabled_metrics | gcr disabled metrics list | |
| _gcr_dump_cpu_consumers | FALSE | if TRUE, enable dumps of CPU consumers |
| _gcr_enable_async_slaves | TRUE | if TRUE, GCR will spawn slave actions asynchronously |
| _gcr_enable_high_cpu_kill | FALSE | if TRUE, GCR may kill foregrounds under high load |
| _gcr_enable_high_cpu_rm | TRUE | if TRUE, GCR may enable a RM plan under high load |
| _gcr_enable_high_cpu_rt | TRUE | if TRUE, GCR may boost bg priority under high load |
| _gcr_enable_high_memory_kill | FALSE | if TRUE, GCR may kill foregrounds under high memory load |
| _gcr_enable_kill_inst_diags | FALSE | if TRUE, GCR will collect OS diags prior to kill instance |
| _gcr_enable_ktfbue_gather_stats | TRUE | enable/disable gather stats on X$KTFBUE |
| _gcr_enable_new_drm_check | TRUE | if FALSE, revert to old drm load metric |
| _gcr_enable_pdb_abort | FALSE | if TRUE, GCR will process pdb abort messages |
| _gcr_enable_statistical_cpu_check | TRUE | if FALSE, revert to old cpu load metric |
| _gcr_ges_cachedres_mult | 20 | ges cached resources multiplier |
| _gcr_ges_longchain_mult | 5 | ges longchain multiplier |
| _gcr_high_cpu_threshold | 10 | minimum amount of CPU process must consume to be kill target |
| _gcr_high_cpwt_threshold | 30 | longest tolerable ctwr process waits time |
| _gcr_high_fbwt_threshold | 300 | longest tolerable free buffer waits time |
| _gcr_high_hashlist_latch_nowait_misses | 10000 | highest hash list get nowait fails tolerable |
| _gcr_high_hashlist_latch_wait_misses | 10000 | highest hash list get wait fails tolerable |
| _gcr_high_lfsci_threshold | 1800 | longest tolerable log file switch (checkpoint incomplete) wait |
| _gcr_high_memory_threshold | 10 | minimum amount of Memory process must consume to be kill target |
| _gcr_max_rt_procs | maximum number of RT DLM processes allowed by GCR | |
| _gcr_mem_min_free | 10 | minimum amount of free memory to flag an anomaly |
| _gcr_min_free_memory_hard_limit | 1073741824 | hard limit for minimum free memory,for high memory systems |
| _gcr_tick | duration of time tick used by state machine, centisecs | |
| _gcr_use_css | TRUE | if FALSE, GCR wont register with CSS nor use any CSS feature |
| _gcs_cluster_flash_cache_mode | 0 | cluster flash cache mode |
| _gcs_cluster_flash_cache_persistency | FALSE | Enable cluster flash cache persistency (FALSE = disable (default), TRUE = enable |
| _gcs_cr_master_ping_remote | TRUE | if TRUE, cr request from master will ping the remote holder |
| _gcs_crslave_check_time | 10 | time interval to check for load on cr slaves in seconds |
| _gcs_crslave_longq_cnt | 2000 | long queue time threshold for cr slave |
| _gcs_crslave_longq_us | 1000 | long queue time for cr slave in microseconds |
| _gcs_current_rdma | 1 | if greater than 0, rdma read of current blocks is enabled |
| _gcs_current_rdma_grant_global | TRUE | if TRUE, enable rdma read of current blocks for global role |
| _gcs_disable_imc_preallocation | FALSE | disable preallocation for imc memory requirement in RAC |
| _gcs_disable_remote_handles | FALSE | disable remote client/shadow handles |
| _gcs_disable_skip_close_remastering | FALSE | if TRUE, disable skip close optimization in remastering |
| _gcs_dynamic_sga | FALSE | if TRUE, enable dynamic cache fusion resources in runtime |
| _gcs_dynamic_sga_preference | 0 | gcs dynamic sga preference |
| _gcs_dynamic_slaves | TRUE | if TRUE, it enables dynamic adjustment of the number of gcs slaves |
| _gcs_enable_private_iterator | TRUE | Enable private iterator for GCS locks |
| _gcs_fast_reconfig | TRUE | if TRUE, enable fast reconfiguration for gcs locks |
| _gcs_flash_cache_mode | 0 | flash cache mode |
| _gcs_freelists_alloc_percent | 0 | initial allocation of gcs freelists percentage of max usage |
| _gcs_integrity_checks | 1 | cache fusion integrity check level |
| _gcs_latches | 128 | number of gcs resource hash latches to be allocated per LMS process |
| _gcs_lsr_frequency | 60 | frequency of invoking lock state resolution in seconds |
| _gcs_min_cr_slaves | 0 | if non zero, it enables the minimum number of gcs slaves |
| _gcs_min_slaves | 0 | if non zero, it enables the minimum number of gcs slaves |
| _gcs_partial_open_mode | 1 | partial open cache fusion service in reconfiguration |
| _gcs_pkey_history | 16384 | number of pkey remastering history |
| _gcs_process_in_recovery | TRUE | if TRUE, process gcs requests during instance recovery |
| _gcs_recoverable_asserts | 0 | if non-zero, enable recoverable assert resolution |
| _gcs_res_hash_buckets | number of gcs resource hash buckets to be allocated | |
| _gcs_res_per_bucket | 4 | number of gcs resource per hash bucket |
| _gcs_reserved_resources | 400 | allocate the number of reserved resources in reconfiguration |
| _gcs_reserved_shadows | 400 | allocate the number of reserved shadows in reconfiguration |
| _gcs_resources | 0 | number of gcs resources to be allocated |
| _gcs_shadow_locks | 0 | number of gcs shadow locks to be allocated |
| _gcs_spin_check_instance_threshold | 30 | threshold timeout to dump proc in spin check in seconds |
| _gcs_spin_check_threshold | 4096 | spin check attempt count |
| _gcs_spin_check_time_interval | 300 | spin check time interval in seconds |
| _gcs_testing | 0 | GCS testing parameter |
| _gcs_trace_bucket | FALSE | TRUE: use GCS trace bucket and trace LOW by default, FALSE: use default bucket but trace only if enabled |
| _gcs_trace_bucket_size | LMS:1048576-RMV:1048576-CRV:1048576-DBW:524288 | size of the GCS trace bucket in bytes (format: "LMS: |
| _gcs_track_reliable_block_sends | FALSE | if TRUE, track block lost on reliable interconnect |
| _gcs_verify_antilock | FALSE | if TRUE, enable anti-lock check |
| _gdr_clear_active_only | FALSE | GDR: Clear active ranges only |
| _gdr_clear_inactive_only | FALSE | GDR: Clear inactive ranges only |
| _gdr_control_flags | 0 | gdr control flags |
| _gds_allow_nullkey | 0 | allow the use of nullable shard key columns |
| _gds_chunk_num | 0 | number of chunks in sharding environment |
| _gds_lddlid | 0 | the id of the last executed DDL query |
| _gds_max_chunk_num | 0 | max chunk_num used in sharding environment |
| _gds_shardgroup_id | 0 | shardgroup database is in |
| _generalized_pruning_enabled | TRUE | controls extensions to partition pruning for general predicates |
| _ges_dd_debug | 1 | if 1 or higher enables GES deadlock detection debug diagnostics |
| _ges_default_lmds | * | default lmds for enqueue hashing |
| _ges_designated_master | TRUE | designated master for GES and GCS resources |
| _ges_diagnostics | TRUE | if TRUE enables GES diagnostics |
| _ges_diagnostics_asm_dump_level | 11 | systemstate level on global enqueue diagnostics blocked by ASM |
| _ges_direct_free | FALSE | if TRUE, free each resource directly to the freelist |
| _ges_direct_free_res_type | string of resource types(s) to directly free to the freelist | |
| _ges_dump_open_locks | FALSE | if TRUE, dump open locks for the LCK process during shutdown |
| _ges_fggl | TRUE | DLM fg grant lock on/off |
| _ges_freeable_res_chunk_free | TRUE | if TRUE, free dynamic resource chunks which are freeable |
| _ges_freeable_res_chunk_free_interval | 180 | time interval for freeing freeable dynamic resource chunks |
| _ges_gather_res_reuse_stats | FALSE | if TRUE, gather resource reuse statistics |
| _ges_hash_groups | * | enqueue hash table groups |
| _ges_health_check | 0 | if greater than 0 enables GES system health check |
| _ges_lmd_mapping | * | enqueue to lmd mapping |
| _ges_mseq_demo | 0 | demo mseq wrap scenarios (dflt is 0) |
| _ges_nres_divide | 0 | how to divide number of enqueue resources among hash tables |
| _ges_num_blockers_to_kill | 1 | number of blockers to be killed for hang resolution |
| _ges_optimizations | 3 | GES optimizations level |
| _ges_resource_memory_opt | 4 | enable different level of ges res memory optimization |
| _ges_server_processes | 1 | number of background global enqueue server processes |
| _ges_vbfreelists | 0 | number of valueblock freelists (will be adjusted to power of 2) |
| _global_hang_analysis_interval_secs | 10 | the interval at which global hang analysis is run |
| _globaldict_analyzer_pct | 100 | Maximum percentage of unique values in analyzer phase for GD |
| _globaldict_chain_limit | 32 | Chain limit for global dictionary |
| _globaldict_check | 0 | Dictionary checking |
| _globaldict_chunk_minalloc | FALSE | Force minimum chunk allocation size |
| _globaldict_dbg | 0 | Global dictionary debug modes |
| _globaldict_enable | 2 | Enable segment dictionary |
| _globaldict_max_gdsize | 1073741824 | Maximum number of entries in a Global dictionary |
| _globaldict_reprobe_limit | 1 | Reprobe limit for global dictionary |
| _globaldict_use_ndv | TRUE | Use NDV for sizing global dictionary, if available |
| _globalindex_pnum_filter_enabled | TRUE | enables filter for global index with partition extended syntax |
| _grant_read_instead_of_select | FALSE | grant read privilege instead of select wherever applicable |
| _grant_secure_role | FALSE | Disallow granting of SR to other SR or NSR |
| _grant_unlimited_tablespace_role | FALSE | Allow UNLIMITED TABLESPACE privilege grant to database roles |
| _group_membership_bucket_batch_size | 8 | ksimpoll group membership bucket batch size |
| _group_membership_bucket_scan_timeout | 5 | ksimpoll group membership bucket scan timeout |
| _group_membership_entries_per_bucket | 100 | ksimpoll group membership entries per bucket |
| _groupby_nopushdown_cut_ratio | 3 | groupby nopushdown cut ratio |
| _groupby_orderby_combine | 5000 | groupby/orderby don't combine threshold |
| _gs_anti_semi_join_allowed | TRUE | enable anti/semi join for the GS query |
| _gsm | GSM descriptions | |
| _gsm_config_vers | 0 | version of gsm config |
| _gsm_cpu_thresh | 75 | CPU busy threshold |
| _gsm_drv_interval | 30 | metric derived values interval |
| _gsm_max_instances_per_db | 8 | maximum number of instances per database in gsm cloud |
| _gsm_max_num_regions | 10 | maximum number of regions in gsm cloud |
| _gsm_pool_size | 134217728 | Global Shared Memory size |
| _gsm_region_list | List of GSM Regions | |
| _gsm_srlat_thresh | 20 | Single block read latency threshold |
| _gsm_srvctl_diag_time | 0 | gsm invoked srvctl pre-timeout diagnostic time |
| _gsm_srvctl_timeout | 0 | gsm invoked srvctl timeout |
| _gsm_svcrgnmax | 100 | Maximum Service x Region statistics |
| _gsm_thresh_respct | 50 | threshold resource percentage |
| _gsm_thresh_zone | 10 | threshold zone |
| _gwm_autoons_ha_subscription | AutoONS HA notification subscription string | |
| _gwm_autoons_rlb_subscription | AutoONS RLB notification subscription string | |
| _gwm_database_flags | GWM Database Flags | |
| _gwm_db_unique_name | gsm db_unique_name name | |
| _gwm_disable_ra | FALSE | Oracle internal parameter |
| _gwm_int_dbnum | 0 | GWM internal db id |
| _gwm_lagtype | gsm lag type | |
| _gwm_spare1 | gsm spare 1 | |
| _gwm_spare2 | 0 | gsm spare 2 |
| _gwm_spare3 | 0 | gsm spare 3 |
| _gwm_sys_ddl | 0 | allow DDL as SYS |
| _gwm_use_srvctl | 0 | use srvctl for service mnagement |
| _gws_cache_version | 0 | the shard/catalog cache version. |
| _gws_catalog_wallet | 0 | the sharding catalog has a wallet |
| _gws_deployed | 0 | the shardb/catalog has been deployed for sharding. |
| _gws_encddl | 0 | Encrypt DDL text. |
| _gws_sharding_method | 0 | Sharding method used (system-managed/user-defined/composite) |
| _hang_allow_resolution_on_single_nonrac | DBRM | Hang Management allow resolution on single non-RAC instances |
| _hang_analysis_num_call_stacks | 3 | hang analysis num call stacks |
| _hang_analyze_elapsed_time_limit | 1800 | Hang Analyze elapsed time limit in seconds |
| _hang_analyze_oradebug_time_limit | 900 | timeout for oradebug invoked hang analysis |
| _hang_appl_issue_session_threshold | 0 | Hang Management application issue session threshold |
| _hang_application_hang_resolution_enabled | FALSE | Hang Management application related hang resolution enabled |
| _hang_asm_hang_resolution_enabled | FALSE | Hang Management ASM hang resolution enabled |
| _hang_base_file_count | 5 | Number of trace files for the normal base trace file |
| _hang_base_file_space_limit | 100000000 | File space limit for current normal base trace file |
| _hang_blocked_session_percent_threshold | 20 | Hang Manager fast-track blocked session percent threshold |
| _hang_bool_spare1 | TRUE | Hang Management bool 1 |
| _hang_bool_spare2 | TRUE | Hang Management bool 2 |
| _hang_bool_spare3 | TRUE | Hang Management bool 3 |
| _hang_cpu_hung_thresh_sec | 120 | Hang Manager threshold for resmgr:cpu quantum |
| _hang_cross_boundary_hang_detection_enabled | TRUE | Hang Management Cross Boundary detection |
| _hang_cross_cluster_hang_detection_enabled | TRUE | Hang Management Cross Cluster detection |
| _hang_deadlock_resolution_enabled | TRUE | Hang Management deadlock resolution enabled |
| _hang_delay_resolution_for_libcache | TRUE | Hang Management delays hang resolution for library cache |
| _hang_detection_enabled | TRUE | Hang Management detection |
| _hang_enable_processstate | TRUE | Enable Process State Dumping |
| _hang_fast_tracked_hang_verification_interval | 10 | Hang Manager fast-track hang verification interval |
| _hang_ft_min_degrading_samples_percent_threshold | 60 | Hang Manager fast-track minimum degrading samples threshold |
| _hang_hang_analyze_output_hang_chains | TRUE | if TRUE hang manager outputs hang analysis hang chains |
| _hang_hang_blocked_session_delta_percent_threshold | 20 | Hang Manager hang's blocked session delta percent threshold |
| _hang_high_session_count_update_hb_threshold | 2000 | Hang Manager high session count update heartbeat threshold |
| _hang_hiload_promoted_ignored_hang_count | 2 | Hang Management high load or promoted ignored hang count |
| _hang_hiprior_session_attribute_list | Hang Management high priority session attribute list | |
| _hang_hs_hang_metrics_enabled | TRUE | Hang Management Hang Specific hang metrics enabled |
| _hang_hung_session_ewarn_percent | 34 | Hang Management hung session early warning percentage |
| _hang_ignore_hngmtrc_interval | 150 | Hang Management ignore hang metric dependent hang interval |
| _hang_ignored_hang_count | 1 | Hang Management ignored hang count |
| _hang_ignored_hangs_interval | 300 | Time in seconds ignored hangs must persist after verification |
| _hang_int_spare2 | 0 | Hang Management int 2 |
| _hang_int_spare3 | 0 | Hang Management int 3 |
| _hang_intersecting_chains_scanning_enabled | TRUE | Hang Management intersecting chains scanning is allowed |
| _hang_log_important_hangs_to_alert | TRUE | Hang Management log important hangs to alert log |
| _hang_log_io_hung_sessions_to_alert | FALSE | Hang Management log sessions hung on IO to alert log |
| _hang_log_verified_hangs_to_alert | FALSE | Hang Management log verified hangs to alert log |
| _hang_low_wait_time_cutoff | 6 | Hang Management low wait time cutoff in seconds |
| _hang_lws_file_count | 5 | Number of trace files for long waiting sessions |
| _hang_lws_file_space_limit | 100000000 | File space limit for current long waiting session trace file |
| _hang_mark_some_idle_waits_terminal | FALSE | Hang Management mark some wait events as terminal waits |
| _hang_max_instance_allow_node_eviction | 1 | Hang Manager maximum instance count to allow node eviction |
| _hang_max_local_db_clients_allowed | 0 | Hang Manager maximum local db clients allowed |
| _hang_max_session_hang_time | 96 | Hang Management maximum session hang time in seconds |
| _hang_metrics_older_bitmap_threshold | 25 | Hang Management Hang Metric older bitmap threshold |
| _hang_metrics_recent_bitmap_threshold | 50 | Hang Management Hang Metric recent bitmap threshold |
| _hang_monitor_archiving_related_hang_interval | 300 | Time in seconds ignored hangs must persist after verification |
| _hang_msg_checksum_enabled | TRUE | enable hang graph message checksum |
| _hang_promote_process_termination_interval | 70 | Hang Management promote process termination interval in seconds |
| _hang_px_resolution_on_asm_enabled | TRUE | Hang Management px resolution on ASM enabled |
| _hang_resolution_allow_archiving_issue_termination | TRUE | Hang Management hang resolution allow archiving issue termination |
| _hang_resolution_confidence_promotion | FALSE | Hang Management hang resolution confidence promotion |
| _hang_resolution_global_hang_confidence_promotion | FALSE | Hang Management hang resolution global hang confidence promotion |
| _hang_resolution_partial_hangs_on_asm_enabled | TRUE | Hang Management resolution of partial hangs on ASM enabled |
| _hang_resolution_percent_hung_sessions_threshold | 300 | Hang Manager hang resolution percent hung sessions threshold |
| _hang_resolution_percent_hung_sessions_threshold2 | 5000 | Hang Manager hang resolution percent hung sessions threshold2 |
| _hang_resolution_policy | HIGH | Hang Management hang resolution policy |
| _hang_resolution_promote_process_termination | TRUE | Hang Management hang resolution promote process termination |
| _hang_resolution_scope | INSTANCE | Hang Management hang resolution scope |
| _hang_root_ha_phase_trigger_time | 300 | Hang Management root HA phase trigger time |
| _hang_running_in_lrg | FALSE | Hang Management running in lrg |
| _hang_sess_enq_wait_blocked_session_threshold | 5 | Hang Management session enqueue wait blocked session threshold |
| _hang_sess_enq_wait_resltn_trig_time | 0 | Hang Management session enqueue wait resolution trigger time |
| _hang_short_stacks_output_enabled | TRUE | if TRUE hang manager outputs short stacks |
| _hang_signature_list_match_output_frequency | 10 | Hang Signature List matched output frequency |
| _hang_singleton_detection_rw_enabled | FALSE | Hang Management singleton detection enabled for read-write |
| _hang_singleton_resolution_rw_enabled | FALSE | Hang Management singleton resolution enabled for read-write |
| _hang_statistics_collection_interval | 15 | Hang Management statistics collection interval in seconds |
| _hang_statistics_collection_ma_alpha | 30 | Hang Management statistics collection moving average alpha |
| _hang_statistics_high_io_percentage_threshold | 25 | Hang Management statistics high IO percentage threshold |
| _hang_terminate_session_replay_enabled | TRUE | Hang Management terminates sessions allowing replay |
| _hang_trace_interval | 32 | Hang Management trace interval in seconds |
| _hang_verification_interval | 46 | Hang Management verification interval in seconds |
| _hard_protection | FALSE | if TRUE enable H.A.R.D specific format changes |
| _hash_join_enabled | TRUE | enable/disable hash join |
| _hash_multiblock_io_count | 0 | number of blocks hash join will read/write at once |
| _hashops_prefetch_size | 4 | maximum no of rows whose relevant memory locations are prefetched |
| _hb_redo_interval | 1000 | generic heartbeat redo frequency |
| _hb_redo_msg_interval | 100 | BOC HB redo message interval in ms |
| _hcs_disable_all_prune | FALSE | prune hierarchies pinned to ALL level |
| _hcs_disable_all_qry_optz | FALSE | skip all query optimization on generated SQL |
| _hcs_disable_audit_opt | FALSE | disable audit optimization |
| _hcs_disable_av_jback_opt | FALSE | optimize analytic view query joinback |
| _hcs_disable_av_sql_hint | FALSE | disable analytic view sql hint |
| _hcs_disable_bd_agg_opt | FALSE | optimize base data aggregation |
| _hcs_disable_calc_dtm_to_out_opt | FALSE | apply move calc determined hier to output hier optimization |
| _hcs_disable_calc_opt | FALSE | calc optimize |
| _hcs_disable_calc_union_opt | FALSE | disable determine all optimization |
| _hcs_disable_cell_qry_atr_prune_opt | FALSE | apply attribute prune optimization to cell query |
| _hcs_disable_cell_qry_lvl_prune_opt | FALSE | apply level prune optimization to cell query |
| _hcs_disable_cell_qry_mv_cache_opt | FALSE | apply mv cache optimization to cell query |
| _hcs_disable_cell_qry_no_calc_nav_opt | FALSE | apply no calc navigation optimization to cell query |
| _hcs_disable_cell_qry_no_out_data_opt | FALSE | apply no output data optimization to cell query |
| _hcs_disable_col_prune_optz | FALSE | skip column pruning optimization on generated SQL |
| _hcs_disable_dt_opt_cell_qry | FALSE | disable cell query optimizations for datatype queries |
| _hcs_disable_dup_nav_calc_opt | FALSE | duplicate navigation calc optimize |
| _hcs_disable_dup_src_tbl_opt | FALSE | apply duplicate src table optimization |
| _hcs_disable_exists_distinct | FALSE | no exists distinct |
| _hcs_disable_filter_hierarchies | FALSE | filter hierarchies in hcs queries |
| _hcs_disable_fltr_below_fltr_star_opt | FALSE | apply filter below filtered star optimization |
| _hcs_disable_fltr_fact_opt | FALSE | apply filtered fact optimization |
| _hcs_disable_fltr_hier_star_opt | FALSE | apply filtered hierarchy star optimization |
| _hcs_disable_hier_join_map_nonnull | FALSE | no hier join map non null |
| _hcs_disable_inline | FALSE | add inline hint to star block |
| _hcs_disable_inline_tmpl_opt | FALSE | apply inline single ref top blocks optimization to cell query |
| _hcs_disable_latest_compat_check | FALSE | skip compatibility check for latest compatible version |
| _hcs_disable_level_ord | FALSE | prune away MAX(MAX(...)) around level order columns |
| _hcs_disable_level_prune | FALSE | perform all level pruning |
| _hcs_disable_level_prune_calc_data_joins | FALSE | perform level pruning for joins across calc data |
| _hcs_disable_level_prune_hier_join | FALSE | perform level pruning from hierarchy joins |
| _hcs_disable_level_prune_hier_qry | FALSE | perform level pruning from hierarchy queries |
| _hcs_disable_level_prune_hierarchize | FALSE | level prune hierarchize |
| _hcs_disable_level_prune_in_qry | FALSE | perform level pruning from level IN conditions |
| _hcs_disable_level_prune_mbr_lookup | FALSE | perform level pruning in member lookup queries |
| _hcs_disable_materialize | FALSE | add materialize to result cache hint |
| _hcs_disable_mdx_cache_hint | FALSE | generate hcs query mdx cache hints |
| _hcs_disable_merge_fltr_star_opt | FALSE | disable merge filter star optimization |
| _hcs_disable_mv_rewrite_check | FALSE | skip MV rewrite check when generating for ANALYTIC VIEW cache |
| _hcs_disable_no_bdfltrd_opt | FALSE | apply no base data filtered optimization |
| _hcs_disable_obj_cache_name | FALSE | Do not include the object number in an aggregate or level cache |
| _hcs_disable_opt_cell_qry | FALSE | optimize cell query |
| _hcs_disable_opt_estimate | FALSE | generate opt estimate hints |
| _hcs_disable_prune_unslvd_star_opt | FALSE | disable prune unsolved star optimization |
| _hcs_disable_result_cache_hint | FALSE | generate hcs query result cache hints |
| _hcs_disable_rm_like_withs_optz | FALSE | skip like WITH element removal optimization on generated SQL |
| _hcs_disable_rm_unused_withs_optz | FALSE | skip unused WITH element removal optimization on generated SQL |
| _hcs_disable_smooth_descendants | FALSE | perform smooth descendants |
| _hcs_disable_smooth_drill_all | FALSE | perform smooth drill all |
| _hcs_disable_smooth_hierarchize | FALSE | perform hierarchize smoothing |
| _hcs_disable_smooth_noop_descendants | FALSE | perform smooth no-op descendants |
| _hcs_disable_smooth_remove_all | FALSE | smooth and remove ALL member |
| _hcs_disable_sql_plan_baselines | FALSE | disable sql plan baselines |
| _hcs_disable_unnest | FALSE | disable unnest hint |
| _hcs_disable_use_cache_star_opt | FALSE | disable use cache star optimization |
| _hcs_disable_vector_transform | FALSE | disable vector transform hint |
| _hcs_disable_view_merge | FALSE | disable view merge |
| _hcs_disable_vis_totals | FALSE | generate visual totals |
| _hcs_disable_xform_gby | FALSE | disable transform group by |
| _hcs_enable_adw | FALSE | enable ADW |
| _hcs_enable_aggr_opt_estimate | FALSE | apply OPT_ESTIMATE hint to aggregation queries |
| _hcs_enable_all_distinct | FALSE | use distinct instead of rownum=1 |
| _hcs_enable_auto_av_cache | FALSE | use dynamic across all levels cache |
| _hcs_enable_av_auto_cache | FALSE | enable AV auto-cache |
| _hcs_enable_basetbl_transform | FALSE | enable base table transform |
| _hcs_enable_code_trc | FALSE | enable code tracing |
| _hcs_enable_cube_join | FALSE | enable cube join |
| _hcs_enable_expose_with_expr | FALSE | expose internal with_expression |
| _hcs_enable_fact_rows | FALSE | enable fact rows |
| _hcs_enable_in_mem_cdt_hint | FALSE | add hint opt_param('_in_memory_cdt', 'off') |
| _hcs_enable_mdx_cache_name_col | FALSE | add column for mdx cache name |
| _hcs_enable_mdx_mv_gen | FALSE | enable mdx mv cache SQL generation |
| _hcs_enable_mdx_sleep_after_pin | FALSE | sleep after pinning MDX caches |
| _hcs_enable_no_expand | FALSE | enable no expand hint |
| _hcs_enable_parallel_hint | FALSE | include parallel hint in cell query |
| _hcs_enable_parse_auto_av_cache | FALSE | allow parsing of dynamic across all levels cache |
| _hcs_enable_pred_push | TRUE | enable optimizer AV predicate pushing via reparse |
| _hcs_enable_unsupported_calcs | FALSE | enable unsupported calcs |
| _hcs_log_max_segments | 1000 | maximum number of HCS log segments, 0 for unlimited |
| _hcs_log_segment_size | 10 | HCS log segment size in MB |
| _hcs_logging | SUMMARY | analytic view logging |
| _hcs_max_mdx_cursors | 100 | maximum number of MDX cursors |
| _hcs_mdx_sim_sga_alloc_err | NONE | simulate mdx sga allocation error |
| _hcs_mdx_sim_so_fail | FALSE | simulate state object failure |
| _hcs_mdx_sleep_loc | NONE | mdx location to sleep for testing |
| _hcs_query_hint | query hint | |
| _hcs_sim_sqlopt_err | FALSE | simulate sql optimization error |
| _hcs_stats_max_card | 2000000 | maximum value for stats cardinality |
| _heap_dump_timeout | 60 | timeout in seconds for heap dump |
| _heartbeat_config | NONE | TDE heartbeat configuration parameter |
| _heartbeat_period_multiplier | 0 | Multiplier for the period of the TDE heartbeat |
| _heatmap_format_1block | FALSE | heatmap related - to be used by oracle dev only |
| _heatmap_min_maxsize | 0 | Internal testing only |
| _heur_deadlock_resolution_secs | 0 | the heuristic wait time per node for deadlock resolution |
| _high_intrinsic_scn_growth_alert | 1440 | high intrinsic SCN growth rate alert time in minutes |
| _high_priority_node_instcnt_cap | FALSE | disable high priority lms when node inst count exceeds cap |
| _high_priority_processes | LGWR | LMS* |
| _high_threshold_delta | 65535 | high threshold delta |
| _highest_priority_processes | VKTM | Highest Priority Process Name Mask |
| _highres_drift_allowed_sec | 1 | allowed highres timer drift for VKTM |
| _highthreshold_undoretention | 31536000 | high threshold undo_retention in seconds |
| _hj_bit_filter_threshold | 50 | hash-join bit filtering threshold (0 always enabled) |
| _hm_analysis_oradebug_sys_dump_level | 0 | the oradebug system state level for hang manager hang analysis |
| _hm_xm_enabled | TRUE | If TRUE, DIA0 allows message exchanges across DB/ASM boundary |
| _hpk_compression_range | 5 | hpk compression range |
| _hpk_project_cost_weighting | 20 | hpk project cost weighting |
| _hpk_throughput_range | 5 | hpk throughput range |
| _hstpr_prediction_interval | 10080 | resource SO prediction interval |
| _hstpr_use_linear_prediction | TRUE | use session SO lin-reg prediction |
| _hstpr_use_periodic_prediction | TRUE | use session SO periodic prediction |
| _http_port | 0 | HTTP port number registered with local listener |
| _hugetlbfs_mount_point_for_sga | HugeTLBFS mount point to be used | |
| _hw_watchpoint_on | TRUE | is the HW watchpointing feature turned on? |
| _hwm_sync_threshold | 10 | HWM synchronization threshold in percentage |
| _iat_frequency_short | FALSE | Use short interval (5 minutes) for inactive account time job |
| _idle_session_kill_enabled | TRUE | enables or disables resource manager session idle limit checks |
| _idle_session_scan_frequency | 60 | Idle session scan frequency (in seconds) |
| _idxrb_rowincr | 100000000 | proportionality constant for dop vs. rows in index rebuild |
| _ignore_desc_in_index | FALSE | ignore DESC in indexes, sort those columns ascending anyhow |
| _ignore_edition_enabled_for_EV_creation | FALSE | ignore schema's edition-enabled status during EV creation |
| _ignore_fg_deps | ignore fine-grain dependencies during invalidation | |
| _ignore_pdb_listener | FALSE | ignore pdb listener |
| _ignore_svc_name_conv_mismatch | FALSE | Suppress ORA-65174 for service_name_convert clause mismatch |
| _ilm_mem_limit | 10 | percentage of the max shared pool heat-map can use - internal |
| _ilmflush_stat_limit | 0 | ILM flush statistics limit - Internal testing only |
| _ilmset_stat_limit | 0 | ILM set statistics limit - Internal testing only |
| _ilmstat_memlimit | 5 | Percentage of shared pool for use by ILM Statistics |
| _imado_diagtasks_log_period | 5 | IM-ADO diagnostic tasks logging period (in seconds) |
| _imado_diagtasks_purge_period | 30 | IM diagnostic tasks purge older than X days |
| _imado_disable_bg | FALSE | Disable AIM background task for testing |
| _imado_enable_coloptim | TRUE | Enable AIM Column level optimizations |
| _imado_enhancements | 0 | AIM enhancements |
| _imado_evict_sf | 2 | AIM evict safety factor |
| _imado_mem_threshold | 98 | Memory threshold percent for AIM action |
| _imado_optim_algo | GREEDY | Optimization algorithm for AIM |
| _imado_optimize_period | 0 | IM-store optimize period for AIM (in minutes) |
| _imado_sysaux_usage_limit | 90 | SYSAUX usage percent limit for storing AIM diagnostics |
| _imado_verification | 0 | AIM verification state |
| _image_redo_gen_delay | 0 | Image redo generation delay in centi-seconds (direct write mode) |
| _immediate_commit_propagation | TRUE | if TRUE, propagate commit SCN immediately |
| _improved_outerjoin_card | TRUE | improved outer-join cardinality calculation |
| _improved_row_length_enabled | TRUE | enable the improvements for computing the average row length |
| _imr1_slave | 1 | IMR1 slave |
| _imr_active | TRUE | Activate Instance Membership Recovery feature |
| _imr_avoid_double_voting | TRUE | Avoid device voting for CSS reconfig during IMR |
| _imr_check_css_incarnation_number | TRUE | IMR verify the global consistency of CSS incarnation number |
| _imr_controlfile_access_wait_time | 10 | IMR controlfile access wait time in seconds |
| _imr_dd_slave_wait_time | 30 | IMR max time LMON will wait for slave response in seconds |
| _imr_device_type | controlfile | Type of device to be used by IMR |
| _imr_disk_voting_interval | 3 | Maximum wait for IMR disk voting (seconds) |
| _imr_diskvote_implementation | auto | IMR disk voting implementation method |
| _imr_evicted_member_kill | TRUE | IMR issue evicted member kill after a wait |
| _imr_evicted_member_kill_wait | 20 | IMR evicted member kill wait time in seconds |
| _imr_extra_reconfig_wait | 10 | Extra reconfiguration wait in seconds |
| _imr_highload_threshold | IMR system highload threshold | |
| _imr_largest_hub_membership | TRUE | IMR will derive the largest hub membership from available votes |
| _imr_max_reconfig_delay | 75 | Maximum Reconfiguration delay (seconds) |
| _imr_mount_retry_wait_time | 20 | IMR mount retry wait time (seconds) |
| _imr_non_blocking_device_driver | TRUE | Use the Non Blocking IMR Device Driver Implementation |
| _imr_remount_retry_wait_time | 60 | IMR remount retry wait time in (seconds) |
| _imr_rim_mount_device | FALSE | Enable rim instances to mount IMR device driver |
| _imr_rr_holder_kill_time | 300 | IMR max time instance is allowed to hold RR lock in seconds |
| _imr_slave_debug | 0 | IMR slave debug flags |
| _imr_splitbrain_res_wait | 0 | Maximum wait for split-brain resolution (seconds) |
| _imr_systemload_check | TRUE | Perform the system load check during IMR |
| _imtxn_table_enable | TRUE | is In-Memory Txn Table cache enabled |
| _imtxn_table_flags | 3 | In-Memory Txn Table cache flags |
| _imtxn_table_max_inc_per_slt | 1 | In-Memory Txn Table number of incarnations per slot |
| _imtxn_table_max_slts_per_seg | 34 | In-Memory Txn Table Slots per Undo Segment |
| _imtxn_table_max_undo_segs | 1024 | In-Memory Txn Table Max Undo Segments in Cache |
| _imtxnrma_table_enable | FALSE | is In-Memory RMA Txn Table cache enabled |
| _imtxnrma_table_flags | 0 | In-Memory RMA Txn Table cache Flags |
| _imu_pools | 3 | in memory undo pools |
| _in_memory_cdt | LIMITED | In Memory CDT |
| _in_memory_cdt_maxpx | 4 | Max Parallelizers allowed for IMCDT |
| _in_memory_cleanup_wait_timeout | 10000 | Tiemout for IMCDT cleanup waiting for end of scan |
| _in_memory_memory_threshold | 40 | In Memory CDT memory threshold |
| _in_memory_tbs_search | TRUE | FALSE - disable fast path for alter tablespace read only |
| _in_memory_ts_only | OFF | In Memory CDT use temp segment only |
| _in_memory_undo | TRUE | Make in memory undo for top level transactions |
| _increase_lmd_process | 0 | modifying this hidden parameter, will modify the numberof lmd process by the valueof this parameter |
| _increase_lms_process | 0 | modifying this hidden parameter, will modify the numberof lms process by the valueof this parameter |
| _incremental_purge_size | 200 | Setting for AWR Incremental Purge Size |
| _incremental_recovery_ckpt_min_batch | 500 | minimum number of writes for incremental recovery ckpt every second |
| _index_alert_key_not_found | FALSE | dumps 8102 error to alert log file |
| _index_join_enabled | TRUE | enable the use of index joins |
| _index_load_analysis_frequency | 4 | index load compression analysis frequency |
| _index_load_buf_oltp_over_retry | 0 | index load buf and comp oltp over-estimation retry |
| _index_load_buf_oltp_sacrifice_pct | 10 | index load buf oltp sacrifice pct |
| _index_load_buf_oltp_under_pct | 85 | index load buf and comp oltp under-estimation pct |
| _index_load_last_leaf_comp | 85 | index load write last leaf compression threshold |
| _index_load_min_key_count | 10 | index load min key count for first compression |
| _index_max_inc_trans_pct | 20 | max itl expand percentage soft limit during index insert |
| _index_partition_large_extents | FALSE | Enables large extent allocation for partitioned indices |
| _index_partition_shrink_opt | TRUE | enable alter index modify partition shrink optimization |
| _index_prefetch_factor | 100 | index prefetching factor |
| _index_scan_check_skip_corrupt | FALSE | check and skip corrupt blocks during index scans |
| _index_scan_check_stopkey | FALSE | check stopkey during index range scans |
| _index_split_chk_cancel | 5 | index insert split check cancel |
| _indexable_con_id | TRUE | indexing of CON_ID column enabled for X$ tables |
| _indoubt_pdb_transactions_force_outcome | COMMIT | commit force or rollback force during undo mode switch |
| _inet_cluster_interconnects | InetTable Cluster Interconnects | |
| _influx_scn_wait_timeout | 1 | active dataguard influx scn wait time in centiseconds |
| _influx_scn_waits | 100000 | active dataguard influx scn maximum waits |
| _init_granule_interval | 10 | number of granules to process for deferred cache |
| _init_sql_file | ?/rdbms/admin/sql.bsq | File containing SQL statements to execute upon database creation |
| _inject_simulated_error_period | 131072 | if non-zero, inject IO error once every param_value times |
| _inject_startup_fault | 0 | inject fault in the startup code |
| _inline_sql_in_plsql | FALSE | inline SQL in PL/SQL |
| _inmemory_64k_percent | 30 | percentage of in-memory area for 64k pools |
| _inmemory_adg_batched_flush | TRUE | If true, batched flush is performed |
| _inmemory_adg_journal_quota | FALSE | If true, throttled mining is performed under space pressure |
| _inmemory_adg_parallel_flush | TRUE | If true, parallel flush is performed |
| _inmemory_adg_periodic_sort | FALSE | If true, periodic sort is performed |
| _inmemory_adg_quiesce_timeout | 2 | timeout for getting ZQ enq |
| _inmemory_analyzer_optimize_for | 0 | inmemory analyzer optimize for |
| _inmemory_auto_distribute | TRUE | If true, enable auto distribute |
| _inmemory_autodist_2safe | FALSE | If true, enable auto distribute with 2safe |
| _inmemory_buffer_waittime | 100 | wait interval for one SMU or IMCU to be freed |
| _inmemory_check_prot_meta | FALSE | If true, marks SMU area read only to prevent stray writes |
| _inmemory_checksum | FALSE | If true, checksums in-memory area to detect stray writes |
| _inmemory_crclone_buffer_size | 131072 | In-memory CR Clone buffer size |
| _inmemory_crclone_min_clones | 6 | In-memory CR Clone minimum number of clones |
| _inmemory_crclone_min_space_percent | 50 | In-memory CR Clone minimum space percentage |
| _inmemory_crclone_threshold_rows | 100 | In-memory CR Clone threshold rows |
| _inmemory_cu_checksum | FALSE | If true, checksums CU to detect stray writes |
| _inmemory_cudrop_timeout | 1000 | maximum wait time for IMCU to be freed during drop |
| _inmemory_dbg_scan | 0 | In-memory scan debugging |
| _inmemory_default_flags | 8459 | Default flags based on inmemory_clause_default |
| _inmemory_default_new | FALSE | Force in-memory on new tables |
| _inmemory_default_svc | 0 | Default In-Memory distribute service type for new tables |
| _inmemory_default_svcname | Default In-Memory distribute service name for new tables | |
| _inmemory_delta_population | 0 | Control Delta IMCU population |
| _inmemory_direct_reads | 1 | direct-reads for SMUs population repopulation |
| _inmemory_disable_alter_imco_cycle | FALSE | in-memory disable alter imco cycle |
| _inmemory_disable_selective_vircols | FALSE | disable selective columns for VCs/IMEs |
| _inmemory_distribute_ondemand_timeout | 300 | On demand timeout for redistribute |
| _inmemory_distribute_timeout | 300 | If true, enable auto distribute with 2safe |
| _inmemory_drcancel_cu_percent | 80 | IMCU percentage threshold to switch from DR to BC |
| _inmemory_dynamic_scan_disable_threshold | 20 | Inmemory dynamic scan disable threshold |
| _inmemory_dynamic_scans | AUTO | Enable IM Dynamic Scans |
| _inmemory_dynamic_scans_analyze_batch_size | 5 | Inmemory dynamic scan analyze batch size |
| _inmemory_dynamic_scans_batch_size | 500 | Number of steady state outstanding tasks |
| _inmemory_dynamic_scans_dbg | 0 | Inmemory dynamic scans debug |
| _inmemory_dynamic_scans_result_buffers | 5000 | No. of LWT allocated result buffers per thread |
| _inmemory_enable_population_verify | 1 | verify in-memory population |
| _inmemory_enable_readonly | TRUE | Enable Inmemory on read only DB instance |
| _inmemory_enable_stat_alert | FALSE | dump in-memory stats in alert log file |
| _inmemory_enable_sys | FALSE | enable in-memory on system tablespace with sys user |
| _inmemory_exclto_timeout | 100 | maximum wait time to pin SMU for cleanout |
| _inmemory_expression_count | 20 | IME number of expressions to lookup from the ESS |
| _inmemory_expressions_area_percent | 10 | percentage of in-memory area for IMEUs |
| _inmemory_expressions_mark_unused | FALSE | Mark cold IME expressions unused instead of no inmemory |
| _inmemory_ext_roarea | 0 | size in bytes of inmemory rw extension area |
| _inmemory_ext_rwarea | 0 | size in bytes of inmemory rw extension area |
| _inmemory_external_table | TRUE | Enable inmemory extern table |
| _inmemory_faststart_control_flags | 0 | in-memory faststart control flags |
| _inmemory_force_fs | FALSE | in-memory faststart force |
| _inmemory_force_fs_tbs | SYSAUX | in-memory faststart force tablespace |
| _inmemory_force_fs_tbs_size | 1073741824 | in-memory faststart force tablespace size |
| _inmemory_force_non_engineered | FALSE | force non-engineered systems in-memory behavior on RAC |
| _inmemory_format_compatible | 19.0.0 | In-memory format compatibility parameter |
| _inmemory_fs_blk_inv_blk_percent | 50 | in-memory faststart CU invalidation threshold(blocks) |
| _inmemory_fs_blk_inv_blkcnt | in-memory faststart CU invalidation threshold(blocks) | |
| _inmemory_fs_dmlverify_read_ahead_cnt | 10 | in-memory faststart dmlverify read ahead count |
| _inmemory_fs_enable | TRUE | in-memory faststart enable |
| _inmemory_fs_enable_blk_lvl_inv | TRUE | in-memory faststart enable block level invalidation |
| _inmemory_fs_nodml | FALSE | in-memory faststart assumes no dmls while populating |
| _inmemory_fs_prune_pct | 10 | in-memory faststart out of mem prune percent |
| _inmemory_fs_raise_error | FALSE | in-memory faststart raise error |
| _inmemory_fs_tbsmaxsz | in-memory faststart tablespace maximum size | |
| _inmemory_fs_verify | FALSE | in-memory faststart verify |
| _inmemory_fsdw_cnt | 2147483647 | in-memory faststart defer writes per cycle |
| _inmemory_fsdw_enable | TRUE | in-memory faststart deferwrite enable |
| _inmemory_fsdw_inline | FALSE | in-memory faststart deferwrite inline |
| _inmemory_fsdw_maxcnt | 10 | in-memory faststart max defer writes per cycle |
| _inmemory_fsdw_maxmem | 104755200 | in-memory faststart max defer writes memory cap |
| _inmemory_fsdw_on_populate | TRUE | in-memory faststart deferwrite on populate |
| _inmemory_fsdw_penalty_threshold | 20 | in-memory faststart deferwrite penalty threshold |
| _inmemory_fsdw_populate_threshold_multiplier | 10 | in-memory faststart deferwrite populate threshold multiplier |
| _inmemory_fsdw_priority_penalty_percent | 10 | In-memory faststart defer write percent priority for penalized |
| _inmemory_fsdw_priority_population_percent | 100 | In-memory faststart defer write percent priority for population |
| _inmemory_fsdw_priority_repopulation_percent | 90 | In-memory faststart defer write percent priority for repopulation |
| _inmemory_fsdw_schedlrtm | 1 | in-memory faststart defer write scheduler cycle (sec) |
| _inmemory_fsdw_scheduler_dedicated | FALSE | in-memory faststart defer write dedicated scheduler |
| _inmemory_fsdw_task_timeout | 20 | in-memory faststart defer writes task timeout (sec) |
| _inmemory_fsdw_threshold | 300 | In-memory faststart defer write minimum interval (millisec) |
| _inmemory_granule_size | 134217728 | In-memory granule size |
| _inmemory_grpcolinv_buffer_size | 131072 | In-memory grpcolinv buffer size |
| _inmemory_grpcolinv_granularity | 1 | In-memory grpcolinv blks per colmap |
| _inmemory_hpk4sql_debug | 0 | In-Memory HPK4SQL debug |
| _inmemory_hpk4sql_filter_threshold | 1 | In-Memory HPK4SQL filter threshold |
| _inmemory_hpk4sql_flags | 0 | In-Memory HPK4SQL flags |
| _inmemory_hpk4sql_kv_seg_size | 0 | In-Memory HPK4SQL kv segment size |
| _inmemory_hpk4sql_partbuf_maxrow | 1024 | In-Memory HPK4SQL partbuf maxrow |
| _inmemory_hpk4sql_partbuf_minrow | 8 | In-Memory HPK4SQL partbuf minrow |
| _inmemory_hwm_expand_percent | 20 | max blks percent can exceed in hwmimcu |
| _inmemory_hwm_expansion | 1 | If 0, the highwatermark CU is dropped when expanded |
| _inmemory_hwm_expansion_rac | 0 | If 0, the highwatermark CU is dropped when expanded |
| _inmemory_hwm_inv_blocks_threshold | 64 | If 0, expansion will occur even for very small hwm imcu |
| _inmemory_hybrid_selectivity_threshold | 37 | Selectivity threshold for a qualifying query to enable hybrid IM scans |
| _inmemory_imco_cycle | 120 | IMCO cycle in seconds (sleep period) |
| _inmemory_imcu_align | TRUE | Enforce 8M IMCU alignment |
| _inmemory_imcu_populate_minbytes | 5242880 | minimum free space in IMA for populating IMCU |
| _inmemory_imcu_source_analyze_bytes | 134217728 | number of source analyze bytes per IMCU |
| _inmemory_imcu_source_blocks | 0 | number of source blocks per IMCU |
| _inmemory_imcu_source_extents | 0 | number of source extents per IMCU |
| _inmemory_imcu_source_maxbytes | 536870912 | IMCU maximum source size in bytes |
| _inmemory_imcu_source_minbytes | 1048576 | number of minimum source bytes per IMCU |
| _inmemory_imcu_target_bytes | 0 | IMCU target size in bytes |
| _inmemory_imcu_target_maxrows | 8388608 | IMCU maximum target number of rows |
| _inmemory_imcu_target_rows | 0 | IMCU target number of rows |
| _inmemory_ime_increpop_threshold | 1 | Invalidation threshold for IME incremental repopulation |
| _inmemory_incremental_repopulation | TRUE | If true, incremental repopulation of IMCU will be attempted |
| _inmemory_invalidate_cursors | TRUE | In-memory populate enable cursor invalidations |
| _inmemory_journal_check | 0 | Depending on value does one of the DML verifications |
| _inmemory_journal_cla_stride | 4 | inmemory journal format cla stride |
| _inmemory_journal_format | 1 | inmemory journal format options |
| _inmemory_journal_row_logging | FALSE | If true, log the entire row into the in-memory journal |
| _inmemory_journal_scan | 0 | inmemory journal scan enable |
| _inmemory_journal_scan_format | TRUE | If true, the set journal format will be used for scan |
| _inmemory_lock_for_smucreate | FALSE | take object lock during smu creation |
| _inmemory_log_level | 0 | in-memory log level |
| _inmemory_max_delta | 5 | Inmemory max number of deltas per CU |
| _inmemory_max_expressions_table | 50 | IME maximum number of SYS_IME VCs in a table |
| _inmemory_max_populate_retry | 3 | IM populate maximum number of retry |
| _inmemory_max_queued_tasks | 0 | Maximum queued populating tasks on the auxiliary queue |
| _inmemory_memprot | FALSE | enable or disable memory protection for in-memory |
| _inmemory_min_delta_blocks | 50 | Inmemory minimum blocks per delta |
| _inmemory_min_delta_rows | 255 | Inmemory minimum rows per delta |
| _inmemory_min_ima_defersize | 0 | Defer in-memory area allocation beyond this size |
| _inmemory_num_hash_latches | 256 | Maximum number of latches for IM buffers |
| _inmemory_opaque_contig_space_percent | 80 | Contiguous memory for opaque VC as a percent of hard maximum |
| _inmemory_parallel_load_ext | TRUE | Parallel load inmemory extern table |
| _inmemory_partrowlock_threshold | 10 | Number of committed rows that stay not cleaned out |
| _inmemory_patch_background_blocks | 200 | In-memory SMU patch threshold blocks to start background tasks |
| _inmemory_patch_commit_path | FALSE | If true, enable the SMU patching from DML path |
| _inmemory_patch_threshold_blocks | 25 | In-memory SMU patch threshold blocks |
| _inmemory_pct_inv_blocks_invalidate_imcu | 100 | In-memory percentage invalid blocks for IMCU invalidation |
| _inmemory_pct_inv_rows_invalidate_imcu | 50 | In-memory percentage invalid rows for IMCU invalidation |
| _inmemory_pga_per_server | 536870912 | minimum pga needed per inmemory populate server |
| _inmemory_pin_hist_mode | 16 | settings for IM pinned buffer history |
| _inmemory_populate_blocks_threshold | 8 | If 0, scan triggers populate for any missing blocks |
| _inmemory_populate_fg | FALSE | populate in foreground |
| _inmemory_populate_wait | FALSE | wait for population to complete |
| _inmemory_populate_wait_max | 600 | maximum wait time in seconds for segment populate |
| _inmemory_prefer_xmem_memcompress | Prefer to store tables with given memcompress levels in xmem | |
| _inmemory_prefer_xmem_priority | Prefer to store tables with given priority levels in xmem | |
| _inmemory_prefix_encode_dsbs | FALSE | Prefix-encode the DSB-dictionary |
| _inmemory_prepopulate | TRUE | Enable inmemory populate by IMCO |
| _inmemory_prepopulate_fg | 0 | Force prepopulate of in-memory segment in foreground |
| _inmemory_private_journal_maxexts | 5000000 | Max number of extents per PJ |
| _inmemory_private_journal_numbkts | 512 | Number of priv jrnl ht bkts |
| _inmemory_private_journal_numgran | 255 | Number of granules per HT node |
| _inmemory_private_journal_quota | 100 | quota for transaction in-memory private journals |
| _inmemory_private_journal_sharedpool_quota | 20 | quota for transaction in-memory objects |
| _inmemory_pruning | ON | In-memory pruning |
| _inmemory_query_check | 0 | In-memory query checking |
| _inmemory_query_fetch_by_rowid | FALSE | In-memory fetch-by-rowid enabled |
| _inmemory_query_scan | TRUE | In-memory scan enabled |
| _inmemory_relimcusz_thresh | 25 | in-memory relative imcusz thresh for direct reads |
| _inmemory_repopulate_disable | 2 | disable In-memory repopulate |
| _inmemory_repopulate_flags | 2 | In-memory repopulate decision flags |
| _inmemory_repopulate_invalidate_rate_percent | 0 | In-memory repopulate invalidate rate percent |
| _inmemory_repopulate_optimize | TRUE | If true, itl transfer will be attempted during repopulation of IMCU |
| _inmemory_repopulate_priority_scale_factor | 100 | In-memory repopulate priority threshold scale factor |
| _inmemory_repopulate_priority_threshold_block | 320 | In-memory repopulate priority threshold block |
| _inmemory_repopulate_priority_threshold_row | 160 | In-memory repopulate priority threshold row |
| _inmemory_repopulate_threshold_blocks | In-memory repopulate threshold number of modified blocks | |
| _inmemory_repopulate_threshold_blocks_percent | 10 | In-memory repopulate threshold blocks invalid percentage |
| _inmemory_repopulate_threshold_mintime | 0 | In-memory repopulate minimum interval (millisec) |
| _inmemory_repopulate_threshold_mintime_factor | 5 | In-memory repopulate minimum interval (N*timetorepop) |
| _inmemory_repopulate_threshold_rows | In-memory repopulate threshold number of modified rows | |
| _inmemory_repopulate_threshold_rows_percent | 5 | In-memory repopulate threshold rows invalid percentage |
| _inmemory_repopulate_threshold_scans | 0 | In-memory repopulate threshold number of scans |
| _inmemory_retention_time | 120 | maximum retention time of imcu after repopulation |
| _inmemory_rows_check_interrupt | 1000 | Number of rows buffered before interrupt check |
| _inmemory_scan_invalid_percent | 30 | Inmemory scan invalid percentage |
| _inmemory_scan_override | FALSE | In-memory scan override |
| _inmemory_servers_throttle_pgalim_percent | 55 | In-memory populate servers throttling pga limit percentage |
| _inmemory_shared_journal_maxexts | 1024 | Max number of extents per SJ |
| _inmemory_shared_journal_minexts_repop | 256 | min number of extents per SJ to trigger repop |
| _inmemory_small_segment_threshold | 65536 | In-memory small segment threshold (must be larger for in-memory) |
| _inmemory_smu_patch_options | 7 | Inmemory SMU patching options |
| _inmemory_strdlxid_timeout | 0 | max time to determine straddling transactions |
| _inmemory_subcu_histsize | 0 | In-memory subCU Histogram size |
| _inmemory_subcusize | 512 | In-memory subCU size |
| _inmemory_suppress_vsga_ima | FALSE | Suppress inmemory area in v$sga |
| _inmemory_test_verification | 0 | In-memory verification testing |
| _inmemory_transaction_options | 2806 | in-memory transaction performance options |
| _inmemory_trickle_populate | TRUE | Enable inmemory trickle populate |
| _inmemory_trickle_repopulate | TRUE | Enable inmemory trickle repopulate |
| _inmemory_trickle_repopulate_fg | 0 | Trickle Repopulate in the Foreground |
| _inmemory_trickle_repopulate_min_interval | 300 | IMCO Trickle Repopulate Interval |
| _inmemory_trickle_repopulate_threshold_dirty_ratio | 0 | IMCO Trickle Repopulate threshold dirty ratio |
| _inmemory_txn_checksum | 0 | checksum for SMUs and private journals |
| _inmemory_txnpjrnl_debug | 0 | txn priv jrnl debugging parameter |
| _inmemory_validate_fetch | FALSE | If true, validate single-row fetch between in-memory and disk |
| _inmemory_vector_encode_override | FALSE | Populate and use DSBs for Vector Encode columns |
| _inmemory_waitinvis_count | 8 | in-memory waitinvisible retry count |
| _inmemory_xmem_size | 0 | size in bytes of in-memory xmem area |
| _inplace_update_retry | TRUE | inplace update retry for ora1551 |
| _inquiry_retry_interval | 3 | if greater than 0 enables inquiry retry after specified interval |
| _insert_enable_hwm_brokered | TRUE | during parallel inserts high water marks are brokered |
| _inst_locking_period | 5 | period an instance can retain a newly acquired level1 bitmap |
| _instance_dbnest_name | Instance dbNest Name | |
| _instance_recovery_bloom_filter_fprate | 0 | Allowable false positive percentage [0-100] |
| _instance_recovery_bloom_filter_size | 83886080 | Bloom filter size (in num of bits) used during claim phase |
| _instant_file_create | FALSE | enable instant file creation on sparse media |
| _instant_file_create_exascale | FALSE | enable instant file creation on Exascale |
| _intra_cdb_dblink | FALSE | enable intra CDB implicit dblink |
| _intrapart_pdml_enabled | TRUE | Enable intra-partition updates/deletes |
| _intrapart_pdml_randomlocal_enabled | TRUE | Enable intra-partition updates/deletes with random local dist |
| _invalidate_upon_revoke | TRUE | Invalidate all dependent objects upon revoke |
| _io_internal_test | 0 | I/O internal testing parameter |
| _io_osd_param | 1 | OSD specific parameter |
| _io_outlier_threshold | 500 | Latency threshold for io_outlier table |
| _io_resource_manager_always_on | FALSE | io resource manager always on |
| _io_shared_pool_size | 4194304 | Size of I/O buffer pool from SGA |
| _io_slaves_disabled | FALSE | Do not use I/O slaves |
| _io_statistics | TRUE | if TRUE, ksfd I/O statistics are collected |
| _iocalibrate_init_ios | 2 | iocalibrate init I/Os per process |
| _iocalibrate_max_ios | 0 | iocalibrate max I/Os per process |
| _ioq_fanin_multiplier | 2 | IOQ miss count before a miss exception |
| _ior_serialize_fault | 0 | inject fault in the ior serialize code |
| _iorm_tout | 1000 | IORM scheduler timeout value in msec |
| _ios_root_directory | IOS | IOS default root directory |
| _ioslave_batch_count | 1 | Per attempt IOs picked |
| _ioslave_issue_count | 500 | IOs issued before completion check |
| _ipc_aggr_limit_percentage | 40 | KSIPC memory as a percentage of PGA aggregate limit |
| _ipc_config_opts_dyn | 0 | Dyn config for ipclw startup |
| _ipc_config_opts_stat | 0 | static config for ipclw startup |
| _ipc_emu_aop_timeout | 0 | static emu AOP tinmeout |
| _ipc_fail_network | 0 | Simulate cluster network failer |
| _ipc_switch_reconfig_needed | FALSE | to trigger a ipc switch reconfiguration |
| _ipc_test_failover | 0 | Test transparent cluster network failover |
| _ipc_test_mult_nets | 0 | simulate multiple cluster networks |
| _ipddb_enable | FALSE | Enable IPD/DB data collection |
| _iut_enable | TRUE | Control Index usage tracking |
| _iut_max_entries | 30000 | Maximum Index entries to be tracked |
| _iut_stat_collection_type | SAMPLED | Specify Index usage stat collection type |
| _job_queue_interval | 5 | Wakeup interval in seconds for job queue co-ordinator |
| _k2q_latches | 0 | number of k2q latches |
| _ka_allow_reenable | FALSE | reenability of kernel accelerator service after disable |
| _ka_compatibility_requirement | all | kernel accelerator compatibility operation requirement |
| _ka_doorbell | 0 | kernel accelerator doorbell mode |
| _ka_enabled | FALSE | Enable/disable kernel accelerator |
| _ka_grant_policy | AUTO | KA grant policy to favor fusion grant, make it automatic, or favor KA |
| _ka_lma_msg_wait_count | 100 | KA maximum number of requests to retrieve per OSD wait by LMA |
| _ka_lma_wait_time | 200 | KA wait time for skjcxWait call by LMA process in microseconds |
| _ka_locks_per_sector | 12 | locks per sector in kernel accelerator |
| _ka_max_wait_delay | 1000 | KA maximum amount of time before forcing OSD wait call |
| _ka_mode | 0 | kernel accelerator mode |
| _ka_msg_reap_count | 40 | maximum number of KA messages to receive and process per wait |
| _ka_msg_wait_count | 20 | KA maximum number of requests to retrieve per OSD wait |
| _ka_pbatch_messages | TRUE | kernel accelerator perform pbatch messages |
| _ka_scn_accel_shrmem | TRUE | KA SCN accelerate shr memory |
| _ka_scn_enabled | FALSE | KA SCN processing enabled |
| _ka_scn_use_ka_msgs | TRUE | KA SCN use KA type messages |
| _kcb_reused_max | 16384 | reused array max parameter |
| _kcbl_assert_reset_slot | TRUE | assert slot state in kcblResetSlot |
| _kcfis_automem_level | 1 | Set auto memory management control for kcfis memory allocation |
| _kcfis_block_dump_level | 0 | Smart IO block dump level |
| _kcfis_byteswap_opt_disabled | FALSE | Don't use byte swapping optimization on the storage cell |
| _kcfis_caching_enabled | TRUE | enable kcfis intra-scan session caching |
| _kcfis_cell_passthru_dataonly | TRUE | Allow dataonly passthru for smart scan |
| _kcfis_cell_passthru_enabled | FALSE | Do not perform smart IO filtering on the cell |
| _kcfis_cell_passthru_fromcpu_enabled | TRUE | Enable automatic passthru mode when cell CPU util is too high |
| _kcfis_cellcache_disabled | FALSE | Don't use cellcache rewrite optimization on the storage cell |
| _kcfis_celloflsrv_passthru_enabled | FALSE | Enable offload server usage for passthru operations |
| _kcfis_celloflsrv_usage_enabled | TRUE | Enable offload server usage for offload operations |
| _kcfis_control1 | 0 | Kcfis control1 |
| _kcfis_control2 | 0 | Kcfis control2 |
| _kcfis_control3 | 0 | Kcfis control3 |
| _kcfis_control4 | 0 | Kcfis control4 |
| _kcfis_control5 | 0 | Kcfis control5 |
| _kcfis_control6 | 0 | Kcfis control6 |
| _kcfis_disable_platform_decryption | FALSE | Don't use platform-specific decryption on the storage cell |
| _kcfis_dump_corrupt_block | TRUE | Dump any corrupt blocks found during smart IO |
| _kcfis_fast_response_enabled | TRUE | Enable smart scan optimization for fast response (first rows) |
| _kcfis_fast_response_initiosize | 2 | Fast response - The size of the first IO in logical blocks |
| _kcfis_fast_response_iosizemult | 4 | Fast response - (next IO size = current IO size * this parameter) |
| _kcfis_fast_response_threshold | 1048576 | Fast response - the number of IOs after which smartIO is used |
| _kcfis_fastfileinit_disabled | FALSE | Don't use ffi during file creation |
| _kcfis_fault_control | 0 | Fault Injection Control |
| _kcfis_io_prefetch_size | 8 | Smart IO prefetch size for a cell |
| _kcfis_ioreqs_throttle_enabled | TRUE | Enable Smart IO requests throttling |
| _kcfis_kept_in_cellfc_enabled | TRUE | Enable usage of cellsrv flash cache for kept objects |
| _kcfis_large_payload_enabled | FALSE | enable large payload to be passed to cellsrv |
| _kcfis_max_cached_sessions | 10 | Sets the maximum number of kcfis sessions cached |
| _kcfis_max_out_translations | 5000 | Sets the maximum number of outstanding translations in kcfis |
| _kcfis_nonkept_in_cellfc_enabled | FALSE | Enable use of cellsrv flash cache for non-kept objects |
| _kcfis_oss_io_size | 0 | KCFIS OSS I/O size |
| _kcfis_pmem_enabled | TRUE | RDMA Persistent Memory support enabled |
| _kcfis_qm_prioritize_sys_plan | TRUE | Prioritize Quaranitine Manager system plan |
| _kcfis_qm_user_plan_name | Quaranitine Manager user plan name | |
| _kcfis_rdbms_blockio_enabled | FALSE | Use block IO instead of smart IO in the smart IO module on RDBMS |
| _kcfis_read_buffer_limit | 0 | KCFIS Read Buffer (per session) memory limit in bytes |
| _kcfis_spawn_debugger | FALSE | Decides whether to spawn the debugger at kcfis initialize |
| _kcfis_stats_level | 0 | sets kcfis stats level |
| _kcfis_storageidx_diag_mode | 0 | Debug mode for storage index on the cell |
| _kcfis_storageidx_disabled | FALSE | Don't use storage index optimization on the storage cell |
| _kcfis_storageidx_set_membership_disabled | FALSE | Don't use set membership optimization on the storage cell |
| _kcfis_storageidx_xtss_disabled | FALSE | Don't use storage index optimization on the storage cell for XTSS |
| _kcfis_test_control1 | 0 | kcfis tst control1 |
| _kcfis_trace_bucket_size | 131072 | KCFIS tracing bucket size in bytes |
| _kcfis_xtgran_prefetch_count | 1 | External Table Smart Scan granule prefetch count |
| _kcl_debug | TRUE | if TRUE, record le history |
| _kcl_index_split | TRUE | if TRUE, reject pings on blocks in middle of a split |
| _kcrfwrma_flags | 0 | KCRFWRMA Flags |
| _kd_dbg_control | 0 | kernel data generic control |
| _kd_rows_chk | TRUE | enable or disable row block check |
| _kd_symtab_chk | TRUE | enable or disable symbol table integrity block check |
| _kdbl_enable_post_allocation | FALSE | allocate dbas after populating data buffers |
| _kdfip_bufl_nbkt | 128 | memopt w buffers list buckets |
| _kdfip_cmap_nbkt | 16 | memopt w chunk map buckets |
| _kdfip_debug | 0 | memopt w debug |
| _kdfip_drain_sleeps | 60 | memopt w drain coord sleep count |
| _kdfip_elem_nclatch | 64 | memopt w chunkmap elem child latches |
| _kdfip_flush_nrows | 2147483647 | memopt w flush num rows |
| _kdfip_flush_rowsz | 1048576 | memopt w flush row size |
| _kdfip_flush_rowtm | 60 | memopt w flush time |
| _kdfip_iga_bufsz | 1048576 | memopt w write buffer size |
| _kdfip_iga_maxsz | 2147483648 | memopt w max global area size |
| _kdfip_iga_minsz | 268435456 | memopt w min global area size |
| _kdfip_par_flush | TRUE | memopt w parallel flush |
| _kdfip_trace | FALSE | memopt w tracing on-off |
| _kdfs_fix_control | 0 | dbfs fix_control |
| _kdfs_timer_dmp | FALSE | dbfs timers |
| _kdfs_trace | 1 | dbfs trace level |
| _kdfs_trace_size | 131072 | size of the uts buffer for generic traces |
| _kdi_avoid_block_checking | FALSE | avoid index block checking on sensitive opcodes |
| _kdic_segarr_sz | 0 | size threshold for segmented arrays for seg_info_kdicctx |
| _kdis_reject_level | 24 | b+tree level to enable rejection limit |
| _kdis_reject_limit | 5 | #block rejections in space reclamation before segment extension |
| _kdis_reject_ops | FALSE | enable rejection heuristic for branch splits |
| _kdis_split_xid_prune | TRUE | prune xids during an index split |
| _kdizoltp_uncompsentinal_freq | 16 | kdizoltp uncomp sentinal frequency |
| _kdkv_fg_drop_memopt | TRUE | hashindex foreground drop |
| _kdkv_fg_no_memopt | FALSE | hashindex foreground cleanup |
| _kdkv_fg_populate | FALSE | hashindex foreground populate |
| _kdkv_fg_repopulate | FALSE | hashindex foreground repopulate |
| _kdkv_force_fastpath | FALSE | kdkv fast path on-off |
| _kdkv_force_samehash | FALSE | kdkv hash to same bucket on-off |
| _kdkv_index_lossy | TRUE | hashindex lossiness on-off |
| _kdkv_index_relocate | FALSE | hashindex relocation on-off |
| _kdkv_indexinvalid | FALSE | objd and rdba based index invalidation |
| _kdkv_trace | FALSE | kdkv tracing on-off |
| _kdlf_fast_move_compressed_lob | TRUE | kdlf fast move commpressed lobs |
| _kdlf_layers_cache | TRUE | enable kdlf securefiles layers cache |
| _kdlf_read_flag | 0 | kdlf read flag |
| _kdli_STOP_bsz | 0 | undocumented parameter for internal use only |
| _kdli_STOP_dba | 0 | undocumented parameter for internal use only |
| _kdli_STOP_fsz | 0 | undocumented parameter for internal use only |
| _kdli_STOP_nio | 0 | undocumented parameter for internal use only |
| _kdli_STOP_tsn | 0 | undocumented parameter for internal use only |
| _kdli_adaptive_cache_inode | TRUE | enable adaptive inode cache |
| _kdli_allow_corrupt | FALSE | allow corrupt filesystem_logging data blocks during read/write |
| _kdli_buffer_inject | TRUE | use buffer injection for CACHE [NO]LOGGING lobs |
| _kdli_cache_inode | TRUE | cache inode state across calls |
| _kdli_cache_inode_off_limit | 8192 | cache_off limit for adaptive inode cache |
| _kdli_cache_read_threshold | 0 | minimum lob size for cache->nocache read (0 disables heuristic) |
| _kdli_cache_size | 8 | maximum #entries in inode cache |
| _kdli_cache_verify | FALSE | verify cached inode via deserialization |
| _kdli_cache_write_threshold | 0 | minimum lob size for cache->nocache write (0 disables heuristic) |
| _kdli_cacheable_length | 0 | minimum lob length for inode cacheability |
| _kdli_checkpoint_flush | FALSE | do not invalidate cache buffers after write |
| _kdli_dbc | none | override db_block_checking setting for securefiles |
| _kdli_delay_flushes | TRUE | delay flushing cache writes to direct-write lobs |
| _kdli_descn_adj | FALSE | coalesce extents with deallocation scn adjustment |
| _kdli_flush_cache_reads | FALSE | flush cache-reads data blocks after load |
| _kdli_flush_injections | TRUE | flush injected buffers of CACHE NOLOGGING lobs before commit |
| _kdli_force_cr | TRUE | force CR when reading data blocks of direct-write lobs |
| _kdli_force_cr_meta | TRUE | force CR when reading metadata blocks of direct-write lobs |
| _kdli_force_storage | none | force storage settings for all lobs |
| _kdli_full_readahead_threshold | 0 | maximum lob size for full readahead |
| _kdli_full_vll | FALSE | materialize full vll lobmap for reads |
| _kdli_icache_entries | 3 | size of itree cache |
| _kdli_inject_assert | 0 | inject asserts into the inode |
| _kdli_inject_batch | 0 | buffer injection batch size [1, KCBNEWMAX] |
| _kdli_inject_crash | 0 | inject crashes into the inode |
| _kdli_inline_xfm | TRUE | allow inline transformed lobs |
| _kdli_inode_preference | data | inline inode evolution preference (data, headless, lhb) |
| _kdli_inplace_overwrite | 0 | maximum inplace overwrite size (> chunksize) |
| _kdli_itree_entries | 0 | #entries in lhb/itree blocks (for testing only) |
| _kdli_memory_protect | FALSE | trace accesses to inode memory outside kdli API functions |
| _kdli_mts_so | TRUE | use state objects in shared server for asyncIO pipelines |
| _kdli_oneblk | FALSE | allocate chunks as single blocks |
| _kdli_preallocation_mode | length | preallocation mode for lob growth |
| _kdli_preallocation_pct | 0 | percentage preallocation [0 .. inf) for lob growth |
| _kdli_ralc_length | 10485760 | lob length threshold to trigger rounded allocations |
| _kdli_ralc_rounding | 1048576 | rounding granularity for rounded allocations |
| _kdli_rci_lobmap_entries | 255 | #entries in RCI lobmap before migration to lhb |
| _kdli_readahead_limit | 0 | shared/cached IO readahead limit |
| _kdli_readahead_strategy | contig | shared/cached IO readahead strategy |
| _kdli_recent_scn | FALSE | use recent (not dependent) scns for block format/allocation |
| _kdli_reshape | FALSE | reshape an inode to inline or headless on length truncation |
| _kdli_safe_callbacks | TRUE | invoke inode read/write callbacks safely |
| _kdli_sio_async | TRUE | asynchronous shared IO |
| _kdli_sio_backoff | FALSE | use exponential backoff when attempting SIOP allocations |
| _kdli_sio_bps | 0 | maximum blocks per IO slot |
| _kdli_sio_dop | 2 | degree-of-parallelism in the SIO keep pool |
| _kdli_sio_fbwrite_pct | 35 | percentage of buffer used for direct writes in flashback-db |
| _kdli_sio_fgio | TRUE | reap asynchronous IO in the foreground |
| _kdli_sio_fileopen | none | shared IO fileopen mode: datasync vs nodatasync vs async |
| _kdli_sio_flush | FALSE | enable shared IO pool operations |
| _kdli_sio_free | TRUE | free IO buffers when not in active use |
| _kdli_sio_min_read | 0 | shared IO pool read threshold |
| _kdli_sio_min_write | 0 | shared IO pool write threshold |
| _kdli_sio_nbufs | 8 | maximum #IO buffers to allocate per session |
| _kdli_sio_niods | 8 | maximum #IO descriptors to allocate per session |
| _kdli_sio_on | TRUE | enable shared IO pool operations |
| _kdli_sio_pga | FALSE | use PGA allocations for direct IO |
| _kdli_sio_pga_top | FALSE | PGA allocations come from toplevel PGA heap |
| _kdli_sio_strategy | extent | shared IO strategy: block vs. extent |
| _kdli_sio_write_pct | 100 | percentage of buffer used for direct writes |
| _kdli_small_append_redo | TRUE | detect and use redo optimizations for small appends |
| _kdli_small_cache_limit | 32 | size limit of small inode cache |
| _kdli_sort_dbas | FALSE | sort dbas during chunkification |
| _kdli_space_cache_limit | 2048 | maximum #blocks in per-segment space cache |
| _kdli_space_cache_segments | 16 | #segments in space cache |
| _kdli_squeeze | TRUE | compact lobmap extents with contiguous dbas |
| _kdli_timer_dmp | FALSE | dump inode timers on session termination |
| _kdli_timer_trc | FALSE | trace inode timers to uts/tracefile |
| _kdli_trace | 0 | inode trace level |
| _kdli_vll_direct | TRUE | use skip-navigation and direct-positioning in vll-domain |
| _kdlu_max_bucket_size | 4194304 | UTS kdlu bucket size |
| _kdlu_max_bucket_size_mts | 131072 | UTS kdlu bucket size for mts |
| _kdlu_trace_layer | 0 | UTS kdlu per-layer trace level |
| _kdlu_trace_system | 0 | UTS system dump |
| _kdlw_enable_ksi_locking | FALSE | enable ksi locking for lobs |
| _kdlw_enable_write_gathering | TRUE | enable lob write gathering for sql txns |
| _kdlwp_flush_threshold | 4194304 | WGC flush threshold in bytes |
| _kdlwp_memory_check | TRUE | bug 31354021: memory diagnostics |
| _kdlxp_cmp_subunit_size | 262144 | size of compression sub-unit in bytes |
| _kdlxp_dedup_flush_threshold | 8388608 | deduplication flush threshold in bytes |
| _kdlxp_dedup_hash_algo | SHA1 | secure hash algorithm for deduplication - only on SecureFiles |
| _kdlxp_dedup_inl_pctfree | 5 | deduplication pct size increase by which inlining avoided |
| _kdlxp_dedup_prefix_threshold | 1048576 | deduplication prefix hash threshold in bytes |
| _kdlxp_dedup_wapp_len | 0 | deduplication length to allow write-append |
| _kdlxp_lobcmpadp | FALSE | enable adaptive compression - only on SecureFiles |
| _kdlxp_lobcmplevel | 2 | Default securefile compression |
| _kdlxp_lobcmprciver | 1 | Default securefile compression map version |
| _kdlxp_lobcompress | FALSE | enable lob compression - only on SecureFiles |
| _kdlxp_lobdeduplicate | FALSE | enable lob deduplication - only on SecureFiles |
| _kdlxp_lobdedupvalidate | TRUE | enable deduplicate validate - only on SecureFiles |
| _kdlxp_lobencrypt | FALSE | enable lob encryption - only on SecureFiles |
| _kdlxp_mincmp | 20 | minimum comp ratio in pct - only on SecureFiles |
| _kdlxp_mincmplen | 200 | minimum loblen to compress - only on SecureFiles |
| _kdlxp_minxfm_size | 32768 | minimum transformation size in bytes |
| _kdlxp_no_dedup_on_insert | FALSE | disable deduplication for new inserts of deduplicated lobs |
| _kdlxp_spare1 | 0 | deduplication spare 1 |
| _kdlxp_uncmp | FALSE | lob data uncompressed - only on SecureFiles |
| _kdlxp_xfmcache | TRUE | enable xfm cache - only on SecureFiles |
| _kdmado_partial_pop_backoff_mb | 64 | AIM Backoff for partial populate |
| _kdt_buffering | TRUE | control kdt buffering for conventional inserts |
| _kdtgsp_retries | 1024 | max number of retries in kdtgsp if space returns same block |
| _kdu_array_depth | 16 | array update retry recursion depth limits |
| _kdz_clear_analysis_percent | 60 | percentage to clear dictionary analysis |
| _kdz_hcc_flags | 0 | Miscellaneous HCC flags |
| _kdz_hcc_track_upd_rids | FALSE | Enable rowid tracking during updates |
| _kdz_pcode_flags | 0 | pcode flags |
| _kdz_pred_nrows | 32767 | Number of rows to predicate at a time in kdzt |
| _kdz_proj_nrows | 1024 | Number of rows to project at a time in kdzt |
| _kdzk_enable_init_trace | FALSE | Enable kdzk initialization tracing |
| _kdzk_load_specialized_library | 3 | Flags for loading HPK specialized library |
| _kdzk_specialized_library_name | HPK specialized library name | |
| _kdzk_trace_level | 0 | HPK trace level |
| _kebm_autotask_cont_resource_schedule | FALSE | Enable/disable container resource schedule |
| _kebm_autotask_nstrikes | 3 | kebm # strikes to auto suspend an autotask |
| _kebm_max_parallel_autotasks | AUTO | maximum parallel autotask executions per instance |
| _kebm_nstrikes | 3 | kebm # strikes to auto suspend an action |
| _kebm_preshut_act_enabled | FALSE | Enable/disable MMON Pre-shutdown Action |
| _kebm_sanity_check_enabled | FALSE | Enable/disable MMON Action Sanity Check |
| _kebm_suspension_time | 104400 | kebm auto suspension time in seconds |
| _kecap_cache_size | 10240 | Workload Replay INTERNAL parameter used to set memory usage in Application Replay |
| _keep_19907_during_recovery | FALSE | keep until scn within recovery target check in recovery |
| _keep_relocated_source_pdb | FALSE | Move source pdb to unplugged state after relocation |
| _keep_remote_column_size | FALSE | remote column size does not get modified |
| _kernel_message_network_driver | FALSE | kernel message network driver |
| _kes_parse_model | 2 | SQL Tune/SPA KES Layer Parse Model control parameter |
| _kewm_simulate_oer4031 | 0 | Simulate OER(4031) for one or more Metric Groups |
| _kewm_trace_sga | FALSE | Enable/Disable Metrics SGA Allocation Tracing |
| _key_vector_alternate_dictionary | TRUE | enables or disables key vector alternate dictionary generation |
| _key_vector_create_pushdown_threshold | 20000 | minimum grouping keys for key vector create pushdown |
| _key_vector_double_enabled | TRUE | enables or disables key vector support for binary_double |
| _key_vector_force_alternate_dictionary | FALSE | stops key vector alternate dictionary from being disabled |
| _key_vector_join_pushdown_enabled | TRUE | enables or disables key vector join push down support |
| _key_vector_max_size | 0 | maximum key vector size (in KB) |
| _key_vector_offload | predicate | controls key vector offload to cells |
| _key_vector_predicate_enabled | TRUE | enables or disables key vector filter predicate pushdown |
| _key_vector_predicate_threshold | 0 | selectivity pct for key vector filter predicate pushdown |
| _key_vector_shared_dgk_ht | TRUE | allows shared DGK hash table |
| _key_vector_timestamp_enabled | TRUE | enables or disables key vector support for timestamp |
| _kffmap_hash_size | 1024 | size of kffmap_hash table |
| _kffmlk_hash_size | 512 | size of kffmlk_hash table |
| _kffmof_fprate | 1 | acceptable false positive rate [1-10000] of the kffmof bloom filter |
| _kffmof_size | 1048576 | number of entries of the kffmof opened files bloom filter |
| _kffmop_chunks | 42 | number of chunks of kffmop's |
| _kffmop_hash_size | 2048 | size of kffmop_hash table |
| _kffmop_list_check | FALSE | enable PGA mop list sanity check |
| _kffmspw_hash_size | 128 | size of kffmspw_hash table |
| _kfi_software_patchmap | value of patchmap for software | |
| _kfi_version_patchmap | pairs of version:patchmap for testing | |
| _kfm_disable_set_fence | FALSE | disable set fence calls and revert to default (process fence) |
| _kgh_free_list_min_effort | 12 | typical number of free list chunks to visit |
| _kgh_restricted_subheaps | 180 | number of subheaps in heap restricted mode |
| _kgh_restricted_trace | 0 | trace level for heap dump-restricted mode |
| _kghdsidx_count | 1 | max kghdsidx count |
| _kgl_bucket_bitvector | TRUE | Enable creation of PDB bit vector in KGL Hash Buckets |
| _kgl_bucket_bitvector_clear | TRUE | Enable clearing library cache bucket bit vector |
| _kgl_bucket_count | 9 | Library cache hash table bucket count (2^_kgl_bucket_count * 256) |
| _kgl_cluster_lock | TRUE | Library cache support for cluster lock |
| _kgl_cluster_lock_read_mostly | FALSE | Library cache support for cluster lock read mostly optimization |
| _kgl_cluster_pin | TRUE | Library cache support for cluster pins |
| _kgl_debug | Library cache debugging | |
| _kgl_fixed_extents | TRUE | fixed extent size for library cache memory allocations |
| _kgl_hash_collision | FALSE | Library cache name hash collision possible |
| _kgl_heap_size | 4096 | extent size for library cache heap 0 |
| _kgl_hot_object_copies | 0 | Number of copies for the hot object |
| _kgl_iterator_action | SKIP | Action to take if we dereference in-flux state in kgl iterator |
| _kgl_kqr_cap_so_stacks | 0 | capture stacks for library and row cache state objects |
| _kgl_large_heap_assert_threshold | 524288000 | maximum heap size before KGL raises an internal error |
| _kgl_large_heap_warning_threshold | 52428800 | maximum heap size before KGL writes warnings to the alert log |
| _kgl_latch_count | 0 | number of library cache latches |
| _kgl_message_locks | 0 | RAC message lock count |
| _kgl_min_cached_so_count | 1 | Minimum cached SO count. If > 1 can help find SO corruptions |
| _kgl_time_to_wait_for_locks | 15 | time to wait for locks and pins before timing out |
| _kglsim_maxmem_percent | 5 | max percentage of shared pool size to be used for KGL advice |
| _kgsb_threshold_size | 16777216 | threshold size for base allocator |
| _kgx_latches | 1024 | # of mutex latches if CAS is not supported. |
| _kill_controlfile_enqueue_blocker | TRUE | enable killing controlfile enqueue blocker on timeout |
| _kill_diagnostics_timeout | 60 | timeout delay in seconds before killing enqueue blocker |
| _kill_enqueue_blocker | 2 | if greater than 0 enables killing enqueue blocker |
| _kill_java_threads_on_eoc | FALSE | Kill Java threads and do sessionspace migration at end of call |
| _kill_session_dump | FALSE | Process dump on kill session immediate |
| _kjac_direct_path_enabled | TRUE | If direct path is enabled for TG |
| _kjac_force_outcome_current_session | FALSE | if TRUE, enable to run force outcome on the current session |
| _kjdd_call_stack_dump_enabled | FALSE | Enables printing of short call stack with the WFG |
| _kjdd_wfg_dump_cntrl | 0 | To control the way Wait-For_Graph is dumped |
| _kjltmaxgt | 1000 | record latch requests that takes longer than this many us |
| _kjltmaxht | 1000 | record latch reqeust that are held longer than this many us |
| _kjlton | FALSE | track DLM latch usage on/off |
| _kkfi_trace | FALSE | trace expression substitution |
| _kkpap_zm_pruning_cache | TRUE | cache result of recursive zonemap partition pruning query |
| _kkpogpi_nocpy | 1 | attempt to avoid partition metadata copy in kkpogpi |
| _kkpox_prtmv_rel_lock | 0 | explicitly release PRTMV heap during cursor compile |
| _kks_always_check_bind_equivalence | FALSE | Check bind equivalence every time |
| _kks_cached_parse_errors | 0 | KKS cached parse errors |
| _kks_obsolete_dump_threshold | 1 | Number of parent cursor obsoletions before dumping cursor |
| _kks_parse_error_warning | 100 | Parse error warning |
| _kktAllowInsteadOfDDLTriggeronDDL | 0 | Oracle internal parameter to allow instead of DDL triggers on specified DDLs |
| _kokli_cache_size | 128 | Size limit of ADT Table Lookup Cache |
| _kokln_current_read | FALSE | Make all LOB reads for this session 'current' reads |
| _kolfuseslf | FALSE | allow kolf to use slffopen |
| _kqdsn_cpu_digits | 3 | number of cpu digits in scalable sequence |
| _kqdsn_instance_digits | 2 | number of instance digits in scalable sequence |
| _kql_clientlocks_enabled | 15 | clients allocating DLM memory |
| _kql_subheap_trace | 0 | tracing level for library cache subheap level pins |
| _kqr_enable_conservative_logging | TRUE | log kgl/kqr objects conservativly in redo |
| _kqr_hot_copy_sample_size | 1000000 | number of mutex gets between periodic checks for hot objects |
| _kqr_hot_copy_sleep_limit | 500 | threshold of mutex sleeps to enable object hot copies |
| _kqr_max_hot_copies | 16 | upper limit of object hot copies allowed |
| _kqr_optimistic_reads | TRUE | optimistic reading of row cache objects |
| _kra_cfile_compaction | TRUE | controlfile record compation |
| _kra_trace_buffer_size | 131072 | size of I/O trace buffer |
| _krb_check_osd_block_endianess | TRUE | Check OSD Block Endianess |
| _krb_trace_buffer_size | 131072 | size of per-process I/O trace buffer |
| _krbabr_trace_buffer_size | 131072 | size of I/O trace buffer |
| _krc_trace_buffer_size | 131072 | size of I/O trace buffer |
| _krpm_trace_buffer_size | 262144 | size of per-process mira trace buffer |
| _ksb_restart_clean_time | 30000 | process uptime for restarts |
| _ksb_restart_policy_times | 0, 60, 120, 240 | process restart policy times in seconds |
| _ksd_test_param | 999 | KSD test parmeter |
| _ksdx_charset_ratio | 0 | ratio between the system and oradebug character set |
| _ksdxdocmd_default_timeout_ms | 30000 | default timeout for internal oradebug commands |
| _ksdxdocmd_enabled | TRUE | if TRUE ksdxdocmd* invocations are enabled |
| _ksdxw_cini_flg | 0 | ksdxw context initialization flag |
| _ksdxw_nbufs | 1000 | ksdxw number of buffers in buffered mode |
| _ksdxw_num_pgw | 10 | number of watchpoints on a per-process basis |
| _ksdxw_num_sgw | 10 | number of watchpoints to be shared by all processes |
| _ksdxw_stack_depth | 4 | number of PCs to collect in the stack when watchpoint is hit |
| _ksdxw_stack_readable | FALSE | dump readable stack when watchpoint is hit |
| _kse_alt_stack_sig_syms | 25 | The number of top symbols used for the alternate stack signature |
| _kse_auto_core | FALSE | generate core for unexpected SIGSEGV/SIGBUS |
| _kse_die_timeout | 60000 | amount of time a dying process is spared by PMON (in centi-secs) |
| _kse_pc_table_size | 256 | kse pc table cache size |
| _kse_signature_entries | 0 | number of entries in the kse stack signature cache |
| _kse_signature_limit | 7 | number of stack frames to cache per kse signature |
| _kse_snap_ring_disable | FALSE | set to TRUE or FALSE to disable or enable error logging |
| _kse_snap_ring_record_min | minimize recorded information in error stack history | |
| _kse_snap_ring_record_stack | FALSE | should error snap ring entries show a short stack trace |
| _kse_snap_ring_size | 100 | ring buffer to debug internal error 17090 |
| _kse_snap_ring_suppress | 942 1403 | List of error numbers to suppress in the snap error history |
| _kse_ssnt | FALSE | disables symbol translation in short stacks to make them faster |
| _kse_trace_int_msg_clear | FALSE | enables soft assert of KGECLEAERERROR is cleares an interrupt message |
| _ksfd_fob_pct | 0 | percentage of FOB state objects allocation |
| _ksfd_verify_write | FALSE | verify asynchronous writes issued through ksfd |
| _ksfdx_tests | ksfdx testing - INTERNAL USE ONLY! | |
| _ksfqp_row_count | 0 | row count of x$ksfqp |
| _ksgl_ltchs_held_ctxt | 8 | Average number of latches held per KSGL context |
| _ksgl_max_dyn_latches | 1024 | Maximum number of KSGL dynamic latches |
| _ksi_clientlocks_enabled | TRUE | if TRUE, DLM-clients can provide the lock memory |
| _ksi_pdb_checks | TRUE | if TRUE (default), do consistency checks on PDB IDs |
| _ksi_trace | KSI trace string of lock type(s) | |
| _ksi_trace_bucket | SHARED | memory tracing: use ksi-private or rdbms-shared bucket |
| _ksi_trace_bucket_size | LCK1:1048576-REST:8192 | KSI trace bucket size in bytes (format: "LCK1: |
| _ksim_time_monitor | auto | ksim layer time dynamic monitor and statistics |
| _ksipc_aspc_enabled | FALSE | is KSIPC Address Space Support Enabled |
| _ksipc_cksum_level | Configure IPC Checksum level for clients on a per transport basis | |
| _ksipc_common_sl | Configure a single SL value for all client/transport combinations | |
| _ksipc_efchecks | 3 | Check HCA/OS version for Exafusion |
| _ksipc_group_sz | 1024 | Configure KSIPC group size |
| _ksipc_heap_extent | 1048576 | KSIPC Heap Extent Size |
| _ksipc_ipclw_cksum_enable | 0 | Configure IPCLW cksum |
| _ksipc_ipclw_conn_dump | 0 | Configure IPCLW connection dump rate |
| _ksipc_ipclw_enable_param | ipclw parameter enablement | |
| _ksipc_ipclw_library_path | over-ride default location of lib ipclw | |
| _ksipc_ipclw_rcvbuf_mb | 0 | Configure IPCLW RCVBUF SIZE (in MB) |
| _ksipc_ipclw_spare_param2 | ksipc ipclw spare parameter 2 | |
| _ksipc_ipclw_spare_param3 | ksipc ipclw spare parameter 3 | |
| _ksipc_ipclw_spare_param4 | ksipc ipclw spare parameter 4 | |
| _ksipc_ipclw_spare_param5 | ksipc ipclw spare parameter 5 | |
| _ksipc_ipclw_spare_param6 | ksipc ipclw spare parameter 6 | |
| _ksipc_ipclw_spare_param7 | ksipc ipclw spare parameter 7 | |
| _ksipc_ipclw_spare_param8 | ksipc ipclw spare parameter 8 | |
| _ksipc_libipc_path | over-ride default location of libipc | |
| _ksipc_loopback_ips | KSIPC Loopback IP addresses | |
| _ksipc_mga_segment_size | 268435456 | KSIPC MGA Segment Size |
| _ksipc_mode | 0 | ksipc mode |
| _ksipc_netintr_timeout | ipq.KSMSQ_UDP_TRANS=30 | Specify the timeout for queueing network interrupt to a processon a per transport basis |
| _ksipc_service_level | Configure service level for clients on a per transport basis | |
| _ksipc_service_mask | 1 | KSIPC Service Mask |
| _ksipc_skgxp_compat_library_path | over-ride default location of lib skgxp compat | |
| _ksipc_skgxp_library_path | over-ride default location of lib skgxp | |
| _ksipc_spare_param1 | 0 | ksipc spare param 1 |
| _ksipc_spare_param3 | 0 | ksipc spare param 3 |
| _ksipc_spare_param4 | 0 | ksipc spare param 4 |
| _ksipc_spare_param5 | 0 | ksipc spare param 5 |
| _ksipc_trace_bucket | PRIVATE | memory tracing: use ksipc-private or rdbms-shared bucket |
| _ksipc_trace_bucket_size | IPC0:1048576-REST:8192 | KSIPC trace bucket size in bytes (format: "IPC0: |
| _ksipc_wait_flags | 0 | tune ksipcwait |
| _ksipc_window_size | Configure IPC Windowing Value for clients on a per transport basis | |
| _ksipcsnsrv | Configure Shared Nothing Server Name | |
| _ksm_post_sga_init_notif_delay_secs | 0 | seconds to delay instance startup at sga initialization (post) |
| _ksm_pre_sga_init_notif_delay_secs | 0 | seconds to delay instance startup at sga initialization (pre) |
| _ksm_shared_pool_stats_minsz | 524288 | min value for printing stats |
| _ksm_shared_pool_stats_num_pdb | 8 | number of pdbs to dump shared pool info for |
| _ksm_sp_rcr_hits | 10 | hits to make object recurrent |
| _ksmb_debug | 0 | ksmb debug flags |
| _ksmd_protect_mode | off | KSMD protect mode for catching stale access |
| _ksmd_trace | 0 | ksmd tracing |
| _ksmg_granule_size | 16777216 | granule size in bytes |
| _ksmlsaf | 0 | KSM log alloc and free |
| _ksmsq_conn_per_epoch | 0 | KSMSQ Connections Per Epoch |
| _ksmsq_hintmaxinst | 1024 | KSMSQ Hint Max Instances |
| _ksmsq_hintmaxproc | 320 | KSMSQ Hint Max Processes |
| _kspmx_enabled | FALSE | KSPMX Is Enabled |
| _kspmxs_flush_cache_size | 1 | KSPMXS flush cache size |
| _kspmxs_latch_freelists | 2 | Number of managed PMEM latch freelists |
| _kspmxs_latch_usid_map_size | 256 | KSPMXS latch usid map size |
| _kspmxs_max_regions | 64 | KSPMXS max regions |
| _kspmxs_max_waits | 4 | KSPMXS max waits |
| _kspmxs_txn_freelists | 32 | Number of PMEM transactions freelists |
| _kspmxs_upgrade_mutexes | 64 | KSPMXS upgrade mutex |
| _kspmxs_usid_map_size | 1024 | KSPMXS usid map size |
| _kspmxs_wait_buckets | 1024 | KSPMXS wait buckets |
| _kspol_tac_timeout | 5 | timeouts for TAC registerd by kspol |
| _ksr_control_dyn_flags | 0 | KSR dyanamic control flags |
| _ksr_control_flags | 0 | KSR control flags |
| _ksr_unit_test_processes | 0 | number of ksr unit test processes |
| _ksrma_enabled | AUTO | turn ksrma off, make it automatic, or turn on CMI or KSMSQ provider. Default is off |
| _ksrma_gsm_base_addr | Base Address to use for GSM | |
| _kss_callstack_type | state object callstack trace type | |
| _kss_quiet | TRUE | if TRUE access violations during kss dumps are not recorded |
| _ksu_diag_kill_time | 5 | number of seconds ksuitm waits before killing diag |
| _ksu_proc_percent_target | 50 | dynamic process usage target |
| _ksu_proc_percent_threshold | 70 | dynamic process usage threshold |
| _ksuitm_addon_trccmd | command to execute when dead processes don't go away | |
| _ksuitm_dont_kill_dumper | FALSE | delay inst. termination to allow processes to dump |
| _ksv_dynamic_flags1 | 0 | ksv dynamic flags 1 - override default behavior |
| _ksv_max_spawn_fail_limit | 5 | bg slave spawn failure limit |
| _ksv_pool_hang_kill_to | 0 | bg slave pool terminate timeout |
| _ksv_pool_wait_timeout | 600 | bg slave pool wait limit |
| _ksv_slave_exit_timeout | 120 | slave exit timeout |
| _ksv_spawn_control_all | FALSE | control all spawning of background slaves |
| _ksv_static_flags1 | 0 | ksv static flags 1 - override default behavior |
| _ksvppktmode | 0 | ksv internal pkt test |
| _ksws_alb_block_service | FALSE | enable ALB Blocking of overloaded service |
| _ksws_alb_session_age | 120 | KSWS ALB Minimum age(seconds) of session to consider marking |
| _ksws_alb_test_delta_override | 0 | KSWS ALB total sessions after which service is blocked |
| _ksws_alb_test_drain_timeout | 300 | KSWS ALB time in seconds before draining kicks in |
| _ksws_alb_test_load_balance_frequency | 300 | KSWS ALB Load Balance Frequency in deci seconds |
| _ksws_alb_test_load_percent | 106 | KSWS ALB Load Percentage to trigger marking for draining |
| _ksws_alb_test_selection_bias | 100 | KSWS ALB percentage of sessions to target |
| _ksws_enable_alb | TRUE | enable ALB metrics processing |
| _ksws_fallback_to_root | FALSE | KSWS Fallback to Root CDB service |
| _ksws_goodness_control | 1 | KSWS Goodness Control to Manually override |
| _ksws_java_patching | 0 | java patching mode |
| _ksws_modsvc_call_out_enabled | FALSE | modify service call out enabled |
| _ksws_rlb_cpu_busy_scope | TRUE | KSWS RLB CPU BUSY SCOPE |
| _ksws_use_placement_template_attribute | FALSE | use placement_template attribute |
| _kswsas_close_pdb_on_lstsvc | TRUE | Close a PDB when the last user service is stopped |
| _kswsas_db_svc_mapping | Map db service name to different service | |
| _kswsas_drain_kill_batch_size | 5 | Batch size for killing non-drained sessions |
| _kswsas_ht_log_size | 7 | kswsas_ht_log_size |
| _kswsas_num_jp_slaves | 0 | Number of slaves for java patching |
| _kswsas_pdb_auto_close_timeout | 600 | Close a PDB after the timeout |
| _ksxp_compat_flags | 0 | ksxp compat flags |
| _ksxp_control_flags | 0 | modify ksxp behavior |
| _ksxp_diagmode | OFF | set to OFF to disable automatic slowsend diagnostics |
| _ksxp_disable_clss | 0 | disable CLSS interconnects |
| _ksxp_disable_dynamic_loading | FALSE | disable dynamic loadin of lib skgxp |
| _ksxp_disable_ipc_stats | FALSE | disable ipc statistics |
| _ksxp_disable_rolling_migration | FALSE | disable possibility of starting rolling migration |
| _ksxp_dump_timeout | 20 | set timeout for kjzddmp request |
| _ksxp_dynamic_skgxp_param | dynamic skgxp parameters | |
| _ksxp_exa_ip_config | 0 | ksxp exa ip config |
| _ksxp_if_config | 0 | ksxp if config flags |
| _ksxp_init_stats_bkts | 0 | initial number arrays for ipc statistics |
| _ksxp_ipclw_enabled | 1 | enable ipclw for KSXP |
| _ksxp_ipclw_ptswinsz | 8 | KSXP port conn send window |
| _ksxp_ksmsq_ip_config | 0 | ksxp ksmsq ip config |
| _ksxp_lw_post_flags | 0 | tune ksxp post (lw) |
| _ksxp_max_stats_bkts | 0 | max. arrays for ipc statistics |
| _ksxp_ping_enable | TRUE | disable dynamic loadin of lib skgxp |
| _ksxp_ping_polling_time | 0 | max. arrays for ipc statistics |
| _ksxp_poll_netintr_timeout | 3600 | ksxp poll network interrupt timeout in seconds |
| _ksxp_reaping | 50 | tune ksxp layer reaping limit |
| _ksxp_reporting_process | LMD0 | reporting process for KSXP |
| _ksxp_save_sockets | 0 | Limit foreground process's sockets |
| _ksxp_save_sockets_pattern | * | Process pattern on which sockets saving is active |
| _ksxp_send_timeout | 300 | set timeout for sends queued with the inter-instance IPC |
| _ksxp_skgxp_ant_options | SKGXP ANT options | |
| _ksxp_skgxp_ctx_flags1 | 0 | IPC debug options flags (RAC) |
| _ksxp_skgxp_ctx_flags1mask | 0 | IPC debug options flags mask (RAC) |
| _ksxp_skgxp_dynamic_protocol | 4096 | IPC protocol override (RAC) (0/-1=*,2=UDP,3=RDS,!0x1000=ipc_X) |
| _ksxp_skgxp_inets | limit SKGXP networks | |
| _ksxp_skgxp_rgn_ports | 0 | region socket limits (0xFFFFNNXX): F=flags, N=min, X=max |
| _ksxp_skgxp_spare_param1 | ipc ksxp spare parameter 1 | |
| _ksxp_skgxp_spare_param2 | ipc ksxp spare parameter 2 | |
| _ksxp_skgxp_spare_param3 | ipc ksxp spare parameter 3 | |
| _ksxp_skgxpg_last_parameter | 27 | last defined skgxpg parameter - ksxp |
| _ksxp_spare_param1 | KSXP Spare Parameter 1 | |
| _ksxp_stats_mem_lmt | 0 | limit ipc statistics memory. this parameter is a percentage value |
| _ksxp_testing | 0 | KSXP test parameter |
| _ksxp_unit_test_byte_transformation | FALSE | enable byte transformation unit test |
| _ksxp_validate_cnh_life_cycle | 0 | enable validation of ksxp connection life cycle |
| _ksxp_wait_flags | 0 | tune ksxpwait |
| _ksxp_xrc_cm_port | override XRC CM port | |
| _ksz_dummy_parameter | Internal spare parameter for ksz.c | |
| _ksz_dummy_parameter2 | Internal spare parameter2 for ksz.c | |
| _ktb_debug_flags | 8 | ktb-layer debug flags |
| _ktc_debug | 0 | for ktc debug |
| _ktc_latches | 0 | number of ktc latches |
| _ktilm_uga_off | FALSE | Disable KTILM UGA cache activity tracking |
| _ktilmsc_exp | 600 | expiration time of ktilm segment cache (in second) |
| _ktslj_segext_max_mb | 0 | segment pre-extension max size in MB (0: unlimited) |
| _ktslj_segext_retry | 5 | segment pre-extension retry |
| _ktslj_segext_warning | 10 | segment pre-extension warning threshold in percentage |
| _ktslj_segext_warning_mb | 0 | segment pre-extension warning threshold in MB |
| _ktspsrch_maxsc | 1024 | maximum segments supported by space search cache |
| _ktspsrch_maxskip | 5 | space search cache rejection skip upper limit |
| _ktspsrch_scchk | 60 | cleanout check time of space search cache |
| _ktspsrch_scexp | 60 | expiration time of space search cache |
| _ktst_rss_max | 1000 | maximum temp extents to be released across instance |
| _ktst_rss_min | 100 | minimum temp extents to be released across instance |
| _ktst_rss_retry | 5 | maximum retries of sort segment release |
| _ktt_tsid_reuse_threshold | 60000 | tablespace id reuse threshold |
| _ktte_ts_shrink_group | 6 | tablespace shrink group |
| _ktte_ts_shrink_interval | 3600 | tablespace shrink interval |
| _kttext_warning | 1285 | tablespace pre-extension and shrink warning threshold in percentage |
| _ktu_latches | 0 | number of KTU latches |
| _ku_trace | none | datapump trace parameter |
| _kxdbio_ctx_init_count | 32 | initial count of KXDBIO state object |
| _kxdbio_disable_offload_opcode | 0 | KXDBIO Disable offload for the set opcodes. Value is a Bitmap of 0x00000001 - disable cell to cell data copy offload 0x00000002 - disable disk scrubbing offload to cell 0x00000004 - disable offloaded writes to cell |
| _kxdbio_enable_ds_opcode | 0 | KXDBIO Enable Dumb storage simulation for the set opcodes. |
| _kxdbio_hca_loadavg_thresh | 74 | HCA loadavg threshold at which writes need to get offloaded |
| _kxdbio_offena_timeout | 7200000 | kxdbio re-enable offloaded write timeout |
| _kxdbio_ut_ctl | 0 | kxdbio unit test controls |
| _kxscio_cap_stacks | FALSE | capture location when kxscio is set to null |
| _large_pool_min_alloc | 65536 | minimum allocation size in bytes for the large allocation pool |
| _last_allocation_period | 5 | period over which an instance can retain an active level1 bitmap |
| _latch_class_0 | latch class 0 | |
| _latch_class_1 | latch class 1 | |
| _latch_class_2 | latch class 2 | |
| _latch_class_3 | latch class 3 | |
| _latch_class_4 | latch class 4 | |
| _latch_class_5 | latch class 5 | |
| _latch_class_6 | latch class 6 | |
| _latch_class_7 | latch class 7 | |
| _latch_classes | latch classes override | |
| _latch_miss_stat_sid | 0 | Sid of process for which to collect latch stats |
| _latch_pause_count | 0 | Latch pause count |
| _latch_pause_mode | static | Latch pause mode |
| _latch_wait_list_pri_sleep_secs | 1 | Time to sleep on latch wait list until getting priority |
| _ldap_adaptive_to_no_nested_group_search | TRUE | LDAP adaptive to no nested group search |
| _ldap_config_force_sync_up | FALSE | LDAP configure force sync up |
| _ldap_config_ssl_for_sasl_md5 | TRUE | LDAP configure SSL for SASL-DIGEST-MD5 |
| _ldap_no_nested_group_search | FALSE | LDAP no nested group search |
| _ldap_password_oneway_auth | FALSE | Use oneway auth for password based LDAP directory bind |
| _ldap_reset_user_account_flc | TRUE | LDAP reset user account lockout counter |
| _ldap_use_all_direct_groups_only | TRUE | LDAP use all direct groups only |
| _ldap_warning_on_multi_shared_mappings | FALSE | LDAP warning on multiple shared mappings |
| _ldr_io_size | 1048576 | size of write IOs used during a load operation |
| _ldr_pga_lim | 0 | pga limit, beyond which new partition loads are delayed |
| _ldr_tempseg_threshold | 8388608 | amount to buffer prior to allocating temp segment (extent sizing) |
| _left_nested_loops_random | TRUE | enable random distribution method for left of nestedloops |
| _lgwr_delay_write | FALSE | LGWR write delay for debugging |
| _lgwr_io_outlier | 0 | LGWR I/O outlier frequency |
| _lgwr_io_slaves | 0 | LGWR I/O slaves |
| _lgwr_max_ns_wt | 1 | Maximum wait time for lgwr to allow NetServer to progress |
| _lgwr_ns_nl_max | 1000 | Variable to simulate network latency or buffer threshold |
| _lgwr_ns_nl_min | 500 | Variable to simulate network latency or buffer threshold |
| _lgwr_ns_sim_err | 0 | Variable to simulate errors lgwrns |
| _lgwr_posts_for_pending_bcasts | FALSE | LGWR posts commit waiters for pending broadcasts |
| _lgwr_ta_sim_err | 0 | Variable to simulate errors lgwr true async |
| _library_cache_advice | TRUE | whether KGL advice should be turned on |
| _library_cache_dump_cooling_period | 10 | Period to wait (in minutes) before resetting dump count |
| _library_cache_dump_interval | 0 | Interval (in seconds) between each dump |
| _light_work_rule_debug | FALSE | if TRUE, light work rule debugging is enabled |
| _lightweight_hdrs | TRUE | Lightweight headers for redo |
| _like_with_bind_as_equality | FALSE | treat LIKE predicate with bind as an equality predicate |
| _limit_itls | 20 | limit the number of ITLs in OLTP Compressed Tables |
| _link_ts_force_online | TRUE | force linked tablespace to be online |
| _link_ts_name | Name of linked tablespace | |
| _listener_registration_retry_secs | 60 | listener registration retry time (in seconds) |
| _lm_activate_lms_threshold | 100 | threshold value to activate an additional lms |
| _lm_adrm_interval | 300 | active drm interval in centiseconds |
| _lm_adrm_options | 3 | active drm options |
| _lm_adrm_scan_timeout | 50 | active drm f2a/flush scan timeout in centisecs |
| _lm_adrm_time_out | 120 | active drm timeout in minutes |
| _lm_asm_enq_hashing | TRUE | if TRUE makes ASM use enqueue master hashing for fusion locks |
| _lm_async_da | FALSE | enable async da requests |
| _lm_batch_compression_threshold | 0 | GES threshold to start compression on batch messages |
| _lm_better_ddvictim | TRUE | GES better deadlock victim |
| _lm_big_cluster_optimizations | TRUE | enable certain big cluster optimizations in drm |
| _lm_broadcast_res | enable_broadcast | Enable broadcast of highest held mode of resource. |
| _lm_cache_allocated_res_ratio | 50 | ratio of cached over allocated resources |
| _lm_cache_enqueue | string of enqueues to cache at the client: separate by | |
| _lm_cache_lvl0_cleanup | 0 | how often to cleanup level 0 cache res (in sec) |
| _lm_cache_res_cleanup | 25 | percentage of cached resources should be cleanup |
| _lm_cache_res_cleanup_tries | 10 | max number of batches of cached resources to free per cleanup |
| _lm_cache_res_options | 0 | ges resource cache options |
| _lm_cache_res_skip_cleanup | 20 | multiple of iniital res cache below which cleanup is skipped |
| _lm_cache_res_type | TMHWHVDI | cache resource: string of lock types(s) |
| _lm_check_ges_resource | 0 | GES: additional checks during resource allocation (0 |
| _lm_checksum_batch_msg | 0 | GES checksum batch messages |
| _lm_chk_inv_domenq_ops | TRUE | enable checks for invalid enqueue operations on domains |
| _lm_comm_channel | msgq | GES communication channel type |
| _lm_comm_msgq_bufr_multiple | 8 | MSGQ_DRMQ multiple for maximum buffers |
| _lm_comm_msgq_busywait | 0 | busy wait time in microsecond for msgq |
| _lm_comm_msgq_copy_buffers | FALSE | MSGQ_DRMQ copy msgs to new buffer |
| _lm_comm_msgq_fixed_buffers | FALSE | MSGQ with fixed number of receive buffers |
| _lm_comm_rcv_msg_history_slots | 50 | GES communication receive message history slots |
| _lm_comm_reap_count | 1 | message reap count for receive |
| _lm_comm_send_proxy_nr_delay | 10 | Send proxy delay before sending NULLREQ |
| _lm_comm_send_proxy_tkt_return | TRUE | Allow send proxy to return tickets |
| _lm_comm_slow_op_loop_threshold | 15 | GES communication slow operation loop threshold in ms |
| _lm_comm_slow_op_spx_loop_threshold | 30000 | GES comm slow spx operation loop threshold in microsec |
| _lm_comm_slow_op_stat_dump_threshold | 5 | GES communication slow operation stat dump threshold in sec |
| _lm_comm_sync_seq_on_send_failure | TRUE | GES communication sync seq for failed sends after reconfig |
| _lm_comm_tkts_adaptive | TRUE | Adpative ticketing enabled |
| _lm_comm_tkts_adpt_rsv | 1 | Adpative ticketing reserve multiple |
| _lm_comm_tkts_calc_period_length | 100000 | Weighted average calculation interval length (us) |
| _lm_comm_tkts_max_add | 5 | Ticket allocation maximum allotments |
| _lm_comm_tkts_max_periods | 10 | Max number of periods used in weighted avearage calculation |
| _lm_comm_tkts_min_decrease_wait | 120 | Seconds to wait before allowing an allocation decrease |
| _lm_comm_tkts_min_increase_wait | 10 | Seconds to wait before allowing an allocation increase |
| _lm_comm_tkts_mult_factor | 1 | Ticket allocation multiplication factor |
| _lm_comm_tkts_nullreq_threshold | 1 | Null request threshold |
| _lm_comm_tkts_sub_factor | 10 | Ticket allocation subtraction factor |
| _lm_compression_scheme | zlib | GES compression scheme |
| _lm_contiguous_res_count | 128 | number of contiguous blocks that will hash to the same HV bucket |
| _lm_da_win_enable | TRUE | enable da windowing |
| _lm_da_window | 1 | number of windows in domain action |
| _lm_da_window_interval | 0 | Interval in centiseconds between each domain action window |
| _lm_db_rank | 6 | rank of this DB for process priority purposes |
| _lm_db_ranks | ranks of DBs on this node | |
| _lm_dd_ignore_nodd | FALSE | if TRUE nodeadlockwait/nodeadlockblock options are ignored |
| _lm_dd_interval | 10 | dd time interval in seconds |
| _lm_dd_max_search_time | 180 | max dd search time per token |
| _lm_dd_maxdump | 50 | max number of locks to be dumped during dd validation |
| _lm_dd_scan_interval | 5 | dd scan interval in seconds |
| _lm_dd_search_cnt | 3 | number of dd search per token get |
| _lm_default_failure_action | 0 | default failure action |
| _lm_deferred_msg_timeout | 163 | deferred message timeout |
| _lm_domain_hash_buckets | 64 | number of buckets for the domains hash table |
| _lm_drm_banned_objs | list of objects not allowed to do drm | |
| _lm_drm_batch_time | 10 | time in seconds to wait to batch drm requests |
| _lm_drm_disable | 0 | disable drm in different level |
| _lm_drm_disable_kjfc | FALSE | disable drm at kjfc level |
| _lm_drm_duration_limit | set drm object duration limit (secs time/object size) | |
| _lm_drm_duration_limit_type | 2 | drm object time limit type (time/size) |
| _lm_drm_filter_history_window | drm filter history window | |
| _lm_drm_filter_history_window_type | 2 | drm object time limit type (time/size) |
| _lm_drm_filters | 3 | enable drm filters |
| _lm_drm_hiload_percentage | 200 | drm high load threshold percentage |
| _lm_drm_lowload_percentage | 200 | drm low load threshold percentage |
| _lm_drm_max_banned_objs | 235 | maximum number of objects not allowed to do drm |
| _lm_drm_max_requests | 100 | dynamic remastering maximum affinity requests processed together |
| _lm_drm_min_interval | 600 | minimum interval in secs between two consecutive drms |
| _lm_drm_object_scan | TRUE | enable/disable object scan to force full table scan always |
| _lm_drm_we_interval | 60 | drm wait events collection interval in seconds |
| _lm_drm_we_size | 2000 | size of drm wait events statistics |
| _lm_drm_window | 0 | dynamic remastering bucket window size |
| _lm_drm_xlatch | 0 | dynamic remastering forced exclusive latches |
| _lm_drmopt12 | 56 | enable drm scan optimizations in 12 |
| _lm_dump_null_lock | FALSE | dump null lock in state dump |
| _lm_dynamic_lms | FALSE | dynamic lms invocation |
| _lm_dynamic_load | TRUE | dynamic load adjustment |
| _lm_dynamic_sga_target | dynamically adjust for changes in SGA size | |
| _lm_enable_aff_benefit_stats | FALSE | enables affinity benefit computations if TRUE |
| _lm_enable_pdb_abort | 0 | enable pdb abort as default failure action |
| _lm_enable_translation | FALSE | tells if KJURN_PDBID should translate using kpdb calls |
| _lm_enq_iso_enabled | TRUE | if TRUE enables enqueue isolation |
| _lm_enq_lock_freelist | Number of ges enqueue element freelist | |
| _lm_enq_rcfg | TRUE | if TRUE enables enqueue reconfiguration |
| _lm_enqueue_blocker_dump_timeout | 120 | enqueue blocker dump timeout |
| _lm_enqueue_blocker_dump_timeout_cnt | 30 | enqueue blocker dump timeout count |
| _lm_enqueue_blocker_kill_timeout | 0 | enqueue blocker kill timeout |
| _lm_enqueue_freelist | 3 | Number of enqueue freelist |
| _lm_enqueue_timeout | 360 | enqueue suggested min timeout in seconds |
| _lm_exadata_fence_type | TRUE | if FALSE disable Exadata fence type |
| _lm_fdrm_stats | FALSE | gather full drm statistics |
| _lm_file_affinity | mapping between file id and master instance number | |
| _lm_file_read_mostly | mapping between read-mostly file id and master instance number | |
| _lm_free_queue_threshold | 0 | GES free queue threshold |
| _lm_freeze_kill_time | 30 | timeout for killing unfrozen processes in rcfg/drm freeze step |
| _lm_gcs_rht_alloc_size | 4096 | gcs rht allocation chunk size |
| _lm_ges_rht_alloc_size | 4096 | ges rht allocation chunk size |
| _lm_ges_rht_mem_pct | 15 | options to size RHT structures per pdb |
| _lm_gl_hash_scheme | 1 | group lock table hashing scheme (0 |
| _lm_global_posts | TRUE | if TRUE deliver global posts to remote nodes |
| _lm_hash_control | 5 | bit field controlling the hashing behavior of the lock manager |
| _lm_hashtable_bkt_high | 5 | High element threshold in hash table bucket |
| _lm_hashtable_bkt_low | 3 | Low element threshold in hash table bucket |
| _lm_hashtable_bkt_thr | 70 | Threshold for hash table resizing |
| _lm_hb_acceptable_hang_condition | default | list of acceptable hang conditions in heartbeat check |
| _lm_hb_callstack_collect_time | 5 | hb diagnostic call stack collection time in seconds |
| _lm_hb_callstack_collect_time_long | 60 | extended hb diagnostic call stack collection time in seconds |
| _lm_hb_cfio_timeout | 70 | control file io timeout in seconds |
| _lm_hb_disable_check_list | ARC* | list of process names to be disabled in heartbeat check |
| _lm_hb_enable_acl_check | TRUE | to enable the wait analysis with acceptable condition lists |
| _lm_hb_exponential_hang_time_factor | 2 | heartbeat exponential hang time multiplier |
| _lm_hb_lgio_timeout | 70 | LGWR io timeout in seconds |
| _lm_hb_maximum_hang_report_count | 20 | maximum heartbeat hang report count |
| _lm_hb_per_proc_behavior | default | heartbeat behavior |
| _lm_hb_per_proc_timeout | default | heartbeat timeout |
| _lm_hb_timeout_extension | heartbeat timeout extension in seconds | |
| _lm_high_load_sysload_percentage | 90 | high watermark system load percentage |
| _lm_high_load_threshold | 5 | high load threshold parameter |
| _lm_hwc_disabled | FALSE | to disable handle with care behavior |
| _lm_idle_connection_action | kill | GES idle connection action |
| _lm_idle_connection_check | TRUE | GES idle connection check |
| _lm_idle_connection_check_interval | 140 | GES idle connection check interval time |
| _lm_idle_connection_instance_check_callout | TRUE | GES idle connection instance check callout |
| _lm_idle_connection_kill | TRUE | GES idle connection kill |
| _lm_idle_connection_kill_max_skips | 1 | GES idle connection max skip kill request |
| _lm_idle_connection_load_check | TRUE | GES idle connection load check |
| _lm_idle_connection_max_ignore_kill_count | 2 | GES maximum idle connection kill request ignore count |
| _lm_idle_connection_quorum_threshold | 50 | GES idle connection health quorum threshold |
| _lm_inherited_max_requests | 100 | maximum inherited affinity dissolve requests processed together |
| _lm_kill_fg_on_timeout | TRUE | GES kill fg on IPC timeout |
| _lm_lazy_domain_timeout | 600 | lazy domain timeout in seconds |
| _lm_lazy_recovery_member_timeout | 300 | lazy recovery member detach timeout in seconds |
| _lm_lhupd_interval | 5 | load and health update interval |
| _lm_lmd_waittime | 8 | default wait time for lmd in centiseconds |
| _lm_lmon_nowait_latch | TRUE | if TRUE makes lmon get nowait latches with timeout loop |
| _lm_lms | 0 | number of background gcs server processes to start |
| _lm_lms_no_yield | FALSE | if TRUE, LMS will not yield in spin mode |
| _lm_lms_opt_priority | TRUE | enable freeslot lms priority optimization |
| _lm_lms_priority_check_frequency | 60000 | frequency of LMS priority decisions in milliseconds |
| _lm_lms_priority_dynamic | TRUE | enable lms priority modification |
| _lm_lms_rt_threshold | maximum number of real time lms processes on machine | |
| _lm_lms_spin | FALSE | make lms not sleep |
| _lm_lms_waittime | 3 | default wait time for lms in centiseconds |
| _lm_local_hp_enq | TRUE | use static file affinity for HP enqueue mastership |
| _lm_locks | 12000 | number of enqueues configured for cluster database |
| _lm_low_load_percentage | 75 | low watermark percentage for load threshold |
| _lm_master_weight | 1 | master resource weight for this instance |
| _lm_max_lms | 0 | max. number of background global cache server processes |
| _lm_max_lms_block_time | 5 | max blocking time allowed on LMS (sec) |
| _lm_mp_additional_big_buffers | 20 | GES MP extra big buffers per pool |
| _lm_mp_additional_reg_buffers | 20 | GES MP extra regular buffers per pool |
| _lm_mp_avail_queue_threshold | 0 | GES MP avail queue threshold |
| _lm_mp_bulk_mbuf_free | FALSE | GES MP bulk free message buffer queues |
| _lm_mp_expand_big_pool_percent | 1 | GES MP expand big pool |
| _lm_mp_expand_reg_pool_percent | 5 | GES MP expand regular pool |
| _lm_mp_latch_trigger | 4000 | GES MP Latch trigger threshold for trace lines |
| _lm_mp_latch_trigger_soft | 40000 | GES MP Latch trigger threshold for soft assert |
| _lm_mp_share_lms_pools | TRUE | GES MP share LMS pools with critical BGs |
| _lm_mp_small_lms_pools | TRUE | GES MP small regular pool for LMS when not sharing |
| _lm_msg_batch_size | 0 | GES batch message size |
| _lm_msg_cleanup_interval | 3000 | GES message buffer cleanup interval time |
| _lm_msg_pool_dump_threshold | 20000 | GES message pool dump threshold in terms of buffer count |
| _lm_msg_pool_user_callstack_dump | FALSE | GES message pool call stack dump upon exceeding of threshold |
| _lm_new_esm | 1 | use new enter server mode code |
| _lm_no_lh_check | FALSE | skip load and health check at decision points |
| _lm_no_sync | TRUE | skip reconfiguration/drm syncr/synca messaging |
| _lm_node_join_opt | FALSE | cluster database node join optimization in reconfig |
| _lm_non_fault_tolerant | FALSE | disable cluster database fault-tolerance mode |
| _lm_nonisolated_restype | TOTTUL | string of resource types banned from enqueue isolation |
| _lm_num_bnft_stats_buckets | 1 | number of buckets in the benefit stats hash table |
| _lm_num_msg_pools_per_type | 1 | number of GES message pools per type |
| _lm_num_pt_buckets | 8192 | number of buckets in the object affinity hash table |
| _lm_num_pt_latches | 128 | number of latches in the object affinity hash table |
| _lm_omni_ack_timeout | 60 | Max time to wait for omni acks before triggering netcheck in secs |
| _lm_optmode_switch | 0 | GES: Optmode switching for enqueues (none, manual, stats-driven) |
| _lm_pdb_domains_enable | 7 | enable pdb domains in DLM |
| _lm_pdb_wait_all_gone | FALSE | pdb domain attach wait until all locks are gone |
| _lm_pdb_weight_opts | 27 | options to size RHT structures per pdb |
| _lm_postevent_buffer_size | 256 | postevent buffer size |
| _lm_preregister_css_restype | CF | enqueue type that requires pre-registration to css |
| _lm_proc_freeze_timeout | 70 | reconfiguration: process freeze timeout |
| _lm_process_batching | TRUE | GES implicit process batching for IPC messages |
| _lm_process_lock_q_scan_limit | 100 | limit on scanning process lock queue instead of resource convert lock queue |
| _lm_procs | 1088 | number of client processes configured for cluster database |
| _lm_psrcfg | TRUE | enable pseudo reconfiguration |
| _lm_rac_spare_dp1 | 0 | rac parameter dp1 |
| _lm_rac_spare_dp10 | rac parameter dp10 | |
| _lm_rac_spare_dp2 | 0 | rac parameter dp2 |
| _lm_rac_spare_dp3 | 0 | rac parameter dp3 |
| _lm_rac_spare_dp4 | 0 | rac parameter dp4 |
| _lm_rac_spare_dp5 | 0 | rac parameter dp5 |
| _lm_rac_spare_dp6 | rac parameter dp6 | |
| _lm_rac_spare_dp7 | rac parameter dp7 | |
| _lm_rac_spare_dp8 | rac parameter dp8 | |
| _lm_rac_spare_dp9 | rac parameter dp9 | |
| _lm_rac_spare_p1 | 0 | rac parameter p1 |
| _lm_rac_spare_p10 | rac parameter p10 | |
| _lm_rac_spare_p11 | 0 | rac parameter p11 |
| _lm_rac_spare_p12 | 0 | rac parameter p12 |
| _lm_rac_spare_p13 | 0 | rac parameter p13 |
| _lm_rac_spare_p14 | rac parameter p14 | |
| _lm_rac_spare_p15 | rac parameter p15 | |
| _lm_rac_spare_p16 | rac parameter p16 | |
| _lm_rac_spare_p2 | 0 | rac parameter p2 |
| _lm_rac_spare_p3 | 0 | rac parameter p3 |
| _lm_rac_spare_p4 | 0 | rac parameter p4 |
| _lm_rac_spare_p5 | 0 | rac parameter p5 |
| _lm_rac_spare_p6 | rac parameter p6 | |
| _lm_rac_spare_p7 | rac parameter p7 | |
| _lm_rac_spare_p8 | rac parameter p8 | |
| _lm_rac_spare_p9 | rac parameter p9 | |
| _lm_rcfg_kjcdump_time | 60 | dlm reconfiguration communication dump interval |
| _lm_rcfg_timeout | 489 | dlm reconfiguration timeout |
| _lm_rcvinst | TRUE | instance inheritance |
| _lm_rcvinst_atp_opt | TRUE | recovery instance optimization for ATP |
| _lm_rcvinst_sga_threshold | 85 | recovery buddy SGA threshold |
| _lm_rcvr_hang_allow_time | 70 | receiver hang allow time in seconds |
| _lm_rcvr_hang_cfio_kill | FALSE | to kill receiver hang at control file IO |
| _lm_rcvr_hang_check_frequency | 20 | receiver hang check frequency in seconds |
| _lm_rcvr_hang_check_system_load | TRUE | examine system load when check receiver health |
| _lm_rcvr_hang_kill | TRUE | to kill receiver hang |
| _lm_rcvr_hang_systemstate_dump_level | 0 | systemstate dump level upon receiver hang |
| _lm_receiver_type | 0 | receiver thread type performing receive function |
| _lm_recovery_pdbw_reduction | 4 | recovery member pdbw reduction |
| _lm_recovery_set | 1 | enable recovery set checking for accessing invalid domains |
| _lm_reloc_use_mhint | FALSE | if TRUE, AR-/AH-enqueues use mastering hints |
| _lm_res_hash_bucket | 0 | number of resource hash buckets |
| _lm_res_part | 128 | number of resource partition configured for gcs |
| _lm_res_tm_hash_bucket | 0 | number of extra TM resource hash buckets |
| _lm_resend_open_convert_timeout | 30 | timeout in secs before resubmitting the open-convert |
| _lm_resource_recycle_cnt | 32 | GES: number of resources to recycle optimization |
| _lm_ress | 6000 | number of resources configured for cluster database |
| _lm_rm_object_bypass | TRUE | enable read-mostly object bypass for HARIM |
| _lm_rm_slaves | 1 | number of remastering slaves |
| _lm_send_mode | auto | GES send mode |
| _lm_send_queue_batching | TRUE | GES send queue message batching |
| _lm_send_queue_length | 5000 | GES send queue maximum length |
| _lm_sendproxy_reserve | 25 | GES percentage of send proxy reserve of send tickets |
| _lm_share_lock_opt | TRUE | if TRUE enables share lock optimization |
| _lm_share_lock_pdbisolation | TRUE | if TRUE enables share lock optimization with pdb isolation |
| _lm_share_lock_restype | string of enqueue resource types eligible for S-optimisation | |
| _lm_single_inst_affinity_lock | FALSE | enable single instance affinity lock optimization |
| _lm_singleton_pdb_opt | TRUE | RAC PDB singleton optimization |
| _lm_sndq_flush_int | 5 | send queue flush time interval (ms) |
| _lm_sp_slave_mode | 0 | sendproxy slave operation mode |
| _lm_sp_slaves | 0 | number of sendproxy slaves |
| _lm_spare_threads | 0 | number of spare threads to be created by the GPnP master |
| _lm_spare_undo | 0 | number of spare undo tablespaces to be created by GPnP master |
| _lm_sq_batch_factor | 2 | GES send queue minimum batching factor |
| _lm_sq_batch_type | auto | GES send queue batching mechanism |
| _lm_sq_batch_waittick | 3 | GES send queue batching waittime in tick |
| _lm_sync_timeout | 163 | Synchronization timeout for DLM reconfiguration steps |
| _lm_throttle_time_interval | 60 | GES message throttle interval time in sec |
| _lm_ticket_active_sendback | 50 | Flow control ticket active sendback threshold |
| _lm_ticket_check_inject | FALSE | Inject tickets when flow control tkt leak discoverd |
| _lm_ticket_low_limit_warning | 10 | lowest number of avail tickets percentage threshold warning |
| _lm_ticket_min | 50 | GES messaging tickets per instance minimum |
| _lm_tickets | 1000 | GES messaging tickets |
| _lm_timed_statistics_level | 0 | if non zero, it enables timed statistics on lmd and lms |
| _lm_tkt_leak_check_count | 5 | Consecutive low NULLACKs to trigger leak check |
| _lm_tkt_leak_check_seconds | 300 | Duration of leak check in seconds |
| _lm_tx_delta | 16 | TX lock localization delta |
| _lm_uid_default_lookup_value | TRUE | returns the default value for uid to id translation |
| _lm_use_gcr | TRUE | use GCR module if TRUE |
| _lm_use_new_defmsgtmo_action | TRUE | use new defered msg queue timeout action |
| _lm_use_tx_tsn | TRUE | use undo tsn affinity master as TX enqueue master |
| _lm_use_us_timer | FALSE | Use microsecond timer for LM hist |
| _lm_validate_pbatch | FALSE | GES process batch validation |
| _lm_wait_for_hub_rcv_timeout | 300000 | read-only insts wait for hub avaliable to recover in millis |
| _lm_wait_pending_send_queue | TRUE | GES wait on pending send queue |
| _lm_watchpoint_kjmddp | list of kjmddp fields for memory watchpoint | |
| _lm_watchpoint_maximum | 3 | GES number of watchpoints |
| _lm_watchpoint_timeout | 3600 | GES maximum time in seconds to keep watchpoint |
| _lm_wrkr_mode | 0 | LMS worker thread mode |
| _lm_wrkr_slaves | 0 | number of LMS worker slaves |
| _lm_xids | 1196 | number of transaction IDs configured for cluster database |
| _lmhb_max_dynamic_hb | 10 | max number of proc heartbeats that can be dynamically monitored |
| _lmhb_procstate_dump_cputime_limit | 60 | hb diagnostic cputime limit for process state dump in secs |
| _lmhb_procstate_dump_runtime_limit | 60 | hb diagnostic runtime limit for process state dump in secs |
| _lmn_invalidlkr_enabled | TRUE | suppl logging for invalid lkr enabled |
| _lms_rollbacks | 1000 | Maximum number of CR rollbacks per block under LMS |
| _load_without_compile | none | Load PL/SQL or Database objects without compilation |
| _lob_use_locator_varying_width | FALSE | use varying width flag in lob locator |
| _local_arc_assert_on_wait | FALSE | Assert whenever local ORL arch waits for space |
| _local_communication_costing_enabled | TRUE | enable local communication costing when TRUE |
| _local_communication_ratio | 50 | set the ratio between global and local communication (0..100) |
| _local_hang_analysis_interval_secs | 3 | the interval at which local hang analysis is run |
| _lock_dc_users_time | 120 | max time to attempt to lock dc_users |
| _lock_next_constraint_count | 3 | max number of attempts to lock _NEXT_CONSTRAINT |
| _lock_ref_constraint_count | 50 | number of nowait attempts to lock referential constraint |
| _lock_ref_descendants_count | 50 | number of nowait attempts to lock ref-partitioning descendants |
| _log_archive_buffers | 10 | Number of buffers to allocate for archiving |
| _log_archive_network_redo_size | 10 | Log archive network redo buffer size used by ARCH |
| _log_archive_prot_auto_demote | FALSE | log archive protection auto demotion |
| _log_archive_strong_auth | TRUE | log archive security strong auth |
| _log_archive_trace_pids | log archive trace pids parameter | |
| _log_blocks_during_backup | TRUE | log block images when changed during backup |
| _log_buffer_coalesce | FALSE | Coalescing log buffers for log writes |
| _log_buffers_corrupt | FALSE | corrupt redo buffers before write |
| _log_buffers_debug | FALSE | debug redo buffers (slows things down) |
| _log_checkpoint_recovery_check | 0 | # redo blocks to verify after checkpoint |
| _log_committime_block_cleanout | FALSE | Log commit-time block cleanout |
| _log_deletion_policy | mandatory | archivelog deletion policy for mandatory/all destination |
| _log_file_sync_timeout | 10 | Log file sync timeout (centiseconds) |
| _log_max_optimize_threads | 128 | maximum number of threads to which log scan optimization is applied |
| _log_parallelism_dynamic | TRUE | Enable dynamic strands |
| _log_parallelism_max | 2 | Maximum number of log buffer strands |
| _log_private_mul | 5 | Private strand multiplier for log space preallocation |
| _log_private_parallelism_mul | 10 | Active sessions multiplier to deduce number of private strands |
| _log_read_buffer_size | 8 | buffer size for reading log files |
| _log_read_buffers | 8 | Number of log read buffers for media recovery |
| _log_segment_dump_parameter | TRUE | Dump KSP on Log Segmentation |
| _log_segment_dump_patch | TRUE | Dump Patchinfo on Log Segmentation |
| _log_silicon_secured_memory | TRUE | enable silicon secured memory (log) |
| _log_simultaneous_copies | 8 | number of simultaneous copies into redo buffer(# of copy latches) |
| _log_space_errors | TRUE | should we report space errors to alert log |
| _log_switch_timeout | 0 | Maximum number of seconds redos in the current log could span |
| _log_switch_tracing_iterations | 5 | no. of iterations to trace after logswitch timeout |
| _log_switch_tracing_timeout | 200 | dbwr to trace after logswitch timeout in secs |
| _log_write_info_size | 4096 | Size of log write info array |
| _log_write_worker_post_spinwait | 0 | How long log write workers spin wait before posting FGs |
| _log_write_worker_task_prefetch | EARLY | Log write worker prefetches tasks |
| _log_write_worker_task_spinwait | 0 | How long log write workers spin wait for imminent tasks |
| _log_writer_worker_dlm_hearbeat_update_freq | 5000 | LGWR worker DLM health-monitoring heartbeat update frequency (ms) |
| _logminer_parallel_read | TRUE | LogMiner parallel read |
| _logout_storm_rate | 0 | number of processes that can logout in a second |
| _logout_storm_retrycnt | 600 | maximum retry count for logouts |
| _logout_storm_timeout | 5 | timeout in centi-seconds for time to wait between retries |
| _long_bcast_ack_warning_threshold | 500 | threshold for long bcast ack warning messages in ms |
| _long_log_write_warning_threshold | 500 | threshold for long log write warning messages in ms |
| _longops_enabled | TRUE | longops stats enabled |
| _longops_per_latch | 64 | number of longops to allocate per latch |
| _lost_write_parallelism_change_tracking | 2 | Maximum number of lost write change tracking buffers |
| _low_scn_headroom_warning_threshold_days | 90 | low SCN headroom warning threshold in days |
| _low_server_threshold | 0 | low server thresholds |
| _lowres_drift_allowed_sec | 5 | allowed lowres timer drift for VKTM |
| _lrgdbcz6_ignore_restrictions | FALSE | Temp parameter to ignore app script restrictions for lrgdbcz6 |
| _ltc_trace | 0 | tracing level for load table conventional |
| _lthread_cleanup_intv_secs | 1 | interval for cleaning lightweight threads in secs |
| _lthread_clnup_hk_wait_secs | 3 | timeout after hard killing operation for lthread to exit |
| _lthread_clnup_pmon_softkill_wait_secs | 1 | wait timeout for PMON between soft kill and hard kill of lthreads |
| _lthread_clnup_spawner_sk_wait_secs | 30 | timeout for spawner between soft kill and hard kill of lthreads |
| _lthread_debug | FALSE | Enable Debugging mode for lightweight threads |
| _lthread_enabled | TRUE | Enable lightweight threads |
| _lthread_idle_timeout_secs | 600 | Idle timeout in seconds for LWTs to terminate |
| _lthread_max_spawn_time_csecs | 12000 | maximum time interval a spawner will wait for a lthread to get ready |
| _lthread_spawn_check_intv_ms | 10 | time interval for a spawner to check for spawnee to get ready |
| _lthread_step_debugging | FALSE | Enable Step wise Debugging mode for lightweight threads |
| _main_dead_process_scan_interval | 0 | PMON main dead process scan interval (in seconds) |
| _master_direct_sends | 63 | direct sends for messages from master (DFS) |
| _mav_refresh_consistent_read | TRUE | refresh materialized views using consistent read snapshot |
| _mav_refresh_double_count_prevented | FALSE | materialized view MAV refreshes avoid double counting |
| _mav_refresh_opt | 0 | optimizations during refresh of materialized views |
| _mav_refresh_unionall_tables | 3 | # tables for union all expansion during materialized view refresh |
| _max_aq_persistent_queue_memory | 10 | max aq persistent queue memory |
| _max_async_wait_for_catch_up | 20 | Switchover wait time for async LNS to catch up in seconds |
| _max_clients_per_emon | 8 | maximum number of clients per emon |
| _max_cr_rollbacks | 1000 | Maximum number of CR rollbacks per block (LMS) |
| _max_data_transfer_cache_size | 536870912 | Maximum size of data transfer cache |
| _max_defer_gran_xfer_atonce | 10 | Maximum deferred granules transferred by MMAN atonce |
| _max_dynamic_processes | 320 | max dynamic processes count |
| _max_dynamic_sessions | 504 | max dynamic session count |
| _max_exponential_sleep | 0 | max sleep during exponential backoff |
| _max_filestat_tries | 10 | maximum number of file stat tries |
| _max_flashback_shrink_size | 1048576 | maximum size(in KBs) a datafile can be shrunk with flashback DB |
| _max_fsu_exptime | 7200 | Fast Space Usage: Entry expiration time in seconds |
| _max_fsu_segments | 1024 | Maximum segments to track for fast space usage |
| _max_fsu_sgapcent | 10 | Percentage of shared pool for Fast Space Usage |
| _max_fsu_stale_time | 600 | Allowed space usage staleness in seconds |
| _max_gg_extracts | 65535 | maximum limit for goldengate extract instances |
| _max_incident_file_size | Maximum size (in KB, MB, GB, Blocks) of incident dump file | |
| _max_io_size | 1048576 | Maximum I/O size in bytes for sequential file accesses |
| _max_kcnibr_ranges | 1048576 | Max number of nonlogged data block ranges |
| _max_large_io | 0 | IORM:max number of large I/O's to issue |
| _max_largepage_alloc_time_secs | 10 | Maximum number of seconds to spend on largepage allocation |
| _max_library_cache_dumps | 1000 | Maximum number of dumps allowed |
| _max_lns_shutdown_archival_time | 30 | Maximum time spent by LNS to archive last log during shutdown |
| _max_log_write_parallelism | 1 | Maximum parallelism within a log write (auto=0) |
| _max_lwt_cpu_ratio | 2 | ratio to determine the maximum CPUs for LWTs |
| _max_outstanding_log_writes | 2 | Maximum number of outstanding redo log writes |
| _max_pending_scn_bcasts | 9 | maximum number of pending SCN broadcasts |
| _max_physmem_perc_mmt | 90 | maximum percentage of physical memory for memory_max_target |
| _max_physmem_perc_sga | 80 | maximum percentage of physical memory for SGA |
| _max_protocol_support | 10000 | Max occurrence protocols supported in a process |
| _max_queued_report_requests | 300 | Maximum number of report requests that can be queued in a list |
| _max_reasonable_scn_rate | 32768 | Max reasonable SCN rate |
| _max_remote_tool_requests | 10 | Maximum number of remote tool requests |
| _max_report_flushes_percycle | 5 | Max no of report requests that can be flushed per cycle |
| _max_row_cache_dumps | 1000 | Maximum number of dumps allowed |
| _max_rwgs_groupings | 8192 | maximum no of groupings on materialized views |
| _max_services | 8200 | maximum number of database services |
| _max_shrink_obj_stats | 0 | number of segments for which shrink stats will be maintained |
| _max_shutdown_abort_secs | 10 | Maximum wait time for shutdown abort in seconds |
| _max_sleep_holding_latch | 4 | max time to sleep while holding a latch |
| _max_small_io | 0 | IORM:max number of small I/O's to issue |
| _max_spacebg_msgs_percentage | 50 | maximum space management interrupt message throttling |
| _max_spacebg_slaves | 1024 | maximum space management background slaves |
| _max_spacebg_tasks | 8192 | maximum space management background tasks |
| _max_sql_stmt_length | 0 | Maximum allowed sql statement length |
| _max_stmt_tries_sync | 2 | Maximum number of tries of a statement during Application Sync |
| _max_string_size_bypass | 0 | controls error checking for the max_string_size parameter |
| _max_sys_next_extent | 0 | Dictionary managed SYSTEM tablespace maximum next extent size in MB (allowed range [16-4095], 0 if unlimited) |
| _maxrpop_files_inst | 4 | Maxmimum files rpop works on per instance |
| _maxrpop_instances | 8 | Maxmimum rpop file instances |
| _mdapi_transform_engine | LPX | DDL transformation engine |
| _media_recovery_read_batch | 32 | media recovery block read batch |
| _mem_annotation_pr_lev | 0 | private memory annotation collection level |
| _mem_annotation_scale | 1 | memory annotation pre-allocation scaling |
| _mem_annotation_sh_lev | 0 | shared memory annotation collection level |
| _mem_annotation_store | FALSE | memory annotation in-memory store |
| _mem_std_extent_size | 4096 | standard extent size for fixed-size-extent heaps |
| _memoptimize_xmem_pool_size | 0 | Size of MEMOPTIMIZE buffer pool for standard block size buffers on extended memory |
| _memory_adi_bytes_per_alloc | 0 | bytes per allocation to get memory application data integrity |
| _memory_adi_enabled | TRUE | enable memory application data integrity |
| _memory_adi_extend | FALSE | enable ADI for kgh headers and free memory |
| _memory_adi_heap_mask | 610 | enable ADI versioning for these heaps |
| _memory_adi_module_mask | 0 | bit mask of modules to enable ADI versioning |
| _memory_adi_precise_errors | FALSE | enable precise memory application data integrity errors |
| _memory_broker_log_stat_entries | 5 | memory broker num stat entries |
| _memory_broker_marginal_utility_bc | 12 | Marginal Utility threshold pct for bc |
| _memory_broker_marginal_utility_sp | 7 | Marginal Utility threshold pct for sp |
| _memory_broker_sga_grow_split | TRUE | if TRUE, allow sga grow to be split between cache and sp |
| _memory_broker_sga_grow_splitif_size | 20 | split sga target grow if atleast this many granules. |
| _memory_broker_sga_shrink_chunk_size | 20 | if kmgsbshnkbrk set, sga request resize chunk size in granules. |
| _memory_broker_sga_shrink_chunked | TRUE | if TRUE, break a large sga shrink request to chunks |
| _memory_broker_shrink_heaps | 15 | memory broker allow policy to shrink shared pool |
| _memory_broker_shrink_java_heaps | 900 | memory broker allow policy to shrink java pool |
| _memory_broker_shrink_streams_pool | 900 | memory broker allow policy to shrink streams pool |
| _memory_broker_shrink_timeout | 60000000 | memory broker policy to timeout shrink shared/java pool |
| _memory_broker_stat_interval | 30 | memory broker statistics gathering interval for auto sga |
| _memory_checkinuse_timeintv | 30 | check inuse time interval |
| _memory_imm_mode_without_autosga | TRUE | Allow immediate mode without sga/memory target |
| _memory_initial_sga_split_perc | 60 | Initial default sga target percentage with memory target |
| _memory_management_tracing | 0 | trace memory management activity |
| _memory_max_tgt_inc_cnt | 0 | counts the times checker increments memory target |
| _memory_mgmt_fail_immreq | FALSE | always fail immediate mode request |
| _memory_mgmt_immreq_timeout | 150 | time in seconds to time out immediate mode request |
| _memory_nocancel_defsgareq | FALSE | do not cancel deferred sga reqs with auto-memory |
| _memory_sanity_check | 0 | partial granule sanity check |
| _merge_monitor_threshold | 10000 | threshold for pushing information to MERGE monitoring |
| _messages | 640 | message queue resources - dependent on # processes & # buffers |
| _mga_large_page_path | large page path | |
| _mgd_rcv_handle_orphan_datafiles | FALSE | Managed recovery handle orphan datafile situation |
| _midtier_affinity_cluswait_prc_threshold | 6 | cluster wait precentage threshold to enter affinity |
| _midtier_affinity_goodness_threshold | 2000 | goodness gradient threshold to dissolve affinity |
| _min_autotask_percentage | ||
| _min_lwt_lt | 24 | minimum low threshold for LWTs |
| _min_spacebg_slaves | 2 | minimum space management background slaves |
| _min_sys_percentage | ||
| _min_sys_process | 2 | minimum system processess |
| _min_time_between_psp0_diag_secs | 300 | minimum time between PSP0 diagnostic used for flow control |
| _min_undosegs_for_parallel_fptr | 100 | minimum undo segments for parallel first-pass recovery |
| _minact_timeout | 180 | Configurable interval for minact-scn |
| _minfree_plus | 0 | max percentage of block space + minfree before we mark block full |
| _minimal_stats_aggregation | TRUE | prohibit stats aggregation at compile/partition maintenance time |
| _minimum_blocks_to_shrink | 0 | minimum number freeable blocks for shrink to be present |
| _minimum_db_flashback_retention | 60 | Minimum flashback retention |
| _minimum_extents_to_shrink | 1 | minimum number freeable extents for shrink to be present |
| _minmax_spacebg_slaves | 8 | min-max space management background slaves |
| _mira_free_unused_buffers | TRUE | free unused buffers when idle |
| _mira_mark_archivelog_timeout | 60 | mira mark archive log as applied timeout |
| _mira_num_local_buffers | 25 | Number of local buffers for multi instance media recovery |
| _mira_num_receive_buffers | 25 | Number of receive buffers for multi instance media recovery |
| _mira_rcv_catchup_buffers | 5 | Number of buffers to allocate before catch up |
| _mira_rcv_max_buffers | 500 | Maximum number of outstanding buffers |
| _mira_sender_process | 2 | Number of sender processes |
| _mirror_redo_buffers | FALSE | Save buffers for debugging redo corruptions |
| _mle_compilation_errors_are_fatal | FALSE | failed compilations are fatal for MLE |
| _mle_compile_immediately | FALSE | force compilation for MLE |
| _mle_enable_compilation | FALSE | enable runtime compilation for MLE |
| _mmv_query_rewrite_enabled | TRUE | allow rewrites with multiple MVs and/or base tables |
| _modify_column_index_unusable | FALSE | allow ALTER TABLE MODIFY(column) to violate index key length limit |
| _modify_other_app_object | FALSE | Parameter to allow modification of another application's object |
| _monitor_sql_stmt_length | FALSE | Monitor sql statement length |
| _monitor_workload_interval | 24 | workload monitoring interval in hours |
| _mpmt_enabled | FALSE | MPMT mode enabled |
| _mpmt_enabled_backgrounds | * | mpmt enabled backgrounds |
| _mpmt_fg_enabled | FALSE | MPMT mode foreground enabled |
| _mpmt_fthread_mode | 0 | MPMT - Fthreads Mode for FG/BG/ALL |
| _mpmt_prefer_enabled | TRUE | MPMT prefer mode enabled |
| _mpmt_procs_per_osp | 100 | max procs per osp |
| _mpmt_single_process_instance | FALSE | MPMT - single process instance mode enabled |
| _mpmt_use_fthread | FALSE | MPMT - Use Fthreads |
| _multi_instance_pmr | TRUE | enable multi instance redo apply |
| _multi_join_key_table_lookup | TRUE | TRUE iff multi-join-key table lookup prefetch is enabled |
| _multi_transaction_optimization_enabled | TRUE | reduce SGA memory use during create of a partitioned table |
| _multiple_char_set_cdb | TRUE | Multiple character sets enabled in CDB |
| _multiple_instance_recovery | FALSE | use multiple instances for media recovery |
| _multiple_name_convert_patterns | FALSE | apply multiple patterns on a name during file_name_convert in PDB |
| _mutex_spin_count | 255 | Mutex spin count |
| _mutex_wait_scheme | 2 | Mutex wait scheme |
| _mutex_wait_time | 1 | Mutex wait time |
| _mv_access_compute_fresh_data | ON | mv access compute fresh data |
| _mv_add_log_placeholder | TRUE | add log placeholder |
| _mv_cleanup_orphaned_metadata | TRUE | cleanup orphaned materialized view metadata |
| _mv_complete_refresh_conventional | FALSE | use conventional INSERTs for MV complete refresh |
| _mv_deferred_no_log_age_val | TRUE | avoid build deferred MV log age validate |
| _mv_expression_extend_size | 4096 | MV expression extend size |
| _mv_generalized_oj_refresh_opt | TRUE | enable/disable new algorithm for MJV with generalized outer joins |
| _mv_logical_partition_rewrite_enabled | FALSE | enable/disable Logical Partition based rewrite |
| _mv_logical_partition_tracking_enabled | FALSE | enable/disable Logical Partition Tracking |
| _mv_master_lock_timeout | 3 | timeout that mv create/drop waits to lock the master table |
| _mv_refresh_ana | 0 | what percent to analyze after complete/PCT refresh |
| _mv_refresh_costing | rule | refresh decision based on cost or on rules |
| _mv_refresh_delta_fraction | 10 | delta mv as fractional percentage of size of mv |
| _mv_refresh_enhanced_dml_detection | ON_RC | enable enhanced detection of DML types from MV log |
| _mv_refresh_eut | TRUE | refresh materialized views using EUT(partition)-based algorithm |
| _mv_refresh_force_parallel_query | 0 | force materialized view refreshes to use parallel query |
| _mv_refresh_insert_no_append | TRUE | materialized view refresh using insert no append |
| _mv_refresh_new_setup_disabled | FALSE | materialized view MV refresh new setup disabling |
| _mv_refresh_no_idx_rebuild | FALSE | avoid index rebuild as part of the MV refresh |
| _mv_refresh_pipe_timeout | 600 | timeout that MV refresh coordinator waits for a job pipe |
| _mv_refresh_pkfk_data_units_opt | auto | control MV refresh based on the assumption of PK-FK data units |
| _mv_refresh_pkfk_relationship_opt | TRUE | control MV refresh based on the use of PK-FK relationships |
| _mv_refresh_rebuild_percentage | 10 | minimum percentage change required in MV to force an indexrebuild |
| _mv_refresh_selections | TRUE | create materialized views with selections and fast refresh |
| _mv_refresh_shrink_log | TRUE | materialized view refresh shrink MV log |
| _mv_refresh_truncate_log | FALSE | materialized view refresh truncate MV log |
| _mv_refresh_update_analysis | TRUE | materialized view refresh using update analysis |
| _mv_refresh_use_hash_sj | TRUE | use hash_sj hint in queries |
| _mv_refresh_use_no_merge | TRUE | use no_merge hint in queries |
| _mv_refresh_use_stats | FALSE | pass cardinality hints to refresh queries |
| _mv_refsched_timeincr | 300000 | proportionality constant for dop vs. time in MV refresh |
| _mv_rolling_inv | FALSE | create/alter mv uses rolling cursor invalidation instead of immediate |
| _mwin_schedule | TRUE | Enable/disable Maintenance Window Schedules |
| _nameservice_consistency_check | TRUE | NameService Consistency check switch |
| _nameservice_request_batching | TRUE | NameService request batching switch |
| _nbr_recovery_max_request_size | 8 | the maximum size in MBs of a request for data blocks |
| _nbr_recovery_target_bufs | 0 | the target number of oustanding buffers to maintain |
| _nbr_recovery_timeout | 60 | seconds recovery will wait for any invalid block range to arrive |
| _nchar_imp_cnv | TRUE | NLS allow Implicit Conversion between CHAR and NCHAR |
| _nchar_imp_conv | TRUE | should implicit conversion bewteen clob and nclob be allowed |
| _ncmb_readahead_enabled | 0 | enable multi-block readahead for an index scan |
| _ncmb_readahead_tracing | 0 | turn on multi-block readahead tracing |
| _ncomp_shared_objects_dir | native compilation shared objects dir | |
| _ndb_enable | FALSE | Native Database Blockchain Enable |
| _nested_loop_fudge | 100 | nested loop fudge |
| _nested_mv_fast_oncommit_enabled | TRUE | nested MV refresh fast on commit allowed |
| _new_initial_join_orders | TRUE | enable initial join orders based on new ordering heuristics |
| _new_sort_cost_estimate | TRUE | enables the use of new cost estimate for sort |
| _newsort_enabled | TRUE | controls whether new sorts can be used as system sort |
| _newsort_ordered_pct | 63 | controls when new sort avoids sorting ordered input |
| _newsort_type | 0 | specifies options for the new sort algorithm |
| _next_pdbid | 3 | Hint for the next PDBID to use when creating a new PDB entry |
| _nineteenth_spare_parameter | nineteenth spare parameter - integer | |
| _nineteenth_spare_pdb_parameter | nineteenth spare pdb parameter - integer | |
| _ninetieth_spare_parameter | ninetieth spare parameter - string | |
| _ninety-eighth_spare_parameter | ninety-eighth spare parameter - string | |
| _ninety-fifth_spare_parameter | ninety-fifth spare parameter - string | |
| _ninety-first_spare_parameter | ninety-first spare parameter - string | |
| _ninety-fourth_spare_parameter | ninety-fourth spare parameter - string | |
| _ninety-ninth_spare_parameter | ninety-ninth spare parameter - string | |
| _ninety-second_spare_parameter | ninety-second spare parameter - string | |
| _ninety-seventh_spare_parameter | ninety-seventh spare parameter - string | |
| _ninety-sixth_spare_parameter | ninety-sixth spare parameter - string | |
| _ninety-third_spare_parameter | ninety-third spare parameter - string | |
| _ninth_spare_pdb_parameter | ninth spare pdb parameter - integer | |
| _nlj_batching_ae_flag | 2 | FAE flag type set after restoring to IO batching buffer |
| _nlj_batching_enabled | 1 | enable batching of the RHS IO in NLJ |
| _nlj_batching_misses_enabled | 1 | enable exceptions for buffer cache misses |
| _nls_binary | TRUE | force binary collation |
| _nls_parameter_sync_enabled | TRUE | enables or disables updates to v$parameter whenever an alter session statement modifies various nls parameters |
| _no_catalog | options whose schemas should not be created | |
| _no_objects | FALSE | no object features are used |
| _no_or_expansion | FALSE | OR expansion during optimization disabled |
| _no_recovery_through_resetlogs | FALSE | no recovery through this resetlogs operation |
| _no_small_file | FALSE | Not to apply new extent scheme for small file temp spaces |
| _no_snapshot_root_clone | FALSE | No snapshot clone during Application Root Clone creation |
| _no_stale_joinback_rewrite | FALSE | No joinbacks if mv is stale |
| _node_instcnt_average_interval | 1800 | node inst count average interval in seconds |
| _node_instcnt_sample_frequency | 60 | node inst count average sample frequency in seconds |
| _node_instcnt_update_frequency | 300 | node inst count average global update frequency in seconds |
| _nologging_apply_stall_time | 1000 | milli-seconds recovery waits after DTC full before changing RCVID |
| _nologging_block_cleanout_delay | 300 | Nologging standby: block cleanout delay (seconds) |
| _nologging_fetch_demote_count | 10 | Nologging standby fetch demote count |
| _nologging_fetch_initial_interval | 2 | seconds recovery waits between issuing fetches for old ranges |
| _nologging_fetch_retry_interval_cold | 1800 | Interval before fetch request for older invalid block range |
| _nologging_fetch_retry_interval_hot | 60 | Interval before fetch request for recently created invalid block range |
| _nologging_fetch_slv_wt | 600 | Nologging standby fetch slave wait time |
| _nologging_kcnbuf_hash_buckets | 1024 | Number of nologging buffer hash buckets |
| _nologging_kcnbuf_hash_latches | 256 | Number of nologging buffer hash latches |
| _nologging_load_slotsz | 1048576 | Nologging standby: direct load buffer size |
| _nologging_mode_override | 0 | Override the database logging mode; 1=Force, 2=NoForce, 3=LP, 4=DA |
| _nologging_progress_keep_alive | 10 | Nologging standby progress keep alive time |
| _nologging_sdcl_append_wait | 200 | Nologging standby append sdcl wait time |
| _nologging_sendbuf_ratio | 90 | Nologging standby: outstanding send buffer ratio |
| _nologging_slots | 20 | Nologging standby: initial buffer count |
| _nologging_standby_cold_buffer_timeout | 500 | Centi-seconds recovery will wait for a buffer that is not being sent by a direct load client in Nologging Standby Data Availability mode |
| _nologging_standby_dtc_expire | 600 | The number of seconds a Data Transfer Cache buffer may remain unclaimed |
| _nologging_standby_fetch_disable | FALSE | controls whether invalid block ranges are fecthed during recovery |
| _nologging_standby_hot_buffer_timeout | 500 | Centi-seconds recovery will wait for a buffer being sent by a direct load client in Nologging Standby Data Availabilty mode |
| _nologging_standby_refetch_disable | FALSE | controls fetching of pre-existing invalid block ranges during standby recovery |
| _nologging_txn_cmt_wait | 1500 | Nologging standby transaction commit wait time |
| _nologging_txn_history_to_sessions_percent | 100 | Ratio, as a percentage, of sessions to set X$KCNT max. size |
| _non_app_ignore_errors | TRUE | ignore errors during containers() on non-application object |
| _non_blocking_hard_parse_min_extend_time | 2 | minimum additional lifetime added to cursor |
| _nonce_history_buffer_size | 0 | Size of Nonce History Buffer |
| _nonfatalprocess_redo_dump_time_limit | 3600 | time limit, in secs, for diagnostic redo dumps by a non-fatal process |
| _noseg_for_unusable_index_enabled | TRUE | no segments for unusable indexes if set to TRUE |
| _notify_crs | FALSE | notify cluster ready services of startup and shutdown |
| _ns_max_flush_wt | 1 | Flush wait time for NetServer to flush oustanding writes |
| _ns_max_send_delay | 15 | Data Loss Time Bound for NetServer |
| _num_longop_child_latches | 4 | number of child latches for long op array |
| _num_rlslaves | 8 | number of rl slaves to clear orls |
| _numa_buffer_cache_stats | 0 | Configure NUMA buffer cache stats |
| _numa_shift_enabled | TRUE | Enable NUMA shift |
| _numa_shift_value | 0 | user defined value for numa nodes shift |
| _numa_trace_level | 0 | numa trace event |
| _number_cached_attributes | 10 | maximum number of cached attributes per instance |
| _number_cached_group_memberships | 2048 | maximum number of cached group memberships |
| _number_group_memberships_per_cache_line | 6 | maximum number of group memberships per cache line |
| _number_ksim_group_req_threshold | 64 | ksim maximum number of group operations requests |
| _number_of_undo_blocks_to_prefetch | 8 | number of undo blocks to prefetch |
| _numgrans_per_file | 64 | Number of granules per SGA file |
| _nusa_data_containers | list of data containers in the nusa universe | |
| _nusa_metadata_store | metadata store in nusa | |
| _nvm_dispatcher_bind_policy | 1 | NVM Dispatcher binding policy |
| _nvm_dispatchers | 3 | number of NVM Dispatcher Slaves |
| _nvmeof_zcopy_enable | FALSE | Enable Zero Copy for NVMeoF |
| _obj_ckpt_tracing | 0 | Enable object checkpoint tracing |
| _object_activity_control | 0 | controls tracing for object activity tracking system (OATS) |
| _object_activity_disable | 0 | disables some object activity tracking (OATS) |
| _object_activity_tracking | TRUE | enable object activity tracking system (OATS) |
| _object_link_fixed_enabled | TRUE | object linked views evaluated using fixed table |
| _object_linked_remote | FALSE | Enable remote transformation of Object Linked table |
| _object_number_cache_size | 5 | Object number cache size |
| _object_reuse_bast | 2 | if 1 or higher, handle object reuse |
| _object_statistics | TRUE | enable the object level statistics collection |
| _object_stats_max_entries | 3072 | Maximum number of entries to be tracked per stat |
| _obsolete_result_cache_mode | MANUAL | USERS SHOULD NOT SET THIS! Used for old qksced parameterof result_cache_mode |
| _odci_aggregate_save_space | FALSE | trade speed for space in user-defined aggregation |
| _odci_index_pmo_rebuild | FALSE | domain index running pmo rebuild |
| _offline_rollback_segments | offline undo segment list | |
| _ofs_read_buffer_size | 1031680 | OFS read ahead buffer size in bytes |
| _ofs_write_buffer_size | 1048576 | OFS write buffer size in bytes |
| _ogms_home | GMS home directory | |
| _olap_adv_comp_stats_cc_precomp | 20 | do additional predicate stats analysis for AW rowsource |
| _olap_adv_comp_stats_max_rows | 100000 | do additional predicate stats analysis for AW rowsource |
| _olap_aggregate_buffer_size | 1048576 | OLAP Aggregate max buffer size |
| _olap_aggregate_flags | 0 | OLAP Aggregate debug flags |
| _olap_aggregate_function_cache_enabled | TRUE | OLAP Aggregate function cache enabled |
| _olap_aggregate_max_thread_tuples | 5000 | OLAP Aggregate max thread tuples creation |
| _olap_aggregate_min_buffer_size | 1024 | OLAP Aggregate min buffer size |
| _olap_aggregate_min_thread_status | 64 | OLAP Aggregate minimum cardinality of dimensions for thread |
| _olap_aggregate_multipath_hier | FALSE | OLAP Aggregate Multi-path Hierarhies enabled |
| _olap_aggregate_statlen_thresh | 1024 | OLAP Aggregate status array usage threshold |
| _olap_aggregate_work_per_thread | 1024 | OLAP Aggregate max work parents |
| _olap_aggregate_worklist_max | 5000 | OLAP Aggregate max worklists generated at once |
| _olap_allocate_errorlog_format | %8p %8y %8z %e (%n) | OLAP Allocate Errorlog Format |
| _olap_allocate_errorlog_header | Dim Source Basis | |
| %-8d %-8s %-8b Description | ||
| -------- -------- -------- ----------- | OLAP Allocate Errorlog Header format | |
| _olap_analyze_max | 10000 | OLAP DML ANALYZE command max cells to analyze |
| _olap_continuous_trace_file | false | OLAP logging definition |
| _olap_dbgoutfile_echo_to_eventlog | FALSE | OLAP DbgOutfile copy output to event log (tracefile) |
| _olap_dimension_corehash_force | FALSE | OLAP Dimension In-Core Hash Table Force |
| _olap_dimension_corehash_large | 50000 | OLAP Dimension In-Core Hash Table Large Threshold |
| _olap_dimension_corehash_pressure | 90 | OLAP Dimension In-Core Hash Table Pressure Threshold |
| _olap_dimension_corehash_size | 30 | OLAP Dimension In-Core Hash Table Maximum Memory Use |
| _olap_disable_loop_optimized | FALSE | Disable LOOP OPTIMIZED directive in OLAP_TABLE |
| _olap_eif_export_lob_size | 2147483647 | OLAP EIF Export BLOB size |
| _olap_lmgen_dim_size | 100 | Limitmap generator dimension column size |
| _olap_lmgen_meas_size | 1000 | Limitmap generator measure column size |
| _olap_object_hash_class | 3 | OLAP Object Hash Table Class |
| _olap_page_pool_expand_rate | 20 | OLAP Page Pool Expand Rate |
| _olap_page_pool_hi | 50 | OLAP Page Pool High Watermark |
| _olap_page_pool_hit_target | 100 | OLAP Page Pool Hit Target |
| _olap_page_pool_low | 262144 | OLAP Page Pool Low Watermark |
| _olap_page_pool_pressure | 90 | OLAP Page Pool Pressure Threshold |
| _olap_page_pool_shrink_rate | 50 | OLAP Page Pool Shrink Rate |
| _olap_parallel_update_server_num | 0 | OLAP parallel update server count |
| _olap_parallel_update_small_threshold | 1000 | OLAP parallel update threshold for number of small pagespaces |
| _olap_parallel_update_threshold | 1000 | OLAP parallel update threshold in pages |
| _olap_row_load_time_precision | DEFAULT | OLAP Row Load Time Precision |
| _olap_sesscache_enabled | TRUE | OLAP Session Cache knob |
| _olap_sort_buffer_pct | 10 | OLAP Sort Buffer Size Percentage |
| _olap_sort_buffer_size | 262144 | OLAP Sort Buffer Size |
| _olap_statbool_corebits | 20000000 | OLAP Status Boolean max incore bits |
| _olap_statbool_threshold | 8100 | OLAP Status Boolean CBM threshold |
| _olap_table_function_statistics | FALSE | Specify TRUE to output OLAP table function timed statistics trace |
| _olap_wrap_errors | FALSE | Wrap error messages to OLAP outfile |
| _olapi_history_retention | FALSE | enable olapi history retention |
| _olapi_iface_object_history | 1000 | enable olapi interface object history collection |
| _olapi_iface_object_history_retention | FALSE | enable olapi interface object history retention |
| _olapi_iface_operation_history_retention | FALSE | enable olapi interface operation history retention |
| _olapi_interface_operation_history | 1000 | enable olapi interface operation history collection |
| _olapi_memory_operation_history | 1000 | enable olapi memory alloc/free history collection |
| _olapi_memory_operation_history_pause_at_seqno | 0 | enable olapi memory alloc/free history collection pausing |
| _olapi_memory_operation_history_retention | FALSE | enable olapi memory operation history retention |
| _olapi_session_history | 300 | enable olapi session history collection |
| _olapi_session_history_retention | FALSE | enable olapi session history retention |
| _old_connect_by_enabled | FALSE | enable/disable old connect by |
| _old_extent_scheme | FALSE | Revert to old extent allocation |
| _ols_cleanup_task | TRUE | Clean up unnecessary entries in OLS sessinfo table |
| _oltp_comp_dbg_scan | 0 | oltp compression scan debug |
| _oltp_compress_dbg | 0 | oltp compression debug |
| _oltp_compression | TRUE | oltp compression enabled |
| _oltp_compression_gain | 10 | oltp compression gain |
| _oltp_spill | FALSE | spill rows for oltp compression if loader pga limit is exceeded |
| _omf | enabled | enable/disable OMF |
| _omni_enqueue_enable | 1 | Enable Omni Enqueue feature (0 = disable, 1 = enable on ASM (default), 2 = enable) |
| _one-hundred-and-eighteenth_spare_parameter | one-hundred-and-eighteenth spare parameter - string | |
| _one-hundred-and-eighth_spare_parameter | one-hundred-and-eighth spare parameter - string | |
| _one-hundred-and-eightieth_spare_parameter | FALSE | one-hundred-and-eightieth spare parameter - boolean |
| _one-hundred-and-eighty-eighth_spare_parameter | FALSE | one-hundred-and-eighty-eighth spare parameter - boolean |
| _one-hundred-and-eighty-fifth_spare_parameter | FALSE | one-hundred-and-eighty-fifth spare parameter - boolean |
| _one-hundred-and-eighty-first_spare_parameter | FALSE | one-hundred-and-eighty-first spare parameter - boolean |
| _one-hundred-and-eighty-fourth_spare_parameter | FALSE | one-hundred-and-eighty-fourth spare parameter - boolean |
| _one-hundred-and-eighty-ninth_spare_parameter | FALSE | one-hundred-and-eighty-ninth spare parameter - boolean |
| _one-hundred-and-eighty-second_spare_parameter | FALSE | one-hundred-and-eighty-second spare parameter - boolean |
| _one-hundred-and-eighty-seventh_spare_parameter | FALSE | one-hundred-and-eighty-seventh spare parameter - boolean |
| _one-hundred-and-eighty-sixth_spare_parameter | FALSE | one-hundred-and-eighty-sixth spare parameter - boolean |
| _one-hundred-and-eighty-third_spare_parameter | FALSE | one-hundred-and-eighty-third spare parameter - boolean |
| _one-hundred-and-eleventh_spare_parameter | one-hundred-and-eleventh spare parameter - string | |
| _one-hundred-and-fifteenth_spare_parameter | one-hundred-and-fifteenth spare parameter - string | |
| _one-hundred-and-fifth_spare_parameter | one-hundred-and-fifth spare parameter - string | |
| _one-hundred-and-fifty-eighth_spare_parameter | FALSE | one-hundred-and-fifty-eighth spare parameter - boolean |
| _one-hundred-and-fifty-fifth_spare_parameter | FALSE | one-hundred-and-fifty-fifth spare parameter - boolean |
| _one-hundred-and-fifty-fourth_spare_parameter | FALSE | one-hundred-and-fifty-fourth spare parameter - boolean |
| _one-hundred-and-fifty-ninth_spare_parameter | FALSE | one-hundred-and-fifty-ninth spare parameter - boolean |
| _one-hundred-and-fifty-seventh_spare_parameter | FALSE | one-hundred-and-fifty-seventh spare parameter - boolean |
| _one-hundred-and-fifty-sixth_spare_parameter | FALSE | one-hundred-and-fifty-sixth spare parameter - boolean |
| _one-hundred-and-first_spare_parameter | one-hundred-and-first spare parameter - string | |
| _one-hundred-and-fortieth_spare_parameter | one-hundred-and-fortieth spare parameter - string list | |
| _one-hundred-and-forty-seventh_spare_parameter | FALSE | one-hundred-and-forty-seventh spare parameter - boolean |
| _one-hundred-and-fourteenth_spare_parameter | one-hundred-and-fourteenth spare parameter - string | |
| _one-hundred-and-fourth_spare_parameter | one-hundred-and-fourth spare parameter - string | |
| _one-hundred-and-nineteenth_spare_parameter | one-hundred-and-nineteenth spare parameter - string | |
| _one-hundred-and-ninetieth_spare_parameter | FALSE | one-hundred-and-ninetieth spare parameter - boolean |
| _one-hundred-and-ninety-eighth_spare_parameter | FALSE | one-hundred-and-ninety-eighth spare parameter - boolean |
| _one-hundred-and-ninety-fifth_spare_parameter | FALSE | one-hundred-and-ninety-fifth spare parameter - boolean |
| _one-hundred-and-ninety-first_spare_parameter | FALSE | one-hundred-and-ninety-first spare parameter - boolean |
| _one-hundred-and-ninety-fourth_spare_parameter | FALSE | one-hundred-and-ninety-fourth spare parameter - boolean |
| _one-hundred-and-ninety-ninth_spare_parameter | FALSE | one-hundred-and-ninety-ninth spare parameter - boolean |
| _one-hundred-and-ninety-second_spare_parameter | FALSE | one-hundred-and-ninety-second spare parameter - boolean |
| _one-hundred-and-ninety-seventh_spare_parameter | FALSE | one-hundred-and-ninety-seventh spare parameter - boolean |
| _one-hundred-and-ninety-sixth_spare_parameter | FALSE | one-hundred-and-ninety-sixth spare parameter - boolean |
| _one-hundred-and-ninety-third_spare_parameter | FALSE | one-hundred-and-ninety-third spare parameter - boolean |
| _one-hundred-and-ninth_spare_parameter | one-hundred-and-ninth spare parameter - string | |
| _one-hundred-and-second_spare_parameter | one-hundred-and-second spare parameter - string | |
| _one-hundred-and-seventeenth_spare_parameter | one-hundred-and-seventeenth spare parameter - string | |
| _one-hundred-and-seventh_spare_parameter | one-hundred-and-seventh spare parameter - string | |
| _one-hundred-and-seventieth_spare_parameter | FALSE | one-hundred-and-seventieth spare parameter - boolean |
| _one-hundred-and-seventy-eighth_spare_parameter | FALSE | one-hundred-and-seventy-eighth spare parameter - boolean |
| _one-hundred-and-seventy-fifth_spare_parameter | FALSE | one-hundred-and-seventy-fifth spare parameter - boolean |
| _one-hundred-and-seventy-first_spare_parameter | FALSE | one-hundred-and-seventy-first spare parameter - boolean |
| _one-hundred-and-seventy-fourth_spare_parameter | FALSE | one-hundred-and-seventy-fourth spare parameter - boolean |
| _one-hundred-and-seventy-ninth_spare_parameter | FALSE | one-hundred-and-seventy-ninth spare parameter - boolean |
| _one-hundred-and-seventy-second_spare_parameter | FALSE | one-hundred-and-seventy-second spare parameter - boolean |
| _one-hundred-and-seventy-seventh_spare_parameter | FALSE | one-hundred-and-seventy-seventh spare parameter - boolean |
| _one-hundred-and-seventy-sixth_spare_parameter | FALSE | one-hundred-and-seventy-sixth spare parameter - boolean |
| _one-hundred-and-seventy-third_spare_parameter | FALSE | one-hundred-and-seventy-third spare parameter - boolean |
| _one-hundred-and-sixteenth_spare_parameter | one-hundred-and-sixteenth spare parameter - string | |
| _one-hundred-and-sixth_spare_parameter | one-hundred-and-sixth spare parameter - string | |
| _one-hundred-and-sixtieth_spare_parameter | FALSE | one-hundred-and-sixtieth spare parameter - boolean |
| _one-hundred-and-sixty-eighth_spare_parameter | FALSE | one-hundred-and-sixty-eighth spare parameter - boolean |
| _one-hundred-and-sixty-fifth_spare_parameter | FALSE | one-hundred-and-sixty-fifth spare parameter - boolean |
| _one-hundred-and-sixty-first_spare_parameter | FALSE | one-hundred-and-sixty-first spare parameter - boolean |
| _one-hundred-and-sixty-fourth_spare_parameter | FALSE | one-hundred-and-sixty-fourth spare parameter - boolean |
| _one-hundred-and-sixty-ninth_spare_parameter | FALSE | one-hundred-and-sixty-ninth spare parameter - boolean |
| _one-hundred-and-sixty-second_spare_parameter | FALSE | one-hundred-and-sixty-second spare parameter - boolean |
| _one-hundred-and-sixty-seventh_spare_parameter | FALSE | one-hundred-and-sixty-seventh spare parameter - boolean |
| _one-hundred-and-sixty-sixth_spare_parameter | FALSE | one-hundred-and-sixty-sixth spare parameter - boolean |
| _one-hundred-and-sixty-third_spare_parameter | FALSE | one-hundred-and-sixty-third spare parameter - boolean |
| _one-hundred-and-tenth_spare_parameter | one-hundred-and-tenth spare parameter - string | |
| _one-hundred-and-third_spare_parameter | one-hundred-and-third spare parameter - string | |
| _one-hundred-and-thirteenth_spare_parameter | one-hundred-and-thirteenth spare parameter - string | |
| _one-hundred-and-thirtieth_spare_parameter | one-hundred-and-thirtieth spare parameter - string | |
| _one-hundred-and-thirty-eighth_spare_parameter | one-hundred-and-thirty-eighth spare parameter - string list | |
| _one-hundred-and-thirty-fifth_spare_parameter | one-hundred-and-thirty-fifth spare parameter - string list | |
| _one-hundred-and-thirty-first_spare_parameter | one-hundred-and-thirty-first spare parameter - string list | |
| _one-hundred-and-thirty-fourth_spare_parameter | one-hundred-and-thirty-fourth spare parameter - string list | |
| _one-hundred-and-thirty-ninth_spare_parameter | one-hundred-and-thirty-ninth spare parameter - string list | |
| _one-hundred-and-thirty-second_spare_parameter | one-hundred-and-thirty-second spare parameter - string list | |
| _one-hundred-and-thirty-seventh_spare_parameter | one-hundred-and-thirty-seventh spare parameter - string list | |
| _one-hundred-and-thirty-sixth_spare_parameter | one-hundred-and-thirty-sixth spare parameter - string list | |
| _one-hundred-and-thirty-third_spare_parameter | one-hundred-and-thirty-third spare parameter - string list | |
| _one-hundred-and-twelfth_spare_parameter | one-hundred-and-twelfth spare parameter - string | |
| _one-hundred-and-twentieth_spare_parameter | one-hundred-and-twentieth spare parameter - string | |
| _one-hundred-and-twenty-eighth_spare_parameter | one-hundred-and-twenty-eighth spare parameter - string | |
| _one-hundred-and-twenty-fifth_spare_parameter | one-hundred-and-twenty-fifth spare parameter - string | |
| _one-hundred-and-twenty-first_spare_parameter | one-hundred-and-twenty-first spare parameter - string | |
| _one-hundred-and-twenty-fourth_spare_parameter | one-hundred-and-twenty-fourth spare parameter - string | |
| _one-hundred-and-twenty-ninth_spare_parameter | one-hundred-and-twenty-ninth spare parameter - string | |
| _one-hundred-and-twenty-second_spare_parameter | one-hundred-and-twenty-second spare parameter - string | |
| _one-hundred-and-twenty-seventh_spare_parameter | one-hundred-and-twenty-seventh spare parameter - string | |
| _one-hundred-and-twenty-sixth_spare_parameter | one-hundred-and-twenty-sixth spare parameter - string | |
| _one-hundred-and-twenty-third_spare_parameter | one-hundred-and-twenty-third spare parameter - string | |
| _one-hundredth_spare_parameter | one-hundredth spare parameter - string | |
| _oneside_colstat_for_equijoins | TRUE | sanity check on default selectivity for like/range predicate |
| _onl_ddl_progress | 3 | track progress of online ddl |
| _onl_pmo_wait_query | 0 | online pmos wait for queries after swapping partitions |
| _onl_pmo_wait_timeout | 0 | online pmos wait for queries after swapping partitions timeout |
| _online_ctas_diag | 0 | controls dumping diagnostic information for online ctas |
| _online_file_conversion_batchsize | 16 | Online datafile move/conversion sync batchsize |
| _online_patch_disable_stack_check | FALSE | disable check for function on stack for online patches |
| _online_pmo_global_index_method | CLEANUP ONLY | Unique global index method for partition maintenance DDLs |
| _ops_per_semop | the exact number of operations per semop system call | |
| _optim_adjust_for_part_skews | TRUE | adjust stats for skews across partitions |
| _optim_dict_stats_at_db_cr_upg | TRUE | enable/disable dictionary stats gathering at db create/upgrade |
| _optim_enhance_nnull_detection | TRUE | TRUE to enable index [fast] full scan more often |
| _optim_new_default_join_sel | TRUE | improves the way default equijoin selectivity are computed |
| _optim_peek_user_binds | TRUE | enable peeking of user binds |
| _optimize_dvconfig_cloudpdb | FALSE | Optimize Database Vault setup for cloud PDB |
| _optimizer_adaptive_cursor_sharing | TRUE | optimizer adaptive cursor sharing |
| _optimizer_adaptive_plan_control | 0 | internal controls for adaptive plans |
| _optimizer_adaptive_plans_continuous | FALSE | enable continuously adaptive plans |
| _optimizer_adaptive_plans_iterative | FALSE | enable iterative adaptive plans |
| _optimizer_adaptive_random_seed | 0 | random seed for adaptive plans |
| _optimizer_adjust_for_nulls | TRUE | adjust selectivity for null values |
| _optimizer_ads_for_pq | FALSE | use ADS for parallel queries |
| _optimizer_ads_max_table_count | 0 | maximum number of tables in a join under ADS |
| _optimizer_ads_result_cache_life | 3600 | result cache shelf life for ADS queries |
| _optimizer_ads_spd_cache_owner_limit | 64 | Maximum number of directives under an owner in SPD cache |
| _optimizer_ads_time_limit | 0 | maximum time limit (seconds) under ADS |
| _optimizer_ads_use_partial_results | TRUE | Use partial results of ADS queries |
| _optimizer_ads_use_result_cache | TRUE | use result cache for ADS queries |
| _optimizer_ads_use_spd_cache | TRUE | use Sql Plan Directives for caching ADS queries |
| _optimizer_aggr_groupby_elim | TRUE | group-by and aggregation elimination |
| _optimizer_allow_all_access_paths | TRUE | allow all access paths |
| _optimizer_ansi_join_lateral_enhance | TRUE | optimization of left/full ansi-joins and lateral views |
| _optimizer_ansi_rearchitecture | TRUE | re-architecture of ANSI left, right, and full outer joins |
| _optimizer_answering_query_using_stats | FALSE | enable statistics-based query transformation |
| _optimizer_autostats_job | TRUE | enable/disable auto stats collection job |
| _optimizer_aw_join_push_enabled | TRUE | Enables AW Join Push optimization |
| _optimizer_aw_stats_enabled | TRUE | Enables statistcs on AW olap_table table function |
| _optimizer_band_join_aware | TRUE | enable the detection of band join by the optimizer |
| _optimizer_batch_table_access_by_rowid | TRUE | enable table access by ROWID IO batching |
| _optimizer_better_inlist_costing | ALL | enable improved costing of index access using in-list(s) |
| _optimizer_block_size | 8192 | standard block size used by optimizer |
| _optimizer_bushy_cost_factor | 100 | cost factor for bushy join |
| _optimizer_bushy_fact_dim_ratio | 20 | bushy join dimension to fact ratio |
| _optimizer_bushy_fact_min_size | 100000 | minimumm fact size for bushy join |
| _optimizer_bushy_join | off | enables bushy join |
| _optimizer_cache_stats | FALSE | cost with cache statistics |
| _optimizer_cartesian_enabled | TRUE | optimizer cartesian join enabled |
| _optimizer_cbqt_factor | 50 | cost factor for cost-based query transformation |
| _optimizer_cbqt_no_size_restriction | TRUE | disable cost based transformation query size restriction |
| _optimizer_cbqt_or_expansion | ON | enables cost based OR expansion |
| _optimizer_ceil_cost | TRUE | CEIL cost in CBO |
| _optimizer_cluster_by_rowid | TRUE | enable/disable the cluster by rowid feature |
| _optimizer_cluster_by_rowid_batch_size | 100 | Sorting batch size for cluster by rowid feature |
| _optimizer_cluster_by_rowid_batched | TRUE | enable/disable the cluster by rowid batching feature |
| _optimizer_cluster_by_rowid_control | 129 | internal control for cluster by rowid feature mode |
| _optimizer_coalesce_subqueries | TRUE | consider coalescing of subqueries optimization |
| _optimizer_compare_plans_control | 0 | compare plans controls for testing |
| _optimizer_complex_pred_selectivity | TRUE | enable selectivity estimation for builtin functions |
| _optimizer_compute_index_stats | TRUE | force index stats collection on index creation/rebuild |
| _optimizer_connect_by_cb_whr_only | FALSE | use cost-based transformation for whr clause in connect by |
| _optimizer_connect_by_combine_sw | TRUE | combine no filtering connect by and start with |
| _optimizer_connect_by_cost_based | TRUE | use cost-based transformation for connect by |
| _optimizer_connect_by_elim_dups | TRUE | allow connect by to eliminate duplicates from input |
| _optimizer_control_shard_qry_processing | 65472 | control shard query processing |
| _optimizer_correct_sq_selectivity | TRUE | force correct computation of subquery selectivity |
| _optimizer_cost_based_transformation | LINEAR | enables cost-based query transformation |
| _optimizer_cost_filter_pred | FALSE | enables costing of filter predicates in IO cost model |
| _optimizer_cost_hjsmj_multimatch | TRUE | add cost of generating result set when #rows per key > 1 |
| _optimizer_cost_model | CHOOSE | optimizer cost model |
| _optimizer_cube_join_enabled | TRUE | enable cube join |
| _optimizer_db_blocks_buffers | 0 | optimizer value for _db_blocks_buffers |
| _optimizer_degree | 0 | force the optimizer to use the same degree of parallelism |
| _optimizer_dim_subq_join_sel | TRUE | use join selectivity in choosing star transformation dimensions |
| _optimizer_disable_strans_sanity_checks | 0 | disable star transformation sanity checks |
| _optimizer_distinct_agg_transform | TRUE | Transforms Distinct Aggregates to non-distinct aggregates |
| _optimizer_distinct_elimination | TRUE | Eliminates redundant SELECT DISTNCT's |
| _optimizer_distinct_placement | TRUE | consider distinct placement optimization |
| _optimizer_dsdir_usage_control | 0 | controls optimizer usage of dynamic sampling directives |
| _optimizer_dyn_smp_blks | 32 | number of blocks for optimizer dynamic sampling |
| _optimizer_eliminate_filtering_join | TRUE | optimizer filtering join elimination enabled |
| _optimizer_eliminate_subquery | TRUE | consider elimination of subquery optimization |
| _optimizer_enable_density_improvements | TRUE | use improved density computation for selectivity estimation |
| _optimizer_enable_extended_stats | TRUE | use extended statistics for selectivity estimation |
| _optimizer_enable_plsql_stats | TRUE | Use statistics of plsql functions |
| _optimizer_enable_table_lookup_by_nl | TRUE | consider table lookup by nl transformation |
| _optimizer_enhanced_filter_push | TRUE | push filters before trying cost-based query transformation |
| _optimizer_enhanced_join_elimination | TRUE | Enhanced(12.2) join elimination |
| _optimizer_exists_to_any_rewrite | TRUE | consider exists-to-any rewrite of subqueries |
| _optimizer_extend_jppd_view_types | TRUE | join pred pushdown on group-by, distinct, semi-/anti-joined view |
| _optimizer_extended_cursor_sharing | UDO | optimizer extended cursor sharing |
| _optimizer_extended_cursor_sharing_rel | SIMPLE | optimizer extended cursor sharing for relational operators |
| _optimizer_extended_stats_usage_control | 192 | controls the optimizer usage of extended stats |
| _optimizer_false_filter_pred_pullup | TRUE | optimizer false predicate pull up transformation |
| _optimizer_fast_access_pred_analysis | TRUE | use fast algorithm to traverse predicates for physical optimizer |
| _optimizer_fast_pred_transitivity | TRUE | use fast algorithm to generate transitive predicates |
| _optimizer_feedback_control | controls the optimizer feedback framework | |
| _optimizer_filter_pred_pullup | TRUE | use cost-based flter predicate pull up transformation |
| _optimizer_filter_pushdown | TRUE | enable/disable filter predicate pushdown |
| _optimizer_fkr_index_cost_bias | 10 | Optimizer index bias over FTS/IFFS under first K rows mode |
| _optimizer_force_CBQT | force CBQT transformation regardless of cost | |
| _optimizer_free_transformation_heap | TRUE | free transformation subheap after each transformation |
| _optimizer_full_outer_join_to_outer | TRUE | enable/disable full outer to left outer join conversion |
| _optimizer_gather_feedback | TRUE | optimizer gather feedback |
| _optimizer_gather_stats_on_conventional_config | 0 | settings for optimizer online stats gathering on conventional DML |
| _optimizer_gather_stats_on_conventional_dml | FALSE | optimizer online stats gathering for conventional DML |
| _optimizer_gather_stats_on_load | TRUE | enable/disable online statistics gathering |
| _optimizer_gather_stats_on_load_all | FALSE | enable/disable online statistics gathering for nonempty segments |
| _optimizer_gather_stats_on_load_hist | FALSE | enable/disable online histogram gathering for loads |
| _optimizer_gather_stats_on_load_index | TRUE | enable/disable online index stats gathering for loads |
| _optimizer_generate_ptf_implied_preds | TRUE | Generate implied predicates for PTF |
| _optimizer_generate_transitive_pred | TRUE | optimizer generate transitive predicates |
| _optimizer_group_by_placement | TRUE | consider group-by placement optimization |
| _optimizer_hll_entry | 4096 | number of entries in hll hash table |
| _optimizer_hybrid_fpwj_enabled | TRUE | enable hybrid full partition-wise join when TRUE |
| _optimizer_improve_selectivity | TRUE | improve table and partial overlap join selectivity computation |
| _optimizer_inmemory_access_path | TRUE | optimizer access path costing for in-memory |
| _optimizer_inmemory_autodop | TRUE | optimizer autoDOP costing for in-memory |
| _optimizer_inmemory_bloom_filter | TRUE | controls serial bloom filter for in-memory tables |
| _optimizer_inmemory_capture_stored_stats | TRUE | optimizer capture and store statistics for in-memory tables |
| _optimizer_inmemory_cluster_aware_dop | TRUE | Affinitize DOP for inmemory objects |
| _optimizer_inmemory_gen_pushable_preds | TRUE | optimizer generate pushable predicates for in-memory |
| _optimizer_inmemory_minmax_pruning | TRUE | controls use of min/max pruning for costing in-memory tables |
| _optimizer_inmemory_pruning_ratio_rows | 100 | in-memory pruning ratio for # rows (% of rows remaining after pruning) |
| _optimizer_inmemory_quotient | 0 | in-memory quotient (% of rows in in-memory format) |
| _optimizer_inmemory_table_expansion | TRUE | optimizer in-memory awareness for table expansion |
| _optimizer_inmemory_use_stored_stats | AUTO | optimizer use stored statistics for in-memory tables |
| _optimizer_instance_count | 0 | force the optimizer to use the specified number of instances |
| _optimizer_interleave_jppd | TRUE | interleave join predicate pushdown during CBQT |
| _optimizer_interleave_or_expansion | TRUE | interleave OR Expansion during CBQT |
| _optimizer_invalidation_period | 18000 | time window for invalidation of cursors of analyzed objects |
| _optimizer_join_elimination_enabled | TRUE | optimizer join elimination enabled |
| _optimizer_join_factorization | TRUE | use join factorization transformation |
| _optimizer_join_order_control | 3 | controls the optimizer join order search algorithm |
| _optimizer_join_sel_sanity_check | TRUE | enable/disable sanity check for multi-column join selectivity |
| _optimizer_key_vector_aggr_factor | 75 | the required aggregation between IJK and DGK |
| _optimizer_key_vector_payload | TRUE | enables or disables dimension payloads in vector transform |
| _optimizer_key_vector_payload_dim_aggs | TRUE | enables or disables dimension payloading of aggregates in VT |
| _optimizer_key_vector_pruning_enabled | TRUE | enables or disables key vector partition pruning |
| _optimizer_key_vector_use_max_size | 1048576 | maximum key vector use size (in KB) |
| _optimizer_max_permutations | 2000 | optimizer maximum join permutations per query block |
| _optimizer_min_cache_blocks | 10 | set minimum cached blocks |
| _optimizer_mjc_enabled | TRUE | enable merge join cartesian |
| _optimizer_mode_force | TRUE | force setting of optimizer mode for user recursive SQL also |
| _optimizer_multi_level_push_pred | TRUE | consider join-predicate pushdown that requires multi-level pushdown to base table |
| _optimizer_multi_table_outerjoin | TRUE | allows multiple tables on the left of outerjoin |
| _optimizer_multicol_join_elimination | TRUE | eliminate multi-column key based joins |
| _optimizer_multiple_cenv | generate and run plans using several compilation environments | |
| _optimizer_multiple_cenv_report | result | control what to report in trace file when run in multi-plan mode |
| _optimizer_multiple_cenv_stmt | query | control the types of statements that are run in multi-plan mode |
| _optimizer_native_full_outer_join | FORCE | execute full outer join using native implementaion |
| _optimizer_nested_loop_join | on | favor/unfavor nested loop join |
| _optimizer_nested_rollup_for_gset | 100 | number of groups above which we use nested rollup exec for gset |
| _optimizer_new_join_card_computation | TRUE | compute join cardinality using non-rounded input values |
| _optimizer_nlj_hj_adaptive_join | TRUE | allow adaptive NL Hash joins |
| _optimizer_non_blocking_hard_parse | TRUE | enable non-blocking hard parse |
| _optimizer_null_accepting_semijoin | TRUE | enables null-accepting semijoin |
| _optimizer_null_aware_antijoin | TRUE | null-aware antijoin parameter |
| _optimizer_or_expansion | DEPTH | control or expansion approach used |
| _optimizer_or_expansion_subheap | TRUE | Use subheap for optimizer or-expansion |
| _optimizer_order_by_elimination_enabled | TRUE | Eliminates order bys from views before query transformation |
| _optimizer_outer_join_to_inner | TRUE | enable/disable outer to inner join conversion |
| _optimizer_outer_to_anti_enabled | TRUE | Enable transformation of outer-join to anti-join if possible |
| _optimizer_partial_join_eval | TRUE | partial join evaluation parameter |
| _optimizer_percent_parallel | 101 | optimizer percent parallel |
| _optimizer_performance_feedback | OFF | controls the performance feedback |
| _optimizer_proc_rate_level | BASIC | control the level of processing rates |
| _optimizer_proc_rate_source | DEFAULT | control the source of processing rates |
| _optimizer_purge_stats_iteration_row_count | 10000 | number of rows to be deleted at each iteration of the stats purging process |
| _optimizer_push_down_distinct | 0 | push down distinct from query block to table |
| _optimizer_push_pred_cost_based | TRUE | use cost-based query transformation for push pred optimization |
| _optimizer_random_plan | 0 | optimizer seed value for random plans |
| _optimizer_reduce_groupby_key | TRUE | group-by key reduction |
| _optimizer_reuse_cost_annotations | TRUE | reuse cost annotations during cost-based query transformation |
| _optimizer_rownum_bind_default | 10 | Default value to use for rownum bind |
| _optimizer_rownum_pred_based_fkr | TRUE | enable the use of first K rows due to rownum predicate |
| _optimizer_save_stats | TRUE | enable/disable saving old versions of optimizer stats |
| _optimizer_search_limit | 5 | optimizer search limit |
| _optimizer_self_induced_cache_cost | FALSE | account for self-induced caching |
| _optimizer_skip_scan_enabled | TRUE | enable/disable index skip scan |
| _optimizer_skip_scan_guess | FALSE | consider index skip scan for predicates with guessed selectivity |
| _optimizer_sortmerge_join_enabled | TRUE | enable/disable sort-merge join method |
| _optimizer_sortmerge_join_inequality | TRUE | enable/disable sort-merge join using inequality predicates |
| _optimizer_squ_bottomup | TRUE | enables unnesting of subquery in a bottom-up manner |
| _optimizer_star_tran_in_with_clause | TRUE | enable/disable star transformation in with clause queries |
| _optimizer_star_trans_min_cost | 0 | optimizer star transformation minimum cost |
| _optimizer_star_trans_min_ratio | 0 | optimizer star transformation minimum ratio |
| _optimizer_starplan_enabled | TRUE | optimizer star plan enabled |
| _optimizer_stats_on_conventional_dml_sample_rate | 100 | sampling rate for online stats gathering on conventional DML |
| _optimizer_strans_adaptive_pruning | TRUE | allow adaptive pruning of star transformation bitmap trees |
| _optimizer_synopsis_min_size | 2 | minimal synopsis size (kb) |
| _optimizer_system_stats_usage | TRUE | system statistics usage |
| _optimizer_table_expansion | TRUE | consider table expansion transformation |
| _optimizer_trace | none | optimizer trace parameter |
| _optimizer_track_hint_usage | TRUE | enable tracking of optimizer hint usage |
| _optimizer_transitivity_retain | TRUE | retain equi-join pred upon transitive equality pred generation |
| _optimizer_try_st_before_jppd | TRUE | try Star Transformation before Join Predicate Push Down |
| _optimizer_undo_changes | FALSE | undo changes to query optimizer |
| _optimizer_undo_cost_change | 21.1.0 | optimizer undo cost change |
| _optimizer_union_all_gsets | TRUE | Use Union All Optimization for Grouping Sets |
| _optimizer_unnest_all_subqueries | TRUE | enables unnesting of every type of subquery |
| _optimizer_unnest_corr_set_subq | TRUE | Unnesting of correlated set subqueries (TRUE/FALSE) |
| _optimizer_unnest_disjunctive_subq | TRUE | Unnesting of disjunctive subqueries (TRUE/FALSE) |
| _optimizer_unnest_scalar_sq | TRUE | enables unnesting of of scalar subquery |
| _optimizer_unnest_update_set_subq | on | enables unnesting of subquery in set for update |
| _optimizer_use_auto_indexes | AUTO | Use Auto Index |
| _optimizer_use_cbqt_star_transformation | TRUE | use rewritten star transformation using cbqt framework |
| _optimizer_use_feedback | TRUE | optimizer use feedback |
| _optimizer_use_feedback_for_join | FALSE | optimizer use feedback for join |
| _optimizer_use_gtt_session_stats | TRUE | use GTT session private statistics |
| _optimizer_use_histograms | TRUE | enable/disable the usage of histograms by the optimizer |
| _optimizer_use_stats_models | FALSE | use optimizer statistics extrapolation models |
| _optimizer_use_stats_on_conventional_config | 0 | settings for optimizer usage of online stats on conventional DML |
| _optimizer_use_stats_on_conventional_dml | FALSE | use optimizer statistics gathered for conventional DML |
| _optimizer_use_subheap | TRUE | Enables physical optimizer subheap |
| _optimizer_use_table_scanrate | HADOOP_ONLY | Use Table Specific Scan Rate |
| _optimizer_use_xt_rowid | TRUE | Use external table rowid |
| _optimizer_vector_base_dim_fact_factor | 200 | cost based vector transform base dimension to base fact ratio |
| _optimizer_vector_cost_adj | 100 | cost adjustment for vector aggregation processing estimates |
| _optimizer_vector_fact_dim_ratio | 10 | cost based vector transform dimension to fact ratio |
| _optimizer_vector_fact_payload_ratio | 20 | cost based vector transform payload dimension to fact ratio |
| _optimizer_vector_min_fact_rows | 10000000 | min number of rows required for vector aggregation transform |
| _optimizer_vector_transformation | TRUE | perform vector transform |
| _optimizer_wc_filter_pushdown | TRUE | enable/disable with clause filter predicate pushdown |
| _or_expand_nvl_predicate | TRUE | enable OR expanded plan for NVL/DECODE predicate |
| _oracle_employee_testing | FALSE | Switch on all features for the purpose of testing |
| _oracle_script | FALSE | Running an Oracle-supplied script |
| _oracle_script_counter | 0 | Helper parameter to set the value of _oracle_script counter |
| _oracle_special_license_1_granted | FALSE | Oracle internal parameter |
| _oradbg_pathname | path of oradbg script | |
| _oradebug_cmds_at_startup | oradebug commands to execute at instance startup | |
| _oradebug_force | FALSE | force target processes to execute oradebug commands? |
| _ordered_nested_loop | TRUE | enable ordered nested loop costing |
| _ordered_semijoin | TRUE | enable ordered semi-join subquery |
| _orph_cln_interval | 1200 | qmon periodic interval for removed subscriber messages cleanup |
| _os_sched_high_priority | 1 | OS high priority level |
| _os_sched_highest_priority | 1 | OS highest priority level |
| _oss_skgxp_udp_dynamic_credit_mgmt | OSSLIB set dynamic credit for SKGXP-UDP | |
| _other_wait_event_exclusion | exclude event names from _other_wait_threshold calculations | |
| _other_wait_threshold | 0 | threshold wait percentage for event wait class Other |
| _outline_bitmap_tree | TRUE | BITMAP_TREE hint enabled in outline |
| _override_datafile_encrypt_check | FALSE | if TRUE, override datafile tablespace encryption cross check |
| _parallel_adaptive_max_users | 4 | maximum number of users running with default DOP |
| _parallel_blackbox_enabled | TRUE | parallel execution blackbox enabled |
| _parallel_blackbox_sga | TRUE | true if blackbox will be allocated in SGA, false if PGA |
| _parallel_blackbox_size | 16384 | parallel execution blackbox bucket size |
| _parallel_broadcast_enabled | TRUE | enable broadcasting of small inputs to hash and sort merge joins |
| _parallel_cluster_cache_pct | 80 | max percentage of the global buffer cache to use for affinity |
| _parallel_cluster_cache_policy | ADAPTIVE | policy used for parallel execution on cluster(ADAPTIVE/CACHED) |
| _parallel_conservative_queuing | FALSE | conservative parallel statement queuing |
| _parallel_ctas_enabled | TRUE | enable/disable parallel CTAS operation |
| _parallel_default_max_instances | 1 | default maximum number of instances for parallel query |
| _parallel_execution_message_align | FALSE | Alignment of PX buffers to OS page boundary |
| _parallel_fake_class_pct | 0 | fake db-scheduler percent used for testing |
| _parallel_fault_tolerance_enabled | FALSE | enables or disables fault-tolerance for parallel statement |
| _parallel_fault_tolerance_threshold | 3 | total number of faults fault-tolerance will handle |
| _parallel_fixwrite_bucket | 1000 | Number of buckets for each round of fix write |
| _parallel_heartbeat_snapshot_interval | 2 | interval of snapshot to track px msging between instances |
| _parallel_heartbeat_snapshot_max | 128 | maximum number of historical snapshots archived |
| _parallel_inmemory_min_time_threshold | AUTO | threshold above which a plan is a candidate for parallelization for in-memory tables (in seconds) |
| _parallel_inmemory_time_unit | 1 | unit of work used to derive the degree of parallelism for in-memory tables (in seconds) |
| _parallel_lmd_reconfig | 1 | parallel lmd work in reconfiguration for enqueues. |
| _parallel_load_bal_unit | 0 | number of threads to allocate per instance |
| _parallel_load_balancing | TRUE | parallel execution load balanced slave allocation |
| _parallel_load_publish_threshold | 10 | diffrence in percentage controlling px load propagation |
| _parallel_log_write_cleanup | FALSE | Perform (null) log write cleanup in parallel |
| _parallel_min_message_pool | 491520 | minimum size of shared pool memory to reserve for pq servers |
| _parallel_optimization_phase_for_local | FALSE | parallel optimization phase when all slaves are local |
| _parallel_queuing_max_waitingtime | parallel statement queuing: max waiting time in queue | |
| _parallel_recovery_stopat | 32767 | stop at -position- to step through SMON |
| _parallel_replay_msg_limit | 4000 | Number of messages for each round of parallel replay |
| _parallel_scalability | 50 | Parallel scalability criterion for parallel execution |
| _parallel_server_idle_time | 30000 | idle time before parallel query server dies (in 1/100 sec) |
| _parallel_server_sleep_time | 1 | sleep time between dequeue timeouts (in 1/100ths) |
| _parallel_slave_acquisition_wait | 1 | time(in seconds) to wait before retrying slave acquisition |
| _parallel_statement_queuing | FALSE | parallel statement queuing enabled |
| _parallel_syspls_obey_force | TRUE | TRUE to obey force parallel query/dml/ddl under System PL/SQL |
| _parallel_time_unit | 10 | unit of work used to derive the degree of parallelism (in seconds) |
| _parallel_txn_global | FALSE | enable parallel_txn hint with updates and deletes |
| _parallelism_cost_fudge_factor | 350 | set the parallelism cost fudge factor |
| _parameter_spfile_sync | FALSE | SPFILE sync mode |
| _parameter_table_block_size | 2048 | parameter table block size |
| _part_redef_global_index_update | TRUE | online partition redefinition update global indexes |
| _partial_comp_enabled | TRUE | partial table compression enabled |
| _partial_log_preserve_space | TRUE | use only required space for partial archive logs |
| _partial_pwise_join_enabled | TRUE | enable partial partition-wise join when TRUE |
| _partition_advisor_srs_active | true | enables sampling based partitioning validation |
| _partition_by_con_name | FALSE | enable partitioning by con$name |
| _partition_cdb_view_enabled | TRUE | partitioned cdb view evaluation enabled |
| _partition_large_extents | TRUE | Enables large extent allocation for partitioned tables |
| _partition_read_only | TRUE | bypass all read only check for partition |
| _partition_view_enabled | TRUE | enable/disable partitioned views |
| _passwordfile_enqueue_timeout | 900 | password file enqueue timeout in seconds |
| _path_prefix_create_dir | TRUE | Create path in file system for CREATE DIRECTORY with PATH_PREFIX |
| _pbkdf2_sder_count | 3 | The PBKDF2 count to use for session key derivation |
| _pct_refresh_double_count_prevented | TRUE | materialized view PCT refreshes avoid double counting |
| _pdb_auto_save_state | FALSE | Save pdb state automatically on state change on a given instance |
| _pdb_auto_undots_create_off | FALSE | disable automatic creation of undo tablespace in local undo mode |
| _pdb_char_set_intconv | FALSE | Enforce internal_convert for PDB character set conversion |
| _pdb_clone_preserve_guid | FALSE | Use same guid for a pdb clone |
| _pdb_cluster_database | TRUE | This parameter can be turned-off when cluster_database is TRUE |
| _pdb_create_use_sysoper_conn | FALSE | spread file copy slaves across instances |
| _pdb_datapatch_violation_restricted | TRUE | Open pdb in restricted mode for datapatch error violation |
| _pdb_failure_testing | 0 | Testing failure in pluggable database related operations |
| _pdb_file_copy_affinitize | FALSE | spread file copy slaves across instances |
| _pdb_file_copy_buffers | 8 | number of buffers to use for pdb file copy |
| _pdb_first_script | FALSE | Running a script that is PDB-first/ROOT-last |
| _pdb_force_cfd | FALSE | Force DB_CREATE_FILE_DEST path for all datafiles in PDB |
| _pdb_hash_table_latches | 16 | number of PDB hash table latches |
| _pdb_hash_table_size | 255 | number of buckets in PDB hash table |
| _pdb_hybrid_read_only | FALSE | Hybrid read only mode allows CDB common user to patch the PDB |
| _pdb_ignore_table_clauses | TRUE | Ignore subset of clauses in CREATE TABLE and ALTER TABLE |
| _pdb_inherit_cfd | FALSE | Automatically enable CREATE_FILE_DEST clause in the PDB |
| _pdb_isolation_class | NONE | PDB isolation level: NONE, HIGH or MAX |
| _pdb_ktg_buffer_size | 16 | KTG buffer size (in KB) to store inmemory traces |
| _pdb_ldp_cascade | 0 | pluggable database lockdown profile cascade param |
| _pdb_lockdown_bypass_sr | 0 | special run lockdown parameter |
| _pdb_lockdown_ddl_clauses | 0 | pluggable database lockdown clauses for statements |
| _pdb_lrg_auto_undots_create | FALSE | enable automatic creation of undo tablespace in local undo mode |
| _pdb_mask_cdb_info | FALSE | Enable masking CDB information within a PDB |
| _pdb_max_audit_size | 0 | Default value for MAX_AUDIT_SIZE property in new PDB creation |
| _pdb_max_diag_size | 0 | Default value for MAX_DIAG_SIZE property in new PDB creation |
| _pdb_max_size_discount | 10 | Discount percentable on PDB Max space usage |
| _pdb_name_case_sensitive | FALSE | Keeps PDB name case sensitive |
| _pdb_oper_trace_threshold | 600 | PDB operations timing trace threshold |
| _pdb_oper_trace_threshold_softassert | FALSE | PDB operations timing threshold soft assert |
| _pdb_read_only_refresh | FALSE | allow refresh when pdb is open r/o |
| _pdb_refresh_apply_master_key_rekey | TRUE | Apply master rekey marker during pdb refresh |
| _pdb_refresh_use_dblink_to_catalog | FALSE | Use central catalog for pdb refresh |
| _pdb_refresh_use_local_logs | TRUE | Use local logs for pdb refresh |
| _pdb_seed_mcsc | FALSE | Allow PDB SEED to have different character set than the CDB. |
| _pdb_service_on_root_listener | FALSE | pdb services on CDB ROOT listeners |
| _pdb_small_table_threshold | 20 | lower threshold level of table size for direct reads in a pdb |
| _pdb_strict_plugin_compat | FALSE | Pluggable database strict plugin compatibility |
| _pdb_transition_clean_bg_delay | 0 | delay in GEN0 to transition PDB to clean state |
| _pdb_use_sequence_cache | TRUE | Use sequence cache in PDB mode |
| _pdb_vm_max_size | PDB SGA maximum virtual memory size | |
| _pdml_gim_sampling | 5000 | control separation of global index maintenance for PDML |
| _pdml_gim_staggered | FALSE | slaves start on different index when doing index maint |
| _pdml_slaves_diff_part | TRUE | slaves start on different partition when doing index maint |
| _percent_flashback_buf_partial_full | 50 | Percent of flashback buffer filled to be considered partial full |
| _pga_aggregate_xmem_limit | 0 | limit of aggregate PGA XMEM memory consumed by the instance |
| _pga_auto_snapshot_percentage | 20 | percent growth of PGA memory for additional snapshots |
| _pga_auto_snapshot_threshold | 524288000 | bytes of PGA memory in one process to trigger detail snapshot |
| _pga_in_sga_param1 | pga in sga param1 | |
| _pga_in_sga_param2 | pga in sga param2 | |
| _pga_in_sga_param3 | pga in sga param4 | |
| _pga_in_sga_param4 | pga in sga param4 | |
| _pga_in_sga_param5 | pga in sga param4 | |
| _pga_large_extent_size | 1048576 | PGA large extent size |
| _pga_limit_check_wait_time | 1000000 | microseconds to wait for over limit confirmation |
| _pga_limit_dump_summary | TRUE | dump PGA summary when signalling ORA-4036 |
| _pga_limit_interrupt_smaller | FALSE | whether to interrupt smaller eligible processes |
| _pga_limit_min_req_size | 4194304 | bytes of PGA usage below which process will not get ORA-4036 |
| _pga_limit_per_process_minimum | 3145728 | pga_aggregate_limit per-process minimum |
| _pga_limit_physmem_perc | 90 | default percent of physical memory for pga_aggregate_limit and SGA |
| _pga_limit_simulated_physmem_size | 0 | bytes of physical memory to determine pga_aggregate_limit with |
| _pga_limit_target_perc | 200 | default percent of pga_aggregate_target for pga_aggregate_limit |
| _pga_limit_time_to_interrupt | 2 | seconds to wait until direct interrupt |
| _pga_limit_time_until_idle | 15 | seconds to wait before treating process as idle |
| _pga_limit_time_until_killed | 30 | seconds to wait before killing session over limit |
| _pga_limit_tracing | 0 | trace pga_aggregate_limit activity |
| _pga_limit_use_immediate_kill | TRUE | use immediate kill for sessions over limit |
| _pga_limit_watch_perc | 50 | percentage of limit to have processes watch |
| _pga_limit_watch_size | 104857600 | bytes of PGA usage at which process will begin watching limit |
| _pga_max_size | 209715200 | Maximum size of the PGA memory for one process |
| _pgactx_cap_stacks | FALSE | capture stacks for setting pgactx |
| _pin_time_statistics | FALSE | if TRUE collect statistics for how long a current pin is held |
| _pivot_implementation_method | CHOOSE | pivot implementation method |
| _pkt_enable | FALSE | enable progressive kill test |
| _pkt_pmon_interval | 50 | PMON process clean-up interval (cs) |
| _pkt_start | FALSE | start progressive kill test instrumention |
| _plan_outline_data | TRUE | explain plan outline data enabled |
| _plan_verify_improvement_margin | 150 | Performance improvement criterion for evolving plan baselines |
| _plcmnt_template_svc_name | service placement template name | |
| _plsql_anon_block_code_type | INTERPRETED | PL/SQL anonymous block code-type |
| _plsql_cache_enable | TRUE | PL/SQL Function Cache Enabled |
| _plsql_dump_buffer_events | conditions upon which the PL/SQL circular buffer is dumped | |
| _plsql_icd_arg_dump | FALSE | Dump arguments to ICD |
| _plsql_max_stack_size | 0 | PL/SQL maximum stack size |
| _plsql_minimum_cache_hit_percent | 20 | plsql minimum cache hit percentage required to keep caching active |
| _plsql_native_frame_threshold | 4294967294 | Allocate PL/SQL native frames on the heap if size exceeds this value |
| _plsql_nvl_optimize | FALSE | PL/SQL NVL optimize |
| _plsql_share_instantiation | TRUE | PL/SQL share kgscc for same SQL executed at multiple locations |
| _pluggable_database_debug | 0 | Debug flag for pluggable database related operations |
| _pmem_exchange_cold_victim_threshold | 0 | worthy touch count threshold for a victim buffer to be exchanged into pmem |
| _pmem_small_table_threshold | 20 | lower threshold of PMEM table size as percentage to PMEM cache for direct reads |
| _pmemfs_alloc_dataptrs | 1 | Set PMEMfs to preallocate inode tree |
| _pmemfs_enable_spacetracking | FALSE | Enable PMEMfs Space Accounting Checks |
| _pmemfs_shrink_level | 0 | Enable pmemstore shrink |
| _pmemfs_smallfile_threshold | 1024 | Block count threshold for metedata |
| _pmon_cleanup_max_dfs | 100 | max dfs elements during cleanup |
| _pmon_dead_blkrs_alive_chk_rate_secs | 3 | rate to check blockers are alive during cleanup (in seconds) |
| _pmon_dead_blkrs_max_blkrs | 50 | max blockers to check during cleanup |
| _pmon_dead_blkrs_max_cleanup_attempts | 5 | max attempts per blocker while checking dead blockers |
| _pmon_dead_blkrs_scan_rate_secs | 3 | rate to scan for dead blockers during cleanup (in seconds) |
| _pmon_enable_dead_blkrs | TRUE | look for dead blockers during PMON cleanup |
| _pmon_exitnfy_enabled | FALSE | PMON Exit notification enabled |
| _pmon_idle_scan_interval | 60 | PMON idle scan interval (in seconds) |
| _pmon_incr_slaves | 3 | PMON cleanup: slave increment |
| _pmon_load_constants | 300,192,64,3,10,10,0,0 | server load balancing constants (S,P,D,I,L,C,M) |
| _pmon_max_consec_posts | 5 | PMON max consecutive posts in main loop |
| _pmon_max_slaves | 10 | Maximum number of PMON slaves |
| _pmon_min_slaves | 1 | Minimum number of PMON slaves |
| _pmon_new_slave_secs | 30 | PMON cleanup: new slave (in seconds) |
| _pmon_slave_stop_secs | 60 | PMON cleanup: slave stop limit (in seconds) |
| _pmon_slaves_arr_size | 160 | Array size for PMON slaves |
| _pmon_trees_per_slave | 10 | PMON cleanup: trees per slave |
| _posix_spawn_enabled | TRUE | posix_spawn enabled |
| _post_run_job_evaluation | FALSE | Control if jobs should evaluate at end of execution |
| _post_wait_queues_num_per_class | Post Wait Queues - Num Per Class | |
| _pq_numa_working_set_affinity | TRUE | if TRUE, enable pq slave NUMA affinity |
| _pqq_debug_txn_act | FALSE | pq queuing transaction active |
| _pqq_enabled | TRUE | Enable Resource Manager based Parallel Statement Queuing |
| _pqq_pdb_load_publish_threshold | 0 | difference in percentage controlling PDB load publish |
| _pre_rewrite_push_pred | TRUE | push predicates into views before rewrite |
| _precompute_gid_values | TRUE | precompute gid values and copy them before returning a row |
| _pred_move_around | TRUE | enables predicate move-around |
| _pred_push_cdb_view_enabled | TRUE | predicate pushdown enabled for CDB views |
| _predicate_elimination_enabled | TRUE | allow predicate elimination if set to TRUE |
| _predicate_validity_execution | FALSE | enable execution-time check for predicate validation |
| _prefer_local_temp | FALSE | Use Local Temp as preferred default tablespace |
| _prefered_standby | standby db_unique_name prefered for krb operations | |
| _preplugin_backup | enabled | enable/disable pre-plugin backup feature |
| _prescomm | FALSE | presume commit of IMU transactions |
| _prespawn_batch_count | 20 | prespawn batch count |
| _prespawn_bg_init_count | 0 | prespawn background init count |
| _prespawn_enabled | FALSE | Is prespawn enabled |
| _prespawn_fg_init_count | 0 | prespawn foreground init count |
| _prespawn_min_count | 10 | prespawn minimum count |
| _print_inmem_heatmap | 0 | print inmem ilm heatmap |
| _print_inmem_srmap | 0 | print inmem spacereuse map |
| _print_refresh_schedule | false | enable dbms_output of materialized view refresh schedule |
| _print_stat_segment | 0 | print ilm statistics segment |
| _priv_for_set_current_schema | FALSE | ALTER SESSION privilege required for SET CURRENT_SCHEMA |
| _private_memory_address | Start address of large extent memory segment | |
| _proc_grp_enabled | 3 | proc-group enabled |
| _proc_grp_numa_map | proc-group map string | |
| _process_allocation_slots | 100 | process allocation slots |
| _process_heartbeat_range | 3 | Process heartbeat range |
| _process_max_pred_increase | 20000 | process SO max predicted increase |
| _process_percent_rampup_end | 320 | process SO percent rampup end |
| _process_percent_rampup_start | 320 | process SO percent rampup start |
| _process_prediction_failover_buffer | 1 | process prediction failover buffer |
| _process_save_prediction | FALSE | save process prediction for next instance startup |
| _process_so_max_inc | 20000 | process SO max inc |
| _profile_sensitive_users | Database Users with restricted password profile | |
| _project_view_columns | TRUE | enable projecting out unreferenced columns of a view |
| _projection_pushdown | TRUE | projection pushdown |
| _projection_pushdown_debug | 0 | level for projection pushdown debugging |
| _prop_old_enabled | FALSE | Shift to pre 11g propagation behaviour |
| _propogate_restore_point | TRUE | Allow shipping of restore point from primary to standby |
| _protect_frame_heaps | FALSE | Protect cursor frame heaps |
| _proxy_connect_after_set_container | TRUE | Enable proxy connection after set container |
| _psdclog_enable | FALSE | Mandatory Cloud Logging of PL/SQL Utility Packages Usages |
| _psdclog_threshold | 10 | Threshold for Cloud Logging of PL/SQL Utility Packages Usages |
| _pseudo_bootstrap | FALSE | Indicate that pseudo boostrap be done |
| _psr_opt | enable feature | options for standby pdb recovery |
| _ptf_enable_objects | FALSE | enable object types in PTF |
| _ptf_max_rows | 1024 | number of rows per row-buffer |
| _ptn_cache_threshold | 1 | flags and threshold to control partition metadata caching |
| _ptt_max_num | 16 | Maximum number of PTTs per session |
| _purge_idcs_access_token | FALSE | Purge IDCS Access Token |
| _push_join_predicate | TRUE | enable pushing join predicate inside a view |
| _push_join_union_view | TRUE | enable pushing join predicate inside a union all view |
| _push_join_union_view2 | TRUE | enable pushing join predicate inside a union view |
| _pwise_distinct_enabled | TRUE | enable partition wise distinct |
| _px_adaptive_dist_bypass_enabled | TRUE | enable the bypass table queue for adaptive distribution methods |
| _px_adaptive_dist_bypass_optimization | 1 | sets optimizations for bypass table queue for ADM |
| _px_adaptive_dist_method | CHOOSE | determines the behavior of adaptive distribution methods |
| _px_adaptive_dist_method_threshold | 0 | Buffering / decision threshold for adaptive distribution methods |
| _px_adaptive_dist_nij_enabled | ON | enable adaptive distribution methods for left non-inner joins |
| _px_adaptive_offload_percentage | 30 | percentage for PQ adaptive offloading of granules |
| _px_adaptive_offload_threshold | 10 | threshold (GB/s) for PQ adaptive offloading of granules |
| _px_autodop_pq_overhead | TRUE | adjust auto dop calculation using pq overhead |
| _px_back_to_parallel | OFF | allow going back to parallel after a serial operation |
| _px_bind_peek_sharing | TRUE | enables sharing of px cursors that were built using bind peeking |
| _px_broadcast_fudge_factor | 100 | set the tq broadcasting fudge factor percentage |
| _px_buffer_ttl | 30 | ttl for px mesg buffers in seconds |
| _px_cdb_view_enabled | TRUE | parallel cdb view evaluation enabled |
| _px_cdb_view_join_enabled | TRUE | disable parallelism cap on CDB view |
| _px_chunk_size | 1000000 | default size of a chunk for row id granules (in KB) |
| _px_chunklist_count_ratio | 32 | ratio of the number of chunk lists to the default DOP per instance |
| _px_compilation_debug | 0 | debug level for parallel compilation |
| _px_compilation_trace | 0 | tracing level for parallel compilation |
| _px_concurrent | TRUE | enables pq with concurrent execution of serial inputs |
| _px_cpu_autodop_enabled | TRUE | enables or disables auto dop cpu computation |
| _px_cpu_operator_bandwidth | CPU operator bandwidth in MB/sec for DOP computation | |
| _px_cpu_process_bandwidth | 200 | CPU process bandwidth in MB/sec for DOP computation |
| _px_dist_agg_partial_rollup_pushdown | ADAPTIVE | perform distinct agg partial rollup pushdown for px execution |
| _px_dp_array_size | 32767 | Max number of pq processes supported |
| _px_dump_12805_source | TRUE | enables or disables tracing of 12805 signal source |
| _px_dynamic_granules | TRUE | enable dynamic granule generation |
| _px_dynamic_granules_adjust | 10 | adjust dynamic granule regeneration |
| _px_dynamic_opt | TRUE | turn off/on restartable qerpx dynamic optimization |
| _px_dynamic_sample_size | 50 | num of samples for restartable qerpx dynamic optimization |
| _px_execution_services_enabled | TRUE | enable service-based constraint of px slave allocation |
| _px_extended_join_skew_handling | TRUE | enables extended skew handling for parallel joins |
| _px_external_table_default_stats | TRUE | the external table default stats collection enable/disable |
| _px_filter_parallelized | TRUE | enables or disables correlated filter parallelization |
| _px_filter_skew_handling | TRUE | enable correlated filter parallelization to handle skew |
| _px_freelist_latch_divisor | 2 | Divide the computed number of freelists by this power of 2 |
| _px_gim_factor | 100 | weighted autodop global index maintenance factor |
| _px_granule_alignment | 1024 | default size of a rowid range granule (in KB) |
| _px_granule_batch_size | 26 | maximum size of a batch of granules |
| _px_granule_randomize | TRUE | enables or disables randomization of parallel scans rowid granules |
| _px_granule_size | 1000000 | default size of a rowid range granule (in KB) |
| _px_groupby_pushdown | FORCE | perform group-by pushdown for parallel query |
| _px_hold_time | 0 | hold px at execution time (unit: second) |
| _px_hybrid_TSM_HWMB_load | TRUE | Enable Hybrid Temp Segment Merge/High Water Mark Brokered load method |
| _px_hybrid_partition_execution_enabled | TRUE | enable parallel hybrid partition execution |
| _px_hybrid_partition_skew_threshold | 10 | partitions bigger than threshold times average size are skewed |
| _px_increase_join_frag_size | TRUE | increase join message fragment size |
| _px_index_sampling_objsize | TRUE | parallel query sampling for index create based on object size |
| _px_io_process_bandwidth | 200 | IO process bandwidth in MB/sec for computing DOP |
| _px_io_system_bandwidth | 0 | total IO system bandwidth in MB/sec for computing DOP |
| _px_join_skew_handling | TRUE | enables skew handling for parallel joins |
| _px_join_skew_minfreq | 30 | sets minimum frequency(%) for skewed value for parallel joins |
| _px_join_skew_null_handling | TRUE | enables null skew handling improvement for parallel outer joins |
| _px_join_skew_ratio | 10 | sets skew ratio for parallel joins |
| _px_join_skew_sampling_percent | 0 | Sets sampling percentage for skew handling sampling queries |
| _px_join_skew_sampling_time_limit | 50 | Sets execution time limit for skew handling sampling queries |
| _px_join_skew_use_histogram | TRUE | Enables retrieval of skewed values from histogram when possible |
| _px_join_skewed_values_count | 0 | force join skew handling with specified skewed values count |
| _px_kxib_tracing | 0 | turn on kxib tracing |
| _px_load_balancing_policy | UNIFORM | parallel load balancing policy |
| _px_load_factor | 300 | weighted autodop load factor |
| _px_load_monitor_threshold | 10000 | threshold for pushing information to load slave workload monitor |
| _px_load_publish_interval | 200 | interval at which LMON will check whether to publish PX load |
| _px_loc_msg_cost | 1000 | CPU cost to send a PX message via shared memory |
| _px_max_granules_per_slave | 100 | maximum number of rowid range granules to generate per slave |
| _px_max_map_val | 32 | Maximum value of rehash mapping for PX |
| _px_max_message_pool_pct | 40 | percentage of shared pool for px msg buffers range [5,90] |
| _px_message_compression | TRUE | enable compression of control messages for parallel query |
| _px_min_granules_per_slave | 13 | minimum number of rowid range granules to generate per slave |
| _px_min_ndv_per_slave_perc_func | 2 | mininum NDV of TQ keys needed per slave for parallel percentile |
| _px_minus_intersect | TRUE | enables pq for minus/interect operators |
| _px_net_msg_cost | 10000 | CPU cost to send a PX message over the internconnect |
| _px_nlj_bcast_rr_threshold | 10 | threshold to use broadcast left random right distribution for NLJ |
| _px_no_granule_sort | FALSE | prevent parallel partition granules to be sorted on size |
| _px_no_stealing | FALSE | prevent parallel granule stealing in shared nothing environment |
| _px_nss_planb | TRUE | enables or disables NSS Plan B reparse with outline |
| _px_numa_stealing_enabled | TRUE | enable/disable PQ granule stealing across NUMA nodes |
| _px_numa_support_enabled | FALSE | enable/disable PQ NUMA support |
| _px_object_sampling | 200 | parallel query sampling for base objects (100000 = 100%) |
| _px_object_sampling_enabled | TRUE | use base object sampling when possible for range distribution |
| _px_object_sampling_multiplier | 2 | number of samples to send to QC per slave is DOP * prmixsm |
| _px_onepass_slave_acquisition | TRUE | enable/disable one pass slave acquisition for parallel execution |
| _px_oneslave_per_instance_parse | TRUE | send parse to one slave per instance |
| _px_overhead_exec_ctrlmesg | 4 | pq overhead on sending one control message during execution (in microseconds) |
| _px_overhead_init_endpoints | 4 | pq overhead on setting up one end point during initialization (in microseconds) |
| _px_overhead_init_slavealloc | 1000 | pq overhead on allocating per slave during initialization (in microseconds) |
| _px_overhead_teardown | 600 | pq overhead on setting up one end point during initialization (in microseconds) |
| _px_parallel_spawn_min_count | 2 | PQ parallel spawn min threshold count |
| _px_parallelize_expression | TRUE | enables or disables expression evaluation parallelization |
| _px_parallelize_non_native_datatype | TRUE | enable parallelization for non-native datatypes |
| _px_partial_rollup_pushdown | ADAPTIVE | perform partial rollup pushdown for parallel execution |
| _px_partition_load_dist_threshold | 64 | # of load slave to # of partition ratio to switch distribution |
| _px_partition_scan_enabled | TRUE | enables or disables parallel partition-based scan |
| _px_partition_scan_threshold | 64 | least number of partitions per slave to start partition-based scan |
| _px_partition_skew_threshold | 80 | percentage of table size considered as threshold for skew determination |
| _px_proactive_slave_alloc_threshold | 8 | parallel proactive slave allocation threshold/unit |
| _px_proc_constrain | TRUE | reduce parallel_max_servers if greater than (processes - fudge) |
| _px_pwg_enabled | TRUE | parallel partition wise group by enabled |
| _px_pwise_wif_enabled | TRUE | enable parallel partition wise window function |
| _px_pwmr_enabled | TRUE | parallel partition wise match recognize enabled |
| _px_replication_enabled | TRUE | enables or disables replication of small table scans |
| _px_reuse_server_groups | MULTI | enable/disable reusing of server groups that are already acquired |
| _px_round_robin_rowcnt | 1000 | round robin row count to enq to next slave |
| _px_rownum_pd | TRUE | turn off/on parallel rownum pushdown optimization |
| _px_scalable_gby_invdist | TRUE | scalable PX plan for GBY w/ inverse distribution functions |
| _px_scalable_invdist | TRUE | enable/disable px scalable plan for inverse distribution functions |
| _px_scalable_invdist_mcol | TRUE | enable/disable px plan for percentile functions on multiple columns |
| _px_send_timeout | 300 | IPC message send timeout value in seconds |
| _px_shared_hash_join | FALSE | enable/disable shared hash join |
| _px_single_server_enabled | TRUE | allow single-slave dfo in parallel query |
| _px_slave_parse_first_with_outline_hints | TRUE | Enable/Disable trying outlined plan first |
| _px_split_batches_per_slave | 7 | number of split granules per slave for exadoop |
| _px_split_multi_msg | TRUE | use multiple messages to send batch of split granules |
| _px_split_use_single_list | TRUE | use single list for split granules |
| _px_tq_memcpy_threshold | 100 | threshold for PQ TQ to use memcpy for packing columns |
| _px_tq_rowhvs | TRUE | turn on intra-row hash valueing sharing in TQ |
| _px_trace | none | px trace parameter |
| _px_ual_serial_input | TRUE | enables new pq for UNION operators |
| _px_wif_dfo_declumping | CHOOSE | NDV-aware DFO clumping of multiple window sorts |
| _px_wif_extend_distribution_keys | TRUE | extend TQ data redistribution keys for window functions |
| _px_wif_min_ndv_per_slave | 2 | mininum NDV of TQ keys needed per slave for scalable WiF PX |
| _px_xtgranule_size | 10000 | default size of a external table granule (in KB) |
| _qa_control | 0 | Oracle internal parameter to control QA |
| _qa_lrg_type | 0 | Oracle internal parameter to specify QA lrg type |
| _qesma_bo_lru_sz | 25 | size of base object LRU list for QESMA session cache |
| _qesma_mvob_lru_sz | 25 | size of MVOB LRU list for QESMA session cache |
| _qesmasc_trc | 0 | tracing for QESMA session cache |
| _qksfgi_disable_action_mask | 0 | disable fine-grained cursor invalidation actions |
| _qksfgi_disable_oct_mask | 0 | disable fine-grained cursor invalidation for certain oct |
| _qksfgi_dix_val | FALSE | controls action of fine-grained cursor invalidation for DROP INDEX |
| _qksfgi_dynamic_partitions | enable partition bind SQLIDs for | |
| _qksfgi_feature_level | 0 | controls the feature level for fine-grained cursor invalidation |
| _qkslvc_47510_sys | 1 | enable project 47510 for internal users |
| _qkslvc_47510_test | 0 | enable project 47510 for testing |
| _qkslvc_extended_bind_sz | 1 | controls error checking for the max_string_size parameter |
| _quarantine_enabled | TRUE | quarantine: enable |
| _quarantine_max_mem | 1 | quarantine: max amount of memory |
| _quarantine_max_objs | 10000 | quarantine: max number of objects |
| _quarantine_per_hour | 60 | quarantine: limit per hour |
| _query_cost_rewrite | TRUE | perform the cost based rewrite with materialized views |
| _query_execution_cache_max_size | 131072 | max size of query execution cache |
| _query_execution_time_limit | 0 | Query execution time limit in seconds |
| _query_mmvrewrite_maxcmaps | 20 | query mmv rewrite maximum number of cmaps per dmap in query disjunct |
| _query_mmvrewrite_maxdmaps | 10 | query mmv rewrite maximum number of dmaps per query disjunct |
| _query_mmvrewrite_maxinlists | 5 | query mmv rewrite maximum number of in-lists per disjunct |
| _query_mmvrewrite_maxintervals | 5 | query mmv rewrite maximum number of intervals per disjunct |
| _query_mmvrewrite_maxpreds | 10 | query mmv rewrite maximum number of predicates per disjunct |
| _query_mmvrewrite_maxqryinlistvals | 500 | query mmv rewrite maximum number of query in-list values |
| _query_mmvrewrite_maxregperm | 512 | query mmv rewrite maximum number of region permutations |
| _query_on_physical | TRUE | query on physical |
| _query_rewrite_1 | TRUE | perform query rewrite before&after or only before view merging |
| _query_rewrite_2 | TRUE | perform query rewrite before&after or only after view merging |
| _query_rewrite_drj | FALSE | mv rewrite and drop redundant joins |
| _query_rewrite_expression | TRUE | rewrite with cannonical form for expressions |
| _query_rewrite_fpc | TRUE | mv rewrite fresh partition containment |
| _query_rewrite_fudge | 90 | cost based query rewrite with MVs fudge factor |
| _query_rewrite_jgmigrate | TRUE | mv rewrite with jg migration |
| _query_rewrite_maxdisjunct | 257 | query rewrite max disjuncts |
| _query_rewrite_or_error | FALSE | allow query rewrite, if referenced tables are not dataless |
| _query_rewrite_setopgrw_enable | TRUE | perform general rewrite using set operator summaries |
| _query_rewrite_use_on_query_computation | TRUE | query rewrite use on query computation |
| _query_rewrite_vop_cleanup | TRUE | prune frocol chain before rewrite after view-merging |
| _queue_buffer_max_dump_len | 65536 | max number of bytes to dump to trace file for queue buffer dump |
| _rac_dbtype_reset | FALSE | RAC database type reset from CRS |
| _rac_propagate_last_rba | TRUE | Propagate last written log redo address in RAC for log mining |
| _radm_enabled | TRUE | Data Redaction |
| _rbr_ckpt_tracing | 0 | Enable reuse block range checkpoint tracing |
| _rc_sys_obj_enabled | TRUE | result cache enabled for Sys Objects |
| _rcfg_disable_verify | TRUE | if TRUE disables verify at reconfiguration |
| _rcfg_parallel_fixwrite | TRUE | if TRUE enables parallel fixwrite at reconfiguration |
| _rcfg_parallel_replay | TRUE | if TRUE enables parallel replay and cleanup at reconfiguration |
| _rcfg_parallel_verify | FALSE | if TRUE enables parallel verify at reconfiguration |
| _rdbms_compatibility | 10.1 | default RDBMS compatibility level |
| _rdbms_internal_fplib_enabled | FALSE | enable CELL FPLIB filtering within rdbms |
| _rdbms_internal_fplib_raise_errors | FALSE | enable reraising of any exceptions in CELL FPLIB |
| _re_fast_sql_operator | all | enables fast boxable sql operator |
| _re_independent_expression_cache_size | 20 | defines max number of compiled cached expressions for iee |
| _re_num_complex_operator | 1000 | defines max number of compiled complex operator per ruleset-iee |
| _re_num_rowcache_load | 2 | defines max number of complex operators loaded with row cache |
| _re_result_cache_keysiz | 20 | defines max number key for result cache hash table |
| _re_result_cache_size | 20 | defines max number of cached elements for result cache |
| _read_mostly_enable_logon | FALSE | Read mostly/ Read only instances enable non-privileged logons |
| _read_mostly_instance | FALSE | indicates this is a read_mostly instance |
| _read_mostly_instance_qa_control | 0 | internal parameter to control read mostly instance QA |
| _read_mostly_lock_mitigation | TRUE | Read Mostly Lock mitigation support |
| _read_mostly_slave_timeout | 20 | Time to wait on read mostly node when hub not available |
| _read_only_slave_timeout | 30 | Time to wait on read only node when hub not available |
| _read_only_violation_dump_to_trace | FALSE | read-only violation dump to trace files |
| _read_only_violation_max_count | 500 | read-only violation array max count |
| _read_only_violation_max_count_per_module | 100 | read-only violation array per module max count |
| _read_optimized_table_lookup | TRUE | enables read-optimized table lookup |
| _readable_standby_sync_interval | 0 | readable standby recovery global sync interval |
| _readable_standby_sync_timeout | 10 | readable standby query scn sync timeout |
| _reader_farm_isolation_enable | FALSE | Reader Farm instances isolation enable |
| _reader_farm_isolation_time_threshold | 200 | reader farm isolation time threshold |
| _real_time_apply_sim | 0 | Simulation value with real time apply |
| _realfree_heap_max_size | 32768 | minimum max total heap size, in Kbytes |
| _realfree_heap_mode | 0 | mode flags for real-free heap |
| _realfree_heap_pagesize | 65536 | hint for real-free page size in bytes |
| _realfree_pq_heap_pagesize | 65536 | hint for pq real-free page size in bytes |
| _reclaim_lob_index_scan_limit | 0 | limit lob index scanning during lob space-reclaim |
| _reco_sessions_max_percentage | 50 | allowed RECO sessions as a percentage of total sessions allowed |
| _reconfiguration_opt_level | 237 | reconfiguration optimization level |
| _record_module_name | TRUE | Record module name in BEGIN action |
| _recoverable_recovery_batch_percent | 50 | Recoverable recovery batch size (percentage of buffer cache) |
| _recoverable_recovery_max_influx_buffers | 100000 | Recoverable recovery number of influx buffers limit |
| _recovery_asserts | FALSE | if TRUE, enable expensive integrity checks |
| _recovery_percentage | 50 | recovery buffer cache percentage |
| _recovery_read_limit | 1024 | number of recovery reads which can be outstanding |
| _recovery_skip_cfseq_check | FALSE | allow media recovery even if controlfile seq check fails |
| _recovery_verify_writes | FALSE | enable thread recovery write verify |
| _recursive_imu_transactions | FALSE | recursive transactions may be IMU |
| _recursive_with_branch_iterations | 7 | Expected number of iterations of the recurive branch of RW/CBY |
| _recursive_with_control | 0 | control different uses/algorithms related to recursive with |
| _recursive_with_max_recursion_level | 0 | check for maximum level of recursion instead of checking for cycles |
| _recursive_with_parallel | TRUE | Enable/disable parallelization of Recursive With |
| _recursive_with_using_temp_table | FALSE | Enable the use of CDT for serial execution of Recursive With |
| _redef_on_statement | FALSE | Use on-statement refresh in online redefinition |
| _redo_compatibility_check | FALSE | general and redo/undo compatibility sanity check |
| _redo_log_check_backup | 10 | time interval in minutes between wakeups to check backup of redo logs |
| _redo_log_debug_config | 0 | Various configuration flags for debugging redo logs |
| _redo_log_key_reuse_count | 0 | Determines the number of redo logs sharing the same redo log key |
| _redo_log_record_life | 168 | Life time in hours for redo log table records |
| _redo_read_from_memory | TRUE | Enable reading redo from in-memory log buffer |
| _redo_transport_async_mode | 0 | redo transport ASYNC process mode |
| _redo_transport_catch_up_bandwidth_percentage | 50 | redo transport catch up bandwitdth percent |
| _redo_transport_compress_all | TRUE | Is ASYNC LNS compression allowed? |
| _redo_transport_evict_threshold | 10 | Threshold beyond which a slower ASYNC connection will be evicted |
| _redo_transport_max_kbytes_sec | 0 | redo transport maximum KB/s |
| _redo_transport_min_kbytes_sec | 10 | redo transport minimum KB/s |
| _redo_transport_redo_log_management | redo log management | |
| _redo_transport_resource_management | FALSE | Redo transport resource management |
| _redo_transport_sanity_check | 0 | redo transport sanity check bit mask |
| _redo_transport_stall_time | 360 | use parameter DATA_GUARD_MAX_IO_TIME |
| _redo_transport_stall_time_long | 3600 | use parameter DATA_GUARD_MAX_LONGIO_TIME |
| _redo_transport_stream_test | TRUE | test stream connection? |
| _redo_transport_stream_writes | TRUE | Stream network writes? |
| _redo_transport_vio_size_req | 1048576 | VIO size requirement |
| _redo_write_coalesce_all_threshold | 0 | Redo write coalescing threshold (all strands) in bytes |
| _redo_write_coalesce_slave_threshold | 0 | Redo write coalescing threshold (slave strands) in bytes |
| _redo_write_sync_single_io | TRUE | enable sync I/O for single redo write |
| _reduce_sby_log_scan | TRUE | enable standby log scan optimization |
| _ref_cons_sql_enforcement | TRUE | disable extended/data ref constraint SQL enforcement |
| _reg_cache_status | FALSE | Enables or disabled caching |
| _region_name | gsm region name | |
| _release_insert_threshold | 5 | maximum number of unusable blocks to unlink from freelist |
| _reliable_block_sends | TRUE | if TRUE, no side channel on reliable interconnect |
| _relocate_pdb | FALSE | Relocate PDB to another RAC instance after it is closed in the current instance |
| _relocation_commit_batch_size | 8 | ASM relocation commit batch size |
| _remessage_dbwrs | 0 | DBWR wait and remessage time - in cs |
| _remote_asm | remote ASM configuration | |
| _remote_awr_enabled | FALSE | Enable/disable Remote AWR Mode |
| _remote_http_port | 0 | HTTP port number registered with remote listener |
| _remove_aggr_subquery | TRUE | enables removal of subsumed aggregated subquery |
| _remove_exf_component | TRUE | enable/disable removing of components EXF and RUL during upgrade |
| _rep_base_path | base path for EM reports in database | |
| _replace_virtual_columns | TRUE | replace expressions with virtual columns |
| _report_capture_cycle_time | 60 | Time (in sec) between two cycles of report capture daemon |
| _report_capture_dbtime_percent_cutoff | 50 | 100X Percent of system db time daemon is allowed over 10 cycles |
| _report_capture_recharge_window | 10 | No of report capture cycles after which db time is recharged |
| _report_capture_timeband_length | 1 | Length of time band (in hours) in the reports time bands table |
| _report_request_ageout_minutes | 60 | Time (in min) after which a report request is deleted from queue |
| _request_boundaries | 3 | request boundaries mode |
| _reset_increase_lmd_process | TRUE | set to true to allow reset of _increase_lmd_process changes |
| _reset_increase_lms_process | TRUE | set to true to allow reset of _increase_lms_process changes |
| _resource_includes_unlimited_tablespace | FALSE | Whether RESOURCE role includes UNLIMITED TABLESPACE privilege |
| _resource_manager_always_off | FALSE | disable the resource manager always |
| _resource_manager_plan | resource mgr top plan for internal use | |
| _restore_block0 | on | restore block0 |
| _restore_create_directory | TRUE | automatically create directory during restore |
| _restore_maxopenfiles | 8 | restore assumption for maxopenfiles |
| _restore_spfile | restore spfile to this location | |
| _restrict_become_user | TRUE | become user functionality restricted |
| _restrict_db_link_user_entries | 10000 | Maximum number of entries per db link user |
| _restrict_local_user_dml | TRUE | Restrict Local user's ability to update sensitive tables |
| _restrict_pdb_gv | FALSE | restrict GV$ in a PDB |
| _result_cache_auto_dml_monitoring_duration | 15 | result cache auto dml monitoring duration |
| _result_cache_auto_dml_monitoring_slots | 4 | result cache auto dml monitoring slot |
| _result_cache_auto_dml_threshold | 16 | result cache auto dml threshold |
| _result_cache_auto_dml_trend_threshold | 20 | result cache auto dml trend threshold |
| _result_cache_auto_execution_threshold | 1 | result cache auto execution threshold |
| _result_cache_auto_size_threshold | 100 | result cache auto max size allowed |
| _result_cache_auto_time_distance | 300 | result cache auto time distance |
| _result_cache_auto_time_threshold | 1000 | result cache auto time threshold |
| _result_cache_black_list | cache_id's not allowed to use the result cache | |
| _result_cache_block_size | 4096 | result cache block size |
| _result_cache_copy_block_count | 1 | blocks to copy instead of pinning the result |
| _result_cache_deterministic_plsql | FALSE | result cache deterministic PLSQL functions |
| _result_cache_do_recycle_period | 300 | Timeout value for DOs added through invalidation |
| _result_cache_global | TRUE | Are results available globally across RAC? |
| _result_cache_global_send | TRUE | Is global send conditional in RAC? |
| _result_cache_history_size | 0 | memory used to track PL/SQL function history |
| _result_cache_latch_count | 4 | number of result cache latches |
| _result_cache_latch_free_reads | ADMIN | latch free reads |
| _result_cache_load_rate | 1 | Simulated global load rate (bytes per 1/100 sec) |
| _result_cache_object_black_list | 0 | object numbers not allowed to use the result cache |
| _result_cache_per_pdb | TRUE | Is service result cache per pdb |
| _result_cache_timeout | 1 | maximum time (sec) a session waits for a result |
| _result_cache_use_hash_table | TRUE | whether to use hash table for object tracking |
| _result_cache_white_list | users allowed to use result cache | |
| _resumable_critical_alert | 0 | raise critical alert for resumable failure |
| _reuse_dropped_pdbid_time | 180 | Time in seconds to wait before reusing a dropped PDB ID |
| _reuse_index_loop | 5 | number of blocks being examine for index block reuse |
| _rf_blocks_per_entity | 5 | number of blocks per entity |
| _right_outer_hash_enable | TRUE | Right Outer/Semi/Anti Hash Enabled |
| _rm_atp_cpu_cnt_scale | 1 | Scaling factor for cpu count in ATP |
| _rm_cluster_interconnects | interconnects for RAC use (RM) | |
| _rm_exadata_partition_fc | FALSE | Partition flash cache for Exadata |
| _rm_exadata_pdb_cpu_cnt | FALSE | Use PDB CPU cnt for Exadata smart scan |
| _rm_exadata_pdb_cpu_cnt_mult | 2 | Multiplication factor for PDB cpu count |
| _rm_force_caging | FALSE | |
| _rm_numa_sched_enable | TRUE | Is Resource Manager (RM) related NUMA scheduled policy enabled |
| _rm_numa_simulation_cpus | 0 | number of cpus for each pg for numa simulation in resource manager |
| _rm_numa_simulation_pgs | 0 | number of PGs for numa simulation in resource manager |
| _rm_superlong_threshold | 300000 | DBRM kskrunstatechk superlong threshold |
| _rman_io_priority | 3 | priority at which rman backup i/o's are done |
| _rman_roundrobin_placement | Numa round robin placement for RMAN procs | |
| _rmt_for_table_redef_enabled | TRUE | Use Rowid Mapping Table for table redef |
| _rmv_dynamic_priority | TRUE | enable rmv priority modification |
| _roi_first_open_wait | 120 | duration of ROI first open wait for RWI open |
| _rollback_segment_count | 0 | number of undo segments |
| _rollback_segment_initial | 1 | starting undo segment number |
| _rollback_stopat | 0 | stop at -position to step rollback |
| _rolling_patchlevel | Set Rolling Patch Level for RDBMS instance | |
| _rond_test_mode | 0 | rac one node test mode |
| _root_clone_skip_trigger | TRUE | Skip trigger in Application Root Clone |
| _root_clone_state_from_root | TRUE | Application Root Clone's state comes from Application Root |
| _row_cache_cursors | 20 | number of cached cursors for row cache management |
| _row_cache_dump_cooling_period | 10 | Period to wait (in minutes) before resetting dump count |
| _row_cache_dump_interval | 0 | Interval (in seconds) between each dump |
| _row_cr | TRUE | enable row cr for all sql |
| _row_locking | always | row-locking |
| _row_shipping_explain | FALSE | enable row shipping explain plan support |
| _row_shipping_threshold | 100 | row shipping column selection threshold |
| _rowlen_for_chaining_threshold | 1000 | maximum rowlen above which rows may be chained across blocks |
| _rowsets_cdb_view_enabled | TRUE | rowsets enabled for CDB views |
| _rowsets_enabled | TRUE | enable/disable rowsets |
| _rowsets_max_enc_rows | 64 | maximum number of encoded rows in a rowset |
| _rowsets_max_rows | 256 | maximum number of rows in a rowset |
| _rowsets_target_maxsize | 524288 | target size in bytes for space reserved in the frame for a rowset |
| _rowsets_use_encoding | TRUE | allow/disallow use of encoding with rowsets |
| _rowsource_execution_statistics | FALSE | if TRUE, Oracle will collect rowsource statistics |
| _rowsource_profiling_statistics | TRUE | if TRUE, Oracle will capture active row sources in v$active_session_history |
| _rowsource_statistics_sampfreq | 128 | frequency of rowsource statistic sampling (must be a power of 2) |
| _rowsrc_trace_level | 0 | Row source tree tracing level |
| _rq_shm_max_size | 1024 | maximum size of an RQuery shared memory segement (in KB) |
| _rsrc_cpu_count | 0 | CPU Count for allocating resources. |
| _rta_sync_wait_timeout | 10 | RTA sync wait timeout |
| _rtabnd_update_offload | TRUE | RFS process offload RTA boundary update |
| _rtaddm_trigger_args | comma-separated list of numeric arguments for RT addm trigger | |
| _rtaddm_trigger_enabled | TRUE | To enable or disable Real-Time ADDM automatic trigger |
| _rtc_infeasible_threshold | 25 | Redo Transport Compression infeasible threshold |
| _rule_max_dnfp_cnt | 1024 | Rules max dnf piece count |
| _runtime_index_key_length_check | 0 | allow runtime checking of index key length |
| _runtime_limit_parallel_fptr | 60 | run-time limit for for parallel first-pass recovery |
| _sage_block_checking | FALSE | enable block checking of blocks returned by smartscan |
| _sample_rows_per_block | 4 | number of rows per block used for sampling IO optimization |
| _save_afns_on_subset_pdb_creation | FALSE | Use one reserved AFN for skipped tablespaces on pdb subset creation with lower compat |
| _scalar_type_lob_storage_threshold | 4000 | threshold for VARCHAR2, NVARCHAR2, and RAW storage as BLOB |
| _scatter_gcs_resources | FALSE | if TRUE, gcs resources are scattered uniformly across sub pools |
| _scatter_gcs_shadows | FALSE | if TRUE, gcs shadows are scattered uniformly across sub pools |
| _sched_delay_max_samples | 4 | scheduling delay maximum number of samples |
| _sched_delay_measurement_sleep_us | 1000 | scheduling delay mesurement sleep us |
| _sched_delay_os_tick_granularity_us | 16000 | os tick granularity used by scheduling delay calculations |
| _sched_delay_sample_collection_thresh_ms | 200 | scheduling delay sample collection duration threshold ms |
| _sched_delay_sample_interval_ms | 1000 | scheduling delay sampling interval in ms |
| _scn_wait_interface_max_backoff_time_secs | 600 | max exponential backoff time for scn wait interface in kta |
| _scn_wait_interface_max_timeout_secs | 2147483647 | max timeout for scn wait interface in kta |
| _sdiag_crash | NONE | sql diag crash |
| _sec_enable_test_rpcs | FALSE | Whether to enable the test RPCs |
| _second_spare_pdb_parameter | second spare pdb parameter - integer | |
| _securefile_log_num_latches | 0 | Maximum number of open descriptors for securefile log |
| _securefile_log_shared_pool_size | 0 | Size of securefile log buffer pool from SGA |
| _securefile_shrink_enable_nowaitlck | FALSE | Enable Securefile Shrink NOWAIT row locking |
| _securefile_shrink_hash_table_limit | 100 | Size limit on Securefile Lob Shrink state Hash table |
| _securefile_timers | FALSE | collect kdlu timers and accumulate per layers |
| _securefiles_bgtimeout | 0 | securefiles segment background invocation timeout |
| _securefiles_breakreten_retry | 5 | segment retry before dishonoring retention |
| _securefiles_bulkclnout | TRUE | securefiles segment bulk clnout optization |
| _securefiles_bulkinsert | FALSE | securefiles segment insert only optization |
| _securefiles_concurrency_estimate | 12 | securefiles concurrency estimate |
| _securefiles_dealloc_cfs | 0 | securefiles deallocate directly to CFS |
| _securefiles_fg_retry | 100 | segment retry before foreground waits |
| _securefiles_forceflush | FALSE | securefiles force flush before allocation |
| _securefiles_memory_percentofSGA | 8 | securefiles memory as percent of SGA |
| _securefiles_spcutl | FALSE | securefiles segment utl optimization |
| _seed_root_undo_ratio | 30 | Ratio of PDB$SEED to ROOT undo size, expressed as a percentage |
| _selectivity_for_srf_enabled | FALSE | enable/disable selectivity for storage reduction factor |
| _selfjoin_mv_duplicates | TRUE | control rewrite self-join algorithm |
| _selftune_checkpoint_write_pct | 3 | Percentage of total physical i/os for self-tune ckpt |
| _selftune_checkpointing_lag | 300 | Self-tune checkpointing lag the tail of the redo log |
| _sem_per_semid | the exact number of semaphores per semaphore set to allocate | |
| _send_ast_to_foreground | AUTO | if TRUE, send ast message to foreground |
| _send_close_with_block | TRUE | if TRUE, send close with block even with direct sends |
| _send_requests_to_pi | TRUE | if TRUE, try to send CR requests to PI buffers |
| _sensitive_common_as_local | FALSE | treat common user as local user for sensitive data handling |
| _sensitive_common_users | list of common users to be treated as local | |
| _sequence_scale_extend | FALSE | Force sequence creation with scale extend |
| _sequence_scale_noextend | FALSE | Force sequence creation with scale noextend |
| _serial_direct_read | auto | enable direct read in serial |
| _serial_log_write_worker_io | FALSE | Serialize log write worker I/O |
| _serial_recovery | FALSE | force serial recovery or parallel recovery |
| _serializable | FALSE | serializable |
| _serialize_lgwr_sync_io | FALSE | Serialize LGWR SYNC local and remote io |
| _service_cleanup_timeout | 30 | timeout to peform service cleanup |
| _sess_sign_num_pools | 16 | session signature: number of pools |
| _sess_template_all_overflow | FALSE | session template: put all attributes into overflow |
| _sess_template_cache_buckets | 128 | session template: number of cache buckets |
| _sess_template_enabled | TRUE | session template: enabled |
| _sess_template_max_cache_size | 5 | session template: max cache size (in 1/100% of SGA) |
| _sess_template_new_lists | 16 | session template: number of new lists |
| _sess_template_purge_time_mins | 60 | session template: purge time (in minutes) |
| _sess_template_spares | TRUE | session template: spares |
| _session_allocation_latches | 4 | one latch per group of sessions |
| _session_aware_replay | TRUE | Enable session aware replay |
| _session_cached_instantiations | 60 | Number of pl/sql instantiations to cache in a session. |
| _session_context_size | 10000 | session app context size |
| _session_idle_bit_latches | 0 | one latch per session or a latch per group of sessions |
| _session_limit_percent_cap | 25 | session limit percent cap |
| _session_max_pred_increase | 20000 | session SO max predicted increase |
| _session_modp_list | 2 | send session's modified parameter list to client |
| _session_page_extent | 2048 | Session Page Extent Size |
| _session_percent_rampup_end | 504 | session SO percent rampup end |
| _session_percent_rampup_start | 504 | session SO percent rampup start |
| _session_prediction_failover_buffer | 1 | session prediction failover buffer |
| _session_save_prediction | FALSE | save session prediction for next instance startup |
| _session_so_max_inc | 20000 | session SO max inc |
| _session_wait_history | 10 | enable session wait history collection |
| _set_container_service | DEFAULT | set container service |
| _seventeenth_spare_parameter | seventeenth spare parameter - integer | |
| _seventeenth_spare_pdb_parameter | seventeenth spare pdb parameter - integer | |
| _seventh_spare_pdb_parameter | seventh spare pdb parameter - integer | |
| _seventieth_spare_parameter | seventieth spare parameter - integer | |
| _seventieth_spare_pdb_parameter | seventieth spare pdb parameter - boolean | |
| _seventy-eighth_spare_parameter | seventy-eighth spare parameter - integer | |
| _seventy-fifth_spare_parameter | seventy-fifth spare parameter - integer | |
| _seventy-first_spare_parameter | seventy-first spare parameter - integer | |
| _seventy-fourth_spare_parameter | seventy-fourth spare parameter - integer | |
| _seventy-ninth_spare_parameter | seventy-ninth spare parameter - integer | |
| _seventy-second_spare_parameter | seventy-second spare parameter - integer | |
| _seventy-seventh_spare_parameter | seventy-seventh spare parameter - integer | |
| _seventy-sixth_spare_parameter | seventy-sixth spare parameter - integer | |
| _seventy-third_spare_parameter | seventy-third spare parameter - integer | |
| _sf_default_enabled | TRUE | enable 12g securefile default |
| _sga_alloc_slaves_term_timeout_secs | 120 | Termination timeout in secs for SA** slaves |
| _sga_clear_dump | FALSE | Allow dumping encrypted blocks in clear for debugging |
| _sga_early_trace | 0 | sga early trace event |
| _sga_grow_batch_size | 2147483648 | Dynamic SGA grow batch size |
| _sga_heap_chunk_alignment | FALSE | force SGA heap chunk alignment |
| _sga_heap_chunk_alignment_disabled | FALSE | force SGA heap chunks not to be aligned |
| _sga_shrink_allow | FALSE | Allow SGA shrink operation |
| _shadow_lost_write_found | 118 | Specify shadow lost write error handling |
| _shadow_lost_write_tracing | 0 | Enable new lost write tracing |
| _shard_ddl_policy | ASYNC | DDL execution mode for shards |
| _shard_sesscache_cnt | 0 | enable session caching for shard SQL |
| _shard_sql_use_chunk_ids | 0 | Shard SQL use chunk ids |
| _shardgroup_name | gsm shardgroup name | |
| _shardspace_name | gsm shardspace name | |
| _share_drcp_proxy_sessions | TRUE | Enable Disable Proxy Session Sharing DRCP |
| _shared_io_pool_buf_size | 1048576 | Shared IO pool buffer size |
| _shared_io_pool_debug_trc | 0 | trace kcbi debug info to tracefile |
| _shared_io_pool_size | 117440512 | Size of shared IO pool |
| _shared_io_set_value | FALSE | shared io pool size set internal value - overwrite zero user size |
| _shared_iop_max_size | 134217728 | maximum shared io pool size |
| _shared_pool_max_size | 0 | shared pool maximum size when auto SGA enabled |
| _shared_pool_max_sz | 0 | |
| _shared_pool_minsize_on | FALSE | shared pool minimum size when auto SGA enabled |
| _shared_pool_reserved_min_alloc | 4400 | minimum allocation size in bytes for reserved area of shared pool |
| _shared_pool_reserved_pct | 5 | percentage memory of the shared pool allocated for the reserved area |
| _shared_server_load_balance | 0 | shared server load balance |
| _shared_server_num_queues | 2 | number of shared server common queues |
| _shared_server_sizing_coeff | 1000 | Shared server sizing coefficient |
| _shared_servers_performance | 0 | Tradeoff shared servers resource usage for performance |
| _shd_atomic_move | 0 | Use atomic move |
| _shd_reptype | 0 | replication type of the databse and pool |
| _shmprotect | 0 | allow mprotect use for shared memory |
| _short_stack_timeout_ms | 30000 | short stack timeout in ms |
| _show_login_pdb_sessions | FALSE | return logon pdb container id from v$session |
| _shrd_que_tm_processes | 1 | number of sharded queue Time Managers to start |
| _shrd_que_tm_statistics_duration | 0 | Shaded queue statistics collection window duration |
| _shrunk_aggs_disable_threshold | 60 | percentage of exceptions at which to switch to full length aggs |
| _shrunk_aggs_enabled | TRUE | enable use of variable sized buffers for non-distinct aggregates |
| _shutdown_completion_timeout_mins | 60 | minutes for shutdown operation to wait for sessions to complete |
| _shutdown_sync_enable | TRUE | if TRUE, shutdown sync is issued before shutdown normal |
| _side_channel_batch_size | 240 | number of messages to batch in a side channel message (DFS) |
| _side_channel_batch_timeout | 6 | timeout before shipping out the batched side channelmessages in seconds |
| _side_channel_batch_timeout_ms | 500 | timeout before shipping out the batched side channelmessages in milliseconds |
| _simple_view_merging | TRUE | control simple view merging performed by the optimizer |
| _simulate_dax_storage | DISABLE | Simulate log on DAX storage |
| _simulate_disk_sectorsize | 0 | Enables skgfr to report simulated physical disk sector size |
| _simulate_io_wait | 0 | Simulate I/O wait to test segment advisor |
| _simulate_logical_sectorsize | 0 | Enables skgfr to report simulated logical disk sector size |
| _simulate_mem_transfer | FALSE | simulate auto memory sga/pga transfers |
| _simulated_log_write_usecs | 0 | Simulated latency of log writes (usecs) |
| _simulator_bucket_mindelta | 8192 | LRU bucket minimum delta |
| _simulator_internal_bound | 10 | simulator internal bound percent |
| _simulator_lru_rebalance_sizthr | 5 | LRU list rebalance threshold (size) |
| _simulator_lru_rebalance_thresh | 10240 | LRU list rebalance threshold (count) |
| _simulator_lru_scan_count | 8 | LRU scan count |
| _simulator_pin_inval_maxcnt | 16 | maximum count of invalid chunks on pin list |
| _simulator_reserved_heap_count | 4096 | simulator reserved heap count |
| _simulator_reserved_obj_count | 1024 | simulator reserved object count |
| _simulator_sampling_factor | 2 | sampling factor for the simulator |
| _simulator_upper_bound_multiple | 2 | upper bound multiple of pool size |
| _single_process | FALSE | run without detached processes |
| _singleton_service_goodness_disabled | TRUE | singleton srvc goodness |
| _siop_flashback_scandepth | 20 | Shared IO pool flashback io completion scan depth |
| _siop_init_mem_gradually | TRUE | will cause shared io pool in small chunks |
| _siop_perc_of_bc_x100 | 625 | percentange * 100 of cache to transfer to shared io pool |
| _sixteenth_spare_parameter | sixteenth spare parameter - integer | |
| _sixteenth_spare_pdb_parameter | sixteenth spare pdb parameter - integer | |
| _sixth_spare_pdb_parameter | sixth spare pdb parameter - integer | |
| _sixtieth_spare_parameter | sixtieth spare parameter - integer | |
| _sixtieth_spare_pdb_parameter | sixtieth spare pdb parameter - boolean | |
| _sixty-eighth_spare_parameter | sixty-eighth spare parameter - integer | |
| _sixty-eighth_spare_pdb_parameter | sixty-eighth spare pdb parameter - boolean | |
| _sixty-fifth_spare_parameter | sixty-fifth spare parameter - integer | |
| _sixty-fifth_spare_pdb_parameter | sixty-fifth spare pdb parameter - boolean | |
| _sixty-first_spare_parameter | sixty-first spare parameter - integer | |
| _sixty-first_spare_pdb_parameter | sixty-first spare pdb parameter - boolean | |
| _sixty-fourth_spare_parameter | sixty-fourth spare parameter - integer | |
| _sixty-fourth_spare_pdb_parameter | sixty-fourth spare pdb parameter - boolean | |
| _sixty-ninth_spare_parameter | sixty-ninth spare parameter - integer | |
| _sixty-ninth_spare_pdb_parameter | sixty-ninth spare pdb parameter - boolean | |
| _sixty-second_spare_parameter | sixty-second spare parameter - integer | |
| _sixty-second_spare_pdb_parameter | sixty-second spare pdb parameter - boolean | |
| _sixty-seventh_spare_parameter | sixty-seventh spare parameter - integer | |
| _sixty-seventh_spare_pdb_parameter | sixty-seventh spare pdb parameter - boolean | |
| _sixty-sixth_spare_parameter | sixty-sixth spare parameter - integer | |
| _sixty-sixth_spare_pdb_parameter | sixty-sixth spare pdb parameter - boolean | |
| _sixty-third_spare_parameter | sixty-third spare parameter - integer | |
| _sixty-third_spare_pdb_parameter | sixty-third spare pdb parameter - boolean | |
| _size_of_log_table | 100 | modifying this hidden parameter, will modify the sizeof the v$gcr_log table |
| _skgxp_ant_options | SKGXP ANT options (oss) | |
| _skgxp_ctx_flags1 | 0 | IPC debug options flags (oss) |
| _skgxp_ctx_flags1mask | 0 | IPC debug options flags mask (oss) |
| _skgxp_dynamic_protocol | 0 | IPC protocol override (!0/-1=*,2=UDP,3=RDS,0x1000=ipc_X) |
| _skgxp_gen_ant_off_rpc_timeout_in_sec | 30 | VRPC request timeout when ANT disabled |
| _skgxp_gen_ant_ping_misscount | 3 | ANT protocol ping miss count |
| _skgxp_gen_rpc_no_path_check_in_sec | 5 | ANT ping protocol miss count |
| _skgxp_gen_rpc_timeout_in_sec | 300 | VRPC request timeout when ANT enabled |
| _skgxp_inets | limit SKGXP networks (oss) | |
| _skgxp_min_rpc_rcv_zcpy_len | 0 | IPC threshold for rpc rcv zcpy operation (default = 0 - disabled) |
| _skgxp_min_zcpy_len | 0 | IPC threshold for zcpy operation (default = 0 - disabled) |
| _skgxp_reaping | 1000 | tune skgxp OSD reaping limit |
| _skgxp_rgn_ports | 0 | region socket limits (0xFFFFNNXX): F=flags, N=min, X=max |
| _skgxp_spare_param1 | ipc oss spare parameter 1 | |
| _skgxp_spare_param2 | ipc oss spare parameter 2 | |
| _skgxp_spare_param3 | ipc oss spare parameter 3 | |
| _skgxp_spare_param4 | ipc oss spare parameter 4 | |
| _skgxp_spare_param5 | ipc oss spare parameter 5 | |
| _skgxp_udp_ach_reaping_time | 120 | time in minutes before idle ach's are reaped |
| _skgxp_udp_ack_delay | 0 | Enables delayed acks |
| _skgxp_udp_enable_dynamic_credit_mgmt | 0 | Enables dynamic credit management |
| _skgxp_udp_hiwat_warn | 1000 | ach hiwat mark warning interval |
| _skgxp_udp_interface_detection_time_secs | 60 | time in seconds between interface detection checks |
| _skgxp_udp_keep_alive_ping_timer_secs | 300 | connection idle time in seconds before keep alive is initiated. min: 30 sec max: 1800 sec default: 300 sec |
| _skgxp_udp_lmp_mtusize | 0 | MTU size for UDP LMP testing |
| _skgxp_udp_lmp_on | FALSE | enable UDP long message protection |
| _skgxp_udp_timed_wait_buffering | 1024 | diagnostic log buffering space (in bytes) for timed wait (0 means unbufferd |
| _skgxp_udp_timed_wait_seconds | 5 | time in seconds before timed wait is invoked |
| _skgxp_udp_use_tcb | TRUE | disable use of high speek timer |
| _skgxp_zcpy_flags | 0 | IPC zcpy options flags |
| _skgxpg_last_parameter | 27 | last defined skgxpg parameter - oss |
| _skip_acfs_checks | FALSE | Override checking if on an ACFS file system |
| _skip_app_object_check | FALSE | Skip application object checks |
| _skip_app_unconverted_check | FALSE | Skip application unconverted check |
| _skip_assume_msg | TRUE | if TRUE, skip assume message for consigns at the master |
| _skip_oradism_check | FALSE | Switch on all features for the purpose of testing |
| _skip_pdb_recovery_if_keystore_not_open | FALSE | Skip PDB recovery when the PDB's keystore is not open |
| _skip_pset_col_chk | 0 | skip validation of partition set keys in DML |
| _skip_sequence_cache_close_immediate | FALSE | Skip sequence cache flush on pdb shutdown immediate |
| _skip_trstamp_check | TRUE | Skip terminal recovery stamp check |
| _skip_unconverted_change_vector | FALSE | Skip apply of a CV that has no endian conversion function |
| _slave_mapping_enabled | TRUE | enable slave mapping when TRUE |
| _slave_mapping_group_size | 0 | force the number of slave group in a slave mapper |
| _slave_mapping_skew_ratio | 2 | maximum skew before slave mapping is disabled |
| _slow_kill_on_pdb_close_immediate | FALSE | Kill sessions periodically on pdb close immediate |
| _small_table_threshold | 2623 | lower threshold level of table size for direct reads |
| _smm_advice_enabled | TRUE | if TRUE, enable v$pga_advice |
| _smm_advice_log_size | 0 | overwrites default size of the PGA advice workarea history log |
| _smm_auto_cost_enabled | TRUE | if TRUE, use the AUTO size policy cost functions |
| _smm_auto_max_io_size | 248 | Maximum IO size (in KB) used by sort/hash-join in auto mode |
| _smm_auto_min_io_size | 56 | Minimum IO size (in KB) used by sort/hash-join in auto mode |
| _smm_bound | 0 | overwrites memory manager automatically computed bound |
| _smm_control | 0 | provides controls on the memory manager |
| _smm_freeable_retain | 5120 | value in KB of the instance freeable PGA memory to retain |
| _smm_isort_cap | 102400 | maximum work area for insertion sort(v1) |
| _smm_max_size | 102400 | maximum work area size in auto mode (serial) |
| _smm_max_size_static | 102400 | static maximum work area size in auto mode (serial) |
| _smm_min_size | 781 | minimum work area size in auto mode |
| _smm_px_max_size | 390656 | maximum work area size in auto mode (global) |
| _smm_px_max_size_static | 390656 | static maximum work area size in auto mode (global) |
| _smm_retain_size | 0 | work area retain size in SGA for shared server sessions (0 for AUTO) |
| _smm_trace | 0 | Turn on/off tracing for SQL memory manager |
| _smon_internal_errlimit | 100 | limit of SMON internal errors |
| _smon_ofd_sleep_interval | 300 | smon sleep internval for undo ofd test |
| _smon_undo_seg_rescan_limit | 10 | limit of SMON continous undo segments re-scan |
| _smu_debug_mode | 0 | |
| _smu_error_simulation_site | 0 | site ID of error simulation in KTU code |
| _smu_error_simulation_type | 0 | error type for error simulation in KTU code |
| _smu_timeouts | comma-separated AND double-quoted list of AUM timeouts: mql, tur, sess_exprn, qry_exprn, slot_intvl | |
| _snapshot_recovery_enabled | TRUE | enable/disable snapshot recovery |
| _so_percent_lower_bound_final | 80 | SO percent lower bound final |
| _so_percent_lower_bound_strt | 60 | SO percent lower bound start |
| _so_percent_upper_bound_final | 90 | SO percent upper bound final |
| _so_percent_upper_bound_strt | 70 | SO percent upper bound start |
| _sort_elimination_cost_ratio | 0 | cost ratio for sort eimination under first_rows mode |
| _sort_multiblock_read_count | 2 | multi-block read count for sort |
| _sort_spill_threshold | 0 | force sort to spill to disk each time this many rows are received |
| _sort_sync_min_spill_threshold | 90 | controls the mininum spill size for synchronized spill (in percent) |
| _sort_sync_min_spillsize | 262144 | controls the size of mininum run size for synchronized spill (in kb) |
| _space_align_size | 1048576 | space align size |
| _spacebg_sync_segblocks | TRUE | to enable/disable segmon driver |
| _spacereuse_track_memlimit | 10 | Percentage of shared pool for use by spacereuse tracking |
| _spadr | YES | _SPADR |
| _spare_test_parameter | 0 | Spare test parameter |
| _sparse_backing_file | AVM | specifies sparse backing file |
| _spawn_diag_opts | 0 | thread spawn diagnostic options |
| _spawn_diag_thresh_secs | 30 | thread spawn diagnostic minimal threshold in seconds |
| _spec_replace_locks_body | TRUE | Lock body when replacing a package specification |
| _spfdc | OFF | SPFDC |
| _spfei | SPFEI | |
| _spfoc | OFF | SPFOC |
| _spin_count | 2000 | Amount to spin waiting for a latch |
| _split_file_copy | TRUE | Enable block-level parallelism for file copy in Create PDB |
| _spr_max_rules | 10000 | maximum number of rules in sql spreadsheet |
| _spr_push_pred_refspr | TRUE | push predicates through reference spreadsheet |
| _spr_use_AW_AS | TRUE | enable AW for hash table in spreadsheet |
| _sql_alias_scope | TRUE | Use only SQL name resolution for a column whose alias matches that of some table |
| _sql_analyze_enable_auto_txn | FALSE | SQL Analyze Autonomous Transaction control parameter |
| _sql_analyze_parse_model | 2 | SQL Analyze Parse Model control parameter |
| _sql_compatibility | 0 | sql compatability bit vector |
| _sql_connect_capability_override | 0 | SQL Connect Capability Table Override |
| _sql_connect_capability_table | SQL Connect Capability Table (testing only) | |
| _sql_diag_repo_origin | all | duarations where sql diag repository are retained |
| _sql_diag_repo_retain | retain sql diag repository to cursor or not | |
| _sql_hash_debug | 0 | Hash value of the SQL statement to debug |
| _sql_hvshare_debug | 1 | control hash value sharing debug level |
| _sql_hvshare_threshold | 0 | threshold to control hash value sharing across operators |
| _sql_model_unfold_forloops | RUN_TIME | specifies compile-time unfolding of sql model forloops |
| _sql_ncg_mode | OFF | Optimization mode for SQL NCG |
| _sql_plan_directive_mgmt_control | 67 | controls internal SQL Plan Directive management activities |
| _sql_plan_management_control | 0 | controls various internal SQL Plan Management algorithms |
| _sql_show_expreval | FALSE | show expression evalution as shared hash producer in plan |
| _sqlexec_aggregation_settings | 0 | runtime settings for aggregation |
| _sqlexec_bitmap_options | 0 | settings for bitmap count distinct optimizations |
| _sqlexec_bitmap_sparse_size | 100 | maximum number of sparse bitmap values |
| _sqlexec_cache_aware_hash_aggr_enabled | TRUE | enable/disable cache aware hash aggregation |
| _sqlexec_cache_aware_hash_join_enabled | TRUE | enable/disable cache aware hash join |
| _sqlexec_disable_hash_based_distagg_tiv | FALSE | disable hash based distinct aggregation in TIV for gby queries |
| _sqlexec_distagg_optimization_settings | 0 | settings for distinct aggregation optimizations |
| _sqlexec_encoding_aware_hj_enabled | TRUE | enable/disable encoding aware hash join |
| _sqlexec_encoding_aware_hj_min_compression_ratio | 8 | minimum compression ratio to leverage encoding for HJ probe |
| _sqlexec_hash_aggr_small_mem_blocks | 2 | hash aggregation small initial memory footprint number of blocks |
| _sqlexec_hash_based_distagg_enabled | TRUE | enable hash based distinct aggregation for gby queries |
| _sqlexec_hash_based_distagg_ser_civ_enabled | TRUE | enable hash based distinct aggregation in serial/CIV queries |
| _sqlexec_hash_based_distagg_ssf_enabled | TRUE | enable hash based distinct aggregation for single set gby queries |
| _sqlexec_hash_based_set_operation_enabled | TRUE | enable/disable hash based set operation |
| _sqlexec_hash_join_uses_xmem | FALSE | enable/disable xmem PGA for hash join areas |
| _sqlexec_hash_rollup_enabled | TRUE | enable hash rollup |
| _sqlexec_join_group_aware_hj_enabled | TRUE | enable/disable join group aware hash join |
| _sqlexec_join_group_aware_hj_unencoded_rowsets_tolerated | 50 | minimum number of unencoded rowsets processed before adaptation |
| _sqlexec_pwiseops_with_binds_enabled | TRUE | enable partition wise execution in the presence of bind variables in inlist equality operator in where clause |
| _sqlexec_pwiseops_with_sqlfuncs_enabled | TRUE | enables partition wise operations even in the presence of functions over table partition keys |
| _sqlexec_reorder_wif_enabled | TRUE | enable re-ordering of window functions |
| _sqlexec_sort_uses_xmem | TRUE | enable/disable xmem PGA for sort areas |
| _sqlexec_use_delayed_unpacking | TRUE | enable/disable the usage of delayed unpacking |
| _sqlexec_use_kgghash3 | TRUE | use CRC-based hash function |
| _sqlexec_use_rwo_aware_expr_analysis | TRUE | enable/disable the usage of row vector aware expression analysis |
| _sqlmon_binds_xml_format | default | format of column binds_xml in [G]V$SQL_MONITOR |
| _sqlmon_max_plan | 80 | Maximum number of plans entry that can be monitored. Defaults to 20 per CPU |
| _sqlmon_max_planlines | 1000 | Number of plan lines beyond which a plan cannot be monitored |
| _sqlmon_recycle_time | 5 | Minimum time (in s) to wait before a plan entry can be recycled |
| _sqlmon_threshold | 5 | CPU/IO time threshold before a statement is monitored. 0 is disabled |
| _sqlset_hash_max_size | 100000 | Max size of hash table used when loading into a SQL set |
| _sqltune_category_parsed | DEFAULT | Parsed category qualifier for applying hintsets |
| _srvntfn_job_deq_timeout | 60 | srvntfn job deq timeout |
| _srvntfn_jobsubmit_interval | 3 | srvntfn job submit interval |
| _srvntfn_max_concurrent_jobs | 20 | srvntfn max concurrent jobs |
| _srvntfn_q_msgcount | 50 | srvntfn q msg count for job exit |
| _srvntfn_q_msgcount_inc | 100 | srvntfn q msg count increase for job submit |
| _sscr_dir | Session State Capture and Restore DIRectory object | |
| _sscr_osdir | Session State Capture and Restore OS DIRectory | |
| _sta_control | 0 | SQL Tuning Advisory control parameter |
| _stack_guard_level | 0 | stack guard level |
| _standby_auto_flashback | TRUE | Standby automatic flashback when primary flashed back |
| _standby_causal_heartbeat_timeout | 2 | readable standby causal heartbeat timeout |
| _standby_flush_mode | SLFLUSH | standby flush mode |
| _standby_implicit_rcv_timeout | 3 | minutes to wait for redo during standby implicit recovery |
| _standby_newkey_keystore_location | Location of keystore on standby having new key | |
| _standby_switchover_timeout | 120 | Number of secords for standby switchover enqueue timeout |
| _stat_aggs_one_pass_algorithm | FALSE | enable one pass algorithm for variance-related functions |
| _static_backgrounds | static backgrounds | |
| _statistics_based_srf_enabled | TRUE | enable/disable the use of statistics for storage reduction factor |
| _stats_encryption_enabled | FALSE | Enable statistics encryption on sensitive data |
| _step_down_limit_in_pct | 20 | step down limit in percentage |
| _streams_pool_max_size | 0 | streams pool maximum size when auto SGA enabled |
| _strict_dml_data_link | FALSE | Enable strict semantics for DML into [Extended] Data Link |
| _strict_redaction_semantics | TRUE | Strict Data Redaction semantics |
| _strict_utl_http_smtp | TRUE | Enforce strict URL checks on UTL_HTTP and UTL_SMTP Packages |
| _subquery_pruning_cost_factor | 20 | subquery pruning cost factor |
| _subquery_pruning_enabled | TRUE | enable the use of subquery predicates to perform pruning |
| _subquery_pruning_flags | 0 | subquery pruning flags |
| _subquery_pruning_mv_enabled | FALSE | enable the use of subquery predicates with MVs to perform pruning |
| _subquery_pruning_reduction | 50 | subquery pruning reduction factor |
| _super_shared_conversion_threshold | 320 | conversion threshold limit for supershared mode |
| _super_shared_enable | FALSE | enable super shared mode for latches |
| _super_shared_max_exclusive_conversions | 4 | Maximum consecutive exclusive conversions to convert a super shared latch |
| _suppress_identifiers_on_dupkey | FALSE | supress owner index name err msg |
| _suppress_migration_errors | TRUE | Suppress migration errors during Application Sync |
| _suspend_4031_timeout | 14400 | sga timeout in seconds for 4031 |
| _suspend_4036_timeout | 14400 | pga timeout in seconds for 4036 |
| _suspended_session_timeout | 300 | Timeout to kill suspended sess aft switchover |
| _swat_ver_mv_knob | 0 | Knob to control MV/REWRITE behavior |
| _switch_current_scan_scn | TRUE | switch current uses scan scn |
| _switchover_through_cascade | TRUE | Enable switchover through farsync |
| _switchover_timeout | 0 | Switchover timeout in minutes |
| _switchover_to_standby_option | OPEN_ALL_IGNORE_SESSIONS | option for graceful switchover to standby |
| _switchover_to_standby_switch_log | FALSE | Switchover to standby switches log for open redo threads |
| _swrf_metric_frequent_mode | FALSE | Enable/disable SWRF Metric Frequent Mode Collection |
| _swrf_mmon_dbfus | TRUE | Enable/disable SWRF MMON DB Feature Usage |
| _swrf_mmon_flush | TRUE | Enable/disable SWRF MMON FLushing |
| _swrf_mmon_metrics | TRUE | Enable/disable SWRF MMON Metrics Collection |
| _swrf_on_disk_enabled | TRUE | Parameter to enable/disable SWRF |
| _swrf_test_action | 0 | test action parameter for SWRF |
| _swrf_test_dbfus | FALSE | Enable/disable DB Feature Usage Testing |
| _symbol_no_translation | FALSE | disable symbol tranlations in call stacks |
| _sync_app_pdb_first_open | FALSE | sync application PDB automatically on first open |
| _sync_error_handler | error handler function for Application Sync | |
| _sync_primary_wait_time | 5 | wait time for alter session sync with primary |
| _synchronous_rewrap_rac_ts_keys | FALSE | if TRUE, synchronously rewrap TS keys in all nodes in MK rekey |
| _synonym_repoint_tracing | FALSE | whether to trace metadata comparisons for synonym repointing |
| _sys_logon_delay | 1 | The failed logon delay for the database instance |
| _sysaux_test_param | 1 | test parameter for SYSAUX |
| _sysdate_at_dbtimezone | FALSE | return SYSDATE at database timezone |
| _system_api_interception_debug | FALSE | enable debug tracing for system api interception |
| _system_index_caching | 0 | optimizer percent system index caching |
| _system_memory_simulate | FALSE | system memory simulation mode, TRUE for hugetlbfs simulation |
| _system_partition_with_default | FALSE | allow default partition for system partitioned tables |
| _system_state_cputime_limit | 4294967294 | cputime limit for system state dump |
| _system_state_runtime_limit | 4294967294 | runtime limit for system state dump |
| _system_trig_enabled | TRUE | are system triggers enabled |
| _table_lookup_prefetch_size | 40 | table lookup prefetch vector size |
| _table_lookup_prefetch_thresh | 2 | table lookup prefetch threshold |
| _table_scan_cost_plus_one | TRUE | bump estimated full table scan and index ffs cost by one |
| _tablespaces_per_transaction | 10 | estimated number of tablespaces manipulated by each transaction |
| _target_log_write_size | 0 | Do log write if this many redo blocks in buffer (auto=0) |
| _target_log_write_size_percent_for_poke | 100 | Ask LGWR to write if strand has this % of target write size blocks |
| _target_log_write_size_spinwait | 0 | How long LGWR spins to waits for target write size blocks |
| _target_log_write_size_timeout | 0 | How long LGWR will wait for redo to accumulate (msecs) |
| _target_rba_max_lag_percentage | 81 | target rba max log lag percentage |
| _tcpinfo_statistics_save_atexit | FALSE | TCP Info Statistics Save At Exit |
| _tdb_debug_mode | 16 | set debug mode for testing transportable database |
| _temp_tran_block_threshold | 100 | number of blocks for a dimension before we temp transform |
| _temp_tran_cache | TRUE | determines if temp table is created with cache option |
| _temp_undo_disable_adg | FALSE | is temp undo disabled on ADG |
| _temp_undo_disable_refresh_clone | TRUE | is temp undo disabled on refreshable clone PDB |
| _temp_undo_optimal_extents | 0 | optimal number of extents for temp undo |
| _tenth_spare_parameter | tenth spare parameter - integer | |
| _tenth_spare_pdb_parameter | tenth spare pdb parameter - integer | |
| _test_flashback_shrink | 0 | test flashback datafile shrink feature |
| _test_hm_extent_map | FALSE | heatmap related - to be used by oracle dev only |
| _test_ksusigskip | 5 | test the function ksusigskip |
| _test_offload_pdb_sga_init | FALSE | Test offload of PDB SGA creation |
| _test_param_1 | 25 | test parmeter 1 - integer |
| _test_param_10 | test parameter 10 - string param | |
| _test_param_10_bi | 10 | test parameter 10 - bigint param |
| _test_param_10_i | test parameter 10 - int param | |
| _test_param_11_base | 3 | test parameter 11 base |
| _test_param_11_dep | 0_STARTUP, 1_STARTUP, 2_STARTUP | test parameter 11 dependent |
| _test_param_12 | 0 | test parameter 12 - int param |
| _test_param_13 | FALSE | test parmeter 13 - boolean |
| _test_param_14 | test parmeter 14 - string list | |
| _test_param_15 | 50 | test parmeter 15 - integer |
| _test_param_2 | test parameter 2 - string | |
| _test_param_3 | test parameter 3 - string | |
| _test_param_4 | test parameter 4 - string list | |
| _test_param_4_1 | test parameter 4_1 - nonsys mod. string list | |
| _test_param_5 | 25 | test parmeter 5 - deprecated integer |
| _test_param_6 | 0 | test parmeter 6 - size (ub8) |
| _test_param_7 | 100, 1100, 2100, 3100, 4100 | test parameter 7 - big integer list |
| _test_param_8 | 20 | test parameter 8 - cdb tests |
| _test_param_9 | test parameter 9 - umbrella param | |
| _test_param_9_1 | 0 | test parameter 9_1 - cascade param1 |
| _test_param_9_2 | 0_startup | test parameter 9_2 - cascade param2 |
| _test_param_9_3 | 1_startup, 2_startup, 3_startup | test parameter 9_3 - cascade param3 |
| _test_param_pdb_spare | test parameter pdb spare | |
| _test_param_spare | test parameter spare | |
| _test_xmem_alloc_size | 0 | unit test xmem alloc size |
| _third_spare_parameter | third spare parameter - integer | |
| _third_spare_pdb_parameter | third spare pdb parameter - integer | |
| _thirteenth_spare_pdb_parameter | thirteenth spare pdb parameter - integer | |
| _thirtieth_spare_parameter | thirtieth spare parameter - integer | |
| _thirtieth_spare_pdb_parameter | thirtieth spare pdb parameter - string | |
| _thirty-eighth_spare_parameter | thirty-eighth spare parameter - integer | |
| _thirty-eighth_spare_pdb_parameter | thirty-eighth spare pdb parameter - string | |
| _thirty-fifth_spare_parameter | thirty-fifth spare parameter - integer | |
| _thirty-fifth_spare_pdb_parameter | thirty-fifth spare pdb parameter - string | |
| _thirty-first_spare_parameter | thirty-first spare parameter - integer | |
| _thirty-first_spare_pdb_parameter | thirty-first spare pdb parameter - string | |
| _thirty-fourth_spare_parameter | thirty-fourth spare parameter - integer | |
| _thirty-fourth_spare_pdb_parameter | thirty-fourth spare pdb parameter - string | |
| _thirty-ninth_spare_parameter | thirty-ninth spare parameter - integer | |
| _thirty-ninth_spare_pdb_parameter | thirty-ninth spare pdb parameter - string | |
| _thirty-second_spare_parameter | thirty-second spare parameter - integer | |
| _thirty-second_spare_pdb_parameter | thirty-second spare pdb parameter - string | |
| _thirty-seventh_spare_parameter | thirty-seventh spare parameter - integer | |
| _thirty-seventh_spare_pdb_parameter | thirty-seventh spare pdb parameter - string | |
| _thirty-sixth_spare_parameter | thirty-sixth spare parameter - integer | |
| _thirty-sixth_spare_pdb_parameter | thirty-sixth spare pdb parameter - string | |
| _thirty-third_spare_parameter | thirty-third spare parameter - integer | |
| _thirty-third_spare_pdb_parameter | thirty-third spare pdb parameter - string | |
| _thread_state_change_timeout_pnp | 1800 | Thread state change timeout for PnP instance (in sec) |
| _threshold_alerts_enable | 1 | if 1, issue threshold-based alerts |
| _time_based_rcv_ckpt_target | 180 | time-based incremental recovery checkpoint target in sec |
| _time_based_rcv_hdr_update_interval | 180 | time-based incremental recovery file header update interval in sec |
| _timemodel_collection | TRUE | enable timemodel collection |
| _timeout_actions_enabled | TRUE | enables or disables KSU timeout actions |
| _timer_precision | 10 | VKTM timer precision in milli-sec |
| _tkh_in_fsc_per_ts | 5 | Max tkh records stored in FSC per tablespace |
| _total_large_extent_memory | 0 | Total memory for allocating large extents |
| _touch_sga_pages_during_allocation | FALSE | touch SGA pages during allocation |
| _tq_dump_period | 0 | time period for duping of TQ statistics (s) |
| _trace_buffer_wait_timeouts | 0 | trace buffer busy wait timeouts |
| _trace_buffers | ALL:256 | trace buffer sizes per process |
| _trace_dump_all_procs | FALSE | if TRUE on error buckets of all processes will be dumped to the current trace file |
| _trace_dump_client_buckets | TRUE | if TRUE dump client (ie. non-kst) buckets |
| _trace_dump_cur_proc_only | FALSE | if TRUE on error just dump our process bucket |
| _trace_dump_static_only | FALSE | if TRUE filter trace dumps to always loaded dlls |
| _trace_events | trace events enabled at startup | |
| _trace_files_public | FALSE | Create publicly accessible trace files |
| _trace_kqlidp | FALSE | trace kqlidp0 operation |
| _trace_ktds | FALSE | Trace block reuse |
| _trace_ktfs | FALSE | Trace ILM Stats Tracking |
| _trace_ktfs_mem | FALSE | Debug memleak |
| _trace_navigation_scope | global | enabling trace navigation linking |
| _trace_pin_time | FALSE | trace how long a current pin is held |
| _trace_pool_size | trace pool size in bytes | |
| _trace_processes | ALL | enable KST tracing in process |
| _trace_suppress | suppresses matching trace for a given substring(prefix) | |
| _trace_suppress_disable | FALSE | Disable trace suppress feature |
| _trace_temp | FALSE | Trace Tempspace Management |
| _trace_virtual_columns | FALSE | trace virtual columns exprs |
| _track_metrics_memory | TRUE | Enable/disable Metrics Memory Tracking |
| _track_space_reuse | FALSE | SpaceReuse Tracking |
| _track_space_reuse_rac | FALSE | SpaceReuse Tracking Enable in RAC |
| _transaction_auditing | TRUE | transaction auditing records generated in the redo log |
| _transaction_recovery_servers | 0 | max number of parallel recovery slaves that may be used |
| _transient_logical_clear_hold_mrp_bit | FALSE | clear KCCDI2HMRP flag during standby recovery |
| _truncate_optimization_enabled | TRUE | do truncate optimization if set to TRUE |
| _tsenc_obfuscate_key | NONE | Encryption key obfuscation in memory |
| _tsenc_tracing | 0 | Enable TS encryption tracing |
| _tsm_connect_string | TSM test connect string | |
| _tsm_disable_auto_cleanup | 1 | Disable TSM auto cleanup actions |
| _tstz_localtime_bypass | FALSE | Should TTC not convert to LocalTime to preserve Timestamp with Timezone values |
| _ttc_annotations_level | 0 | enable ttc annotations |
| _tts_allow_charset_mismatch | FALSE | allow plugging in a tablespace with an incompatible character set |
| _twelfth_spare_pdb_parameter | twelfth spare pdb parameter - integer | |
| _twentieth_spare_parameter | twentieth spare parameter - integer | |
| _twentieth_spare_pdb_parameter | twentieth spare pdb parameter - integer | |
| _twenty-eighth_spare_parameter | twenty-eighth spare parameter - integer | |
| _twenty-eighth_spare_pdb_parameter | twenty-eighth spare pdb parameter - string | |
| _twenty-fifth_spare_parameter | twenty-fifth spare parameter - integer | |
| _twenty-fifth_spare_pdb_parameter | twenty-fifth spare pdb parameter - string | |
| _twenty-first_spare_parameter | twenty-first spare parameter - integer | |
| _twenty-first_spare_pdb_parameter | twenty-first spare pdb parameter - string | |
| _twenty-fourth_spare_parameter | twenty-fourth spare parameter - integer | |
| _twenty-fourth_spare_pdb_parameter | twenty-fourth spare pdb parameter - string | |
| _twenty-ninth_spare_parameter | twenty-ninth spare parameter - integer | |
| _twenty-ninth_spare_pdb_parameter | twenty-ninth spare pdb parameter - string | |
| _twenty-second_spare_parameter | twenty-second spare parameter - integer | |
| _twenty-second_spare_pdb_parameter | twenty-second spare pdb parameter - string | |
| _twenty-seventh_spare_parameter | twenty-seventh spare parameter - integer | |
| _twenty-seventh_spare_pdb_parameter | twenty-seventh spare pdb parameter - string | |
| _twenty-sixth_spare_parameter | twenty-sixth spare parameter - integer | |
| _twenty-sixth_spare_pdb_parameter | twenty-sixth spare pdb parameter - string | |
| _twenty-third_spare_parameter | twenty-third spare parameter - integer | |
| _twenty-third_spare_pdb_parameter | twenty-third spare pdb parameter - string | |
| _two-hundred-and-eighteenth_spare_parameter | FALSE | two-hundred-and-eighteenth spare parameter - boolean |
| _two-hundred-and-eighth_spare_parameter | FALSE | two-hundred-and-eighth spare parameter - boolean |
| _two-hundred-and-eleventh_spare_parameter | FALSE | two-hundred-and-eleventh spare parameter - boolean |
| _two-hundred-and-fifteenth_spare_parameter | FALSE | two-hundred-and-fifteenth spare parameter - boolean |
| _two-hundred-and-fifth_spare_parameter | FALSE | two-hundred-and-fifth spare parameter - boolean |
| _two-hundred-and-first_spare_parameter | FALSE | two-hundred-and-first spare parameter - boolean |
| _two-hundred-and-fourteenth_spare_parameter | FALSE | two-hundred-and-fourteenth spare parameter - boolean |
| _two-hundred-and-fourth_spare_parameter | FALSE | two-hundred-and-fourth spare parameter - boolean |
| _two-hundred-and-nineteenth_spare_parameter | FALSE | two-hundred-and-nineteenth spare parameter - boolean |
| _two-hundred-and-ninth_spare_parameter | FALSE | two-hundred-and-ninth spare parameter - boolean |
| _two-hundred-and-second_spare_parameter | FALSE | two-hundred-and-second spare parameter - boolean |
| _two-hundred-and-seventeenth_spare_parameter | FALSE | two-hundred-and-seventeenth spare parameter - boolean |
| _two-hundred-and-seventh_spare_parameter | FALSE | two-hundred-and-seventh spare parameter - boolean |
| _two-hundred-and-sixteenth_spare_parameter | FALSE | two-hundred-and-sixteenth spare parameter - boolean |
| _two-hundred-and-sixth_spare_parameter | FALSE | two-hundred-and-sixth spare parameter - boolean |
| _two-hundred-and-tenth_spare_parameter | FALSE | two-hundred-and-tenth spare parameter - boolean |
| _two-hundred-and-third_spare_parameter | FALSE | two-hundred-and-third spare parameter - boolean |
| _two-hundred-and-thirteenth_spare_parameter | FALSE | two-hundred-and-thirteenth spare parameter - boolean |
| _two-hundred-and-twelfth_spare_parameter | FALSE | two-hundred-and-twelfth spare parameter - boolean |
| _two-hundred-and-twentieth_spare_parameter | FALSE | two-hundred-and-twentieth spare parameter - boolean |
| _two-hundredth_spare_parameter | FALSE | two-hundredth spare parameter - boolean |
| _two_pass | TRUE | enable two-pass thread recovery |
| _two_pass_reverse_polish_enabled | TRUE | uses two-pass reverse polish alg. to generate canonical forms |
| _txn_control_trace_buf_size | 4096 | size the in-memory buffer size of txn control |
| _txn_spare1 | 0 | transaction spare variable1 |
| _txn_spare2 | 0 | transaction spare variable2 |
| _txn_spare3 | 0 | transaction spare variable3 |
| _uga_cga_large_extent_size | 262144 | UGA/CGA large extent size |
| _ultrafast_latch_statistics | TRUE | maintain fast-path statistics for ultrafast latches |
| _umf_remote_enabled | FALSE | Enable remote UMF operations |
| _umf_remote_target_dblink | UMF Remote Target DBLink for Flushing | |
| _umf_test_action | 0 | test action parameter for UMF |
| _undo_autotune | TRUE | enable auto tuning of undo_retention |
| _undo_block_compression | TRUE | enable undo block compression |
| _undo_debug_mode | 0 | debug flag for undo related operations |
| _undo_debug_usage | 0 | invoke undo usage functions for testing |
| _undo_ofd_enabled | TRUE | enable ordered offline drop of undo segments for datafile shrink |
| _undo_ofd_excess | 10 | percent of excess undo segments to offline or drop |
| _undo_ofd_reserve | 30 | percent of excess undo segments to keep online |
| _undo_tbs_slave_percent | 0 | Percentage of redo slaves for undo tablespace |
| _undotbs_regular_tables | FALSE | Create regular tables in undo tablespace |
| _undotbs_stepdown_pcent | 75 | Undo Tablespace small allocation step down percentage |
| _unified_audit_policy_disabled | FALSE | Disable Default Unified Audit Policies on DB Create |
| _unified_pga_block_size | 262144 | Unified PGA internal block size |
| _unified_pga_gran_free_timeout | 3000 | Granule free timeout |
| _unified_pga_gran_leak_timeout | 180000 | Granule leak timeout |
| _unified_pga_list_count | 16 | Unified PGA internal list count |
| _unified_pga_max_pool_size | 0 | max size in bytes of the unified pga pool |
| _unified_pga_pool_size | 0 | size in bytes of the unified pga pool |
| _union_rewrite_for_gs | YES_GSET_MVS | expand queries with GSets into UNIONs for rewrite |
| _uniq_cons_sql_enforcement | TRUE | disable extended data unique constraint SQL enforcement |
| _unnest_subquery | TRUE | enables unnesting of complex subqueries |
| _unused_block_compression | TRUE | enable unused block compression |
| _update_datafile_headers_with_space_information | FALSE | user requested update of datafile headers of locally managed datafiles with space information |
| _upddel_dba_hash_mask_bits | 0 | controls masking of lower order bits in DBA |
| _upgrade_capture_noops | TRUE | do not skip capturing noops during upgrade |
| _upgrade_optim | TRUE | Upgrade optimization enabled |
| _upgrade_pdb_on_open | TRUE | Enable upgrading a PDB automatically on open |
| _usd_preload_blks | 4 | USD preload block count for prefetch |
| _usd_recent_read | TRUE | Allow to scan recent USD blocks |
| _use_adaptive_log_file_sync | TRUE | Adaptively switch between post/wait and polling |
| _use_best_fit | FALSE | use best fit to allocate space |
| _use_cached_asm_free_space | FALSE | Should x$kttets use cached ASM free space info |
| _use_column_stats_for_function | TRUE | enable the use of column statistics for DDP functions |
| _use_dynamic_shares | 1 | use dynamic shares |
| _use_fallocate_for_mga | FALSE | MGA fallocate enabled |
| _use_fips_mode | FALSE | Enable use of crypographic libraries in FIPS mode |
| _use_futex_ipc | FALSE | use futex ipc |
| _use_hugetlbfs_for_SGA | FALSE | Enable HugeTLBFS usage for SGA |
| _use_hugetlbfs_per_granule | FALSE | Enable file per granule with HugeTLBFS |
| _use_hybrid_encryption_mode | FALSE | Enable platform optimized encryption in hybrid mode |
| _use_ism | TRUE | Enable Shared Page Tables - ISM |
| _use_ism_for_pga | TRUE | Use ISM for allocating large extents |
| _use_large_pages_for_mga | FALSE | MGA largepage enabled |
| _use_nosegment_indexes | FALSE | use nosegment indexes in explain plan |
| _use_pdb_parselock | TRUE | use PDB level parselock on ADG |
| _use_platform_compression_lib | TRUE | Enable platform optimized compression implementation |
| _use_platform_encryption_lib | TRUE | Enable platform optimized encryption implementation |
| _use_platform_hash_function | TRUE | control use of platform specific hash function |
| _use_realfree_heap | TRUE | use real-free based allocator for PGA memory |
| _use_seq_process_cache | TRUE | whether to use process local seq cache |
| _use_single_log_writer | ADAPTIVE | Use a single process for redo log writing |
| _use_vector_post | TRUE | use vector post |
| _use_zero_copy_io | TRUE | Should network vector IO interface be used for data transfer |
| _user_defined_sharding | 0 | enable user-defined sharding |
| _ut_fast_lrg_prediction | FALSE | use short interval for session SO prediction |
| _utl32k_mv_query | FALSE | utl32k.sql is compiling a materialized view query |
| _utlfile_dirpath | FALSE | return Utl_File Accessible |
| _utlmmig_table_stats_gathering | TRUE | enable/disable utlmmig table stats gathering at upgrade |
| _uts_disable_client_ip_trace | FALSE | Disables the printing of client IP address in trace files |
| _uts_enable_alltrc_stats | FALSE | Enables accounting of trace data in incident and cdmp trace files |
| _uts_first_segment_retain | TRUE | Should we retain the first trace segment |
| _uts_first_segment_size | 0 | Maximum size (in bytes) of first segments |
| _uts_force_seclabel_prefix | FALSE | Force output of trace record security label prefix |
| _uts_inc_inmem_trace | 0 | Controls UTS in-memory tracing during an active incident |
| _uts_trace_buffer_size | 0 | Trace disk buffer size |
| _uts_trace_disk_threshold | 0 | Trace disk threshold parameter |
| _uts_trace_files_nopurge | FALSE | Sets trace files to not get purged |
| _uts_trace_segment_size | 0 | Maximum size (in bytes) of a trace segment |
| _uts_trace_segments | 5 | Maximum number of trace segments |
| _validate_flashback_database | FALSE | Scan database to validate result of flashback database |
| _validate_metric_groups | FALSE | Enable/disable SGA Metric Structure validation |
| _validate_readmem_redo | HEADER_ONLY | validate redo blocks read from in-memory log buffer |
| _vector_aggregation_max_size | 0 | max size of vector aggregation space |
| _vector_dense_accum_max | 100 | vector group by dense accumulator space max |
| _vector_encoding_mode | MANUAL | enable vector encoding(OFF/MANUAL/AUTO) |
| _vector_operations_control | 0 | control different uses/algorithms related to vector transform |
| _vector_serialize_temp_threshold | 1000 | threshold for serializing vector transform temp table writes |
| _vendor_lib_loc | Vendor library search root directory | |
| _verify_encrypted_tablespace_keys | TRUE | if TRUE, verify encryption key signature for data files |
| _verify_fg_log_checksum | FALSE | LGWR verifies redo checksums generated by foreground processes |
| _verify_flashback_redo | TRUE | Verify that the redo logs needed for flashback are available |
| _verify_undo_quota | FALSE | TRUE - verify consistency of undo quota statistics |
| _very_large_object_threshold | 500 | upper threshold level of object size for direct reads |
| _virtual_column_access_control | TRUE | require VPD/RAS protection for virtual columns derived from protected columns |
| _virtual_column_overload_allowed | TRUE | overload virtual columns expression |
| _vkrm_schedule_interval | 10 | VKRM scheduling interval |
| _vktm_assert_thresh | 30 | soft assert threshold VKTM timer drift |
| _wait_breakup_threshold_csecs | 600 | Wait breakup threshold (in centiseconds) |
| _wait_breakup_time_csecs | 300 | Wait breakup time (in centiseconds) |
| _wait_for_busy_session | 10 | Wait time before killing active sessions during switchover |
| _wait_for_sync | TRUE | wait for sync on commit MUST BE ALWAYS TRUE |
| _wait_outlier_detection_enable | OFF | Enable wait outlier detection module? |
| _wait_outlier_dump_flags | 0 | Wait Outlier Dump Flags |
| _wait_outlier_event_names | Wait events to watch for outliers | |
| _wait_outlier_lambda_x1000 | 1500 | Lambda (in thousands) to compute outliers |
| _wait_outlier_min_waits | 10 | Minimum waits required to enable wait outliers detection |
| _wait_outlier_num_outliers | 600 | Max number of outliers tracked |
| _wait_samples_max_sections | 40 | Wait Samples maximum sections |
| _wait_samples_max_time_secs | 120 | Wait Samples maximum time in seconds |
| _wait_tracker_interval_secs | 10 | Wait Tracker number of seconds per interval |
| _wait_tracker_num_intervals | 0 | Wait Tracker number of intervals |
| _wait_yield_hp_mode | yield | Wait Yield - High Priority Mode |
| _wait_yield_mode | yield | Wait Yield - Mode |
| _wait_yield_sleep_freq | 100 | Wait Yield - Sleep Frequency |
| _wait_yield_sleep_time_msecs | 1 | Wait Yield - Sleep Time (in milliseconds) |
| _wait_yield_yield_freq | 20 | Wait Yield - Yield Frequency |
| _walk_insert_threshold | 0 | maximum number of unusable blocks to walk across freelist |
| _watchpoint_on | FALSE | is the watchpointing feature turned on? |
| _wcr_control | 0 | Oracle internal test WCR parameter used ONLY for testing! |
| _wcr_grv_cache_size | 65535 | Oracle internal: Set the replay cache size for WRR$_REPLAY_DATA. |
| _wcr_seq_cache_size | 65535 | Oracle internal: Set the replay cache size for WRR$_REPLAY_SEQ_DATA. |
| _wcr_test_action | 0 | Oracle internal test WCR parameter used for test actions |
| _widetab_comp_enabled | TRUE | wide table compression enabled |
| _windowfunc_optimization_settings | 0 | settings for window function optimizations |
| _with_subquery | OPTIMIZER | WITH subquery transformation |
| _worker_threads | 0 | Number of worker threads |
| _workload_attributes | session workload attributes | |
| _write_clones | 3 | write clones flag |
| _write_renamed_datafile_name | FALSE | print renamed datafile names to alert log |
| _xa_internal_retries | 600 | number of internal retries for xa transactions |
| _xds_max_child_cursors | 100 | Maximum number of XDS user-specific child cursors |
| _xengem_devname | DEFAULT | override default VM GEM device name used by skgvm |
| _xengem_diagmode | OFF | set to OFF to disable VM GEM support and functionalities |
| _xengem_enabled | TRUE | Enable OVM GEM support |
| _xpl_peeked_binds_log_size | 8192 | maximum bytes for logging peeked bind values for V$SQL_PLAN (0 = OFF) |
| _xpl_trace | 0 | Explain Plan tracing parameter |
| _xs_cleanup_task | TRUE | Triton Session Cleanup |
| _xs_dispatcher_only | FALSE | XS dispatcher only mode |
| _xs_logon_grant | FALSE | Create session privilege is required for RAS direct logon user to login to database |
| _xs_sidp_allow_sha1 | TRUE | XS SIDP allow use of SHA1 |
| _xsolapi_auto_materialization_bound | 20 | OLAP API lower bound for auto materialization. |
| _xsolapi_auto_materialization_type | PRED_AND_RC | OLAP API behavior for auto materialization |
| _xsolapi_build_trace | FALSE | OLAP API output build info to trace file |
| _xsolapi_debug_output | SUPPRESS | OLAP API debug output disposition |
| _xsolapi_densify_cubes | TABULAR | OLAP API cube densification |
| _xsolapi_dimension_group_creation | OVERFETCH | OLAP API symmetric overfetch |
| _xsolapi_dml_trace | OLAP API output dml commands and expressions to trace file | |
| _xsolapi_fetch_type | PARTIAL | OLAP API fetch type |
| _xsolapi_fix_vptrs | TRUE | OLAP API Enable vptr fixing logic in shared server mode |
| _xsolapi_generate_with_clause | FALSE | OLAP API generates WITH clause? |
| _xsolapi_hierarchy_value_type | unique | OLAP API hierarchy value type |
| _xsolapi_load_at_process_start | NEVER | When to load OLAP API library at server process start |
| _xsolapi_materialization_rowcache_min_rows_for_use | 1 | OLAP API min number of rows required to use rowcache in query materialization |
| _xsolapi_materialize_sources | TRUE | OLAP API Enable source materialization |
| _xsolapi_metadata_reader_mode | DEFAULT | OLAP API metadata reader mode |
| _xsolapi_odbo_mode | FALSE | OLAP API uses ODBO mode? |
| _xsolapi_opt_aw_position | TRUE | OLAP API enables AW position and count optimization? |
| _xsolapi_optimize_suppression | TRUE | OLAP API optimizes suppressions? |
| _xsolapi_precompute_subquery | TRUE | OLAP API precomputes subqueries? |
| _xsolapi_remove_columns_for_materialization | TRUE | OLAP API removes columns for materialization? |
| _xsolapi_set_nls | TRUE | OLAP API sets NLS? |
| _xsolapi_share_executors | TRUE | OLAP API share executors? |
| _xsolapi_source_trace | FALSE | OLAP API output Source definitions to trace file |
| _xsolapi_sql_all_multi_join_non_base_hints | OLAP API multi-join non-base hints | |
| _xsolapi_sql_all_non_base_hints | OLAP API non-base hints | |
| _xsolapi_sql_auto_dimension_hints | FALSE | OLAP API enable automatic dimension hints |
| _xsolapi_sql_auto_measure_hints | TRUE | OLAP API enable automatic measure hints |
| _xsolapi_sql_dimension_hints | OLAP API dimension hints | |
| _xsolapi_sql_enable_aw_join | TRUE | OLAP API enables AW join? |
| _xsolapi_sql_enable_aw_qdr_merge | TRUE | OLAP API enables AW QDR merge? |
| _xsolapi_sql_hints | OLAP API generic hints | |
| _xsolapi_sql_measure_hints | OLAP API measure hints | |
| _xsolapi_sql_minus_threshold | 1000 | OLAP API SQL MINUS threshold |
| _xsolapi_sql_optimize | TRUE | OLAP API enable optimization |
| _xsolapi_sql_prepare_stmt_cache_size | 16 | OLAP API prepare statement cache size |
| _xsolapi_sql_remove_columns | TRUE | OLAP API enable remove unused columns optimizations |
| _xsolapi_sql_result_set_cache_size | 32 | OLAP API result set cache size |
| _xsolapi_sql_symmetric_predicate | TRUE | OLAP API enable symmetric predicate for dimension groups |
| _xsolapi_sql_top_dimension_hints | OLAP API top dimension hints | |
| _xsolapi_sql_top_measure_hints | OLAP API top measure hints | |
| _xsolapi_sql_use_bind_variables | TRUE | OLAP API enable bind variables optimization |
| _xsolapi_stringify_order_levels | FALSE | OLAP API stringifies order levels? |
| _xsolapi_support_mtm | FALSE | OLAP API MTM mapping classes supported? |
| _xsolapi_suppression_aw_mask_threshold | 1000 | OLAP API suppression AW mask threshold |
| _xsolapi_suppression_chunk_size | 4000 | OLAP API suppression chunk size |
| _xsolapi_use_models | TRUE | OLAP API uses models? |
| _xsolapi_use_olap_dml | TRUE | OLAP API uses OLAP DML? |
| _xsolapi_use_olap_dml_for_rank | TRUE | OLAP API uses OLAP DML for rank? |
| _xt_coverage | none | external tables code coverage parameter |
| _xt_def_compression_ratio | 4 | Default compression ratio for external table data files |
| _xt_enable_columnar_fetch | TRUE | Enable external table columnar fetch |
| _xt_http_wscl | FALSE | Use KGWSCL for HTTP requests |
| _xt_legacy_debug_flags | 0 | Debug flags for ORACLE_LOADER and ORACLE_DATAPUMP |
| _xt_preproc_timeout | 100 | external table preprocessor timeout |
| _xt_sampling_scan_granules | ON | Granule Sampling for Block Sampling of External Tables |
| _xt_sampling_scan_granules_min_granules | 1 | Minimum number of granules to scan for granule sampling |
| _xt_trace | none | external tables trace parameter |
| _xtbigdata_max_buffersize | 10240 | maximum size of IO Buffers for exadoop external tables (in KB) |
| _xtbuffer_size | 0 | buffer size in KB needed for populate/query operation |
| _xtts_allow_pre10 | FALSE | allow cross platform for pre10 compatible tablespace |
| _xtts_set_platform_info | FALSE | set cross platform info during file header read |
| _zonemap_auto_candidate_table_min_size | 5000 | Minimum size for a table to be candidate for an automatic zonemap |
| _zonemap_auto_clustering_ratio | 50 | Data clustering ratio in percent for automatic zonemap columns |
| _zonemap_control | 0 | control different uses/algorithms related to zonemaps |
| _zonemap_refresh_within_load | TRUE | Control the refresh of basic zonemaps during/after data load |
| _zonemap_staleness_tracking | 1 | control the staleness tracking of zonemaps via trigger |
| _zonemap_usage_tracking | TRUE | Control the capture of zonemap usage statistics |
| _zonemap_use_enabled | TRUE | enable the use of zonemaps for IO pruning |
| active_instance_count | number of active instances in the cluster database | |
| adg_account_info_tracking | LOCAL | ADG user account info tracked in standby(LOCAL) or in Primary(GLOBAL) |
| adg_redirect_dml | FALSE | Enable DML Redirection from ADG |
| allow_deprecated_rpcs | YES | allow deprecated rpcs |
| allow_global_dblinks | FALSE | LDAP lookup for DBLINKS |
| allow_group_access_to_sga | FALSE | Allow read access for SGA to users of Oracle owner group |
| allow_rowid_column_type | FALSE | Allow creation of rowid column |
| approx_for_aggregation | FALSE | Replace exact aggregation with approximate aggregation |
| approx_for_count_distinct | FALSE | Replace count distinct with approx_count_distinct |
| approx_for_percentile | NONE | Replace percentile_* with approx_percentile |
| aq_tm_processes | 1 | number of AQ Time Managers to start |
| archive_lag_target | 0 | Maximum number of seconds of redos the standby could lose |
| asm_diskstring | disk set locations for discovery | |
| asm_preferred_read_failure_groups | preferred read failure groups | |
| audit_file_dest | /u01/app/oracle/admin/orcl21c/adump | Directory in which auditing files are to reside |
| audit_sys_operations | TRUE | enable sys auditing |
| audit_syslog_level | Syslog facility and level | |
| audit_trail | DB | enable system auditing |
| auto_start_pdb_services | FALSE | Automatically start all PDB services on PDB Open |
| autotask_max_active_pdbs | 2 | Setting for Autotask Maximum Maintenance PDBs |
| awr_pdb_autoflush_enabled | FALSE | Enable/Disable AWR automatic PDB flushing |
| awr_pdb_max_parallel_slaves | 10 | maximum concurrent AWR PDB MMON slaves per instance |
| awr_snapshot_time_offset | 0 | Setting for AWR Snapshot Time Offset |
| background_core_dump | partial | Core Size for Background Processes |
| background_dump_dest | /u01/app/oracle/homes/OraDB21Home1/rdbms/log | Detached process dump directory |
| backup_tape_io_slaves | FALSE | BACKUP Tape I/O slaves |
| bitmap_merge_area_size | 1048576 | maximum memory allow for BITMAP MERGE |
| blank_trimming | FALSE | blank trimming semantics parameter |
| blockchain_table_max_no_drop | maximum idle retention minutes for blockchain tables | |
| buffer_pool_keep | Number of database blocks/latches in keep buffer pool | |
| buffer_pool_recycle | Number of database blocks/latches in recycle buffer pool | |
| cdb_cluster | FALSE | if TRUE startup in CDB Cluster mode |
| cdb_cluster_name | CDB Cluster name | |
| cell_offload_compaction | ADAPTIVE | Cell packet compaction strategy |
| cell_offload_decryption | TRUE | enable SQL processing offload of encrypted data to cells |
| cell_offload_parameters | Additional cell offload parameters | |
| cell_offload_plan_display | AUTO | Cell offload explain plan display |
| cell_offload_processing | TRUE | enable SQL processing offload to cells |
| cell_offloadgroup_name | Set the offload group name | |
| circuits | max number of circuits | |
| client_result_cache_lag | 3000 | client result cache maximum lag in milliseconds |
| client_result_cache_size | 0 | client result cache max size in bytes |
| client_statistics_level | TYPICAL | Client Statistics Level |
| clonedb | FALSE | clone database |
| clonedb_dir | CloneDB Directory | |
| cluster_database | FALSE | if TRUE startup in cluster database mode |
| cluster_interconnects | interconnects for RAC use | |
| commit_logging | transaction commit log write behaviour | |
| commit_point_strength | 1 | Bias this node has toward not preparing in a two-phase commit |
| commit_wait | transaction commit log wait behaviour | |
| commit_write | transaction commit log write behaviour | |
| common_user_prefix | C## | Enforce restriction on a prefix of a Common User/Role/Profile name |
| compatible | 21.0.0 | Database will be completely compatible with this software version |
| connection_brokers | ((TYPE=DEDICATED)(BROKERS=1)), ((TYPE=EMON)(BROKERS=1)) | connection brokers specification |
| container_data | ALL | which containers should data be returned from? |
| containers_parallel_degree | 65535 | Parallel degree for a CONTAINERS() query |
| control_file_record_keep_time | 7 | control file record keep time in days |
| control_files | /u01/app/oracle/oradata/ORCL21C/control01.ctl, /u01/app/oracle/oradata/ORCL21C/control02.ctl | control file names list |
| control_management_pack_access | DIAGNOSTIC+TUNING | declares which manageability packs are enabled |
| core_dump_dest | /u01/app/oracle/diag/rdbms/orcl21c/orcl21c/cdump | Core dump directory |
| cpu_count | 4 | maximum number of CPUs |
| cpu_min_count | 4 | minimum number of CPUs required |
| create_bitmap_area_size | 8388608 | size of create bitmap buffer for bitmap index |
| create_stored_outlines | create stored outlines for DML statements | |
| cursor_bind_capture_destination | memory+disk | Allowed destination for captured bind variables |
| cursor_invalidation | IMMEDIATE | default for DDL cursor invalidation semantics |
| cursor_sharing | EXACT | cursor sharing mode |
| cursor_space_for_time | FALSE | use more memory in order to get faster execution |
| data_guard_max_io_time | 240 | maximum I/O time before process considered hung |
| data_guard_max_longio_time | 240 | maximum long I/O time before process considered hung |
| data_guard_sync_latency | 0 | Data Guard SYNC latency |
| data_transfer_cache_size | 0 | Size of data transfer cache |
| db_16k_cache_size | 0 | Size of cache for 16K buffers |
| db_2k_cache_size | 0 | Size of cache for 2K buffers |
| db_32k_cache_size | 0 | Size of cache for 32K buffers |
| db_4k_cache_size | 0 | Size of cache for 4K buffers |
| db_8k_cache_size | 0 | Size of cache for 8K buffers |
| db_big_table_cache_percent_target | 0 | Big table cache target size in percentage |
| db_block_buffers | 0 | Number of database blocks cached in memory |
| db_block_checking | FALSE | header checking and data and index block checking |
| db_block_checksum | TYPICAL | store checksum in db blocks and check during reads |
| db_block_size | 8192 | Size of database block in bytes |
| db_cache_advice | ON | Buffer cache sizing advisory |
| db_cache_size | 0 | Size of DEFAULT buffer pool for standard block size buffers |
| db_create_file_dest | default database location | |
| db_create_online_log_dest_1 | online log/controlfile destination #1 | |
| db_create_online_log_dest_2 | online log/controlfile destination #2 | |
| db_create_online_log_dest_3 | online log/controlfile destination #3 | |
| db_create_online_log_dest_4 | online log/controlfile destination #4 | |
| db_create_online_log_dest_5 | online log/controlfile destination #5 | |
| db_domain | directory part of global database name stored with CREATE DATABASE | |
| db_file_multiblock_read_count | 128 | db block to be read each IO |
| db_file_name_convert | datafile name convert patterns and strings for standby/clone db | |
| db_files | 200 | max allowable # db files |
| db_flash_cache_file | flash cache file for default block size | |
| db_flash_cache_size | 0 | flash cache size for db_flash_cache_file |
| db_flashback_retention_target | 1440 | Maximum Flashback Database log retention time in minutes. |
| db_index_compression_inheritance | NONE | options for table or tablespace level compression inheritance |
| db_keep_cache_size | 0 | Size of KEEP buffer pool for standard block size buffers |
| db_lost_write_protect | NONE | enable lost write detection |
| db_name | orcl21c | database name specified in CREATE DATABASE |
| db_performance_profile | Database performance category | |
| db_recovery_file_dest | /u01/fra | default database recovery file location |
| db_recovery_file_dest_size | 107374182400 | database recovery files size limit |
| db_recycle_cache_size | 0 | Size of RECYCLE buffer pool for standard block size buffers |
| db_securefile | PREFERRED | permit securefile storage during lob creation |
| db_ultra_safe | OFF | Sets defaults for other parameters that control protection levels |
| db_unique_name | orcl21c | Database Unique Name |
| db_unrecoverable_scn_tracking | TRUE | Track nologging SCN in controlfile |
| db_writer_processes | 1 | number of background database writer processes to start |
| dbnest_enable | NONE | database Nest enable |
| dbnest_pdb_fs_conf | PDB Filesystem configuration | |
| dbwr_io_slaves | 0 | DBWR I/O slaves |
| ddl_lock_timeout | 0 | timeout to restrict the time that ddls wait for dml lock |
| default_sharing | metadata | Default sharing clause |
| deferred_segment_creation | TRUE | defer segment creation to first insert |
| dg_broker_config_file1 | /u01/app/oracle/homes/OraDB21Home1/dbs/dr1orcl21c.dat | data guard broker configuration file #1 |
| dg_broker_config_file2 | /u01/app/oracle/homes/OraDB21Home1/dbs/dr2orcl21c.dat | data guard broker configuration file #2 |
| dg_broker_start | FALSE | start Data Guard broker (DMON process) |
| diagnostic_dest | /u01/app/oracle | diagnostic base directory |
| diagnostics_control | IGNORE | controls response when 'enabling diagnostics' privilege is absent |
| disable_pdb_feature | 0 | Disable features |
| disk_asynch_io | TRUE | Use asynch I/O for random access devices |
| dispatchers | (PROTOCOL=TCP) (SERVICE=orcl21cXDB) | specifications of dispatchers |
| distributed_lock_timeout | 60 | number of seconds a distributed transaction waits for a lock |
| dml_locks | 2216 | dml locks - one for each table modified in a transaction |
| dnfs_batch_size | 4096 | Max number of dNFS asynch I/O requests queued per session |
| drcp_connection_limit | 0 | DRCP connection limit |
| drcp_dedicated_opt | NO | Turn on/off dedicated optimization for DRCP |
| dst_upgrade_insert_conv | TRUE | Enables/Disables internal conversions during DST upgrade |
| enable_automatic_maintenance_pdb | TRUE | Enable/Disable Automated Maintenance for Non-Root PDB |
| enable_ddl_logging | FALSE | enable ddl logging |
| enable_dnfs_dispatcher | FALSE | Enable DNFS Dispatcher |
| enable_goldengate_replication | FALSE | goldengate replication enabled |
| enable_imc_with_mira | FALSE | enable IMC with multi instance redo apply |
| enable_per_pdb_drcp | FALSE | Turn on/off per PDB DRCP |
| enable_pluggable_database | TRUE | Enable Pluggable Database |
| enabled_PDBs_on_standby | * | List of Enabled PDB patterns |
| encrypt_new_tablespaces | CLOUD_ONLY | whether to encrypt newly created tablespaces |
| event | debug event control - default null string | |
| external_keystore_credential_location | external keystore credential location | |
| fal_client | FAL client | |
| fal_server | FAL server list | |
| fast_start_io_target | 0 | Upper bound on recovery reads |
| fast_start_mttr_target | 0 | MTTR target in seconds |
| fast_start_parallel_rollback | LOW | max number of parallel recovery slaves that may be used |
| file_mapping | FALSE | enable file mapping |
| fileio_network_adapters | Network Adapters for File I/O | |
| filesystemio_options | setall | IO operations on filesystem files |
| fixed_date | fixed SYSDATE value | |
| forward_listener | forward listener | |
| gcs_server_processes | 0 | number of background gcs server processes to start |
| global_names | FALSE | enforce that database links have same name as remote database |
| global_txn_processes | 1 | number of background global transaction processes to start |
| hash_area_size | 131072 | size of in-memory hash work area |
| heartbeat_batch_size | 5 | Number of heartbeats to be sent in a batch |
| heat_map | OFF | ILM Heatmap Tracking |
| hi_shared_memory_address | 0 | SGA starting address (high order 32-bits on 64-bit platforms) |
| hs_autoregister | TRUE | enable automatic server DD updates in HS agent self-registration |
| http_proxy | http_proxy | |
| hybrid_read_only | FALSE | Hybrid read only mode allows CDB common user to patch the PDB |
| ifile | include file in init.ora | |
| ignore_session_set_param_errors | Ignore errors during alter session param set | |
| inmemory_adg_enabled | TRUE | Enable IMC support on ADG |
| inmemory_automatic_level | OFF | Enable Automatic In-Memory management |
| inmemory_clause_default | Default in-memory clause for new tables | |
| inmemory_deep_vectorization | TRUE | In-Memory Deep Vectorization Enabled |
| inmemory_expressions_usage | ENABLE | Controls which In-Memory Expressions are populated in-memory |
| inmemory_force | DEFAULT | Force tables to be in-memory or not |
| inmemory_max_populate_servers | 0 | maximum inmemory populate servers |
| inmemory_optimized_arithmetic | DISABLE | Controls whether or not DSBs are stored in-memory |
| inmemory_prefer_xmem_memcompress | Prefer to store tables with given memcompress levels in xmem | |
| inmemory_prefer_xmem_priority | Prefer to store tables with given priority levels in xmem | |
| inmemory_query | ENABLE | Specifies whether in-memory queries are allowed |
| inmemory_size | 0 | size in bytes of in-memory area |
| inmemory_trickle_repopulate_servers_percent | 1 | inmemory trickle repopulate servers percent |
| inmemory_virtual_columns | MANUAL | Controls which user-defined virtual columns are stored in-memory |
| inmemory_xmem_size | 0 | size in bytes of in-memory xmem area |
| instance_abort_delay_time | 0 | time to delay an internal initiated abort (in seconds) |
| instance_groups | list of instance group names | |
| instance_mode | READ-WRITE | indicates whether the instance read-only or read-write or read-mostly |
| instance_name | orcl21c | instance name supported by the instance |
| instance_number | 0 | instance number |
| instance_type | RDBMS | type of instance to be executed |
| instant_restore | FALSE | instant repopulation of datafiles |
| java_jit_enabled | TRUE | Java VM JIT enabled |
| java_max_sessionspace_size | 0 | max allowed size in bytes of a Java sessionspace |
| java_pool_size | 0 | size in bytes of java pool |
| java_restrict | none | Restrict Java VM Access |
| java_soft_sessionspace_limit | 0 | warning limit on size in bytes of a Java sessionspace |
| job_queue_processes | 80 | maximum number of job queue slave processes |
| kafka_config_file | KSR pub/sub external message bus(KSRPS) CONFIGuration file | |
| large_pool_size | 0 | size in bytes of large pool |
| ldap_directory_access | NONE | RDBMS's LDAP access option |
| ldap_directory_sysauth | no | OID usage parameter |
| license_max_sessions | 0 | maximum number of non-system user sessions allowed |
| license_max_users | 0 | maximum number of named users that can be created in the database |
| license_sessions_warning | 0 | warning level for number of non-system user sessions |
| listener_networks | listener registration networks | |
| lob_signature_enable | FALSE | enable lob signature |
| local_listener | LISTENER_ORCL21C | local listener |
| lock_name_space | lock name space used for generating lock names for standby/clone database | |
| lock_sga | FALSE | Lock entire SGA in physical memory |
| log_archive_config | log archive config | |
| log_archive_dest | archival destination text string | |
| log_archive_dest_1 | archival destination #1 text string | |
| log_archive_dest_10 | archival destination #10 text string | |
| log_archive_dest_11 | archival destination #11 text string | |
| log_archive_dest_12 | archival destination #12 text string | |
| log_archive_dest_13 | archival destination #13 text string | |
| log_archive_dest_14 | archival destination #14 text string | |
| log_archive_dest_15 | archival destination #15 text string | |
| log_archive_dest_16 | archival destination #16 text string | |
| log_archive_dest_17 | archival destination #17 text string | |
| log_archive_dest_18 | archival destination #18 text string | |
| log_archive_dest_19 | archival destination #19 text string | |
| log_archive_dest_2 | archival destination #2 text string | |
| log_archive_dest_20 | archival destination #20 text string | |
| log_archive_dest_21 | archival destination #21 text string | |
| log_archive_dest_22 | archival destination #22 text string | |
| log_archive_dest_23 | archival destination #23 text string | |
| log_archive_dest_24 | archival destination #24 text string | |
| log_archive_dest_25 | archival destination #25 text string | |
| log_archive_dest_26 | archival destination #26 text string | |
| log_archive_dest_27 | archival destination #27 text string | |
| log_archive_dest_28 | archival destination #28 text string | |
| log_archive_dest_29 | archival destination #29 text string | |
| log_archive_dest_3 | archival destination #3 text string | |
| log_archive_dest_30 | archival destination #30 text string | |
| log_archive_dest_31 | archival destination #31 text string | |
| log_archive_dest_4 | archival destination #4 text string | |
| log_archive_dest_5 | archival destination #5 text string | |
| log_archive_dest_6 | archival destination #6 text string | |
| log_archive_dest_7 | archival destination #7 text string | |
| log_archive_dest_8 | archival destination #8 text string | |
| log_archive_dest_9 | archival destination #9 text string | |
| log_archive_dest_state_1 | enable | archival destination #1 state text string |
| log_archive_dest_state_10 | enable | archival destination #10 state text string |
| log_archive_dest_state_11 | enable | archival destination #11 state text string |
| log_archive_dest_state_12 | enable | archival destination #12 state text string |
| log_archive_dest_state_13 | enable | archival destination #13 state text string |
| log_archive_dest_state_14 | enable | archival destination #14 state text string |
| log_archive_dest_state_15 | enable | archival destination #15 state text string |
| log_archive_dest_state_16 | enable | archival destination #16 state text string |
| log_archive_dest_state_17 | enable | archival destination #17 state text string |
| log_archive_dest_state_18 | enable | archival destination #18 state text string |
| log_archive_dest_state_19 | enable | archival destination #19 state text string |
| log_archive_dest_state_2 | enable | archival destination #2 state text string |
| log_archive_dest_state_20 | enable | archival destination #20 state text string |
| log_archive_dest_state_21 | enable | archival destination #21 state text string |
| log_archive_dest_state_22 | enable | archival destination #22 state text string |
| log_archive_dest_state_23 | enable | archival destination #23 state text string |
| log_archive_dest_state_24 | enable | archival destination #24 state text string |
| log_archive_dest_state_25 | enable | archival destination #25 state text string |
| log_archive_dest_state_26 | enable | archival destination #26 state text string |
| log_archive_dest_state_27 | enable | archival destination #27 state text string |
| log_archive_dest_state_28 | enable | archival destination #28 state text string |
| log_archive_dest_state_29 | enable | archival destination #29 state text string |
| log_archive_dest_state_3 | enable | archival destination #3 state text string |
| log_archive_dest_state_30 | enable | archival destination #30 state text string |
| log_archive_dest_state_31 | enable | archival destination #31 state text string |
| log_archive_dest_state_4 | enable | archival destination #4 state text string |
| log_archive_dest_state_5 | enable | archival destination #5 state text string |
| log_archive_dest_state_6 | enable | archival destination #6 state text string |
| log_archive_dest_state_7 | enable | archival destination #7 state text string |
| log_archive_dest_state_8 | enable | archival destination #8 state text string |
| log_archive_dest_state_9 | enable | archival destination #9 state text string |
| log_archive_duplex_dest | duplex archival destination text string | |
| log_archive_format | %t_%s_%r.dbf | archival destination format |
| log_archive_max_processes | 4 | maximum number of active ARCH processes |
| log_archive_min_succeed_dest | 1 | minimum number of archive destinations that must succeed |
| log_archive_start | FALSE | start archival process on SGA initialization |
| log_archive_trace | 0 | Establish archive operation tracing level |
| log_buffer | 6766592 | redo circular buffer size |
| log_checkpoint_interval | 0 | # redo blocks checkpoint threshold |
| log_checkpoint_timeout | 1800 | Maximum time interval between checkpoints in seconds |
| log_checkpoints_to_alert | FALSE | log checkpoint begin/end to alert file |
| log_file_name_convert | logfile name convert patterns and strings for standby/clone db | |
| long_module_action | TRUE | Use longer module and action |
| mandatory_user_profile | Enforce Mandatory Password Profile for multitenant database | |
| max_auth_servers | 25 | Maximum size of auth pool |
| max_datapump_jobs_per_pdb | 100 | maximum number of concurrent Data Pump Jobs per PDB |
| max_datapump_parallel_per_job | 50 | maximum number of parallel processes per Data Pump Job |
| max_dispatchers | max number of dispatchers | |
| max_dump_file_size | unlimited | Maximum size (in bytes) of dump file |
| max_idle_blocker_time | 0 | maximum idle time for a blocking session in minutes |
| max_idle_time | 0 | maximum session idle time in minutes |
| max_iops | 0 | MAX IO per second |
| max_mbps | 0 | MAX MB per second |
| max_pdbs | 254 | max number of pdbs allowed in CDB or Application ROOT |
| max_shared_servers | max number of shared servers | |
| max_string_size | STANDARD | controls maximum size of VARCHAR2, NVARCHAR2, and RAW types in SQL |
| memoptimize_pool_size | 0 | Size of cache for imoltp buffers |
| memory_max_target | 0 | Max size for Memory Target |
| memory_target | 0 | Target size of Oracle SGA and PGA memory |
| min_auth_servers | 1 | Minimum size of auth pool |
| multishard_query_data_consistency | strong | consistency setting for multishard queries |
| multishard_query_partial_results | not allowed | enable partial results for multishard queries |
| native_blockchain_features | Native block chain enable/disable | |
| nls_calendar | GREGORIAN | NLS calendar system name |
| nls_comp | BINARY | NLS comparison |
| nls_currency | $ | NLS local currency symbol |
| nls_date_format | DD-MON-RR | NLS Oracle date format |
| nls_date_language | AMERICAN | NLS date language name |
| nls_dual_currency | $ | Dual currency symbol |
| nls_iso_currency | AMERICA | NLS ISO currency territory name |
| nls_language | AMERICAN | NLS language name |
| nls_length_semantics | BYTE | create columns using byte or char semantics by default |
| nls_nchar_conv_excp | FALSE | NLS raise an exception instead of allowing implicit conversion |
| nls_numeric_characters | ., | NLS numeric characters |
| nls_sort | BINARY | NLS linguistic definition name |
| nls_territory | AMERICA | NLS territory name |
| nls_time_format | HH.MI.SSXFF AM | time format |
| nls_time_tz_format | HH.MI.SSXFF AM TZR | time with timezone format |
| nls_timestamp_format | DD-MON-RR HH.MI.SSXFF AM | time stamp format |
| nls_timestamp_tz_format | DD-MON-RR HH.MI.SSXFF AM TZR | timestamp with timezone format |
| noncdb_compatible | FALSE | Non-CDB Compatible |
| object_cache_max_size_percent | 10 | percentage of maximum size over optimal of the user session's object cache |
| object_cache_optimal_size | 10240000 | optimal size of the user session's object cache in bytes |
| ofs_threads | 4 | Number of OFS threads |
| olap_page_pool_size | 0 | size of the olap page pool in bytes |
| one_step_plugin_for_pdb_with_tde | FALSE | Facilitate one-step plugin for PDB with TDE encrypted data |
| open_cursors | 300 | max # cursors per session |
| open_links | 4 | max # open links per session |
| open_links_per_instance | 4 | max # open links per instance |
| optimizer_adaptive_plans | TRUE | controls all types of adaptive plans |
| optimizer_adaptive_reporting_only | FALSE | use reporting-only mode for adaptive optimizations |
| optimizer_adaptive_statistics | FALSE | controls all types of adaptive statistics |
| optimizer_capture_sql_plan_baselines | FALSE | automatic capture of SQL plan baselines for repeatable statements |
| optimizer_capture_sql_quarantine | FALSE | enable automatic creation/update of sql quarantine configuration |
| optimizer_cross_shard_resiliency | FALSE | enables resilient execution of cross shard queries |
| optimizer_dynamic_sampling | 2 | optimizer dynamic sampling |
| optimizer_features_enable | 21.1.0 | optimizer plan compatibility parameter |
| optimizer_ignore_hints | FALSE | enables the embedded hints to be ignored |
| optimizer_ignore_parallel_hints | FALSE | enables embedded parallel hints to be ignored |
| optimizer_index_caching | 0 | optimizer percent index caching |
| optimizer_index_cost_adj | 100 | optimizer index cost adjustment |
| optimizer_inmemory_aware | TRUE | optimizer in-memory columnar awareness |
| optimizer_mode | ALL_ROWS | optimizer mode |
| optimizer_real_time_statistics | FALSE | optimizer real time statistics on conventional DML |
| optimizer_secure_view_merging | TRUE | optimizer secure view merging and predicate pushdown/movearound |
| optimizer_session_type | NORMAL | Controls Auto Index |
| optimizer_use_invisible_indexes | FALSE | Usage of invisible indexes (TRUE/FALSE) |
| optimizer_use_pending_statistics | FALSE | Control whether to use optimizer pending statistics |
| optimizer_use_sql_plan_baselines | TRUE | use of SQL plan baselines for captured sql statements |
| optimizer_use_sql_quarantine | TRUE | enable use of sql quarantine |
| os_authent_prefix | ops$ | prefix for auto-logon accounts |
| os_roles | FALSE | retrieve roles from the operating system |
| outbound_dblink_protocols | ALL | Outbound DBLINK Protocols allowed |
| parallel_adaptive_multi_user | FALSE | enable adaptive setting of degree for multiple user streams |
| parallel_degree_limit | CPU | limit placed on degree of parallelism |
| parallel_degree_policy | MANUAL | policy used to compute the degree of parallelism (MANUAL/LIMITED/AUTO/ADAPTIVE) |
| parallel_execution_message_size | 16384 | message buffer size for parallel execution |
| parallel_force_local | FALSE | force single instance execution |
| parallel_instance_group | instance group to use for all parallel operations | |
| parallel_max_servers | 80 | maximum parallel query servers per instance |
| parallel_min_degree | 1 | controls the minimum DOP computed by Auto DOP |
| parallel_min_percent | 0 | minimum percent of threads required for parallel query |
| parallel_min_servers | 1 | minimum parallel query servers per instance |
| parallel_min_time_threshold | AUTO | threshold above which a plan is a candidate for parallelization (in seconds) |
| parallel_servers_target | 80 | instance target in terms of number of parallel servers |
| parallel_threads_per_cpu | 1 | number of parallel execution threads per CPU |
| pdb_file_name_convert | PDB file name convert patterns and strings for create cdb/pdb | |
| pdb_lockdown | pluggable database lockdown profile | |
| pdb_os_credential | pluggable database OS credential to bind | |
| pdb_template | PDB template | |
| permit_92_wrap_format | FALSE | allow 9.2 or older wrap format in PL/SQL |
| pga_aggregate_limit | 2147483648 | limit of aggregate PGA memory for the instance or PDB |
| pga_aggregate_target | 800063488 | Target size for the aggregate PGA memory consumed by the instance |
| pkcs11_library_location | PKCS#11 library location for Transparent Data Encryption | |
| plscope_settings | IDENTIFIERS:NONE | plscope_settings controls the compile time collection, cross reference, and storage of PL/SQL source code identifier and SQL statement data |
| plsql_ccflags | PL/SQL ccflags | |
| plsql_code_type | INTERPRETED | PL/SQL code-type |
| plsql_debug | FALSE | PL/SQL debug |
| plsql_optimize_level | 2 | PL/SQL optimize level |
| plsql_v2_compatibility | FALSE | PL/SQL version 2.x compatibility flag |
| plsql_warnings | DISABLE:ALL | PL/SQL compiler warnings settings |
| pmem_filestore | Persistent Memory Filestore list | |
| pre_page_sga | TRUE | pre-page sga for process |
| private_temp_table_prefix | ORA$PTT_ | Private temporary table prefix |
| processes | 320 | user processes |
| processor_group_name | Name of the processor group that this instance should run in. | |
| query_rewrite_enabled | TRUE | allow rewrite of queries using materialized views if enabled |
| query_rewrite_integrity | enforced | perform rewrite using materialized views with desired integrity |
| rdbms_server_dn | RDBMS's Distinguished Name | |
| read_only | FALSE | Restrict WRITE operations in user session |
| read_only_open_delayed | FALSE | if TRUE delay opening of read only files until first access |
| recovery_parallelism | 0 | number of server processes to use for parallel recovery |
| recyclebin | on | recyclebin processing |
| redo_transport_user | Data Guard transport user when using password file | |
| remote_dependencies_mode | TIMESTAMP | remote-procedure-call dependencies mode parameter |
| remote_listener | remote listener | |
| remote_login_passwordfile | EXCLUSIVE | password file usage parameter |
| remote_os_roles | FALSE | allow non-secure remote clients to use os roles |
| remote_recovery_file_dest | default remote database recovery file location for refresh/relocate | |
| replication_dependency_tracking | TRUE | tracking dependency for Replication parallel propagation |
| resource_limit | TRUE | master switch for resource limit |
| resource_manage_goldengate | FALSE | goldengate resource manager enabled |
| resource_manager_cpu_allocation | 0 | Resource Manager CPU allocation |
| resource_manager_cpu_scope | INSTANCE_ONLY | scope of CPU resource management |
| resource_manager_plan | SCHEDULER[0x52C4]:DEFAULT_MAINTENANCE_PLAN | resource mgr top plan |
| result_cache_execution_threshold | 2 | minimum executions before a PL/SQL function is cached |
| result_cache_max_result | 5 | maximum result size as percent of cache size |
| result_cache_max_size | 12058624 | maximum amount of memory to be used by the cache |
| result_cache_max_temp_result | 5 | maximum temp per result as percent of total temp for result cache |
| result_cache_max_temp_size | 120586240 | maximum amount of temp space to be used |
| result_cache_mode | MANUAL | result cache operator usage mode |
| result_cache_remote_expiration | 0 | maximum life time (min) for any result using a remote object |
| resumable_timeout | 0 | set resumable_timeout |
| rollback_segments | undo segment list | |
| scheduler_follow_pdbtz | FALSE | Make scheduler objects follow PDB TZ |
| sec_max_failed_login_attempts | 3 | maximum number of failed login attempts on a connection |
| sec_protocol_error_further_action | (DROP,3) | TTC protocol error continue action |
| sec_protocol_error_trace_action | TRACE | TTC protocol error action |
| sec_return_server_release_banner | FALSE | whether the server retruns the complete version information |
| serial_reuse | disable | reuse the frame segments |
| service_names | orcl21c | service names supported by the instance |
| session_cached_cursors | 50 | Number of cursors to cache in a session. |
| session_max_open_files | 10 | maximum number of open files allowed per session |
| sessions | 504 | user and system sessions |
| sga_max_size | 2399141888 | max total SGA size |
| sga_min_size | 0 | Minimum, guaranteed size of PDB's SGA |
| sga_target | 2399141888 | Target size of SGA |
| shadow_core_dump | partial | Core Size for Shadow Processes |
| shard_queries_restricted_by_key | FALSE | add shard key predicates to the query |
| shared_memory_address | 0 | SGA starting address (low order 32-bits on 64-bit platforms) |
| shared_pool_reserved_size | 46976204 | size in bytes of reserved area of shared pool |
| shared_pool_size | 0 | size in bytes of shared pool |
| shared_server_sessions | max number of shared server sessions | |
| shared_servers | 1 | number of shared servers to start up |
| shrd_dupl_table_refresh_rate | 60 | duplicated table refresh rate (in seconds) |
| skip_unusable_indexes | TRUE | skip unusable indexes if set to TRUE |
| smtp_out_server | utl_smtp server and port configuration parameter | |
| sort_area_retained_size | 0 | size of in-memory sort work area retained between fetch calls |
| sort_area_size | 65536 | size of in-memory sort work area |
| spatial_vector_acceleration | TRUE | enable spatial vector acceleration |
| spfile | /u01/app/oracle/dbs/spfileorcl21c.ora | server parameter file |
| sql92_security | TRUE | require select privilege for searched update/delete |
| sql_trace | FALSE | enable SQL trace |
| sqltune_category | DEFAULT | Category qualifier for applying hintsets |
| ssl_wallet | ssl_wallet | |
| standby_db_preserve_states | NONE | Preserve state cross standby role transition |
| standby_file_management | MANUAL | if auto then files are created/dropped automatically on standby |
| standby_pdb_source_file_dblink | database link to standby source files | |
| standby_pdb_source_file_directory | standby source file directory location | |
| star_transformation_enabled | FALSE | enable the use of star transformation |
| statistics_level | TYPICAL | statistics level |
| streams_pool_size | 0 | size in bytes of the streams pool |
| tablespace_encryption_default_algorithm | AES128 | default tablespace encryption block cipher mode |
| tape_asynch_io | TRUE | Use asynch I/O requests for tape devices |
| target_pdbs | 4 | Parameter is a hint to adjust certain attributes of the CDB |
| tde_configuration | Per-PDB configuration for Transparent Data Encryption | |
| tde_key_cache | FALSE | Enable caching of TDE intermediate key |
| temp_undo_enabled | FALSE | is temporary undo enabled |
| thread | 0 | Redo thread to mount |
| threaded_execution | FALSE | Threaded Execution Mode |
| timed_os_statistics | 0 | internal os statistic gathering interval in seconds |
| timed_statistics | TRUE | maintain internal timing statistics |
| timezone_version_upgrade_online | FALSE | enable/disable time zone version upgrade online |
| trace_enabled | TRUE | enable in memory tracing |
| tracefile_identifier | trace file custom identifier | |
| transactions | 554 | max. number of concurrent active transactions |
| transactions_per_rollback_segment | 5 | number of active transactions per rollback segment |
| undo_management | AUTO | instance runs in SMU mode if TRUE, else in RBU mode |
| undo_retention | 900 | undo retention in seconds |
| undo_tablespace | UNDOTBS1 | use/switch undo tablespace |
| unified_audit_common_systemlog | Syslog facility and level for only common unified audit records | |
| unified_audit_systemlog | Syslog facility and level for Unified Audit | |
| uniform_log_timestamp_format | TRUE | use uniform timestamp formats vs pre-12.2 formats |
| use_dedicated_broker | FALSE | Use dedicated connection broker |
| use_large_pages | TRUE | Use large pages if available (TRUE/FALSE/ONLY) |
| user_dump_dest | /u01/app/oracle/homes/OraDB21Home1/rdbms/log | User process dump directory |
| wallet_root | wallet root instance initialization parameter | |
| workarea_size_policy | AUTO | policy used to size SQL working areas (MANUAL/AUTO) |
| xml_db_events | enable | are XML DB events enabled |
Double-Underscore(__)) parameters in 21c:
Double Underscore parameters are memory snapsnot values in current database, and allow database to restore previous self-tuned values across database restart.
SELECT /*+ use_hash(x y) */
ksppinm name,
ksppstvl value,
ksppdesc description
FROM
x$ksppi x,
x$ksppcv y
WHERE
( x.indx = y.indx )
AND bitand(ksppiflg, 268435456) = 0
AND ksppinm like '\_\_%' escape '\'
ORDER BY ksppinm;
| name | value | description |
|---|---|---|
| __asm_max_connected_clients | 3 | The high water mark value for connected clients |
| __data_transfer_cache_size | 0 | Actual size of data transfer cache |
| __db_16k_cache_xmem_size_metadata | 0 | Size of extended cache metadata for 16k buffer pool |
| __db_2k_cache_xmem_size_metadata | 0 | Size of extended cache metadata for 2k buffer pool |
| __db_32k_cache_xmem_size_metadata | 0 | Size of extended cache metadata for 32k buffer pool |
| __db_4k_cache_xmem_size_metadata | 0 | Size of extended cache metadata for 4k buffer pool |
| __db_8k_cache_xmem_size_metadata | 0 | Size of extended cache metadata for 8k buffer pool |
| __db_cache_size | 1056964608 | Actual size of DEFAULT buffer pool for standard block size buffers |
| __db_cache_xmem_size_metadata | 0 | Size of extended memory metadata of DEFAULT buffer pool for standard block size buffers |
| __db_keep_cache_xmem_size_metadata | 0 | Size of extended cache metadata of KEEP buffer pool for standard block size buffers |
| __db_pmem_direct_map_size_metadata | 0 | Size of PMEM memory metadata of DEFAULT buffer pool for standard block size buffers |
| __db_recycle_cache_xmem_size_metadata | 0 | Size of extended memory metadata of recycle buffer pool for standard block size buffers |
| __dg_broker_service_names | service names for broker use | |
| __inmemory_ext_roarea | 0 | Actual size in bytes of inmemory ro extension area |
| __inmemory_ext_rwarea | 0 | Actual size in bytes of inmemory rw extension area |
| __java_pool_size | 150994944 | Actual size in bytes of java pool |
| __large_pool_size | 16777216 | Actual size in bytes of large pool |
| __latch_test_param | 0 | latch test parameter |
| __maintenance_is_planned | 0 | Is maintenance scheduled soon? |
| __memoptimize_xmem_pool_size_metadata | 0 | Size of extended cache metadata of MEMOPTIMIZE buffer pool for standard block size buffers |
| __oracle_base | /u01/app/oracle | ORACLE_BASE |
| __persistent_cl2_slave_size | 0 | Actual size of slave cluster flash cache for default block size |
| __pga_aggregate_target | 805306368 | Current target size for the aggregate PGA memory consumed |
| __reload_lsnr | 0 | reload listener |
| __sess_template_test_attrs | FALSE | session template: include test attributes |
| __sga_current_size | 0 | Current size for PDB SGA |
| __sga_target | 2399141888 | Actual size of SGA |
| __shared_io_pool_size | 117440512 | Actual size of shared IO pool |
| __shared_pool_size | 1006632960 | Actual size in bytes of shared pool |
| __streams_pool_size | 33554432 | Actual size in bytes of streams pool |
| __unified_pga_pool_size | 0 | Actual size in bytes of unified pga pool |
| __wait_test_param | 0 | wait test parameter |
No comments:
Post a Comment