Oracle11g版本中未归档隐藏参数

In this post, I will give a list of all undocumented parameters in Oracle 11g. Here is a query to see all the parameters (documented and undocumented) which contain the string you enter when prompted:

– Enter name of the parameter when prompted

SET linesize 235
col Parameter FOR a50
col SESSION FOR a28
col Instance FOR a55
col S FOR a1
col I FOR a1
col D FOR a1
col Description FOR a90

SELECT 
  a.ksppinm  "Parameter",
  decode(p.isses_modifiable,'FALSE',NULL,NULL,NULL,b.ksppstvl) "Session",
  c.ksppstvl "Instance",
  decode(p.isses_modifiable,'FALSE','F','TRUE','T') "S",
  decode(p.issys_modifiable,'FALSE','F','TRUE','T','IMMEDIATE','I','DEFERRED','D') "I",
  decode(p.isdefault,'FALSE','F','TRUE','T') "D",
  a.ksppdesc "Description"
FROM x$ksppi a, x$ksppcv b, x$ksppsv c, v$parameter p
WHERE a.indx = b.indx AND a.indx = c.indx
  AND p.name(+) = a.ksppinm
  AND UPPER(a.ksppinm) LIKE UPPER('%&1%')
ORDER BY a.ksppinm;

Enter value for 1: 
Here is the list of all undocumented parameters in Oracle 11g  :
PARAMETER NAME PARAMETER VALUE DESCRIPTION
_4031_dump_bitvec67194879bitvec to specify dumps prior to 4031 error
_4031_dump_interval300Dump 4031 error once for each n-second interval
_4031_max_dumps100Maximum number of 4031 dumps for this process
_4031_sga_dump_interval3600Dump 4031 SGA heapdump error once for each n-second interval
_4031_sga_max_dumps10Maximum number of SGA heapdumps
_NUMA_instance_mappingNot specifiedSet of nodes that this instance should run on
_NUMA_pool_sizeNot specifiedaggregate size in bytes of NUMA pool
_PX_use_large_poolFALSEUse Large Pool as source of PX buffers
_UTL_FILE_FOLLOW_SYMLINKSFALSEUTL_FILE backout event which allows UTL_FILE to open symlinks
__db_cache_size314572800Actual size of DEFAULT buffer pool for standard block size buffers
__dg_broker_service_namespdb11_XPTservice names for broker use
__java_pool_size20971520Actual size in bytes of java pool
__large_pool_size4194304Actual size in bytes of large pool
__oracle_base/u01/app/oracleORACLE_BASE
__pga_aggregate_target209715200Current target size for the aggregate PGA memory consumed
__sga_target629145600Actual size of SGA
__shared_io_pool_size0Actual size of shared IO pool
__shared_pool_size281018368Actual size in bytes of shared pool
__streams_pool_size0Actual size in bytes of streams pool
_abort_recovery_on_joinFALSEif TRUE, abort recovery on join reconfigurations
_accept_versions List of parameters for rolling operation
_active_standby_fast_reconfigurationTRUEif TRUE optimize dlm reconfiguration for active/standby OPS
_adaptive_direct_readTRUEAdaptive Direct Read
_adaptive_fetch_enabledTRUEenable/disable adaptive fetch in parallel group by
_add_col_optim_enabledTRUEAllows new add column optimization
_add_stale_mv_to_dependency_listTRUEadd stale mv to dependency list
_addm_auto_enableTRUEgoverns whether ADDM gets run automatically after every AWR snapshot
_addm_skiprules comma-separated list of ADDM nodes to skip
_addm_version_checkTRUEgoverns whether ADDM checks the input AWR snapshot version
_adjust_literal_replacementFALSEIf TRUE, we will adjust the SQL/PLUS output
_affinity_onTRUEenable/disable affinity at run time
_aiowait_timeouts100Number of aiowait timeouts before error is reported
_alert_expiration604800seconds before an alert message is moved to exception queue
_alert_message_cleanup1Enable Alert Message Cleanup
_alert_message_purge1Enable Alert Message Purge
_alert_post_background1Enable Background Alert Posting
_all_shared_dblinks treat all dblinks as shared
_allocate_creation_orderFALSEshould files be examined in creation order during allocation
_allocation_update_interval3interval at which successful search in L1 should be updated
_allow_commutativityTRUEallow for commutativity of +, * when comparing expressions
_allow_drop_snapshot_standby_grspFALSEAllow dropping snapshot standby guaranteed restore point
_allow_error_simulationFALSEAllow error simulation for testing
_allow_level_without_connect_byFALSEallow level without connect by
_allow_read_only_corruptionFALSEallow read-only open even if database is corrupt
_allow_resetlogs_corruptionFALSEallow resetlogs even if it will cause corruption
_allow_sage_attrTRUEAllow checking Disk Group SAGE Attr
_allow_terminal_recovery_corruptionFALSEFinish terminal recovery even if it may cause corruption
_alternate_iot_leaf_block_split_pointsTRUEenable alternate index-organized table leaf-block split-points
_always_anti_joinCHOOSEalways use this method for anti-join when possible
_always_semi_joinCHOOSEalways use this method for semi-join when possible
_always_star_transformationFALSEalways favor use of star transformation
_app_ctx_versFALSEenable app ctx versioning
_aq_tm_scanlimit0scan limit for Time Managers to clean up IOT
_arch_corrupted_redo_log0Variable to simulate corruption errors during archivals
_arch_io_slaves0ARCH I/O slaves
_array_update_vector_read_enabledFALSEEnable array update vector read
_ash_disk_filter_ratio10Ratio of the number of in-memory samples to the number of samples actually written to disk
_ash_disk_write_enableTRUETo enable or disable Active Session History flushing
_ash_dummy_test_param0Oracle internal dummy ASH parameter used ONLY for testing!
_ash_eflush_trigger66The percentage above which if the in-memory ASH is full the emergency flusher will be triggered
_ash_enableTRUETo enable or disable Active Session sampling and flushing
_ash_min_mmnl_dump90Minimum Time interval passed to consider MMNL Dump
_ash_sample_allFALSETo enable or disable sampling every connected session including ones waiting for idle waits
_ash_sampling_interval1000Time interval between two successive Active Session samples in millisecs
_ash_size1048618To set the size of the in-memory Active Session History buffers
_asm_acd_chunks1initial ACD chunks created
_asm_allow_only_raw_disksTRUEDiscovery only raw devices
_asm_allow_resilver_corruptionFALSEEnable disk resilvering for external redundancy
_asm_ausize1048576allocation unit size
_asm_blksize4096metadata block size
_asm_compatibility10.1default ASM compatibility level
_asm_dbmsdg_nohdrchkFALSEdbms_diskgroup.checkfile does not check block headers
_asm_disk_repair_time14400seconds to wait before dropping a failing disk
_asm_emulmax10000max number of concurrent disks to emulate I/O errors
_asm_emultimeout0timeout before emulation begins (in 3s ticks)
_asm_kfdpevent0KFDP event
_asm_kfioevent0KFIO event
_asm_librariesufslibrary search order for discovery
_asm_maxio1048576Maximum size of individual I/O request
_asm_repairquantum60quantum (in 3s) used to compute elapsed time for disk drop
_asm_runtime_capability_volume_supportFALSEruntime capability for volume support returns supported
_asm_skip_resize_checkFALSEskip the checking of the clients for s/w compatibility for resize
_asm_stripesize131072ASM file stripe size
_asm_stripewidth8ASM file stripe width
_asm_wait_time18Max/imum time to wait before asmb exits
_asmlib_test0Osmlib test event
_asmsidasmASM instance id
_assm_defaultTRUEASSM default
_async_recovery_claimsTRUEif TRUE, issue recovery claims asynchronously
_async_recovery_readsTRUEif TRUE, issue recovery reads asynchronously
_async_ts_threshold1check tablespace thresholds asynchronously
_auto_assign_cg_for_sessionsFALSEauto assign CGs for sessions
_automatic_maintenance_test0Enable AUTOTASK Test Mode
_automemory_broker_interval3memory broker statistics gathering interval for auto memory
_autotask_max_window480Maximum Logical Maintenance Window Length in minutes
_autotask_min_window15Minimum Maintenance Window Length in minutes
_autotune_gtx_idle_time600idle time to trigger auto-shutdown a gtx background process
_autotune_gtx_interval5interval to autotune global transaction background processes
_autotune_gtx_threshold60auto-tune threshold for degree of global transaction concurrency
_avoid_prepareTRUEif TRUE, do not prepare a buffer when the master is local
_aw_row_source_enabledTRUEEnables AW Row Source instead of collection iterator
_awr_corrupt_modeFALSEAWR Corrupt Mode
_awr_disabled_flush_tables Disable flushing of specified AWR tables
_awr_flush_threshold_metricsTRUEEnable/Disable Flushing AWR Threshold Metrics
_awr_flush_workload_metricsFALSEEnable/Disable Flushing AWR Workload Metrics
_awr_mmon_cpuusageTRUEEnable/disable AWR MMON CPU Usage Tracking
_awr_restrict_modeFALSEAWR Restrict Mode
_awr_sql_child_limit200Setting for AWR SQL Child Limit
_b_tree_bitmap_plansTRUEenable the use of bitmap plans for tables even when  the tables only have B-tree indexes
_backup_disk_io_slaves0BACKUP Disk I/O slaves
_backup_encrypt_opt_mode4294967294specifies encryption block optimization mode
_backup_io_pool_size1048576memory to reserve from the large pool
_backup_kgc_bufsz0specifies buffer size to be used by BZIP2 compression
_backup_kgc_memlevel8specifies memory level for ZLIB compression
_backup_kgc_niters0specifies number of iterations done by BZIP2 compression
_backup_kgc_perflevel1specifies compression (performance) level for ZLIB compression
_backup_kgc_schemeZLIBspecifies compression scheme
_backup_kgc_type0specifies compression type used by kgc BZIP2 compression
_backup_kgc_windowbits15specifies window size for ZLIB compression
_backup_ksfq_bufcnt0number of the ksfq buffers used for backup/restore
_backup_ksfq_bufcnt_max0maximum number of the ksfq buffer used for backup/restore
_backup_ksfq_bufsz0size of the ksfq buffer used for backup/restore
_backup_max_gap_size4294967294largest gap in an incremental/optimized backup buffer, in bytes
_bct_bitmaps_per_file8number of bitmaps to store for each datafile
_bct_buffer_allocation_max104857600maximum size of all change tracking buffer allocations, in bytes
_bct_buffer_allocation_min_extents1mininum number of extents to allocate per buffer allocation
_bct_buffer_allocation_size2097152size of one change tracking buffer allocation, in bytes
_bct_chunk_size0change tracking datafile chunk size, in bytes
_bct_crash_reserve_size262144change tracking reserved crash recovery SGA space, in bytes
_bct_file_block_size0block size of change tracking file, in bytes
_bct_file_extent_size0extent size of change tracking file, in bytes
_bct_fixtab_file change tracking file for fixed tables
_bct_initial_private_dba_buffer_size0initial number of entries in the private change tracking dba buffers
_bct_public_dba_buffer_size0total size of all public change tracking dba buffers, in bytes
_bitmap_or_improvement_enabledTRUEcontrols extensions to partition pruning for general predicates
_block_change_trackingTRUEchange tracking possible
_blocking_sess_graph_cache_size blocking session graph cache size in bytes
_blocks_per_cache_server64number of consecutive blocks per global cache server
_bloom_filter_debug0debug level for bloom filtering
_bloom_filter_enabledTRUEenables or disables bloom filter
_bloom_predicate_enabledFALSEenables or disables bloom filter predicate pushdown
_bloom_pruning_enabledTRUEEnable partition pruning using bloom filtering
_bloom_vector_elements0number of elements in a bloom filter vector
_bsln_adaptive_thresholds_enabledTRUEAdaptive Thresholds Enabled
_bt_mmv_query_rewrite_enabledTRUEallow rewrites with multiple MVs and base tables
_buffer_busy_wait_timeout100buffer busy wait time in centiseconds
_buffered_publisher_flow_control_threshold0Flow control threshold for buffered publishers except capture
_bufq_stop_flow_controlFALSEStop enforcing flow control for buffered queues
_build_deferred_mv_skipping_mvlog_updateFALSEDEFERRED MV creation skipping MV log setup update
_bump_highwater_mark_count0how many blocks should we allocate per free list on advancing HWM
_bwr_for_flushed_piTRUEif TRUE, generate a BWR for a flushed PI
_cache_stats_monitorFALSEif TRUE, enable cache stats monitoring
_capture_buffer_size65536To set the size of the PGA I/O recording buffers
_capture_publisher_flow_control_threshold0Flow control threshold for capture publishers
_case_sensitive_logonTRUEcase sensitive logon enabled
_cgs_reconfig_timeout1000CGS reconfiguration timeout interval
_cgs_send_timeout300CGS send timeout value
_cgs_tickets1000CGS messaging tickets
_check_block_after_checksumTRUEperform block check after checksum if both are turned on
_check_block_new_invariant_for_flashbackFALSEcheck block new invariant for flashback
_check_ts_threshold0check tablespace thresholds
_cleanup_rollback_entries100no. of undo entries to apply per transaction cleanup
_client_result_cache_bypassFALSEbypass the client result cache
_close_cached_open_cursorsFALSEclose cursors cached by PL/SQL at each commit
_cluster_libraryclsscluster library selection
_clusterwide_global_transactionsTRUEenable/disable clusterwide global transactions
_collapse_wait_historyFALSEcollapse wait history
_collect_undo_statsTRUECollect Statistics v$undostat
_column_compression_factor0Column compression ratio
_column_elimination_offFALSEturn off predicate-only column elimination
_column_tracking_level1column usage tracking
_compilation_call_heap_extent_size16384Size of the compilation call heaps extents
_complex_view_mergingTRUEenable complex view merging
_compression_above_cache0number of recompression above cache for sanity check
_compression_advisor0Compression advisor
_compression_chain50percentage of chained rows allowed for Compression
_controlfile_block_size0control file block size in bytes
_controlfile_enqueue_dumpFALSEdump the system states after controlfile enqueue timeout
_controlfile_enqueue_holding_time780control file enqueue max holding time in seconds
_controlfile_enqueue_timeout900control file enqueue timeout in seconds
_controlfile_section_init_size control file initial section size
_controlfile_section_max_expand control file max expansion rate
_controlfile_update_checkOFFcontrolfile update sanity check
_convert_set_to_joinFALSEenables conversion of set operator to join
_coord_message_buffer0parallel recovery coordinator side extra message buffer size
_corrupted_rollback_segments corrupted undo segment list
_cost_equality_semi_joinTRUEenables costing of equality semi-join
_cp_num_hash_latches1connection pool number of hash latches
_cpu_to_io0divisor for converting CPU cost to I/O cost
_cr_grant_global_roleTRUEif TRUE, grant lock for CR requests when block is in global role
_cr_grant_local_roleAUTOturn 3-way CR grants off, make it automatic, or turn it on
_cr_server_log_flushTRUEif TRUE, flush redo log before serving a CR buffer
_cursor_bind_capture_area_size400maximum size of the cursor bind capture area
_cursor_bind_capture_interval900interval (in seconds) between two bind capture for a cursor
_cursor_db_buffers_pinned178additional number of buffers a cursor can pin at once
_cursor_features_enabled2Shared cursor features enabled bits.
_cursor_plan_enabledTRUEenable collection and display of cursor plans
_cursor_plan_hash_version1version of cursor plan hash value
_cursor_plan_unparse_enabledTRUEenables/disables using unparse to build projection/predicates
_cursor_stats_bucket15Hash table buckets for cursor stats (2^).
_cursor_stats_heap4Heaps/latches for cursor stats.
_cvw_enable_weak_checkingTRUEenable weak view checking
_db_aging_cool_count1Touch count set when buffer cooled
_db_aging_freeze_crFALSEMake CR buffers always be too cold to keep in cache
_db_aging_hot_criteria2Touch count which sends a buffer to head of replacement list
_db_aging_stay_count0Touch count set when buffer moved to head of replacement list
_db_aging_touch_time3Touch count which sends a buffer to head of replacement list
_db_always_check_system_tsTRUEAlways perform block check and checksum for System tablespace
_db_block_adjcheckTRUEadjacent cache buffer checks – low blkchk overwrite parameter
_db_block_adjchk_level0adjacent cache buffer check level
_db_block_align_direct_readTRUEAlign Direct Reads
_db_block_bad_write_checkFALSEenable bad write checks
_db_block_buffers27060Number of database blocks cached in memory: hidden parameter
_db_block_cache_cloneFALSEAlways clone data blocks on get (for debugging)
_db_block_cache_history0buffer header tracing (non-zero only when debugging)
_db_block_cache_history_level2buffer header tracing level
_db_block_cache_num_umap0number of unmapped buffers (for tracking swap calls on blocks)
_db_block_cache_protectFALSEprotect database blocks (true only when debugging)
_db_block_cache_protect_internal0protect database blocks (for strictly internal use only)
_db_block_check_for_debugFALSECheck more and dump block before image for debugging
_db_block_check_objtypTRUEcheck objd and typ on cache disk read
_db_block_corruption_recovery_threshold5threshold number of block recovery attempts
_db_block_do_full_mbreadsFALSEdo full block read even if some blocks are in cache
_db_block_hash_buckets65536Number of database block hash buckets
_db_block_hash_latches2048Number of database block hash latches
_db_block_header_guard_level0number of extra buffer headers to use as guard pages
_db_block_hi_priority_batch_size0Fraction of writes for high priority reasons
_db_block_known_clean_pct2Initial Percentage of buffers to maintain known clean
_db_block_lru_latches8number of lru latches
_db_block_max_cr_dba6Maximum Allowed Number of CR buffers per dba
_db_block_max_scan_pct40Percentage of buffers to inspect when looking for free
_db_block_med_priority_batch_size0Fraction of writes for medium priority reasons
_db_block_numa1Number of NUMA nodes
_db_block_prefetch_fast_longjumps_enabledTRUEBatched IO enable fast longjumps
_db_block_prefetch_limit0Prefetch limit in blocks
_db_block_prefetch_override0Prefetch force override in blocks
_db_block_prefetch_private_cache_enabledTRUEBatched IO enable private cache
_db_block_prefetch_quota10Prefetch quota as a percent of cache size
_db_block_prefetch_skip_reading_enabledTRUEBatched IO enable skip reading buffers
_db_block_table_scan_buffer_size4194304Size of shared table scan read buffer
_db_block_temp_redoFALSEgenerate redo for temp blocks
_db_block_trace_protectFALSEtrace buffer protect calls
_db_block_vlm_checkFALSEcheck of rvlm mapping leaks (for debugging)
_db_block_vlm_leak_threshold3Threshold for allowable vlm leaks
_db_blocks_per_hash_latch Number of blocks per hash latch
_db_cache_advice_batch_size128cache advisory simulation batch size
_db_cache_advice_sample_factor4cache advisory sampling factor
_db_cache_crx_checkFALSEcheck for costly crx examination functions
_db_cache_pre_warmTRUEBuffer Cache Pre-Warm Enabled : hidden parameter
_db_cache_process_cr_pin_max maximum number of cr pins a process may have
_db_change_notification_enableTRUEenable db change notification
_db_disable_temp_encryptionFALSEDiable Temp Encryption for Spills
_db_fast_obj_checkFALSEenable fast object drop sanity check
_db_fast_obj_ckptTRUEenable fast object checkpoint
_db_fast_obj_truncateTRUEenable fast object truncate
_db_file_direct_io_count1048576Sequential I/O buf size
_db_file_exec_read_count128multiblock read count for regular clients
_db_file_format_io_buffers4Block formatting I/O buf count
_db_file_noncontig_mblock_read_count11number of noncontiguous db blocks to be prefetched
_db_file_optimizer_read_count8multiblock read count for regular clients
_db_handles750System-wide simultaneous buffer operations
_db_handles_cached5Buffer handles cached each process
_db_hot_block_trackingFALSEtrack hot blocks for hash latch contention
_db_index_block_checkingTRUEindex block checking override parameter
_db_large_dirty_queue25Number of buffers which force dirty queue to be written
_db_lost_write_checkingFALSEEnable scn based lost write detection mechanism
_db_mttr_adviceONMTTR advisory
_db_mttr_partitions0number of partitions for MTTR advisory
_db_mttr_sample_factor64MTTR simulation sampling factor
_db_mttr_sim_target MTTR simulation targets
_db_mttr_sim_trace_size256MTTR simulation trace size
_db_mttr_trace_to_alertFALSEdump trace entries to alert file
_db_noarch_disble_optimFALSEImage redo logging (NOARCHIVEMODE)
_db_num_evict_waitevents64number of evict wait events
_db_obj_enable_ksrTRUEenable ksr in object checkpoint/reuse
_db_percent_hot_default50Percent of default buffer pool considered hot
_db_percent_hot_keep0Percent of keep buffer pool considered hot
_db_percent_hot_recycle0Percent of recycle buffer pool considered hot
_db_percpu_create_cachesize2size of cache created per cpu in deferred cache create
_db_recovery_temporal_file_dest default database recovery temporal file location
_db_required_percent_fairshare_usage10percent of fairshare a processor group should always use
_db_row_overlap_checkingTRUErow overlap checking override parameter for data/index blocks
_db_todefer_cache_createTRUEbuffer cache deferred create
_db_writer_chunk_writes0Number of writes DBWR should wait for
_db_writer_coalesce_area_size2293760Size of memory allocated to dbwriter for coalescing writes
_db_writer_coalesce_write_limit131072Limit on size of coalesced write
_db_writer_flush_imuTRUEIf FALSE, DBWR will not downgrade IMU txns for AGING
_db_writer_histogram_statisticsFALSEmaintain dbwr histogram statistics in x$kcbbhs
_db_writer_max_writes0Max number of outstanding DB Writer IOs
_db_writer_nomemcopy_coalesceFALSEEnable DBWR no-memcopy coalescing
_db_writer_verify_writesFALSEEnable lost write detection mechanism
_dbg_proc_startupFALSEdebug process startup
_dbms_sql_security_level1Security level in DBMS_SQL
_dbwr_async_ioTRUEEnable dbwriter asynchronous writes
_dbwr_scan_interval300dbwriter scan interval
_dbwr_tracing0Enable dbwriter tracing
_dde_flood_control_initTRUEInitialize Flood Control at database open
_dead_process_scan_interval60PMON dead process scan interval
_deadlock_diagnostic_level2automatic deadlock resolution diagnostics level
_deadlock_resolution_incidents_enabledTRUEcreate incidents during deadlock resolution
_deadlock_resolution_level1automatic deadlock resolution level
_deadlock_resolution_min_wait_timeout_secs60the minimum wait timeout required for deadlock resolution
_deadlock_resolution_signal_process_thresh_secs60the amount of time given to process a deadlock resolution signal
_dedicated_server_poll_count10dedicated server poll count
_dedicated_server_post_waitFALSEdedicated server post/wait
_dedicated_server_post_wait_callFALSEdedicated server post/wait call
_default_encrypt_alg0default encryption algorithm
_default_non_equality_sel_checkTRUEsanity check on default selectivity for like/range predicate
_defer_log_boundary_ckptTRUEdefer media recovery checkpoint at log boundary
_defer_log_count2Number of log boundaries media recovery checkpoint lags behind
_delay_index_maintainTRUEdelays index maintenance until after MV is refreshed
_desired_readmem_rate70The desired percentage of redo reading from memory
_diag_adr_auto_purgeTRUEEnable/disable ADR MMON Auto Purging
_diag_adr_enabledTRUEParameter to enable/disable Diag ADR
_diag_adr_test_param0Test parameter for Diagnosability
_diag_backward_compatTRUEBackward Compatibility for Diagnosability
_diag_cc_enabledTRUEParameter to enable/disable Diag Call Context
_diag_conf_cap_enabledTRUEParameter to enable/disable Diag Configuration Capture
_diag_daemonTRUEstart DIAG daemon
_diag_dde_async_age_limit300diag dde async actions: message age limit (in seconds)
_diag_dde_async_cputime_limit300diag dde async actions: action cputime limit (in seconds)
_diag_dde_async_mode1diag dde async actions: dispatch mode
_diag_dde_async_msg_capacity1024diag dde async actions: message buffer capacity
_diag_dde_async_msgs50diag dde async actions: number of preallocated message buffers
_diag_dde_async_process_rate5diag dde async actions: message processing rate – per loop
_diag_dde_async_runtime_limit900diag dde async actions: action runtime limit (in seconds)
_diag_dde_async_slaves5diag dde async actions: max number of concurrent slave processes
_diag_dde_enabledTRUEenable DDE handling of critical errors
_diag_dde_fc_enabledTRUEParameter to enable/disable Diag Flood Control
_diag_dde_fc_implicit_time0Override Implicit Error Flood Control time parameter
_diag_dde_fc_macro_time0Override Macro Error Flood Control time parameter
_diag_dde_inc_proc_delay1The minimum delay between two MMON incident sweeps (minutes)
_diag_diagnosticsTRUETurn off diag diagnostics
_diag_dump_timeout30timeout parameter for SYNC dump
_diag_hm_rc_enabledTRUEParameter to enable/disable Diag HM Reactive Checks
_diag_hm_tc_enabledFALSEParameter to enable/disable Diag HM Test(dummy) Checks
_diag_uts_control0UTS control parameter
_dimension_skip_nullTRUEcontrol dimension skip when null feature
_direct_path_insert_features0disable direct path insert features
_disable_12751FALSEdisable policy timeout error (ORA-12751)
_disable_adaptive_shrunk_aggregationFALSEadaptive shrunk aggregation
_disable_autotune_gtxFALSEdisable autotune global transaction background processes
_disable_datalayer_samplingFALSEdisable datalayer sampling
_disable_duplex_linkTRUETurn off connection duplexing
_disable_fast_aggregationFALSEfast aggregation
_disable_fast_validateFALSEdisable PL/SQL fast validation
_disable_fastopenFALSEDo Not Use Fastopen
_disable_fba_qrw0disable flashback archiver query rewrite
_disable_fba_wpr0disable flashback archiver wait for prepared transactions
_disable_file_locksFALSEdisable file locks for control, data, redo log files
_disable_flashback_archiver0disable flashback archiver
_disable_flashback_wait_callbackFALSEDisable flashback wait callback
_disable_function_based_indexFALSEdisable function-based index matching
_disable_health_checkFALSEDisable Health Check
_disable_highres_ticksFALSEdisable high-res tick counter
_disable_image_checkFALSEDisable Oracle executable image checking
_disable_incremental_checkpointsFALSEDisable incremental checkpoints for thread recovery
_disable_incremental_recovery_ckptFALSEDisable incremental recovery checkpoint mechanism
_disable_index_block_prefetchingFALSEdisable index block prefetching
_disable_instance_params_checkFALSEdisable instance type check for ksp
_disable_interface_checkingFALSEdisable interface checking at startup
_disable_kcb_flashback_blocknew_optFALSEDisable KCB flashback block new optimization
_disable_kcbhxor_osdFALSEdisable kcbh(c)xor OSD functionality
_disable_kcbl_flashback_blocknew_optFALSEDisable KCBL flashback block new optimization
_disable_latch_free_SCN_writes_via_32casFALSEdisable latch-free SCN writes using 32-bit compare & swap
_disable_latch_free_SCN_writes_via_64casFALSEdisable latch-free SCN writes using 64-bit compare & swap
_disable_loggingFALSEDisable logging
_disable_metrics_group0Disable Metrics Group (or all Metrics Groups)
_disable_multiple_block_sizesFALSEdisable multiple block size support (for debugging)
_disable_odmFALSEdisable odm feature
_disable_parallel_conventional_loadFALSEDisable parallel conventional loads
_disable_read_only_open_dict_checkFALSEDisable read-only open dictionary check
_disable_rebalance_space_checkFALSEdisable space usage checks for storage reconfiguration
_disable_recoverable_recoveryFALSEDisable the new recoverable recovery mechanism
_disable_recovery_read_skipFALSEDisable the read optimization during media recovery
_disable_sample_io_optimFALSEdisable row sampling IO optimization
_disable_savepoint_resetFALSEdisable the fix for bug 1402161
_disable_sec_ticksFALSEdisable low-res (sec) counter
_disable_selftune_checkpointingFALSEDisable self-tune checkpointing
_disable_streams_pool_auto_tuningFALSEdisable streams pool auto tuning
_disable_sun_rsmTRUEDisable IPC OSD support for Sun RSMAPI
_disable_system_state4294967294disable system state dump
_disable_thread_internal_disableFALSEDisable thread internal disable feature
_disable_txn_alert0disable txn layer alert
_disable_vktmFALSEdisable vktm process
_disable_wait_stackFALSEDisable wait stack
_discrete_transactions_enabledFALSEenable OLTP mode
_diskmon_pipe_name DiSKMon skgznp pipe name
_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_view_unnestingFALSEenables unnesting of in subquery into distinct view
_distributed_recovery_connection_hold_time200number of seconds RECO holds outbound connections open
_dlmtrace Trace string of global enqueue type(s)
_dm_max_shared_pool_pct1max percentage of the shared pool to use for a mining model
_dml_monitoring_enabledTRUEenable modification monitoring
_domain_index_batch_size2000maximum number of rows from one call to domain index fetch routine
_domain_index_dml_batch_size200maximum number of rows for one call to domain index dml routines
_dra_bmr_number_threshold1000Maximum number of BMRs that can be done to a file
_dra_bmr_percent_threshold10Maximum percentage of blocks in a file that can be BMR-ed
_dra_enable_offline_dictionaryTRUEEnable the periodic creation of the offline dictionary for DRA
_drop_table_granule256drop_table_granule
_drop_table_optimization_enabledTRUEreduce SGA memory use during drop of a partitioned table
_ds_iocount_iosize6553664Dynamic Sampling Service defaults: #IOs and IO Size
_dss_cache_flushFALSEenable full cache flush for parallel execution
_dtree_area_size131072size of Decision Tree Classification work area
_dtree_binning_enabledTRUEDecision Tree Binning Enabled
_dtree_bintest_id0Decision Tree Binning Test ID
_dtree_compressbmp_enabledTRUEDecision Tree Using Compressed Bitmaps Enabled
_dtree_max_surrogates1maximum number of surrogates
_dtree_pruning_enabledTRUEDecision Tree Pruning Enabled
_dummy_instanceFALSEdummy instance started by RMAN
_dump_common_subexpressionsFALSEdump common subexpressions
_dump_connect_by_loop_dataFALSEdump connect by loop error message into trc file
_dump_cursor_heap_sizesFALSEdump comp/exec heap sizes to tryace file
_dump_interval_limit120trace dump time interval limit (in seconds)
_dump_max_limit5max number of dump within dump interval
_dump_qbc_tree0dump top level query parse tree to trace
_dump_rcvr_ipcTRUEif TRUE enables IPC dump at instance eviction time
_dump_system_state_scopelocalscope of sysstate dump during instance termination
_dump_trace_scopeglobalscope of trace dump during a process crash
_dynamic_rls_policiesTRUErls policies are dynamic
_dynamic_stats_threshold30delay threshold (in seconds) between sending statistics messages
_edition_based_redefinitionFALSEenable edition based redefinition
_eliminate_common_subexprTRUEenables elimination of common sub-expressions
_emon_regular_ntfn_slaves4number of EMON slaves doing regular database notifications
_enable_NUMA_optimizationTRUEEnable NUMA specific optimizations
_enable_automatic_maintenance1if 1, Automated Maintenance Is Enabled
_enable_automatic_sqltuneTRUEAutomatic SQL Tuning Advisory enabled parameter
_enable_block_level_transaction_recoveryTRUEenable block level recovery
_enable_cscn_cachingFALSEenable commit SCN caching for all transactions
_enable_ddl_wait_lockTRUEuse this to turn off ddls with wait semantics
_enable_default_affinity0to enable default implementation of affinity osds
_enable_dml_lock_escalationTRUEenable dml lock escalation against partitioned tables if TRUE
_enable_exchange_validation_using_checkTRUEuse check constraints on the table for validation
_enable_fast_ref_after_mv_tbsFALSEenable fast refresh after move tablespace
_enable_hash_overflowFALSETRUE – enable hash cluster overflow based on SIZE
_enable_hwm_syncTRUEenable HWM synchronization
_enable_list_ioFALSEEnable List I/O
_enable_midtier_affinityTRUEenable midtier affinity metrics processing
_enable_nativenet_tcpipFALSEEnable skgxp driver usage for native net
_enable_obj_queuesTRUEenable object queues
_enable_online_index_without_s_lockingTRUEAllow online index creation algorithm without S DML lock
_enable_query_rewrite_on_remote_objsTRUEmv rewrite on remote table/view
_enable_refresh_scheduleTRUEenable or disable MV refresh scheduling (revert to 9.2 behavior)
_enable_reliable_latch_waitsTRUEEnable reliable latch waits
_enable_rlbTRUEenable RLB metrics processing
_enable_row_shippingTRUEuse the row shipping optimization for wide table selects
_enable_scn_wait_interfaceTRUEuse this to turn off scn wait interface in kta
_enable_separable_transactionsFALSEenable/disable separable transactions
_enable_shared_pool_durationsTRUEtemporary to disable/enable kgh policy
_enable_shared_server_vector_ioFALSEEnable shared server vector I/O
_enable_space_preallocation3enable space pre-allocation
_enable_spacebgTRUEenable space management background task
_enable_tablespace_alertsTRUEenable tablespace alerts
_enable_type_dep_selectivityTRUEenable type dependent selectivity estimates
_endprot_chunk_commentchk 10235 dfltchunk comment for selective overrun protection
_endprot_heap_commenthp 10235 dfltheap comment for selective overrun protection
_endprot_subheapsTRUEselective overrun protection for subeheaps
_enqueue_deadlock_time_sec5requests with timeout <= this will not have deadlock detection
_enqueue_debug_multi_instanceFALSEdebug enqueue multi instance
_enqueue_hash375enqueue hash table length
_enqueue_hash_chain_latches1enqueue hash chain latches
_enqueue_locks2260locks for managed enqueues
_enqueue_resources968resources for enqueues
_evolve_plan_baseline_report_levelTYPICALLevel of detail to show in plan verification/evolution report
_evt_system_event_propagationTRUEdisable system event propagation
_expand_aggregatesTRUEexpand aggregates
_explain_rewrite_modeFALSEallow additional messages to be generated during explain rewrite
_extended_pruning_enabledTRUEdo runtime pruning in iterator if set to TRUE
_fair_remote_cvtFALSEif TRUE enables fair remote convert
_fairness_threshold4number of times to CR serve before downgrading lock
_fast_dual_enabledTRUEenable/disable fast dual
_fast_full_scan_enabledTRUEenable/disable index fast full scan
_fastpin_enable1enable reference count based fast pins
_fbda_busy_percentage0flashback archiver busy percentage
_fbda_inline2_percentage0flashback archiver full inline percentage
_fbda_inline_percentage0flashback archiver inline percentage
_fg_iorm_slaves1ForeGround I/O slaves for IORM
_fg_log_checksumTRUEChecksum redo in foreground process
_fic_algorithm_setautomaticSet Frequent Itemset Counting Algorithm
_fic_area_size131072size of Frequent Itemset Counting work area
_fic_max_length20Frequent Itemset Counting Maximum Itemset Length
_fic_min_bmsize1024Frequent Itemset Counting Minimum BITMAP Size
_fic_outofmem_candidatesFALSEFrequent Itemset Counting Out Of Memory Candidates Generation
_fifth_spare_parameter fifth spare parameter – string
_filemap_dir FILEMAP directory
_first_k_rows_dynamic_prorationTRUEenable the use of dynamic proration of join cardinalities
_first_spare_parameter first spare parameter – integer
_fix_control bug fix control parameter
_flashback_allow_noarchivelogFALSEAllow enabling flashback on noarchivelog database
_flashback_archiver_partition_size0flashback archiver table partition size
_flashback_barrier_interval1800Flashback barrier interval in seconds
_flashback_copy_latches10Number of flashback copy latches
_flashback_format_chunk_mb4Chunk mega-bytes for formatting flashback logs using sync write
_flashback_format_chunk_mb_dwrite16Chunk mega-bytes for formatting flashback logs using delayed write
_flashback_fuzzy_barrierTRUEUse flashback fuzzy barrier
_flashback_generation_buffer_size4194304flashback generation buffer size
_flashback_hint_barrier_percent20Flashback hint barrier percent
_flashback_log_io_error_behavior0Specify Flashback log I/O error behavior
_flashback_log_min_size100Minimum flashback log size
_flashback_log_size1000Flashback log size
_flashback_logfile_enqueue_timeout600flashback logfile enqueue timeout for opens
_flashback_marker_cache_enabledTRUEEnable flashback database marker cache
_flashback_marker_cache_size328Size of flashback database marker cache
_flashback_max_log_size0Maximum flashback log size in bytes (OS limit)
_flashback_max_n_log_per_thread2048Maximum number of flashback logs per flashback thread
_flashback_max_standby_sync_span900Maximum time span between standby recovery sync for flashback
_flashback_n_log_per_thread128Desired number of flashback logs per flashback thread
_flashback_standby_barrier_interval1800Flashback standby barrier interval in seconds
_flashback_verbose_infoFALSEPrint verbose information about flashback database
_flashback_write_max_loop_limit10Flashback writer loop limit before it returns
_force_datefold_truncFALSEforce use of trunc for datefolding rewrite
_force_hsc_compressFALSEcompress all new created tables
_force_oltp_compressFALSEOLTP Compress all new created tables
_force_rewrite_enableFALSEcontrol new query rewrite features
_force_slave_mapping_intra_part_loadsFALSEForce slave mapping for intra partition loads
_force_temptables_for_gsetsFALSEexecutes concatenation of rollups using temp tables
_force_tmp_segment_loadsFALSEForce tmp segment loads
_forwarded_2pc_threshold10auto-tune threshold for two-phase commit rate across RAC instances
_fourth_spare_parameter fourth spare parameter – string
_full_pwise_join_enabledTRUEenable full partition-wise join when TRUE
_gby_hash_aggregation_enabledTRUEenable group-by and aggregation using hash scheme
_gby_onekey_enabledTRUEenable use of one comparison of all group by keys
_gc_affinity_lockingTRUEif TRUE, enable object affinity
_gc_affinity_locksTRUEif TRUE, get affinity locks
_gc_affinity_ratio50dynamic object affinity ratio
_gc_async_memcpyFALSEif TRUE, use async memcpy
_gc_bypass_readersTRUEif TRUE, modifications bypass readers
_gc_check_bscnTRUEif TRUE, check for stale blocks
_gc_coalesce_recovery_readsTRUEif TRUE, coalesce recovery reads
_gc_defer_time3how long to defer down converts for hot buffers
_gc_dissolve_undo_affinityFALSEif TRUE, dissolve undo affinity after an offline
_gc_element_percent110global cache element percent
_gc_global_checkpoint_scnTRUEif TRUE, enable global checkpoint scn
_gc_global_lruAUTOturn global lru off, make it automatic, or turn it on
_gc_initiate_undo_affinityTRUEif TRUE, initiate undo affinity after an online
_gc_integrity_checks1set the integrity check level
_gc_keep_recovery_buffersTRUEif TRUE, make recovery buffers current
_gc_latches8number of latches per LMS process
_gc_long_query_threshold0threshold for long running query
_gc_maximum_bids0maximum number of bids which can be prepared
_gc_policy_minimum1500dynamic object policy minimum activity per minute
_gc_policy_time10how often to make object policy decisions in minutes
_gc_read_mostly_lockingTRUEif TRUE, enable read-mostly locking
_gc_statisticsTRUEif TRUE, kcl statistics are maintained
_gc_transfer_ratio2dynamic object read-mostly transfer ratio
_gc_undo_affinityTRUEif TRUE, enable dynamic undo affinity
_gc_undo_block_disk_readsTRUEif TRUE, enable undo block disk reads
_gc_use_crTRUEif TRUE, allow CR pins on PI and WRITING buffers
_gc_vector_readTRUEif TRUE, vector read current buffers
_gc_voluntary_down_convert_obj0object number for voluntary down-convert
_gcs_fast_reconfigTRUEif TRUE, enable fast reconfiguration for gcs locks
_gcs_latches0number of gcs resource hash latches to be allocated per LMS process
_gcs_process_in_recoveryTRUEif TRUE, process gcs requests during instance recovery
_gcs_res_per_bucket16number of gcs resource per hash bucket
_gcs_resources number of gcs resources to be allocated
_gcs_shadow_locks number of pcm shadow locks to be allocated
_gcs_testing0GCS testing parameter
_generalized_pruning_enabledTRUEcontrols extensions to partition pruning for general predicates
_ges_dd_debug1if 1 or higher enables GES deadlock detection debug diagnostics
_ges_diagnosticsTRUEif TRUE enables GES diagnostics
_ges_health_check1if greater than 0 enables GES system health check
_global_hang_analysis_interval_secs10the interval at which global hang analysis is run
_globalindex_pnum_filter_enabledTRUEenables filter for global index with partition extended syntax
_groupby_nopushdown_cut_ratio3groupby nopushdown cut ratio
_groupby_orderby_combine5000groupby/orderby don’t combine threshold
_gs_anti_semi_join_allowedTRUEenable anti/semi join for the GS query
_hang_analysis_num_call_stacks3hang analysis num call stacks
_hang_detection60Hang Management detection interval
_hang_resolutionFALSEHang Management hang resolution
_hard_protectionFALSEif TRUE enable H.A.R.D specific format changes
_hash_join_enabledTRUEenable/disable hash join
_hash_multiblock_io_count0number of blocks hash join will read/write at once
_heur_deadlock_resolution_secs0the heuristic wait time per node for deadlock resolution
_high_priority_processesLMS*|VKTMHigh Priority Process Name Mask
_high_server_threshold0high server thresholds
_hj_bit_filter_threshold50hash-join bit filtering threshold (0 always enabled)
_hm_analysis_oradebug_node_dump_level0the oradebug node dump level for hang manager hang analysis
_hm_analysis_oradebug_sys_dump_level0the oradebug system state level for hang manager hang analysis
_hm_analysis_output_diskFALSEif TRUE the hang manager outputs hang analysis results to disk
_hm_log_incidentsFALSEHang Manager incident logging
_hm_verification_interval60the hang manager verification interval
_hwm_sync_threshold10HWM synchronization threshold in percentage
_idl_conventional_index_maintenanceTRUEenable conventional index maintenance for insert direct load
_idle_session_kill_enabledTRUEenables or disables resource manager session idle limit checks
_idxrb_rowincr100000000proportionality constant for dop vs. rows in index rebuild
_ignore_desc_in_indexFALSEignore DESC in indexes, sort those columns ascending anyhow
_ignore_fg_deps ignore fine-grain dependencies during invalidation
_immediate_commit_propagationTRUEif TRUE, propagate commit SCN immediately
_improved_outerjoin_cardTRUEimproved outer-join cardinality calculation
_improved_row_length_enabledTRUEenable the improvements for computing the average row length
_imr_activeTRUEActivate Instance Membership Recovery feature
_imr_avoid_double_votingTRUEAvoid device voting for CSS reconfig during IMR
_imr_device_typecontrolfileType of device to be used by IMR
_imr_disk_voting_interval3Maximum wait for IMR disk voting (seconds)
_imr_evicted_member_killTRUEIMR issue evicted member kill after a wait
_imr_evicted_member_kill_wait20IMR evicted member kill wait time in seconds
_imr_highload_threshold IMR system highload threshold
_imr_max_reconfig_delay300Maximum Reconfiguration delay (seconds)
_imr_splitbrain_res_wait600Maximum wait for split-brain resolution (seconds)
_imr_systemload_checkTRUEPerform the system load check during IMR
_imu_pools3in memory undo pools
_in_memory_undoTRUEMake in memory undo for top level transactions
_incremental_recovery_ckpt_min_batch30Minimum number of writes for incremental recovery ckpt every 3 sec
_index_join_enabledTRUEenable the use of index joins
_index_prefetch_factor100index prefetching factor
_init_granule_interval10number of granules to process for deferred cache
_init_sql_file?/rdbms/admin/sql.bsqFile containing SQL statements to execute upon database creation
_inject_startup_fault0inject fault in the startup code
_inline_sql_in_plsqlFALSEinline SQL in PL/SQL
_insert_enable_hwm_brokeredTRUEduring parallel inserts high water marks are brokered
_inst_locking_period5period an instance can retain a newly acquired level1 bitmap
_interconnect_checksumTRUEif TRUE, checksum interconnect blocks
_intrapart_pdml_enabledTRUEEnable intra-partition updates/deletes
_intrapart_pdml_randomlocal_enabledTRUEEnable intra-partition updates/deletes with random local dist
_io_resource_manager_always_onFALSEio resource manager always on
_io_shared_pool_size4194304Size of I/O buffer pool from SGA
_io_slaves_disabledFALSEDo not use I/O slaves
_io_statisticsTRUEif TRUE, ksfd I/O statistics are collected
_ioq_fanin_multiplier2IOQ miss count before a miss exception
_ior_serialize_fault0inject fault in the ior serialize code
_iorm_tout1000IORM scheduler timeout value in msec
_ioslave_batch_count1Per attempt IOs picked
_ioslave_issue_count500IOs issued before completion check
_ipc_fail_network0Simulate cluster network failer
_ipc_test_failover0Test transparent cluster network failover
_ipc_test_mult_nets0simulate multiple cluster networks
_job_queue_interval5Wakeup interval in seconds for job queue co-ordinator
_k2q_latches0number of k2q latches
_kcfis_fault_control0trace level setting for KCFIS module
_kcfis_max_appliances40Max. appliances in a KCFIS session
_kcfis_oss_io_size0KCFIS OSS I/O size
_kcfis_read_buffer_limit0KCFIS Read Buffer (per session) memory limit in bytes
_kcfis_trace_level0trace level setting for KCFIS module
_kcfis_work_set_appliances6Working Set of appliances in a KCFIS session
_kcl_commitTRUEif TRUE, call kjbcommit
_kcl_conservative_log_flushFALSEif TRUE, conservatively log flush before CR serving
_kcl_debugTRUEif TRUE, record le history
_kcl_index_splitTRUEif TRUE, reject pings on blocks in middle of a split
_kdbl_enable_post_allocationFALSEallocate dbas after populating data buffers
_kdi_avoid_block_checkingFALSEavoid index block checking on sensitive opcodes
_kdli_STOP_bsz0undocumented parameter for internal use only
_kdli_STOP_dba0undocumented parameter for internal use only
_kdli_STOP_fsz0undocumented parameter for internal use only
_kdli_STOP_nio0undocumented parameter for internal use only
_kdli_STOP_tsn0undocumented parameter for internal use only
_kdli_allow_corruptTRUEallow corrupt filesystem_logging data blocks during read/write
_kdli_cache_inodeTRUEcache inode state across calls
_kdli_cache_read_threshold0minimum lob size for cache->nocache read (0 disables heuristic)
_kdli_cache_size8maximum #entries in inode cache
_kdli_cache_verifyFALSEverify cached inode via deserialization
_kdli_cache_write_threshold0minimum lob size for cache->nocache write (0 disables heuristic)
_kdli_cacheable_length0minimum lob length for inode cacheability
_kdli_force_crTRUEforce CR when reading data blocks of direct-write lobs
_kdli_force_cr_metaTRUEforce CR when reading metadata blocks of direct-write lobs
_kdli_force_storagenoneforce storage settings for all lobs
_kdli_full_readahead_threshold0maximum lob size for full readahead
_kdli_inject_assert0inject asserts into the inode
_kdli_inject_crash0inject crashes into the inode
_kdli_inline_xfmTRUEallow inline transformed lobs
_kdli_inode_preferencedatainline inode evolution preference (data, headless, lhb)
_kdli_itree_entries0#entries in lhb/itree blocks (for testing only)
_kdli_memory_protectFALSEtrace accesses to inode memory outside kdli API functions
_kdli_rci_lobmap_entries255#entries in RCI lobmap before migration to lhb
_kdli_readahead_limit0shared/cached IO readahead limit
_kdli_readahead_strategycontigshared/cached IO readahead strategy
_kdli_recent_scnFALSEuse recent (not dependent) scns for block format/allocation
_kdli_reshapeFALSEreshape an inode to inline or headless on length truncation
_kdli_safe_callbacksTRUEinvoke inode read/write callbacks safely
_kdli_sio_asyncTRUEasynchronous shared IO
_kdli_sio_backoffFALSEuse exponential backoff when attempting SIOP allocations
_kdli_sio_bps0maximum blocks per IO slot
_kdli_sio_dop2degree-of-parallelism in the SIO keep pool
_kdli_sio_fgioTRUEreap asynchronous IO in the foreground
_kdli_sio_fileopennodsyncshared IO fileopen mode: datasync vs nodatasync vs async
_kdli_sio_flushFALSEenable shared IO pool operations
_kdli_sio_freeTRUEfree IO buffers when not in active use
_kdli_sio_min_read0shared IO pool read threshold
_kdli_sio_min_write0shared IO pool write threshold
_kdli_sio_nbufs8maximum #IO buffers to allocate per session
_kdli_sio_niods8maximum #IO descriptors to allocate per session
_kdli_sio_onTRUEenable shared IO pool operations
_kdli_sio_pgaFALSEuse PGA allocations for direct IO
_kdli_sio_pga_topFALSEPGA allocations come from toplevel PGA heap
_kdli_sio_strategyautoshared IO strategy: block vs. extent
_kdli_small_cache_limit32size limit of small inode cache
_kdli_sort_dbasFALSEsort dbas during chunkification
_kdli_space_cache_limit2048maximum size of the space cache in #blocks
_kdli_squeezeTRUEcompact lobmap extents with contiguous dbas
_kdli_timer_dmpFALSEdump inode timers on session termination
_kdli_timer_trcFALSEtrace inode timers to uts/tracefile
_kdli_trace0inode trace level
_kdlu_max_bucket_size4194304UTS kdlu bucket size
_kdlu_max_bucket_size_mts131072UTS kdlu bucket size for mts
_kdlu_trace_layer0UTS kdlu per-layer trace level
_kdlu_trace_session0UTS session dump
_kdlu_trace_system0UTS system dump
_kdlw_enable_ksi_lockingFALSEenable ksi locking for lobs
_kdlw_enable_write_gatheringTRUEenable lob write gathering for sql txns
_kdlwp_flush_threshold4194304WGC flush threshold in bytes
_kdlxp_cmp_subunit_size262144size of compression sub-unit in bytes
_kdlxp_dedup_flush_threshold8388608deduplication flush threshold in bytes
_kdlxp_dedup_hash_algoSHA1secure hash algorithm for deduplication – only on SecureFiles
_kdlxp_dedup_prefix_threshold1048576deduplication prefix hash threshold in bytes
_kdlxp_lobcompressFALSEenable lob compression – only on SecureFiles
_kdlxp_lobdeduplicateFALSEenable lob deduplication – only on SecureFiles
_kdlxp_lobdedupvalidateTRUEenable deduplicate validate – only on SecureFiles
_kdlxp_lobencryptFALSEenable lob encryption – only on SecureFiles
_kdlxp_min_xfm_size32768minimum transformation size in bytes
_kdlxp_mincmp20minimum comp ratio in pct – only on SecureFiles
_kdlxp_spare10deduplication spare 1
_kdlxp_xfmcacheTRUEenable xfm cache – only on SecureFiles
_kdt_bufferingTRUEcontrol kdt buffering for conventional inserts
_kebm_nstrikes3kebm # strikes to auto suspend an action
_kebm_suspension_time82800kebm auto suspension time in seconds
_keep_remote_column_sizeFALSEremote column size does not get modified
_kernel_message_network_driverFALSEkernel message network driver
_kffmap_hash_size1024size of kffmap_hash table
_kffmop_hash_size2048size of kffmop_hash table
_kfm_disable_set_fenceFALSEdisable set fence calls and revert to default (process fence)
_kghdsidx_count1max kghdsidx count
_kgl_bucket_count9index to the bucket count array
_kgl_debug Library cache debugging
_kgl_features_enabled2Library cache features enabled bits
_kgl_fixed_extentsTRUEfixed extent size for library cache memory allocations
_kgl_hash_collisionFALSEwhether KGL hash collision is possible
_kgl_heap_size1024extent size for library cache heap 0
_kgl_kqr_cap_so_stacksFALSEcapture stacks for library and row cache state objects
_kgl_large_heap_warning_threshold52428800maximum heap size before KGL writes warnings to the alert log
_kgl_latch_count0number of library cache latches
_kgl_message_locks64RAC message lock count
_kgl_min_cached_so_count1Minimum cached SO count. If > 1 can help find SO corruptions
_kgl_multi_instance_invalidationTRUEwhether KGL to support multi-instance invalidations
_kgl_multi_instance_lockTRUEwhether KGL to support multi-instance locks
_kgl_multi_instance_pinTRUEwhether KGL to support multi-instance pins
_kgl_so_stack_depth16The depth of the stack capture for SO get or free
_kgl_time_to_wait_for_locks15time to wait for locks and pins before timing out
_kglsim_maxmem_percent5max percentage of shared pool size to be used for KGL advice
_kgsb_threshold_size16777216threshold size for base allocator
_kgx_latches1024# of mutex latches if CAS is not supported.
_kgx_spin_count255third spare parameter – integer
_kill_controlfile_enqueue_blockerTRUEenable killing controlfile enqueue blocker on timeout
_kill_diagnostics_timeout60timeout delay in seconds before killing enqueue blocker
_kill_enqueue_blocker2if greater than 0 enables killing enqueue blocker
_kill_java_threads_on_eocFALSEKill Java threads and do sessionspace migration at end of call
_kill_session_dumpTRUEProcess dump on kill session immediate
_kkdlgon_max_iter20000kkdlgon maximum number of iterations
_kkfi_traceFALSEtrace expression substitution
_kks_free_cursor_stat_pct10percentage of cursor stats buckets to scan on each load, in 1/10th of a percent
_kks_use_mutex_pinTRUETurning on this will make KKS use mutex for cursor pins.
_kokli_cache_size32Size limit of Materialized View and Object Table Lookup Cache
_kolfuseslfFALSEallow kolf to use slffopen
_kql_subheap_trace0tracing level for library cache subheap level pins
_ksb_disable_diagpidFALSEdisable the call to ksb_diagpid
_ksb_restart_clean_time30000process uptime for restarts
_ksb_restart_policy_times0, 60, 120, 240process restart policy times in seconds
_ksd_test_param999KSD test parmeter
_ksdxdocmd_default_timeout_ms30000default timeout for internal oradebug commands
_ksdxdocmd_enabledTRUEif TRUE ksdxdocmd* invocations are enabled
_ksdxw_cini_flg0ksdxw context initialization flag
_ksdxw_nbufs1000ksdxw number of buffers in buffered mode
_ksdxw_num_pgw10number of watchpoints on a per-process basis
_ksdxw_num_sgw10number of watchpoints to be shared by all processes
_ksdxw_stack_depth4number of PCs to collect in the stack when watchpoint is hit
_kse_die_timeout60000amount of time a dying process is spared by PMON (in centi-secs)
_kse_pc_table_size256kse pc table cache size
_kse_signature_entries0number of entries in the kse stack signature cache
_kse_signature_limit7number of stack frames to cache per kse signature
_kse_snap_ring_size0ring buffer to debug internal error 17090
_ksfd_verify_writeFALSEverify asynchronous writes issued through ksfd
_ksi_trace KSI trace string of lock type(s)
_ksi_trace_bucketPRIVATEmemory tracing: use ksi-private or rdbms-shared bucket
_ksi_trace_bucket_size8192size of the KSI trace bucket
_ksmb_debug0ksmb debug flags
_ksmd_protect_modeoffKSMD protect mode for catching stale access
_ksmg_granule_locking_status1granule locking status
_ksmg_granule_size4194304granule size in bytes
_ksmg_lock_check_interval timeout action interval in minutes
_ksmg_lock_reacquire_count5repeat count for acquisition of locks
_kspol_tac_timeout5timeouts for TAC registerd by kspol
_ksr_unit_test_processes0number of ksr unit test processes
_kss_quietFALSEif TRUE access violations during kss dumps are not recorded
_ksu_diag_kill_time5number of seconds ksuitm waits before killing diag
_ksuitm_addon_trccmd command to execute when dead processes don’t go away
_ksuitm_dont_kill_dumperFALSEdelay inst. termination to allow processes to dump
_ksv_max_spawn_fail_limit5bg slave spawn failure limit
_ksv_pool_hang_kill_to0bg slave pool terminate timeout
_ksv_pool_wait_timeout600bg slave pool wait limit
_ksv_spawn_control_allFALSEcontrol all spawning of background slaves
_ksvppktmode0ksv internal pkt test
_ksxp_diagmodeOFFset to OFF to disable automatic slowsend diagnostics
_ksxp_disable_dynamic_loadingFALSEdisable dynamic loadin of lib skgxp
_ksxp_disable_ipc_statsFALSEdisable ipc statistics
_ksxp_init_stats_bkts0initial number arrays for ipc statistics
_ksxp_max_stats_bkts0max. arrays for ipc statistics
_ksxp_ping_enableTRUEdisable dynamic loadin of lib skgxp
_ksxp_ping_polling_time0max. arrays for ipc statistics
_ksxp_reaping20tune ksxp layer reaping limit
_ksxp_reporting_processLMD0reporting process for KSXP
_ksxp_send_timeout300set timeout for sends queued with the inter-instance IPC
_ksxp_skgxp_compat_library_path over-ride default location of lib skgxp compat
_ksxp_skgxp_library_path over-ride default location of lib skgxp
_ksxp_stats_mem_lmt0limit ipc statistics memory. this parameter is a percentage value
_ksxp_testing0KSXP test parameter
_ksxp_unit_test_byte_transformationFALSEenable byte transformation unit test
_ktc_debug0for ktc debug
_ktc_latches0number of ktc latches
_ktslj_segext_warning10segment pre-extension warning threshold in percentage
_ktspsrch_maxsc32maximum segments supported by space search cache
_kttext_warning5tablespace pre-extension warning threshold in percentage
_ktu_latches0number of KTU latches
_ku_tracenonedatapump trace parameter
_large_pool_min_alloc16000minimum allocation size in bytes for the large allocation pool
_last_allocation_period5period 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_sid0Sid of process for which to collect latch stats
_latch_recovery_alignment65534align latch recovery structures
_ldr_io_size262144size of write IOs used during a load operation
_left_nested_loops_randomTRUEenable random distribution method for left of nestedloops
_lgwr_async_broadcastsTRUELGWR Asynchronous Broadcasts enabling boolean flag
_lgwr_delay_writeFALSELGWR write delay for debugging
_lgwr_io_slaves0LGWR I/O slaves
_lgwr_max_ns_wt1Maximum wait time for lgwr to allow NetServer to progress
_lgwr_ns_nl_max1000Variable to simulate network latency or buffer threshold
_lgwr_ns_nl_min500Variable to simulate network latency or buffer threshold
_lgwr_ns_sim_err0Variable to simulate errors lgwrns
_lgwr_ta_sim_err0Variable to simulate errors lgwr true async
_library_cache_adviceTRUEwhether KGL advice should be turned on
_lightweight_hdrsTRUELightweight headers for redo
_like_with_bind_as_equalityFALSEtreat LIKE predicate with bind as an equality predicate
_lm_activate_lms_threshold100threshold value to activate an additional lms
_lm_asm_enq_hashingTRUEif TRUE makes ASM use enqueue master hashing for fusion locks
_lm_better_ddvictimTRUEGES better deadlock victim
_lm_cache_lvl0_cleanup0how often to cleanup level 0 cache res (in sec)
_lm_cache_res_cleanup25percentage of cached resources should be cleanup
_lm_cache_res_typeTMHWDIcache resource: string of lock types(s)
_lm_checksum_batch_msg0GES checksum batch messages
_lm_contiguous_res_count128number of contiguous blocks that will hash to the same HV bucket
_lm_dd_interval10dd time interval in seconds
_lm_dd_max_search_time180max dd search time per token
_lm_dd_scan_interval5dd scan interval in seconds
_lm_dd_search_cnt3number of dd search per token get
_lm_drm_max_requests100dynamic remastering maximum affinity requests processed together
_lm_drm_window0dynamic remastering bucket window size
_lm_drm_xlatch0dynamic remastering forced exclusive latches
_lm_dynamic_lmsFALSEdynamic lms invocation
_lm_dynamic_loadTRUEdynamic load adjustment
_lm_enq_lock_freelist Number of ges enqueue element freelist
_lm_enq_rcfgTRUEif TRUE enables enqueue reconfiguration
_lm_enqueue_freelist3Number of enqueue freelist
_lm_file_affinity mapping between file id and master instance number
_lm_global_postsTRUEif TRUE deliver global posts to remote nodes
_lm_idle_connection_checkTRUEGES idle connection check
_lm_idle_connection_check_interval10GES idle connection check interval time
_lm_idle_connection_killFALSEGES idle connection kill
_lm_lmd_waittime8default wait time for lmd in centiseconds
_lm_lmon_nowait_latchTRUEif TRUE makes lmon get nowait latches with timeout loop
_lm_lms0number of background gcs server processes to start
_lm_lms_waittime8default wait time for lms in centiseconds
_lm_locks12000number of enqueues configured for cluster database
_lm_master_weight1master resource weight for this instance
_lm_max_lms0max. number of background global cache server processes
_lm_msg_batch_size0GES batch message size
_lm_msg_cleanup_interval3000GES message buffer cleanup interval time
_lm_node_join_optFALSEcluster database node join optimization in reconfig
_lm_non_fault_tolerantFALSEdisable cluster database fault-tolerance mode
_lm_num_pt_buckets8192number of buckets in the object affinity hash table
_lm_num_pt_latches128number of latches in the object affinity hash table
_lm_postevent_buffer_size256postevent buffer size
_lm_proc_freeze_timeout300reconfiguration: process freeze timeout
_lm_process_batchingTRUEGES implicit process batching for IPC messages
_lm_procs320number of client processes configured for cluster database
_lm_psrcfgFALSEenable pseudo reconfiguration
_lm_rcfg_timeout1260Reconfiguration timeout
_lm_rcvr_hang_allow_time200receiver hang allow time in seconds
_lm_rcvr_hang_check_frequency60receiver hang check frequency in seconds
_lm_rcvr_hang_killFALSEto kill receiver hang
_lm_res_hash_bucket0number of resource hash buckets
_lm_res_part128number of resource partition configured for gcs
_lm_ress6000number of resources configured for cluster database
_lm_send_modeautoGES send mode
_lm_send_queue_batchingTRUEGES send queue message batching
_lm_send_queue_length5000GES send queue maximum length
_lm_sendproxy_reserve25GES percentage of send proxy reserve of send tickets
_lm_share_lock_optFALSEif TRUE enables share lock optimization
_lm_sq_batch_factor2GES send queue minimum batching factor
_lm_sq_batch_typeautoGES send queue batching mechanism
_lm_sq_batch_waittick3GES send queue batching waittime in tick
_lm_sync_timeout420Synchronization timeout for DLM reconfiguration steps
_lm_ticket_active_sendback Flow control ticket active sendback threshold
_lm_tickets1000GES messaging tickets
_lm_tx_delta16TX lock localization delta
_lm_validate_resource_typeFALSEif TRUE enables resource name validation
_lm_xids352number of transaction IDs configured for cluster database
_lmn_compressionFALSEsuppl logging for compression enabled
_load_without_compileNONELoad PL/SQL or Database objects without compilation
_local_communication_costing_enabledTRUEenable local communication costing when TRUE
_local_communication_ratio50set the ratio between global and local communication (0..100)
_local_hang_analysis_interval_secs3the interval at which local hang analysis is run
_lock_sga_areas0Lock specified areas of the SGA in physical memory
_log_archive_avoid_memcpyTRUElog archive avoid memcpy
_log_archive_buffers10Number of buffers to allocate for archiving
_log_archive_callout archival callout
_log_archive_compress_enableFALSEBypass database rules for enabling archivelog compression
_log_archive_network_redo_size10Log archive network redo buffer size used by ARCH
_log_archive_prot_auto_demoteFALSElog archive protection auto demotion
_log_archive_security_enabledTRUElog archive security enabled
_log_archive_strong_authTRUElog archive security strong auth
_log_blocks_during_backupTRUElog block images when changed during backup
_log_buffers_corruptFALSEcorrupt redo buffers before write
_log_buffers_debugFALSEdebug redo buffers (slows things down)
_log_checkpoint_recovery_check0# redo blocks to verify after checkpoint
_log_committime_block_cleanoutFALSELog commit-time block cleanout
_log_deletion_policymandatoryarchivelog deletion policy for mandatory/all destination
_log_event_queues0number of the log writer event queues
_log_io_size0automatically initiate log write if this many redo blocks in buffer
_log_parallelism_dynamicTRUEEnable dynamic strands
_log_parallelism_max1Maximum number of log buffer strands
_log_private_mul5Private strand multiplier for log space preallocation
_log_private_parallelismFALSENumber of private log buffer strands for zero-copy redo
_log_private_parallelism_mul10Active sessions multiplier to deduce number of private strands
_log_read_buffers4Number of log read buffers for media recovery
_log_simultaneous_copies2number of simultaneous copies into redo buffer(# of copy latches)
_log_space_errorsTRUEshould we report space errors to alert log
_log_switch_timeout0Maximum number of seconds redos in the current log could span
_logout_storm_rate0number of processes that can logout in a second
_logout_storm_retrycnt600maximum retry count for logouts
_logout_storm_timeout5timeout in centi-seconds for time to wait between retries
_longops_enabledTRUElongops stats enabled
_low_server_threshold0low server thresholds
_ltc_trace0tracing level for load table conventional
_master_direct_sends31direct sends for messages from master (DFS)
_mav_refresh_consistent_readTRUErefresh materialized views using consistent read snapshot
_mav_refresh_double_count_preventedFALSEmaterialized view MAV refreshes avoid double counting
_mav_refresh_opt0optimizations during refresh of materialized views
_mav_refresh_unionall_tables3# tables for union all expansion during materialized view refresh
_max_arch_lns_wait120Maximum wait by ARCH to allow NetServer to complete archival
_max_exponential_sleep0max sleep during exponential backoff
_max_io_size1048576Maximum I/O size in bytes for sequential file accesses
_max_large_io0IORM:max number of large I/O’s to issue
_max_lns_shutdown_archival_time30Maximum time spent by LNS to archive last log during shutdown
_max_protocol_support10000Max occurrence protocols supported in a process
_max_shrink_obj_stats0number of segments for which shrink stats will be maintained
_max_sleep_holding_latch4max time to sleep while holding a latch
_max_small_io0IORM:max number of small I/O’s to issue
_max_spacebg_slaves10maximum space management background slaves
_max_spacebg_tasks1000maximum space management background tasks
_max_temp_overhead0max tempspc overhead
_media_recovery_read_batch128media recovery block read batch
_mem_annotation_pr_lev0private memory annotation collection level
_mem_annotation_scale1memory annotation pre-allocation scaling
_mem_annotation_sh_lev0shared memory annotation collection level
_mem_annotation_storeFALSEmemory annotation in-memory store
_mem_std_extent_size4096standard extent size for fixed-size-extent heaps
_memory_broker_log_stat_entries5memory broker num stat entries
_memory_broker_marginal_utility_bc12Marginal Utility threshold pct for bc
_memory_broker_marginal_utility_sp7Marginal Utility threshold pct for sp
_memory_broker_shrink_heaps15memory broker allow policy to shrink shared pool
_memory_broker_shrink_java_heaps900memory broker allow policy to shrink java pool
_memory_broker_shrink_streams_pool900memory broker allow policy to shrink streams pool
_memory_broker_shrink_timeout60000000memory broker policy to timeout shrink shared/java pool
_memory_broker_stat_interval30memory broker statistics gathering interval for auto sga
_memory_management_tracing0trace memory management activity
_memory_nocancel_defsgareqFALSEdo not cancel deferred sga reqs with auto-memory
_memory_sanity_check0partial granule sanity check
_messages300message queue resources – dependent on # processes & # buffers
_midtier_affinity_clusterwait_threshold100cluster wait threshold to enter affinity
_midtier_affinity_goodness_threshold2000goodness gradient threshold to dissolve affinity
_midtier_affinity_timeout30000default timeout for midtier affinity processing
_minfree_plus0max percentage of block space + minfree before we mark block full
_minimal_stats_aggregationTRUEprohibit stats aggregation at compile/partition maintenance time
_minimum_blocks_to_shrink0minimum number freeable blocks for shrink to be present
_minimum_db_flashback_retention60Minimum flashback retention
_minimum_extents_to_shrink1minimum number freeable extents for shrink to be present
_minimum_giga_scn0Minimum SCN to start with in 2^30 units
_mirror_redo_buffersFALSESave buffers for debugging redo corruptions
_mmv_query_rewrite_enabledTRUEallow rewrites with multiple MVs and/or base tables
_multi_instance_pmrTRUEforce multi instance or single instance parallel recovery
_multi_join_key_table_lookupTRUETRUE iff multi-join-key table lookup prefetch is enabled
_multiple_instance_recoveryFALSEuse multiple instances for media recovery
_mv_refresh_ana0what percent to analyze after complete/PCT refresh
_mv_refresh_costingrulerefresh decision based on cost or on rules
_mv_refresh_delta_fraction10delta mv as fractional percentage of size of mv
_mv_refresh_eutTRUErefresh materialized views using EUT(partition)-based algorithm
_mv_refresh_force_parallel_query0force materialized view refreshes to use parallel query
_mv_refresh_new_setup_disabledFALSEmaterialized view MV refresh new setup disabling
_mv_refresh_rebuild_percentage10minimum percentage change required in MV to force an indexrebuild
_mv_refresh_selectionsTRUEcreate materialized views with selections and fast refresh
_mv_refresh_use_statsFALSEpass cardinality hints to refresh queries
_mv_refsched_timeincr300000proportionality constant for dop vs. time in MV refresh
_mv_rolling_invFALSEcreate/alter mv uses rolling cursor invalidation instead of immediate
_mwin_scheduleTRUEEnable/disable Maintenance Window Schedules
_nchar_imp_cnvTRUENLS allow Implicit Conversion between CHAR and NCHAR
_nchar_imp_convTRUEshould implicit conversion bewteen clob and nclob be allowed
_ncmb_readahead_enabled0enable multi-block readahead for an index scan
_ncmb_readahead_tracing0turn on multi-block readahead tracing
_ncomp_shared_objects_dir native compilation shared objects dir
_nested_loop_fudge100nested loop fudge
_nested_mav_fast_oncommit_enabledTRUEnested MAV refresh fast on commit allowed
_new_initial_join_ordersTRUEenable initial join orders based on new ordering heuristics
_new_sort_cost_estimateTRUEenables the use of new cost estimate for sort
_newsort_enabledTRUEcontrols whether new sorts can be used as system sort
_newsort_ordered_pct63controls when new sort avoids sorting ordered input
_newsort_type0specifies options for the new sort algorithm
_nlj_batching_enabled1enable batching of the RHS IO in NLJ
_nlj_batching_misses_enabled1enable exceptions for buffer cache misses
_no_objectsFALSEno object features are used
_no_or_expansionFALSEOR expansion during optimization disabled
_no_recovery_through_resetlogsFALSEno recovery through this resetlogs operation
_notify_crsFALSEnotify cluster ready services of startup and shutdown
_ns_max_flush_wt1Flush wait time for NetServer to flush oustanding writes
_ns_max_send_delay15Data Loss Time Bound for NetServer
_num_longop_child_latches1number of child latches for long op array
_number_cached_attributes10maximum number of cached attributes per instance
_object_reuse_bast2if 1 or higher, handle object reuse
_object_statisticsTRUEenable the object level statistics collection
_object_stats_max_entries3072Maximum number of entries to be tracked per stat
_offline_rollback_segments offline undo segment list
_ogms_home GMS home directory
_olap_aggregate_buffer_size1048576OLAP Aggregate max buffer size
_olap_aggregate_flags0OLAP Aggregate debug flags
_olap_aggregate_function_cache_enabledTRUEOLAP Aggregate function cache enabler
_olap_aggregate_function_merge_threshold529OLAP Aggregate function merge threshold
_olap_aggregate_max_thread_tuples5000OLAP Aggregate max thread tuples creation
_olap_aggregate_min_buffer_size1024OLAP Aggregate min buffer size
_olap_aggregate_min_thread_status64OLAP Aggregate minimum cardinality of dimensions for thread
_olap_aggregate_multipath_hierFALSEOLAP Aggregate Multi-path Hierarhies enabled
_olap_aggregate_statlen_thresh1024OLAP Aggregate status array usage threshold
_olap_aggregate_store_probability100OLAP Aggregate function storeback probability
_olap_aggregate_work_per_thread1024OLAP Aggregate max work parents
_olap_aggregate_worklist_max5000OLAP Aggregate max worklists generated at once
_olap_allocate_errorlog_format%8p %8y %8z %e (%n)OLAP Allocate Errorlog Format
_olap_allocate_errorlog_headerDim Source Basis %-8d %-8s %-8b Description ——– ——– ——– ———–OLAP Allocate Errorlog Header format
_olap_analyze_max10000OLAP DML ANALYZE command max cells to analyze
_olap_continuous_trace_fileFALSESpecify TRUE to enable continuous OLAP tracing – otherwise only exceptional events will be logged
_olap_dbgoutfile_echo_to_eventlogFALSEOLAP DbgOutfile copy output to event log (tracefile)
_olap_dimension_corehash_class1OLAP Dimension In-Core Hash Table Class
_olap_dimension_corehash_large50000OLAP Dimension In-Core Hash Table Large Threshold
_olap_dimension_corehash_pressure90OLAP Dimension In-Core Hash Table Pressure Threshold
_olap_dimension_corehash_size30OLAP Dimension In-Core Hash Table Maximum Memory Use
_olap_dimension_corehash_small1000OLAP Dimension In-Core Hash Table Small Threshold
_olap_eif_export_lob_size2147483647OLAP EIF Export BLOB size
_olap_lmgen_dim_size100Limitmap generator dimension column size
_olap_lmgen_meas_size1000Limitmap generator measure column size
_olap_object_hash_class2OLAP Object Hash Table Class
_olap_page_pool_expand_rate20OLAP Page Pool Expand Rate
_olap_page_pool_hi50OLAP Page Pool High Watermark
_olap_page_pool_hit_target100OLAP Page Pool Hit Target
_olap_page_pool_low262144OLAP Page Pool Low Watermark
_olap_page_pool_pressure90OLAP Page Pool Pressure Threshold
_olap_page_pool_shrink_rate50OLAP Page Pool Shrink Rate
_olap_parallel_update_small_group400OLAP parallel update pagespace by group
_olap_parallel_update_small_threshold1000OLAP parallel update threshold for number of small pagespaces
_olap_parallel_update_threshold1000OLAP parallel update threshold in pages
_olap_poutlog_echo_to_eventlogFALSEOLAP POutLog copy output to event log (tracefile)
_olap_sesscache_enabledTRUEOLAP Session Cache knob
_olap_sort_buffer_size262144OLAP Sort Buffer Size
_olap_statbool_corebits20000000OLAP Status Boolean max incore bits
_olap_statbool_threshold8100OLAP Status Boolean CBM threshold
_olap_table_function_statisticsFALSESpecify TRUE to output OLAP table function timed statistics trace
_olap_wrap_errorsFALSEWrap error messages to OLAP outfile
_olapi_history_retentionFALSEenable olapi history retention
_olapi_iface_object_history1000enable olapi interface object history collection
_olapi_iface_object_history_retentionFALSEenable olapi interface object history retention
_olapi_iface_operation_history_retentionFALSEenable olapi interface operation history retention
_olapi_interface_operation_history1000enable olapi interface operation history collection
_olapi_memory_operation_history1000enable olapi memory alloc/free history collection
_olapi_memory_operation_history_pause_at_seqno0enable olapi memory alloc/free history collection pausing
_olapi_memory_operation_history_retentionFALSEenable olapi memory operation history retention
_olapi_session_history300enable olapi session history collection
_olapi_session_history_retentionFALSEenable olapi session history retention
_old_connect_by_enabledFALSEenable/disable old connect by
_ols_cleanup_taskTRUEClean up unnecessary entries in OLS sessinfo table
_oltp_compressionTRUEoltp compression enabled
_oltp_compression_gain10oltp compression gain
_omfenabledenable/disable OMF
_oneside_colstat_for_equijoinsTRUEsanity check on default selectivity for like/range predicate
_online_patch_disable_stack_checkFALSEdisable check for function on stack for online patches
_optim_adjust_for_part_skewsTRUEadjust stats for skews across partitions
_optim_dict_stats_at_db_cr_upgTRUEenable/disable dictionary stats gathering at db create/upgrade
_optim_enhance_nnull_detectionTRUETRUE to enable index [fast] full scan more often
_optim_new_default_join_selTRUEimproves the way default equijoin selectivity are computed
_optim_peek_user_bindsTRUEenable peeking of user binds
_optimizer_adaptive_cursor_sharingTRUEoptimizer adaptive cursor sharing
_optimizer_adjust_for_nullsTRUEadjust selectivity for null values
_optimizer_autostats_jobTRUEenable/disable auto stats collection job
_optimizer_aw_join_push_enabledTRUEEnables AW Join Push optimization
_optimizer_aw_stats_enabledTRUEEnables statistcs on AW olap_table table function
_optimizer_better_inlist_costingALLenable improved costing of index access using in-list(s)
_optimizer_block_size8192standard block size used by optimizer
_optimizer_cache_statsFALSEcost with cache statistics
_optimizer_cartesian_enabledTRUEoptimizer cartesian join enabled
_optimizer_cbqt_factor50cost factor for cost-based query transformation
_optimizer_cbqt_no_size_restrictionTRUEdisable cost based transformation query size restriction
_optimizer_ceil_costTRUECEIL cost in CBO
_optimizer_choose_permutation0force the optimizer to use the specified permutation
_optimizer_complex_pred_selectivityTRUEenable selectivity estimation for builtin functions
_optimizer_compute_index_statsTRUEforce index stats collection on index creation/rebuild
_optimizer_connect_by_combine_swTRUEcombine no filtering connect by and start with
_optimizer_connect_by_cost_basedTRUEuse cost-based transformation for connect by
_optimizer_correct_sq_selectivityTRUEforce correct computation of subquery selectivity
_optimizer_cost_based_transformationLINEARenables cost-based query transformation
_optimizer_cost_filter_predFALSEenables costing of filter predicates in IO cost model
_optimizer_cost_hjsmj_multimatchTRUEadd cost of generating result set when #rows per key > 1
_optimizer_cost_modelCHOOSEoptimizer cost model
_optimizer_degree0force the optimizer to use the same degree of parallelism
_optimizer_dim_subq_join_selTRUEuse join selectivity in choosing star transformation dimensions
_optimizer_disable_strans_sanity_checks0disable star transformation sanity checks
_optimizer_distinct_eliminationTRUEEliminates redundant SELECT DISTNCT’s
_optimizer_dyn_smp_blks32number of blocks for optimizer dynamic sampling
_optimizer_enable_density_improvementsTRUEuse improved density computation for selectivity estimation
_optimizer_enable_extended_statsTRUEuse extended statistics for selectivity estimation
_optimizer_enhanced_filter_pushTRUEpush filters before trying cost-based query transformation
_optimizer_extend_jppd_view_typesTRUEjoin pred pushdown on group-by, distinct, semi-/anti-joined view
_optimizer_extended_cursor_sharingUDOoptimizer extended cursor sharing
_optimizer_extended_cursor_sharing_relSIMPLEoptimizer extended cursor sharing for relational operators
_optimizer_extended_stats_usage_control240controls the optimizer usage of extended stats
_optimizer_filter_pred_pullupTRUEuse cost-based flter predicate pull up transformation
_optimizer_fkr_index_cost_bias10Optimizer index bias over FTS/IFFS under first K rows mode
_optimizer_free_transformation_heapTRUEfree transformation subheap after each transformation
_optimizer_group_by_placementTRUEconsider group-by placement optimization
_optimizer_ignore_hintsFALSEenables the embedded hints to be ignored
_optimizer_improve_selectivityTRUEimprove table and partial overlap join selectivity computation
_optimizer_invalidation_period18000time window for invalidation of cursors of analyzed objects
_optimizer_join_elimination_enabledTRUEoptimizer join elimination enabled
_optimizer_join_order_control3controls the optimizer join order search algorithm
_optimizer_join_sel_sanity_checkTRUEenable/disable sanity check for multi-column join selectivity
_optimizer_max_permutations2000optimizer maximum join permutations per query block
_optimizer_min_cache_blocks10set minimum cached blocks
_optimizer_mjc_enabledTRUEenable merge join cartesian
_optimizer_mode_forceTRUEforce setting of optimizer mode for user recursive SQL also
_optimizer_multi_level_push_predTRUEconsider join-predicate pushdown that requires multi-level pushdown to base table
_optimizer_multiple_cenv generate and run plans using several compilation environments
_optimizer_native_full_outer_joinFORCEexecute full outer join using native implementaion
_optimizer_nested_rollup_for_gset100number of groups above which we use nested rollup exec for gset
_optimizer_new_join_card_computationTRUEcompute join cardinality using non-rounded input values
_optimizer_null_aware_antijoinTRUEnull-aware antijoin parameter
_optimizer_or_expansionDEPTHcontrol or expansion approach used
_optimizer_or_expansion_subheapTRUEUse subheap for optimizer or-expansion
_optimizer_order_by_elimination_enabledTRUEEliminates order bys from views before query transformation
_optimizer_outer_to_anti_enabledTRUEEnable transformation of outer-join to anti-join if possible
_optimizer_percent_parallel101optimizer percent parallel
_optimizer_push_down_distinct0push down distinct from query block to table
_optimizer_push_pred_cost_basedTRUEuse cost-based query transformation for push pred optimization
_optimizer_random_plan0optimizer seed value for random plans
_optimizer_reuse_cost_annotationsTRUEreuse cost annotations during cost-based query transformation
_optimizer_rownum_bind_default10Default value to use for rownum bind
_optimizer_rownum_pred_based_fkrTRUEenable the use of first K rows due to rownum predicate
_optimizer_save_statsTRUEenable/disable saving old versions of optimizer stats
_optimizer_search_limit5optimizer search limit
_optimizer_self_induced_cache_costFALSEaccount for self-induced caching
_optimizer_skip_scan_enabledTRUEenable/disable index skip scan
_optimizer_skip_scan_guessFALSEconsider index skip scan for predicates with guessed selectivity
_optimizer_sortmerge_join_enabledTRUEenable/disable sort-merge join method
_optimizer_sortmerge_join_inequalityTRUEenable/disable sort-merge join using inequality predicates
_optimizer_squ_bottomupTRUEenables unnesting of subquery in a bottom-up manner
_optimizer_star_tran_in_with_clauseTRUEenable/disable star transformation in with clause queries
_optimizer_star_trans_min_cost0optimizer star transformation minimum cost
_optimizer_star_trans_min_ratio0optimizer star transformation minimum ratio
_optimizer_starplan_enabledTRUEoptimizer star plan enabled
_optimizer_system_stats_usageTRUEsystem statistics usage
_optimizer_tracenoneoptimizer trace parameter
_optimizer_transitivity_retainTRUEretain equi-join pred upon transitive equality pred generation
_optimizer_undo_changesFALSEundo changes to query optimizer
_optimizer_undo_cost_change11.1.0.6optimizer undo cost change
_optimizer_use_subheapTRUEEnables physical optimizer subheap
_or_expand_nvl_predicateTRUEenable OR expanded plan for NVL/DECODE predicate
_oradbg_pathname path of oradbg script
_oradebug_forceFALSEforce target processes to execute oradebug commands?
_ordered_nested_loopTRUEenable ordered nested loop costing
_ordered_semijoinTRUEenable ordered semi-join subquery
_orph_cln_interval1200qmon periodic interval for removed subscriber messages cleanup
_os_sched_high_priority1OS high priority level
_other_wait_event_exclusion exclude event names from _other_wait_threshold calculations
_other_wait_threshold0threshold wait percentage for event wait class Other
_outline_bitmap_treeTRUEBITMAP_TREE hint enabled in outline
_parallel_adaptive_max_users2maximum number of users running with default DOP
_parallel_broadcast_enabledTRUEenable broadcasting of small inputs to hash and sort merge joins
_parallel_default_max_instances1default maximum number of instances for parallel query
_parallel_execution_message_alignFALSEAlignment of PX buffers to OS page boundary
_parallel_fake_class_pct0fake db-scheduler percent used for testing
_parallel_fixwrite_bucket1000Number of buckets for each round of fix write
_parallel_load_bal_unit0number of threads to allocate per instance
_parallel_load_balancingTRUEparallel execution load balanced slave allocation
_parallel_min_message_pool206592minimum size of shared pool memory to reserve for pq servers
_parallel_policyMANUALpolicy used to compute the degree of parallelism (MANUAL/LIMITED/AUTO)
_parallel_recovery_stopat32767stop at -position- to step through SMON
_parallel_replay_msg_limit4000Number of messages for each round of parallel replay
_parallel_server_idle_time30000idle time before parallel query server dies (in 1/100 sec)
_parallel_server_sleep_time10sleep time between dequeue timeouts (in 1/100ths)
_parallel_slave_acquisition_wait1time(in seconds) to wait before retrying slave acquisition
_parallel_time_threshold10threshold above which a plan is a candidate for parallelization (in seconds)
_parallel_time_unit10unit of work used to derive the degree of parallelism (in seconds)
_parallel_txn_globalFALSEenable parallel_txn hint with updates and deletes
_parallelism_cost_fudge_factor350set the parallelism cost fudge factor
_parameter_table_block_size2048parameter table block size
_partial_pwise_join_enabledTRUEenable partial partition-wise join when TRUE
_partition_view_enabledTRUEenable/disable partitioned views
_passwordfile_enqueue_timeout900password file enqueue timeout in seconds
_pct_refresh_double_count_preventedTRUEmaterialized view PCT refreshes avoid double counting
_pdml_gim_sampling5000control separation of global index maintenance for PDML
_pdml_gim_staggeredFALSEslaves start on different index when doing index maint
_pdml_slaves_diff_partTRUEslaves start on different partition when doing index maint
_percent_flashback_buf_partial_full50Percent of flashback buffer filled to be considered partial full
_pga_large_extent_size1048576PGA large extent size
_pga_max_size209715200Maximum size of the PGA memory for one process
_ping_level3fusion ping level
_pivot_implementation_methodCHOOSEpivot implementation method
_pkt_enableFALSEenable progressive kill test
_pkt_pmon_interval50PMON process clean-up interval (cs)
_pkt_startFALSEstart progressive kill test instrumention
_plan_outline_dataTRUEexplain plan outline data enabled
_plan_verify_improvement_margin150Performance improvement criterion for evolving plan baselines
_plan_verify_local_time_limit0Local time limit to use for an individual plan verification
_plsql_anon_block_code_typeINTERPRETEDPL/SQL anonymous block code-type
_plsql_cache_enableTRUEPL/SQL Function Cache Enabled
_plsql_dump_buffer_events conditions upon which the PL/SQL circular buffer is dumped
_plsql_minimum_cache_hit_percent20plsql minimum cache hit percentage required to keep caching active
_plsql_nvl_optimizeFALSEPL/SQL NVL optimize
_pmon_load_constants300,192,64,3,10,10,0,0server load balancing constants (S,P,D,I,L,C,M)
_pre_rewrite_push_predTRUEpush predicates into views before rewrite
_precompute_gid_valuesTRUEprecompute gid values and copy them before returning a row
_pred_move_aroundTRUEenables predicate move-around
_predicate_elimination_enabledTRUEallow predicate elimination if set to TRUE
_prescommFALSEpresume commit of IMU transactions
_print_refresh_schedulefalseenable dbms_output of materialized view refresh schedule
_private_memory_address Start address of large extent memory segment
_project_view_columnsTRUEenable projecting out unreferenced columns of a view
_projection_pushdownTRUEprojection pushdown
_projection_pushdown_debug0level for projection pushdown debugging
_prop_old_enabledFALSEShift to pre 11g propagation behaviour
_protect_frame_heapsFALSEProtect cursor frame heaps
_push_join_predicateTRUEenable pushing join predicate inside a view
_push_join_union_viewTRUEenable pushing join predicate inside a union all view
_push_join_union_view2TRUEenable pushing join predicate inside a union view
_px_async_getgranuleFALSEasynchronous get granule in the slave
_px_bind_peek_sharingTRUEenables sharing of px cursors that were built using bind peeking
_px_broadcast_fudge_factor100set the tq broadcasting fudge factor percentage
_px_buffer_ttl30ttl for px mesg buffers in seconds
_px_compilation_debug0debug level for parallel compilation
_px_compilation_trace0tracing level for parallel compilation
_px_dump_12805_sourceTRUEenables or disables tracing of 12805 signal source
_px_dynamic_optTRUEturn off/on restartable qerpx dynamic optimization
_px_dynamic_sample_size50num of samples for restartable qerpx dynamic optimization
_px_execution_services_enabledTRUEenable service-based constraint of px slave allocation
_px_granule_size100000default size of a rowid range granule (in KB)
_px_index_sampling200parallel query sampling for index create (100000 = 100%)
_px_io_process_bandwidth200IO process bandwidth in MB/sec for computing DOP
_px_io_system_bandwidth0total IO system bandwidth in MB/sec for computing DOP
_px_kxib_tracing0turn on kxib tracing
_px_load_publish_interval200interval at which LMON will check whether to publish PX load
_px_loc_msg_cost1000CPU cost to send a PX message via shared memory
_px_max_granules_per_slave100maximum number of rowid range granules to generate per slave
_px_min_granules_per_slave13minimum number of rowid range granules to generate per slave
_px_minus_intersectTRUEenables pq for minus/interect operators
_px_net_msg_cost10000CPU cost to send a PX message over the internconnect
_px_no_granule_sortFALSEprevent parallel partition granules to be sorted on size
_px_no_stealingFALSEprevent parallel granule stealing in shared nothing environment
_px_nss_planbTRUEenables or disables NSS Plan B reparse with outline
_px_proc_constrainTRUEreduce parallel_max_servers if greater than (processes – fudge)
_px_pwg_enabledTRUEparallel partition wise group by enabled
_px_rownum_pdTRUEturn off/on parallel rownum pushdown optimization
_px_send_timeout300IPC message send timeout value in seconds
_px_slaves_share_cursors0slaves share cursors with QC
_px_tracenonepx trace parameter
_px_ual_serial_inputTRUEenables new pq for UNION operators
_px_xtgranule_size10000default size of a external table granule (in KB)
_qa_control0Oracle internal parameter to control QA
_qa_lrg_type0Oracle internal parameter to specify QA lrg type
_query_cost_rewriteTRUEperform the cost based rewrite with materialized views
_query_execution_cache_max_size65536max size of query execution cache
_query_mmvrewrite_maxcmaps20query mmv rewrite maximum number of cmaps per dmap in query disjunct
_query_mmvrewrite_maxdmaps10query mmv rewrite maximum number of dmaps per query disjunct
_query_mmvrewrite_maxinlists5query mmv rewrite maximum number of in-lists per disjunct
_query_mmvrewrite_maxintervals5query mmv rewrite maximum number of intervals per disjunct
_query_mmvrewrite_maxmergedcmaps50query mmv rewrite maximum number of merged cmaps
_query_mmvrewrite_maxpreds10query mmv rewrite maximum number of predicates per disjunct
_query_mmvrewrite_maxqryinlistvals500query mmv rewrite maximum number of query in-list values
_query_mmvrewrite_maxregperm512query mmv rewrite maximum number of region permutations
_query_rewrite_1TRUEperform query rewrite before&after or only before view merging
_query_rewrite_2TRUEperform query rewrite before&after or only after view merging
_query_rewrite_drjTRUEmv rewrite and drop redundant joins
_query_rewrite_expressionTRUErewrite with cannonical form for expressions
_query_rewrite_fpcTRUEmv rewrite fresh partition containment
_query_rewrite_fudge90cost based query rewrite with MVs fudge factor
_query_rewrite_jgmigrateTRUEmv rewrite with jg migration
_query_rewrite_maxdisjunct257query rewrite max disjuncts
_query_rewrite_or_errorFALSEallow query rewrite, if referenced tables are not dataless
_query_rewrite_setopgrw_enableTRUEperform general rewrite using set operator summaries
_query_rewrite_vop_cleanupTRUEprune frocol chain before rewrite after view-merging
_rcfg_parallel_fixwriteTRUEif TRUE enables parallel fixwrite at reconfiguration
_rcfg_parallel_replayTRUEif TRUE enables parallel replay and cleanup at reconfiguration
_rcfg_parallel_verifyTRUEif TRUE enables parallel verify at reconfiguration
_rdbms_compatibility10.1default RDBMS compatibility level
_rdbms_internal_fplib_enabledFALSEenable SAGE FPLIB filtering within rdbms
_rdbms_internal_fplib_raise_errorsFALSEenable reraising of any exceptions in SAGE FPLIB
_readable_standby_modeSLFLUSHreadable standby mode
_readable_standby_sync_timeout10readable standby query scn sync timeout
_real_time_apply_sim0Simulation value with real time apply
_realfree_heap_max_size32768minimum max total heap size, in Kbytes
_realfree_heap_mode0mode flags for real-free heap
_realfree_heap_pagesize_hint65536hint for real-free page size in bytes
_recoverable_recovery_batch_percent50Recoverable recovery batch size (percentage of buffer cache)
_recovery_assertsFALSEif TRUE, enable expensive integrity checks
_recovery_percentage50recovery buffer cache percentage
_recovery_verify_writesFALSEenable thread recovery write verify
_recursive_imu_transactionsFALSErecursive transactions may be IMU
_redo_compatibility_checkFALSEgeneral and redo/undo compatibility sanity check
_redo_read_from_memoryTRUEEnable reading redo from memory
_redo_transport_compress_allFALSEIs ASYNC LNS compression allowed?
_release_insert_threshold5maximum number of unusable blocks to unlink from freelist
_reliable_block_sendsFALSEif TRUE, block sends across interconnect are reliable
_remove_aggr_subqueryTRUEenables removal of subsumed aggregated subquery
_replace_virtual_columnsTRUEreplace expressions with virtual columns
_resource_manager_always_offFALSEdisable the resource manager always
_resource_manager_always_onTRUEenable the resource manager always
_restore_spfile restore spfile to this location
_result_cache_auto_execution_threshold1result cache auto execution threshold
_result_cache_auto_size_threshold100result cache auto max size allowed
_result_cache_auto_time_distance300result cache auto time distance
_result_cache_auto_time_threshold1000result cache auto time threshold
_result_cache_block_size1024result cache block size
_result_cache_timeout60maximum time (sec) a session waits for a result
_reuse_index_loop5number of blocks being examine for index block reuse
_right_outer_hash_enableTRUERight Outer/Semi/Anti Hash Enabled
_rman_io_priority3priority at which rman backup i/o’s are done
_rman_restore_through_linkFALSERMAN restore through link
_rollback_segment_count0number of undo segments
_rollback_segment_initial1starting undo segment number
_rollback_stopat0stop at -position to step rollback
_row_cache_cursors20number of cached cursors for row cache management
_row_crTRUEenable row cr for all sql
_row_lockingalwaysrow-locking
_row_shipping_explainFALSEenable row shipping explain plan support
_row_shipping_threshold80row shipping column selection threshold
_rowsource_execution_statisticsFALSEif TRUE, Oracle will collect rowsource statistics
_rowsource_profiling_statisticsTRUEif TRUE, Oracle will capture active row sources in v$active_session_history
_rowsource_statistics_sampfreq128frequency of rowsource statistic sampling (must be a power of 2)
_rowsrc_trace_level0Row source tree tracing level
_rtc_infeasible_threshold10Redo Transport Compression infeasible threshold
_sage_enabled1enable real SAGE functionality
_sage_fcreTRUEAllow optimized file creation path for SAGE
_sample_rows_per_block4number of rows per block used for sampling IO optimization
_scatter_gcs_resourcesFALSEif TRUE, gcs resources are scattered uniformly across sub pools
_scatter_gcs_shadowsFALSEif TRUE, gcs shadows are scattered uniformly across sub pools
_scn_wait_interface_max_backoff_time_secs600max exponential backoff time for scn wait interface in kta
_scn_wait_interface_max_timeout_secs2147483647max timeout for scn wait interface in kta
_sdiag_crashNONEsql diag crash
_sec_enable_test_rpcsFALSEWhether to enable the test RPCs
_second_spare_parameter second spare parameter – integer
_securefile_timersFALSEcollect kdlu timers and accumulate per layers
_selectivity_for_srf_enabledFALSEenable/disable selectivity for storage reduction factor
_selfjoin_mv_duplicatesTRUEcontrol rewrite self-join algorithm
_selftune_checkpoint_write_pct3Percentage of total physical i/os for self-tune ckpt
_selftune_checkpointing_lag300Self-tune checkpointing lag the tail of the redo log
_send_ast_to_foregroundTRUEif TRUE, send ast message to foreground
_send_close_with_blockTRUEif TRUE, send close with block even with direct sends
_send_requests_to_piTRUEif TRUE, try to send CR requests to PI buffers
_serial_direct_readFALSEenable direct read in serial
_serial_recoveryFALSEforce serial recovery or parallel recovery
_serializableFALSEserializable
_session_cached_instantiations60Number of pl/sql instantiations to cache in a session.
_session_context_size10000session app context size
_session_idle_bit_latches0one latch per session or a latch per group of sessions
_session_idle_check_interval60Resource Manager session idle limit check interval in seconds
_session_kept_cursor_pins0Number of cursors pins to keep in a session
_session_wait_history10enable session wait history collection
_seventh_spare_parameter seventh spare parameter – string list
_sga_clear_dumpFALSEAllow dumping encrypted blocks in clear for debugging
_sga_early_trace0sga early trace event
_sga_lockingnonesga granule locking state
_shared_io_pool_buf_size1048576Shared IO pool buffer size
_shared_io_pool_debug_trc0trace kcbi debug info to tracefile
_shared_io_pool_size0Size of shared IO pool
_shared_io_set_valueFALSEshared io pool size set internal value – overwrite zero user size
_shared_iop_max_size536870912maximum shared io pool size
_shared_pool_max_size0shared pool maximum size when auto SGA enabled
_shared_pool_minsize_onFALSEshared pool minimum size when auto SGA enabled
_shared_pool_reserved_min_alloc4400minimum allocation size in bytes for reserved area of shared pool
_shared_pool_reserved_pct5percentage memory of the shared pool allocated for the reserved area
_shared_server_load_balance0shared server load balance
_shared_server_num_queues1number of shared server common queues
_short_stack_timeout_ms30000short stack timeout in ms
_shrunk_aggs_disable_threshold60percentage of exceptions at which to switch to full length aggs
_shrunk_aggs_enabledTRUEenable use of variable sized buffers for non-distinct aggregates
_side_channel_batch_size200number of messages to batch in a side channel message (DFS)
_side_channel_batch_timeout6timeout before shipping out the batched side channelmessages in seconds
_side_channel_batch_timeout_ms500timeout before shipping out the batched side channelmessages in milliseconds
_simple_view_mergingTRUEcontrol simple view merging performed by the optimizer
_simulate_mem_transferFALSEsimulate auto memory sga/pga transfers
_simulator_bucket_mindelta8192LRU bucket minimum delta
_simulator_internal_bound10simulator internal bound percent
_simulator_lru_rebalance_sizthr5LRU list rebalance threshold (size)
_simulator_lru_rebalance_thresh10240LRU list rebalance threshold (count)
_simulator_lru_scan_count8LRU scan count
_simulator_pin_inval_maxcnt16maximum count of invalid chunks on pin list
_simulator_reserved_heap_count4096simulator reserved heap count
_simulator_reserved_obj_count1024simulator reserved object count
_simulator_sampling_factor2sampling factor for the simulator
_simulator_upper_bound_multiple2upper bound multiple of pool size
_single_processFALSErun without detached processes
_siop_flashback_scandepth20Shared IO pool flashback io completion scan depth
_sixth_spare_parameter sixth spare parameter – string list
_skgxp_reaping1000tune skgxp OSD reaping limit
_skgxp_udp_ach_reaping_time120time in minutes before idle ach’s are reaped
_skgxp_udp_ack_delay0Enables delayed acks
_skgxp_udp_enable_dynamic_credit_mgmt0Enables dynamic credit management
_skgxp_udp_hiwat_warn1000ach hiwat mark warning interval
_skgxp_udp_interface_detection_time_secs60time in seconds between interface detection checks
_skgxp_udp_keep_alive_ping_timer_secs300connection idle time in seconds before keep alive is initiated. min: 30 sec max: 1800 sec default: 300 sec
_skgxp_udp_lmp_mtusize0MTU size for UDP LMP testing
_skgxp_udp_lmp_onFALSEenable UDP long message protection
_skgxp_udp_timed_wait_buffering1024diagnostic log buffering space (in bytes) for timed wait (0 means unbufferd
_skgxp_udp_timed_wait_seconds5time in seconds before timed wait is invoked
_skgxp_udp_use_tcbTRUEdisable use of high speek timer
_skip_assume_msgTRUEif TRUE, skip assume message for consigns at the master
_slave_mapping_enabledTRUEenable slave mapping when TRUE
_slave_mapping_group_size0force the number of slave group in a slave mapper
_small_table_threshold541threshold level of table size for direct reads
_smm_advice_enabledTRUEif TRUE, enable v$pga_advice
_smm_advice_log_size0overwrites default size of the PGA advice workarea history log
_smm_auto_cost_enabledTRUEif TRUE, use the AUTO size policy cost functions
_smm_auto_max_io_size248Maximum IO size (in KB) used by sort/hash-join in auto mode
_smm_auto_min_io_size56Minimum IO size (in KB) used by sort/hash-join in auto mode
_smm_bound0overwrites memory manager automatically computed bound
_smm_control0provides controls on the memory manager
_smm_freeable_retain5120value in KB of the instance freeable PGA memory to retain
_smm_isort_cap102400maximum work area for insertion sort(v1)
_smm_max_size40960maximum work area size in auto mode (serial)
_smm_min_size204minimum work area size in auto mode
_smm_px_max_size102400maximum work area size in auto mode (global)
_smm_retain_size0work area retain size in SGA for shared server sessions (0 for AUTO)
_smm_trace0Turn on/off tracing for SQL memory manager
_smon_internal_errlimit100limit of SMON internal errors
_smon_undo_seg_rescan_limit10limit of SMON continous undo segments re-scan
_smu_debug_mode0- set debug event for testing SMU operations
_smu_error_simulation_site0site ID of error simulation in KTU code
_smu_error_simulation_type0error 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
_sort_elimination_cost_ratio0cost ratio for sort eimination under first_rows mode
_sort_multiblock_read_count2multi-block read count for sort
_space_align_size1048576space align size
_spin_count1Amount to spin waiting for a latch
_spr_max_rules10000maximum number of rules in sql spreadsheet
_spr_push_pred_refsprTRUEpush predicates through reference spreadsheet
_spr_use_AW_ASTRUEenable AW for hash table in spreadsheet
_spr_use_hash_tableFALSEuse hash table for spreadsheet
_sql_analyze_parse_model2SQL Analyze Parse Model control parameter
_sql_connect_capability_override0SQL Connect Capability Table Override
_sql_connect_capability_table SQL Connect Capability Table (testing only)
_sql_hash_debug0Hash value of the SQL statement to debug
_sql_model_unfold_forloopsRUN_TIMEspecifies compile-time unfolding of sql model forloops
_sql_plan_baseline_capture_on_1_execFALSEWith auto-capture on, create new SQL plan baseline on first exec
_sqlexec_progression_cost1000sql execution progression monitoring cost threshold
_sqlmon_max_plan20Maximum number of plans entry that can be monitored. Defaults to 20 per CPU
_sqlmon_max_planlines300Number of plan lines beyond which a plan cannot be monitored
_sqlmon_threshold5CPU/IO time threshold before a statement is monitored. 0 is disabled
_sqltune_category_parsedDEFAULTParsed category qualifier for applying hintsets
_srvntfn_job_deq_timeout60srvntfn job deq timeout
_srvntfn_jobsubmit_interval3srvntfn job submit interval
_srvntfn_max_concurrent_jobs20srvntfn max concurrent jobs
_srvntfn_q_msgcount50srvntfn q msg count for job exit
_srvntfn_q_msgcount_inc100srvntfn 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_control0SQL Tuning Advisory control parameter
_stack_guard_level0stack guard level
_static_backgrounds static backgrounds
_statistics_based_srf_enabledTRUEenable/disable the use of statistics for storage reduction factor
_step_down_limit_in_pct1step down limit in percentage
_stn_trace0SQL tracing parameter
_storage_predicate_access_predicate0put storage predicate into access predicate in explain plan
_streams_pool_max_size0streams pool maximum size when auto SGA enabled
_subquery_pruning_cost_factor20subquery pruning cost factor
_subquery_pruning_enabledTRUEenable the use of subquery predicates to perform pruning
_subquery_pruning_mv_enabledFALSEenable the use of subquery predicates with MVs to perform pruning
_subquery_pruning_reduction50subquery pruning reduction factor
_swrf_metric_frequent_modeFALSEEnable/disable SWRF Metric Frequent Mode Collection
_swrf_mmon_dbfusTRUEEnable/disable SWRF MMON DB Feature Usage
_swrf_mmon_flushTRUEEnable/disable SWRF MMON FLushing
_swrf_mmon_metricsTRUEEnable/disable SWRF MMON Metrics Collection
_swrf_on_disk_enabledTRUEParameter to enable/disable SWRF
_swrf_test_action0test action parameter for SWRF
_swrf_test_dbfusFALSEEnable/disable DB Feature Usage Testing
_synonym_repoint_tracingFALSEwhether to trace metadata comparisons for synonym repointing
_sysaux_test_param1test parameter for SYSAUX
_system_index_caching0optimizer percent system index caching
_system_trig_enabledTRUEare system triggers enabled
_ta_lns_wait_for_arch_log20LNS Wait time for arhcived version of online log
_table_lookup_prefetch_size40table lookup prefetch vector size
_table_lookup_prefetch_thresh2table lookup prefetch threshold
_table_scan_cost_plus_oneTRUEbump estimated full table scan and index ffs cost by one
_target_rba_max_lag_percentage90target rba max log lag percentage
_tdb_debug_mode16set debug mode for testing transportable database
_temp_tran_block_threshold100number of blocks for a dimension before we temp transform
_temp_tran_cacheTRUEdetermines if temp table is created with cache option
_test_ksusigskip5test the function ksusigskip
_test_param_125test parmeter 1 – 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_525test parmeter 5 – deprecated integer
_test_param_60test parmeter 6 – size (ub8)
_test_spacebg0test space management background task
_third_spare_parameter third spare parameter – integer
_threshold_alerts_enable1if 1, issue threshold-based alerts
_timemodel_collectionTRUEenable timemodel collection
_timeout_actions_enabledTRUEenables or disables KSU timeout actions
_timer_precision20VKTM sleep time in milli-sec
_total_large_extent_memory0Total memory for allocating large extents
_tq_dump_period0time period for duping of TQ statistics (s)
_trace_buffer_wait_timeouts0trace buffer busy wait timeouts
_trace_buffersALL:256trace buffer sizes per process
_trace_dump_all_procsFALSEif TRUE on error buckets of all processes will be dumped to the current trace file
_trace_dump_client_bucketsTRUEif TRUE dump client (ie. non-kst) buckets
_trace_dump_cur_proc_onlyFALSEif TRUE on error just dump our process bucket
_trace_dump_static_onlyFALSEif TRUE filter trace dumps to always loaded dlls
_trace_events trace events enabled at startup
_trace_files_publicFALSECreate publicly accessible trace files
_trace_kqlidpFALSEtrace kqlidp0 operation
_trace_navigation_scopeglobalenabling trace navigation linking
_trace_pin_time0trace how long a current pin is held
_trace_pool_size trace pool size in bytes
_trace_processesALLenable KST tracing in process
_trace_virtual_columnsFALSEtrace virtual columns exprs
_transaction_auditingTRUEtransaction auditing records generated in the redo log
_transaction_recovery_servers0max number of parallel recovery slaves that may be used
_truncate_optimization_enabledTRUEdo truncate optimization if set to TRUE
_tsenc_tracing0Enable TS encryption tracing
_tsm_connect_string TSM test connect string
_tsm_disable_auto_cleanup1Disable TSM auto cleanup actions
_tts_allow_charset_mismatchFALSEallow plugging in a tablespace with an incompatible character set
_two_passTRUEenable two-pass thread recovery
_two_pass_reverse_polish_enabledTRUEuses two-pass reverse polish alg. to generate canonical forms
_uga_cga_large_extent_size262144UGA/CGA large extent size
_ultrafast_latch_statisticsTRUEmaintain fast-path statistics for ultrafast latches
_undo_autotuneTRUEenable auto tuning of undo_retention
_undo_block_compressionTRUEenable undo block compression
_undo_debug_mode0debug flag for undo related operations
_undo_debug_usage0invoke undo usage functions for testing
_union_rewrite_for_gsYES_GSET_MVSexpand queries with GSets into UNIONs for rewrite
_unnest_subqueryTRUEenables unnesting of correlated subqueries
_unused_block_compressionTRUEenable unused block compression
_update_datafile_headers_with_space_informationFALSEuser requested update of datafile headers of locally managed datafiles with space information
_use_best_fitFALSEuse best fit to allocate space
_use_column_stats_for_functionTRUEenable the use of column statistics for DDP functions
_use_ismTRUEEnable Shared Page Tables – ISM
_use_ism_for_pgaTRUEUse ISM for allocating large extents
_use_nosegment_indexesFALSEuse nosegment indexes in explain plan
_use_realfree_heapTRUEuse real-free based allocator for PGA memory
_use_seq_process_cacheTRUEwhether to use process local seq cache
_use_vector_postTRUEuse vector post
_use_zero_copy_ioTRUEShould network vector IO interface be used for data transfer
_validate_flashback_databaseFALSEScan database to validate result of flashback database
_vendor_lib_loc Vendor library search root directory
_verify_flashback_redoTRUEVerify that the redo logs needed for flashback are available
_verify_undo_quotaFALSETRUE – verify consistency of undo quota statistics
_very_large_partitioned_table1024very_large_partitioned_table
_virtual_column_overload_allowedTRUEoverload virtual columns expression
_wait_breakup_threshold_csecs600Wait breakup threshold (in centiseconds)
_wait_breakup_time_csecs300Wait breakup time (in centiseconds)
_wait_for_syncTRUEwait for sync on commit MUST BE ALWAYS TRUE
_walk_insert_threshold0maximum number of unusable blocks to walk across freelist
_watchpoint_onFALSEis the watchpointing feature turned on?
_wcr_control0Oracle internal test WCR parameter used ONLY for testing!
_windowfunc_optimization_settings0settings for window function optimizations
_with_subqueryOPTIMIZERWITH subquery transformation
_write_clones3write clones flag
_xpl_peeked_binds_log_size8192maximum bytes for logging peeked bind values for V$SQL_PLAN (0 = OFF)
_xpl_trace0Explain Plan tracing parameter
_xsolapi_auto_materialization_bound20OLAP API lower bound for auto materialization.
_xsolapi_auto_materialization_typePRED_AND_RCOLAP API behavior for auto materialization
_xsolapi_build_traceFALSEOLAP API output build info to trace file
_xsolapi_debug_outputSUPPRESSOLAP API debug output disposition
_xsolapi_densify_cubesTABULAROLAP API cube densification
_xsolapi_dimension_group_creationOVERFETCHOLAP API symmetric overfetch
_xsolapi_dml_traceFALSEOLAP API output dml commands and expressions to trace file
_xsolapi_fetch_typePARTIALOLAP API fetch type
_xsolapi_fix_vptrsFALSEOLAP API Enable vptr fixing logic in shared server mode
_xsolapi_generate_with_clauseFALSEOLAP API generates WITH clause?
_xsolapi_hierarchy_value_typeuniqueOLAP API hierarchy value type
_xsolapi_load_at_process_startNEVERWhen to load OLAP API library at server process start
_xsolapi_materialization_rowcache_min_rows_for_use1OLAP API min number of rows required to use rowcache in query materialization
_xsolapi_materialize_sourcesTRUEOLAP API Enable source materialization
_xsolapi_metadata_reader_mode11_ONLYOLAP API metadata reader mode
_xsolapi_odbo_modeFALSEOLAP API uses ODBO mode?
_xsolapi_opt_aw_positionTRUEOLAP API enables AW position and count optimization?
_xsolapi_optimize_suppressionTRUEOLAP API optimizes suppressions?
_xsolapi_precompute_subqueryTRUEOLAP API precomputes subqueries?
_xsolapi_remove_columns_for_materializationTRUEOLAP API removes columns for materialization?
_xsolapi_set_nlsTRUEOLAP API sets NLS?
_xsolapi_share_executorsTRUEOLAP API share executors?
_xsolapi_source_traceFALSEOLAP 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_hintsFALSEOLAP API enable automatic dimension hints
_xsolapi_sql_auto_measure_hintsTRUEOLAP API enable automatic measure hints
_xsolapi_sql_dimension_hints OLAP API dimension hints
_xsolapi_sql_enable_aw_joinTRUEOLAP API enables AW join?
_xsolapi_sql_enable_aw_qdr_mergeTRUEOLAP API enables AW QDR merge?
_xsolapi_sql_hints OLAP API generic hints
_xsolapi_sql_measure_hints OLAP API measure hints
_xsolapi_sql_minus_threshold1000OLAP API SQL MINUS threshold
_xsolapi_sql_optimizeTRUEOLAP API enable optimization
_xsolapi_sql_prepare_stmt_cache_size16OLAP API prepare statement cache size
_xsolapi_sql_remove_columnsTRUEOLAP API enable remove unused columns optimizations
_xsolapi_sql_result_set_cache_size32OLAP API result set cache size
_xsolapi_sql_symmetric_predicateTRUEOLAP 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_variablesTRUEOLAP API enable bind variables optimization
_xsolapi_stringify_order_levelsFALSEOLAP API stringifies order levels?
_xsolapi_support_mtmFALSEOLAP API MTM mapping classes supported?
_xsolapi_suppression_aw_mask_threshold1000OLAP API suppression AW mask threshold
_xsolapi_suppression_chunk_size4000OLAP API suppression chunk size
_xsolapi_use_modelsTRUEOLAP API uses models?
_xsolapi_use_olap_dmlTRUEOLAP API uses OLAP DML?
_xsolapi_use_olap_dml_for_rankTRUEOLAP API uses OLAP DML for rank?
_xt_coveragenoneexternal tables code coverage parameter
_xt_tracenoneexternal tables trace parameter
_xtbuffer_size0buffer size in KB needed for populate/query operation
_xtts_allow_pre10FALSEallow cross platform for pre10 compatible tablespace
_xtts_set_platform_infoFALSEset cross platform info during file header read
_yield_check_interval100000interval to check whether actses should yield


  • 0
    点赞
  • 0
    收藏
    觉得还不错? 一键收藏
  • 0
    评论

“相关推荐”对你有帮助么?

  • 非常没帮助
  • 没帮助
  • 一般
  • 有帮助
  • 非常有帮助
提交
评论
添加红包

请填写红包祝福语或标题

红包个数最小为10个

红包金额最低5元

当前余额3.43前往充值 >
需支付:10.00
成就一亿技术人!
领取后你会自动成为博主和红包主的粉丝 规则
hope_wisdom
发出的红包
实付
使用余额支付
点击重新获取
扫码支付
钱包余额 0

抵扣说明:

1.余额是钱包充值的虚拟货币,按照1:1的比例进行支付金额的抵扣。
2.余额无法直接购买下载,可以购买VIP、付费专栏及课程。

余额充值