v$parameter动态视图并不能查到Oracle的全部参数,通过v$parameter动态视图我们只能查看到Oracle数据库相关的一些一般普通常用的参数,v$parameter动态视图中并没有包含很多以下划线打头的Oracle核心内部参数,而这些被隐藏的oracle未公开的内部参数,有时对我们实际工作学习中的问题解决有十分重要的作用。
那如何才能查看到这些隐含参数呢,这里提供一个脚本。
这个脚本来自于 secooler 老师技术博客中的一篇文章,《【脚本】隐含参数及注释信息的查询方法》,这里向大师致敬一下。
脚本
col name for a32
col value for a24
col description for a70
select a.ksppinm name,b.ksppstvl value,a.ksppdesc description
from x$ksppi a,x$ksppcv b
where a.inst_id = USERENV ('Instance')
and b.inst_id = USERENV ('Instance')
and a.indx = b.indx
and upper(a.ksppinm) LIKE upper('%¶m%')
order by name
/
-----------------------
例子:(这里我把倒数第二句 and upper(a.ksppinm) LIKE upper('%¶m%') 去掉执行的,这样我们来看一下oracle的全部参数)
SQL> set linesize 8000
SQL> set pagesize 8000
SQL> col name for a32
SQL> col value for a24
SQL> col description for a70
SQL>
SQL> select a.ksppinm name,b.ksppstvl value,a.ksppdesc description
2 from x$ksppi a,x$ksppcv b
3 where a.inst_id = USERENV ('Instance')
4 and b.inst_id = USERENV ('Instance')
5 and a.indx = b.indx
6 order by name;
NAME VALUE DESCRIPTION
-------------------------------- ------------------------ ----------------------------------------------------------------------
O7_DICTIONARY_ACCESSIBILITY FALSE Version 7 Dictionary Accessibility Support
_4031_dump_bitvec 67194879 bitvec to specify dumps prior to 4031 error
_4031_dump_interval 300 Dump 4031 error once for each n-second interval
_4031_max_dumps 100 Maximum number of 4031 dumps for this process
_4031_sga_dump_interval 3600 Dump 4031 SGA heapdump error once for each n-second interval
_4031_sga_max_dumps 10 Maximum number of SGA heapdumps
_NUMA_instance_mapping Not specified Set of nodes that this instance should run on
_NUMA_pool_size Not specified aggregate size in bytes of NUMA pool
_PX_use_large_pool FALSE Use Large Pool as source of PX buffers
__db_cache_size 406847488 Actual size of DEFAULT buffer pool for standard block size buffers
__dg_broker_service_names chic_XPT service names for broker use
__java_pool_size 4194304 Actual size in bytes of java pool
__large_pool_size 4194304 Actual size in bytes of large pool
__shared_pool_size 188743680 Actual size in bytes of shared pool
__streams_pool_size 0 Actual size in bytes of streams pool
_abort_recovery_on_join FALSE if TRUE, abort recovery on join reconfigurations
_accept_versions List of parameters for rolling operation
_active_standby_fast_reconfigura TRUE if TRUE optimize dlm reconfiguration for active/standby OPS
tion
_adaptive_direct_read TRUE Adaptive Direct Read
_adaptive_fetch_enabled TRUE enable/disable adaptive fetch in parallel group by
_add_stale_mv_to_dependency_list TRUE add stale mv to dependency list
_addm_auto_enable TRUE governs whether ADDM gets run automatically after every AWR snapshot
_addm_skiprules comma-separated list of ADDM nodes to skip
_addm_version_check TRUE governs whether ADDM checks the input AWR snapshot version
_adjust_literal_replacement FALSE If TRUE, we will adjust the SQL/PLUS output
_affinity_on TRUE enable/disable affinity at run time
_aiowait_timeouts 100 Number of aiowait timeouts before error is reported
_alert_expiration 604800 seconds before an alert message is moved to exception queue
_alert_message_cleanup 1 Enable Alert Message Cleanup
_alert_message_purge 1 Enable Alert Message Purge
_alert_post_background 1 Enable Background Alert Posting
_all_shared_dblinks treat all dblinks as shared
_allocate_creation_order FALSE should files be examined in creation order during allocation
_allocation_update_interval 3 interval at which successful search in L1 should be updated
_allow_commutativity TRUE allow for commutativity of +, * when comparing expressions
_allow_error_simulation FALSE Allow error simulation for testing
_allow_level_without_connect_by FALSE allow level without connect by
_allow_read_only_corruption FALSE allow read-only open even if database is corrupt
_allow_resetlogs_corruption FALSE allow resetlogs even if it will cause corruption
_allow_terminal_recovery_corrupt FALSE Finish terminal recovery even if it may cause corruption
ion
_alternate_iot_leaf_block_split_ TRUE enable alternate index-organized table leaf-block split-points
points
_always_anti_join CHOOSE always use this method for anti-join when possible
_always_semi_join CHOOSE always use this method for semi-join when possible
_always_star_transformation FALSE always favor use of star transformation
_app_ctx_vers FALSE enable app ctx versioning
_aq_tm_scanlimit 0 scan limit for Time Managers to clean up IOT
_arch_io_slaves 0 ARCH I/O slaves
_array_update_vector_read_enable FALSE Enable array update vector read
d
_ash_disk_filter_ratio 10 Ratio of the number of in-memory samples to the number of samples actu
ally written to disk
_ash_disk_write_enable TRUE To enable or disable Active Session History flushing
_ash_dummy_test_param 0 Oracle internal dummy ASH parameter used ONLY for testing!
_ash_eflush_trigger 66 The percentage above which if the in-memory ASH is full the emergency
flusher will be triggered
_ash_enable TRUE To enable or disable Active Session sampling and flushing
_ash_sample_all FALSE To enable or disable sampling every connected session including ones w
aiting for idle waits
_ash_sampling_interval 1000 Time interval between two successive Active Session samples in millise
cs
_ash_size 1048618 To set the size of the in-memory Active Session History buffers
_asm_acd_chunks 1 initial ACD chunks created
_asm_allow_only_raw_disks TRUE Discovery only raw devices
_asm_allow_resilver_corruption FALSE Enable disk resilvering for external redundancy
_asm_ausize 1048576 allocation unit size
_asm_blksize 4096 metadata block size
_asm_disk_repair_time 14400 seconds to wait before dropping a failing disk
_asm_droptimeout 60 timeout before offlined disks get dropped (in 3s ticks)
_asm_emulmax 10000 max number of concurrent disks to emulate I/O errors
_asm_emultimeout 0 timeout before emulation begins (in 3s ticks)
_asm_kfdpevent 0 KFDP event
_asm_libraries ufs library search order for discovery
_asm_maxio 1048576 Maximum size of individual I/O request
_asm_stripesize 131072 ASM file stripe size
_asm_stripewidth 8 ASM file stripe width
_asm_wait_time 18 Max/imum time to wait before asmb exits
_asmlib_test 0 Osmlib test event
_asmsid asm ASM instance id
_assm_default TRUE ASSM default
_async_recovery_claims TRUE if TRUE, issue recovery claims asynchronously
_async_recovery_reads TRUE if TRUE, issue recovery reads asynchronously
_avoid_prepare TRUE if TRUE, do not prepare a buffer when the master is local
_awr_corrupt_mode FALSE AWR Corrupt Mode
_awr_disabled_flush_tables Disable flushing of specified AWR tables
_awr_flush_threshold_metrics FALSE Enable/Disable Flushing AWR Workload Metrics
_awr_flush_workload_metrics FALSE Enable/Disable Flushing AWR Workload Metrics
_awr_mmon_cpuusage TRUE Enable/disable AWR MMON CPU Usage Tracking
_awr_restrict_mode FALSE AWR Restrict Mode
_awr_sql_child_limit 200 Setting for AWR SQL Child Limit
_b_tree_bitmap_plans TRUE enable the use of bitmap plans for tables w. only B-tree indexes
_backup_disk_io_slaves 0 BACKUP Disk I/O slaves
_backup_io_pool_size 1048576 memory to reserve from the large pool
_backup_kgc_bufsz 0 specifies buffer size to be used for kgc compression
_backup_kgc_niters 0 specifies number of iterations used for kgc compression
_backup_kgc_type 0 specifies compression type used for kgc compression
_backup_ksfq_bufcnt 0 number of the ksfq buffers used for backup/restore
_backup_ksfq_bufsz 0 size of the ksfq buffer used for backup/restore
_backup_max_gap_size 4294967294 largest gap in an incremental/optimized backup buffer, in bytes
_bct_bitmaps_per_file 8 number of bitmaps to store for each datafile
_bct_buffer_allocation_max 104857600 maximum size of all change tracking buffer allocations, in bytes
_bct_buffer_allocation_min_exten 1 mininum number of extents to allocate per buffer allocation
ts
_bct_buffer_allocation_size 2097152 size of one change tracking buffer allocation, in bytes
_bct_chunk_size 0 change tracking datafile chunk size, in bytes
_bct_crash_reserve_size 262144 change tracking reserved crash recovery SGA space, in bytes
_bct_file_block_size 0 block size of change tracking file, in bytes
_bct_file_extent_size 0 extent size of change tracking file, in bytes
_bct_fixtab_file change tracking file for fixed tables
_bct_initial_private_dba_buffer_ 0 initial number of entries in the private change tracking dba buffers
size
_bct_public_dba_buffer_size 0 total size of all public change tracking dba buffers, in bytes
_bitmap_or_improvement_enabled TRUE controls extensions to partition pruning for general predicates
_block_change_tracking TRUE change tracking possible
_blocks_per_cache_server 128 number of consecutive blocks per global cache server
_bloom_filter_debug 0 debug level for bloom filtering
_bloom_filter_enabled TRUE enables or disables bloom filter
_bt_mmv_query_rewrite_enabled TRUE allow rewrites with multiple MVs and base tables
_buffer_busy_wait_timeout 100 buffer busy wait time in centiseconds
_bufq_flow_control_thrsh 0 flow control threshold value
_bufq_max_msg_sz 0 maximum size of the message allowed in memory
_bufq_stop_flow_control FALSE Stop enforcing flow control for buffered queues
_build_deferred_mv_skipping_mvlo FALSE DEFERRED MV creation skipping MV log setup update
g_update
_bump_highwater_mark_count 0 how many blocks should we allocate per free list on advancing HWM
_bwr_for_flushed_pi TRUE if TRUE, generate a BWR for a flushed PI
_cache_stats_monitor FALSE if TRUE, enable cache stats monitoring
_cgs_reconfig_timeout 120 CGS reconfiguration timeout interval
_cgs_send_timeout 300 CGS send timeout value
_check_block_after_checksum TRUE perform. block check after checksum if both are turned on
_check_ts_threshold 0 check tablespace thresholds
_cleanup_rollback_entries 100 no. of undo entries to apply per transaction cleanup
_close_cached_open_cursors FALSE close cursors cached by PL/SQL at each commit
_cluster_library clss cluster library selection
_collapse_wait_history FALSE collapse wait history
_collect_undo_stats TRUE Collect Statistics v$undostat
_column_compression_factor 0 Column compression ratio
_column_elimination_off FALSE turn off predicate-only column elimination
_column_tracking_level 1 column usage tracking
_compilation_call_heap_extent_si 16384 Size of the compilation call heaps extents
ze
_complex_view_merging TRUE enable complex view merging
_controlfile_block_size 0 control file block size in bytes
_controlfile_enqueue_dump FALSE dump the system states after controlfile enqueue timeout
_controlfile_enqueue_timeout 900 control file enqueue timeout in seconds
_controlfile_section_init_size control file initial section size
_controlfile_section_max_expand control file max expansion rate
_controlfile_update_check OFF controlfile update sanity check
_convert_set_to_join FALSE enables conversion of set operator to join
_coord_message_buffer 0 parallel recovery coordinator side extra message buffer size
_corrupted_rollback_segments corrupted undo segment list
_cost_equality_semi_join TRUE enables costing of equality semi-join
_cpu_to_io 0 divisor for converting CPU cost to I/O cost
_cr_grant_global_role TRUE if TRUE, grant lock for CR requests when block is in global role
_cr_grant_local_role AUTO turn 3-way CR grants off, make it automatic, or turn it on
_cr_server_log_flush TRUE if TRUE, flush redo log before serving a CR buffer
_ctas_hwm_brokered_loads TRUE Enable HWM brokered CTAS
_cursor_bind_capture_area_size 400 maximum size of the cursor bind capture area
_cursor_bind_capture_interval 900 interval (in seconds) between two bind capture for a cursor
_cursor_cache_frame_bind_memory FALSE frame. & bind buffer caching
_cursor_db_buffers_pinned 320 additional number of buffers a cursor can pin at once
_cursor_plan_enabled TRUE enable collection and display of cursor plans
_cursor_plan_hash_version 1 version of cursor plan hash value
_cursor_plan_unparse_enabled TRUE enables/disables using unparse to build projection/predicates
_cursor_stats_bucket 15 Hash table buckets for cursor stats (2^).
_cursor_stats_heap 4 Heaps/latches for cursor stats.
_db_aging_cool_count 1 Touch count set when buffer cooled
_db_aging_freeze_cr FALSE Make CR buffers always be too cold to keep in cache
_db_aging_hot_criteria 2 Touch count which sends a buffer to head of replacement list
_db_aging_stay_count 0 Touch count set when buffer moved to head of replacement list
_db_aging_touch_time 3 Touch count which sends a buffer to head of replacement list
_db_always_check_system_ts TRUE Always perform. block check and checksum for System tablespace
_db_block_adjcheck TRUE adjacent cache buffer checks - low blkchk overwrite parameter
_db_block_adjchk_level 79397888 adjacent cache buffer check level
_db_block_align_direct_read TRUE Align Direct Reads
_db_block_buffers 48403 Number of database blocks cached in memory: hidden parameter
_db_block_cache_clone FALSE Always clone data blocks on get (for debugging)
_db_block_cache_history 0 buffer header tracing (non-zero only when debugging)
_db_block_cache_history_level 2 buffer header tracing level
_db_block_cache_num_umap 0 number of unmapped buffers (for tracking swap calls on blocks)
_db_block_cache_protect FALSE protect database blocks (true only when debugging)
_db_block_cache_protect_internal 0 protect database blocks (for strictly internal use only)
_db_block_check_for_debug FALSE Check more and dump block before image for debugging
_db_block_check_objtyp TRUE check objd and typ on cache disk read
_db_block_do_full_mbreads FALSE do full block read even if some blocks are in cache
_db_block_hash_buckets 131072 Number of database block hash buckets
_db_block_hash_latches 1024 Number of database block hash latches
_db_block_hi_priority_batch_size 0 Fraction of writes for high priority reasons
_db_block_known_clean_pct 2 Initial Percentage of buffers to maintain known clean
_db_block_lru_latches 8 number of lru latches
_db_block_max_cr_dba 6 Maximum Allowed Number of CR buffers per dba
_db_block_max_scan_pct 40 Percentage of buffers to inspect when looking for free
_db_block_med_priority_batch_siz 0 Fraction of writes for medium priority reasons
e
_db_block_numa 1 Number of NUMA nodes
_db_block_prefetch_limit 0 Prefetch limit in blocks
_db_block_prefetch_quota 10 Prefetch quota as a percent of cache size
_db_block_table_scan_buffer_size 4194304 Size of shared table scan read buffer
_db_block_temp_redo FALSE generate redo for temp blocks
_db_block_trace_protect FALSE trace buffer protect calls
_db_cache_advice_batch_size 128 cache advisory simulation batch size
_db_cache_advice_sample_factor 4 cache advisory sampling factor
_db_cache_crx_check FALSE check for costly crx examination functions
_db_cache_pre_warm TRUE Buffer Cache Pre-Warm Enabled : hidden parameter
_db_cache_process_cr_pin_max maximum number of cr pins a process may have
_db_change_notification_enable TRUE enable db change notification
_db_fast_obj_check FALSE enable fast object drop sanity check
_db_fast_obj_ckpt TRUE enable fast object checkpoint
_db_fast_obj_truncate TRUE enable fast object truncate
_db_file_direct_io_count 1048576 Sequential I/O buf size
_db_file_exec_read_count 16 multiblock read count for regular clients
_db_file_format_io_buffers 4 Block formatting I/O buf count
_db_file_noncontig_mblock_read_c 11 number of noncontiguous db blocks to be prefetched
ount
_db_file_optimizer_read_count 16 multiblock read count for regular clients
_db_handles 750 System-wide simultaneous buffer operations
_db_handles_cached 5 Buffer handles cached each process
_db_hot_block_tracking FALSE track hot blocks for hash latch contention
_db_index_block_checking TRUE index block checking override parameter
_db_large_dirty_queue 25 Number of buffers which force dirty queue to be written
_db_lost_write_checking FALSE Enable scn based lost write detection mechanism
_db_mttr_advice ON MTTR advisory
_db_mttr_partitions 0 number of partitions for MTTR advisory
_db_mttr_sample_factor 64 MTTR simulation sampling factor
_db_mttr_sim_target MTTR simulation targets
_db_mttr_sim_trace_size 256 MTTR simulation trace size
_db_mttr_trace_to_alert FALSE dump trace entries to alert file
_db_obj_ckpt_ordered FALSE fast object checkpoint ordered by lrba
_db_obj_enable_ksr TRUE enable ksr in object checkpoint/reuse
_db_percent_hot_default 50 Percent of default buffer pool considered hot
_db_percent_hot_keep 0 Percent of keep buffer pool considered hot
_db_percent_hot_recycle 0 Percent of recycle buffer pool considered hot
_db_percpu_create_cachesize 2 size of cache created per cpu in deferred cache create
_db_recovery_temporal_file_dest default database recovery temporal file location
_db_row_overlap_checking TRUE row overlap checking override parameter for data/index blocks
_db_todefer_cache_create TRUE buffer cache deferred create
_db_writer_chunk_writes 0 Number of writes DBWR should wait for
_db_writer_coalesce_area_size 1048576 Size of memory allocated to dbwriter for coalescing writes
_db_writer_coalesce_write_limit 131072 Limit on size of coalesced write
_db_writer_flush_imu TRUE If FALSE, DBWR will not downgrade IMU txns for AGING
_db_writer_histogram_statistics FALSE maintain dbwr histogram statistics in x$kcbbhs
_db_writer_max_writes 0 Max number of outstanding DB Writer IOs
_db_writer_verify_writes FALSE Enable lost write detection mechanism
_dbg_proc_startup FALSE debug process startup
_dbwr_async_io TRUE Enable dbwriter asynchronous writes
_dbwr_scan_interval 300 dbwriter scan interval
_dbwr_tracing 0 Enable dbwriter tracing
_dead_process_scan_interval 10 PMON dead process scan interval
_debug_enable FALSE wait for debug
_dedicated_server_poll_count 10 dedicated server poll count
_dedicated_server_post_wait FALSE dedicated server post/wait
_dedicated_server_post_wait_call FALSE dedicated server post/wait call
_default_encrypt_alg 0 default encryption algorithm
_default_non_equality_sel_check TRUE sanity check on default selectivity for like/range predicate
_delay_index_maintain TRUE delays index maintenance until after MV is refreshed
_diag_daemon TRUE start DIAG daemon
_diag_diagnostics TRUE Turn off diag diagnostics
_dimension_skip_null TRUE control dimension skip when null feature
_disable_adaptive_shrunk_aggrega FALSE adaptive shrunk aggregation
tion
_disable_datalayer_sampling FALSE disable datalayer sampling
_disable_duplex_link FALSE Turn off connection duplexing
_disable_fast_aggregation FALSE fast aggregation
_disable_file_locks FALSE disable file locks for control, data, redo log files
_disable_function_based_index FALSE disable function-based index matching
_disable_health_check FALSE Disable Health Check
_disable_image_check FALSE Disable Oracle executable image checking
_disable_incremental_checkpoints FALSE Disable incremental checkpoints for thread recovery
_disable_incremental_recovery_ck FALSE Disable incremental recovery checkpoint mechanism
pt
_disable_instance_params_check FALSE disable instance type check for ksp
_disable_interface_checking FALSE disable interface checking at startup
_disable_kcbhxor_osd FALSE disable kcbh(c)xor OSD functionality
_disable_latch_free_SCN_writes_v FALSE disable latch-free SCN writes using 32-bit compare & swap
ia_32cas
_disable_latch_free_SCN_writes_v FALSE disable latch-free SCN writes using 64-bit compare & swap
ia_64cas
_disable_logging FALSE Disable logging
_disable_multiple_block_sizes FALSE disable multiple block size support (for debugging)
_disable_ntlog_events FALSE Disable logging to NT event log
_disable_odm FALSE disable odm feature
_disable_recoverable_recovery FALSE Disable the new recoverable recovery mechanism
_disable_recovery_read_skip FALSE Disable the read optimization during media recovery
_disable_sample_io_optim FALSE disable row sampling IO optimization
_disable_savepoint_reset FALSE disable the fix for bug 1402161
_disable_selftune_checkpointing FALSE Disable self-tune checkpointing
_disable_streams_pool_auto_tunin FALSE disable streams pool auto tuning
g
_disable_system_state 4294967294 disable system state dump
_disable_txn_alert 0 disable txn layer alert
_discrete_transactions_enabled FALSE enable OLTP mode
_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_unnesting FALSE enables unnesting of in subquery into distinct view
_distributed_recovery_connection 200 number of seconds RECO holds outbound connections open
_hold_time
_dlm_send_timeout 30000 DLM send timeout value
_dlmtrace Trace string of global enqueue type(s)
_dm_max_shared_pool_pct 1 max percentage of the shared pool to use for a mining model
_dml_monitoring_enabled TRUE enable modification monitoring
_domain_index_batch_size 2000 maximum number of rows from one call to domain index fetch routine
_domain_index_dml_batch_size 200 maximum number of rows for one call to domain index dml routines
_drop_table_granule 256 drop_table_granule
_drop_table_optimization_enabled TRUE reduce SGA memory use during drop of a partitioned table
_ds_iocount_iosize 6553664 Dynamic Sampling Service defaults: #IOs and IO Size
_dss_cache_flush FALSE enable full cache flush for parallel execution
_dtree_area_size 131072 size of Decision Tree Classification work area
_dtree_binning_enabled TRUE Decision Tree Binning Enabled
_dtree_bintest_id 0 Decision Tree Binning Test ID
_dtree_compressbmp_enabled TRUE Decision Tree Using Compressed Bitmaps Enabled
_dtree_max_surrogates 1 maximum number of surrogates
_dtree_pruning_enabled TRUE Decision Tree Pruning Enabled
_dummy_instance FALSE dummy instance started by RMAN
_dump_common_subexpressions FALSE dump common subexpressions
_dump_connect_by_loop_data FALSE dump connect by loop error message into trc file
_dump_cursor_heap_sizes FALSE dump comp/exec heap sizes to tryace file
_dump_interval_limit 120 trace dump time interval limit (in seconds)
_dump_max_limit 5 max number of dump within dump interval
_dump_qbc_tree 0 dump top level query parse tree to trace
_dump_rcvr_ipc TRUE if TRUE enables IPC dump at instance eviction time
_dump_system_state_scope local scope of sysstate dump during instance termination
_dump_trace_scope global scope of trace dump during a process crash
_dynamic_rls_policies TRUE rls policies are dynamic
_dynamic_stats_threshold 30 delay threshold (in seconds) between sending statistics messages
_eliminate_common_subexpr TRUE enables elimination of common sub-expressions
_enable_NUMA_optimization TRUE Enable NUMA specific optimizations
_enable_block_level_transaction_ TRUE enable block level recovery
recovery
_enable_cscn_caching FALSE enable commit SCN caching for all transactions
_enable_default_affinity 0 to enable default implementation of affinity osds
_enable_dml_lock_escalation TRUE enable dml lock escalation against partitioned tables if TRUE
_enable_exchange_validation_usin TRUE use check constraints on the table for validation
g_check
_enable_fast_ref_after_mv_tbs FALSE enable fast refresh after move tablespace
_enable_hash_overflow FALSE TRUE - enable hash cluster overflow based on SIZE
_enable_hwm_sync TRUE enable HWM synchronization
_enable_kgh_policy FALSE temporary to disable/enable kgh policy
_enable_list_io FALSE Enable List I/O
_enable_nativenet_tcpip FALSE Enable skgxp driver usage for native net
_enable_refresh_schedule TRUE enable or disable MV refresh scheduling (revert to 9.2 behavior)
_enable_reliable_latch_waits TRUE Enable reliable latch waits
_enable_rlb TRUE enable RLB metrics processing
_enable_tablespace_alerts TRUE enable tablespace alerts
_enable_type_dep_selectivity TRUE enable type dependent selectivity estimates
_enqueue_debug_multi_instance FALSE debug enqueue multi instance
_enqueue_hash 375 enqueue hash table length
_enqueue_hash_chain_latches 2 enqueue hash chain latches
_enqueue_locks 2300 locks for managed enqueues
_enqueue_resources 968 resources for enqueues
_expand_aggregates TRUE expand aggregates
_explain_rewrite_mode FALSE allow additional messages to be generated during explain rewrite
_extended_pruning_enabled TRUE do runtime pruning in iterator if set to TRUE
_fair_remote_cvt FALSE if TRUE enables fair remote convert
_fairness_threshold 4 number of times to CR serve before downgrading lock
_fast_dual_enabled TRUE enable/disable fast dual
_fast_full_scan_enabled TRUE enable/disable index fast full scan
_fast_start_instance_recovery_ta 0 cluster availability target time in RAC environment
rget
_fic_algorithm_set automatic Set Frequent Itemset Counting Algorithm
_fic_area_size 131072 size of Frequent Itemset Counting work area
_fic_max_length 20 Frequent Itemset Counting Maximum Itemset Length
_fic_min_bmsize 1024 Frequent Itemset Counting Minimum BITMAP Size
_fic_outofmem_candidates FALSE Frequent Itemset Counting Out Of Memory Candidates Generation
_fifth_spare_parameter fifth spare parameter - string
_filemap_dir FILEMAP directory
_first_spare_parameter first spare parameter - integer
_flashback_allow_noarchivelog FALSE Allow enabling flashback on noarchivelog database
_flashback_barrier_interval 1800 Flashback barrier interval in seconds
_flashback_copy_latches 10 Number of flashback copy latches
_flashback_fuzzy_barrier TRUE Use flashback fuzzy barrier
_flashback_generation_buffer_siz 8388608 flashback generation buffer size
e
_flashback_hint_barrier_percent 20 Flashback hint barrier percent
_flashback_log_io_error_behavior. 0 Specify Flashback log I/O error behavior
_flashback_log_min_size 100 Minimum flashback log size
_flashback_log_size 1000 Flashback log size
_flashback_logfile_enqueue_timeo 600 flashback logfile enqueue timeout for opens
ut
_flashback_max_log_size 0 Maximum flashback log size in bytes (OS limit)
_flashback_max_n_log_per_thread 2048 Maximum number of flashback logs per flashback thread
_flashback_n_log_per_thread 128 Desired number of flashback logs per flashback thread
_flashback_standby_barrier_inter 1800 Flashback standby barrier interval in seconds
val
_flashback_verbose_info FALSE Print verbose information about flashback database
_flashback_write_size_qm 4 Desired flashback write size in quarter MB
_force_datefold_trunc FALSE force use of trunc for datefolding rewrite
_force_rewrite_enable FALSE control new query rewrite features
_force_temptables_for_gsets FALSE executes concatenation of rollups using temp tables
_fourth_spare_parameter fourth spare parameter - string
_full_pwise_join_enabled TRUE enable full partition-wise join when TRUE
_gby_hash_aggregation_enabled TRUE enable group-by and aggregation using hash scheme
_gby_onekey_enabled TRUE enable use of one comparison of all group by keys
_gc_affinity_limit 50 dynamic affinity limit
_gc_affinity_minimum 1200 dynamic affinity minimum activity per minute
_gc_affinity_time 10 if non zero, enable dynamic object affinity
_gc_check_bscn TRUE if TRUE, check for stale blocks
_gc_coalesce_recovery_reads TRUE if TRUE, coalesce recovery reads
_gc_defer_time 3 how long to defer down converts for hot buffers
_gc_dynamic_affinity_locks TRUE if TRUE, get dynamic affinity locks
_gc_element_percent 103 global cache element percent
_gc_global_lru AUTO turn global lru off, make it automatic, or turn it on
_gc_integrity_checks 1 set the integrity check level
_gc_keep_recovery_buffers TRUE if TRUE, make recovery buffers current
_gc_latches 8 number of latches per LMS process
_gc_maximum_bids 0 maximum number of bids which can be prepared
_gc_statistics TRUE if TRUE, kcl statistics are maintained
_gc_undo_affinity TRUE if TRUE, enable dynamic undo affinity
_gc_undo_affinity_locks TRUE if TRUE, get affinity locks for undo
_gc_use_cr TRUE if TRUE, allow CR pins on PI and WRITING buffers
_gc_vector_read TRUE if TRUE, vector read current buffers
_gcs_fast_reconfig TRUE if TRUE, enable fast reconfiguration for gcs locks
_gcs_latches 0 number of gcs resource hash latches to be allocated per LMS process
_gcs_process_in_recovery TRUE if TRUE, process gcs requests during instance recovery
_gcs_resources number of gcs resources to be allocated
_gcs_shadow_locks number of pcm shadow locks to be allocated
_generalized_pruning_enabled TRUE controls extensions to partition pruning for general predicates
_ges_dd_debug TRUE if TRUE enables GES deadlock detection debug diagnostics
_ges_diagnostics TRUE if TRUE enables GES diagnostics
_ges_health_check 1 if greater than 0 enables GES system health check
_groupby_nopushdown_cut_ratio 3 groupby nopushdown cut ratio
_groupby_orderby_combine 5000 groupby/orderby don't combine threshold
_gs_anti_semi_join_allowed TRUE enable anti/semi join for the GS query
_hang_analysis_num_call_stacks 3 hang analysis num call stacks
_hang_detection 0 Hang Management detection interval
_hard_protection FALSE if TRUE enable H.A.R.D specific format changes
_hash_join_enabled TRUE enable/disable hash join
_hash_multiblock_io_count 0 number of blocks hash join will read/write at once
_high_server_threshold 0 high server thresholds
_hj_bit_filter_threshold 50 hash-join bit filtering threshold (0 always enabled)
_hwm_sync_threshold 10 HWM synchronization threshold in percentage
_idl_conventional_index_maintena TRUE enable conventional index maintenance for insert direct load
nce
_idxrb_rowincr 100000000 proportionality constant for dop vs. rows in index rebuild
_ignore_desc_in_index FALSE ignore DESC in indexes, sort those columns ascending anyhow
_immediate_commit_propagation TRUE if TRUE, propagate commit SCN immediately
_improved_outerjoin_card TRUE improved outer-join cardinality calculation
_improved_row_length_enabled TRUE enable the improvements for computing the average row length
_imr_active TRUE Activate Instance Membership Recovery feature
_imr_disk_voting_interval 3 Maximum wait for IMR disk voting (seconds)
_imr_max_reconfig_delay 300 Maximum Reconfiguration delay (seconds)
_imr_splitbrain_res_wait 600 Maximum wait for split-brain resolution (seconds)
_imu_pools 3 in memory undo pools
_in_memory_undo TRUE Make in memory undo for top level transactions
_incremental_recovery_ckpt_min_b 30 Minimum number of writes for incremental recovery ckpt every 3 sec
atch
_index_join_enabled TRUE enable the use of index joins
_index_prefetch_factor 100 index prefetching factor
_init_granule_interval 10 number of granules to process for deferred cache
_init_sql_file %ORACLE_HOME%\RDBMS\ADMI File containing SQL statements to execute upon database creation
N\SQL.BSQ
_inject_startup_fault 0 inject fault in the startup code
_insert_enable_hwm_brokered TRUE during parallel inserts high water marks are brokered
_inst_locking_period 5 period an instance can retain a newly acquired level1 bitmap
_interconnect_checksum TRUE if TRUE, checksum interconnect blocks
_intrapart_pdml_enabled TRUE Enable intra-partition updates/deletes
_intrapart_pdml_randomlocal_enab TRUE Enable intra-partition updates/deletes with random local dist
led
_io_shared_pool_size 4194304 Size of I/O buffer pool from SGA
_io_slaves_disabled FALSE Do not use I/O slaves
_ior_serialize_fault 0 inject fault in the ior serialize code
_ioslave_batch_count 1 Per attempt IOs picked
_ioslave_issue_count 500 IOs issued before completion check
_job_queue_interval 5 Wakeup interval in seconds for job queue co-ordinator
_kcl_commit TRUE if TRUE, call kjbcommit
_kcl_conservative_log_flush FALSE if TRUE, conservatively log flush before CR serving
_kcl_debug TRUE if TRUE, record le history
_kcl_index_split TRUE if TRUE, reject pings on blocks in middle of a split
_kcl_undo_grouping 32 grouping for undo block locks
_kcl_undo_locks 128 number of locks per undo segment
_kdbl_enable_post_allocation FALSE allocate dbas after populating data buffers
_keep_remote_column_size FALSE remote column size does not get modified
_kernel_message_network_driver FALSE kernel message network driver
_kffmap_hash_size 1024 size of kffmap_hash table
_kffmop_hash_size 2048 size of kffmop_hash table
_kghdsidx_count 1 max kghdsidx count
_kgl_bucket_count 9 index to the bucket count array
_kgl_fixed_extents TRUE fixed extent size for library cache memory allocations
_kgl_hash_collision FALSE whether KGL hash collision is possible
_kgl_heap_size 1024 extent size for library cache heap 0
_kgl_keep_cache_pct 30 KGL keep cache minimum threshold
_kgl_keep_cache_retain_pct 20 KGL keep cache retain threshold
_kgl_large_heap_warning_threshol 2097152 maximum heap size before KGL writes warnings to the alert log
d
_kgl_latch_count 0 number of library cache latches
_kgl_multi_instance_invalidation TRUE whether KGL to support multi-instance invalidations
_kgl_multi_instance_lock TRUE whether KGL to support multi-instance locks
_kgl_multi_instance_pin TRUE whether KGL to support multi-instance pins
_kgl_session_cached_objects 10 maximum length of the KGL object cache lru
_kgl_time_to_wait_for_locks 15 time to wait for locks and pins before timing out
_kglsim_maxmem_percent 5 max percentage of shared pool size to be used for KGL advice
_kgx_latches 512 # of mutex latches if CAS is not supported.
_kill_java_threads_on_eoc FALSE Kill Java threads and do sessionspace migration at end of call
_kkfi_trace FALSE trace expression substitution
_kks_use_mutex_pin FALSE Turning on this will make KKS use mutex for cursor pins.
_kolfuseslf FALSE allow kolf to use slffopen
_kql_subheap_trace 0 tracing level for library cache subheap level pins
_ksd_test_param 999 KSD test parmeter
_ksdxdocmd_default_timeout_ms 30000 default timeout for internal oradebug commands
_ksdxw_cini_flg 0 ksdxw context initialization flag
_ksdxw_nbufs 1000 ksdxw number of buffers in buffered mode
_ksdxw_num_pgw 10 number of watchpoints on a per-process basis
_ksdxw_num_sgw 10 number of watchpoints to be shared by all processes
_ksdxw_stack_depth 4 number of PCs to collect in the stack when watchpoint is hit
_kse_die_timeout 60000 amount of time a dying process is spared by PMON (in centi-secs)
_kse_pc_table_size 256 kse pc table cache size
_ksfd_verify_write FALSE verify asynchronous writes issued through ksfd
_ksi_trace KSI trace string of lock type(s)
_ksmg_granule_locking_status 1 granule locking status
_ksmg_granule_size 4194304 granule size in bytes
_ksmg_lock_check_interval timeout action interval in minutes
_ksmg_lock_reacquire_count 5 repeat count for acquisition of locks
_ksu_diag_kill_time 5 number of seconds ksuitm waits before killing diag
_ksuitm_dont_kill_dumper FALSE delay inst. termination to allow processes to dump
_ksxp_diagmode OFF set to OFF to disable automatic slowsend diagnostics
_ksxp_reporting_process LMD0 reporting process for KSXP
_ksxp_send_timeout 300 set timeout for sends queued with the inter-instance IPC
_ktc_debug 0 for ktc debug
_ktc_latches 0 number of ktc latches
_ktu_latches 0 number of KTU latches
_ku_trace none datapump trace parameter
_large_pool_min_alloc 16000 minimum allocation size in bytes for the large allocation pool
_last_allocation_period 5 period over which an instance can retain an active level1 bitmap
_latch_class_0 latch class 0
_latch_class_1 latch class 1
_latch_class_2 latch class 2
_latch_class_3 latch class 3
_latch_class_4 latch class 4
_latch_class_5 latch class 5
_latch_class_6 latch class 6
_latch_class_7 latch class 7
_latch_classes latch classes override
_latch_miss_stat_sid 0 Sid of process for which to collect latch stats
_latch_recovery_alignment 998 align latch recovery structures
_ldr_io_size 262144 size of write IOs used during a load operation
_left_nested_loops_random TRUE enable random distribution method for left of nestedloops
_lgwr_async_broadcasts TRUE LGWR Asynchronous Broadcasts enabling boolean flag
_lgwr_async_io FALSE LGWR Asynchronous IO enabling boolean flag
_lgwr_delay_write FALSE LGWR write delay for debugging
_lgwr_io_slaves 0 LGWR I/O slaves
_lgwr_max_ns_wt 1 Maximum wait time for lgwr to allow NetServer to progress
_lgwr_ns_nl_max 1000 Variable to simulate network latency or buffer threshold
_lgwr_ns_nl_min 500 Variable to simulate network latency or buffer threshold
_lgwr_ns_sim_err 0 Variable to simulate errors lgwrns
_lgwr_ta_sim_err 0 Variable to simulate errors lgwr true async
_library_cache_advice TRUE whether KGL advice should be turned on
_lightweight_hdrs TRUE Lightweight headers for redo
_like_with_bind_as_equality FALSE treat LIKE predicate with bind as an equality predicate
_lm_activate_lms_threshold 100 threshold value to activate an additional lms
_lm_cache_lvl0_cleanup 0 how often to cleanup level 0 cache res (in sec)
_lm_cache_res_cleanup 25 percentage of cached resources should be cleanup
_lm_cache_res_type TMHWDI cache resource: string of lock types(s)
_lm_checksum_batch_msg FALSE GES checksum batch messages
_lm_contiguous_res_count 128 number of contiguous blocks that will hash to the same HV bucket
_lm_dd_interval 60 dd time interval in seconds
_lm_dd_scan_interval 5 dd scan interval in seconds
_lm_drm_max_requests 100 dynamic remastering maximum affinity requests processed together
_lm_drm_window 0 dynamic remastering bucket window size
_lm_drm_xlatch 0 dynamic remastering forced exclusive latches
_lm_dynamic_lms FALSE dynamic lms invocation
_lm_dynamic_load TRUE dynamic load adjustment
_lm_dynamic_remastering FALSE if TRUE enables dynamic remastering
_lm_enq_lock_freelist Number of ges enqueue element freelist
_lm_enq_rcfg TRUE if TRUE enables enqueue reconfiguration
_lm_enqueue_freelist 3 Number of enqueue freelist
_lm_file_affinity mapping between file id and master instance number
_lm_global_posts TRUE if TRUE deliver global posts to remote nodes
_lm_lmd_waittime 8 default wait time for lmd in centiseconds
_lm_lms 0 number of background gcs server processes to start
_lm_lms_waittime 8 default wait time for lms in centiseconds
_lm_locks 12000 number of enqueues configured for cluster database
_lm_master_weight 1 master resource weight for this instance
_lm_max_lms 0 max. number of background global cache server processes
_lm_min_lms 0 min. number of background global cache server processes
_lm_msg_batch_size 0 GES batch message size
_lm_msg_cache_thresholds GES message buffer caching threshold
_lm_msg_cleanup_interval 3000 GES message buffer cleanup interval time
_lm_node_join_opt FALSE cluster database node join optimization in reconfig
_lm_non_fault_tolerant FALSE disable cluster database fault-tolerance mode
_lm_num_pcmhv_latches 0 number of latches covering the PCM HV buckets in cgs
_lm_num_pt_buckets 4096 number of buckets in the object affinity hash table
_lm_num_pt_latches 128 number of latches in the object affinity hash table
_lm_proc_freeze_timeout 300 reconfiguration: process freeze timeout
_lm_process_batching TRUE GES implicit process batching for IPC messages
_lm_procs 320 number of client processes configured for cluster database
_lm_rcfg_timeout 180000 Reconfiguration timeout
_lm_rcv_buffer_size 32768 the size of receive buffer
_lm_res_hash_bucket 0 number of resource hash buckets
_lm_res_part 128 number of resource partition configured for gcs
_lm_ress 6000 number of resources configured for cluster database
_lm_send_buffers 10000 number of cluster database send buffers
_lm_send_mode auto GES send mode
_lm_send_queue_batching TRUE GES send queue message batching
_lm_send_queue_length 5000 GES send queue maximum length
_lm_sendproxy_reserve 25 GES percentage of send proxy reserve of send tickets
_lm_share_lock_opt FALSE if TRUE enables share lock optimization
_lm_sq_batch_factor 2 GES send queue minimum batching factor
_lm_sq_batch_type auto GES send queue batching mechanism
_lm_sq_batch_waittick 3 GES send queue batching waittime in tick
_lm_sync_timeout Synchronization timeout for DLM reconfiguration steps
_lm_ticket_active_sendback Flow control ticket active sendback threshold
_lm_tickets 1000 GES messaging tickets
_lm_tx_delta 16 TX lock localization delta
_lm_validate_resource_type FALSE if TRUE enables resource name validation
_lm_xids 352 number of transaction IDs configured for cluster database
_load_without_compile none Load PL/SQL or Database objects without compilation
_local_communication_costing_ena TRUE enable local communication costing when TRUE
bled
_local_communication_ratio 50 set the ratio between global and local communication (0..100)
_lock_sga_areas 0 Lock specified areas of the SGA in physical memory
_log_archive_avoid_memcpy TRUE log archive avoid memcpy
_log_archive_buffer_size 2048 Size of each archival buffer in log file blocks
_log_archive_buffers 4 Number of buffers to allocate for archiving
_log_archive_callout archival callout
_log_archive_compress_enable FALSE Bypass database rules for enabling archivelog compression
_log_archive_delta_sync_wait 0 iterative sleep time in centiseconds seconds when SYNC=PARALLEL
_log_archive_net_timeout 0 maximum network wait time in seconds when SYNC=PARALLEL
_log_archive_network_redo_size 10 Log archive network redo buffer size used by ARCH
_log_archive_prot_auto_demote FALSE log archive protection auto demotion
_log_archive_security_enabled TRUE log archive security enabled
_log_blocks_during_backup TRUE log block images when changed during backup
_log_buffers_corrupt FALSE corrupt redo buffers before write
_log_buffers_debug FALSE debug redo buffers (slows things down)
_log_checkpoint_recovery_check 0 # redo blocks to verify after checkpoint
_log_committime_block_cleanout FALSE Log commit-time block cleanout
_log_debug_multi_instance FALSE debug redo multi instance code
_log_deletion_policy mandatory archivelog deletion policy for mandatory/all destination
_log_io_size 0 automatically initiate log write if this many redo blocks in buffer
_log_parallelism 1 Number of log buffer strands
_log_parallelism_dynamic TRUE Enable dynamic strands
_log_parallelism_max 2 Maximum number of log buffer strands
_log_private_mul 5 Private strand multiplier for log space preallocation
_log_private_parallelism FALSE Number of private log buffer strands for zero-copy redo
_log_private_parallelism_mul 10 Active sessions multiplier to deduce number of private strands
_log_simultaneous_copies 4 number of simultaneous copies into redo buffer(# of copy latches)
_log_space_errors TRUE should we report space errors to alert log
_log_switch_timeout 0 Maximum number of seconds redos in the current log could span
_longops_enabled TRUE longops stats enabled
_low_server_threshold 0 low server thresholds
_master_direct_sends 31 direct sends for messages from master (DFS)
_mav_refresh_consistent_read TRUE refresh materialized views using consistent read snapshot
_mav_refresh_double_count_preven FALSE materialized view MAV refreshes avoid double counting
ted
_mav_refresh_opt 0 optimizations during refresh of materialized views
_mav_refresh_unionall_tables 3 # tables for union all expansion during materialized view refresh
_max_arch_lns_wait 120 Maximum wait by ARCH to allow NetServer to complete archival
_max_exponential_sleep 0 max sleep during exponential backoff
_max_lns_shutdown_archival_time 30 Maximum time spent by LNS to archive last log during shutdown
_max_protocol_support 10000 Max occurrence protocols supported in a process
_max_rfs_connections 0 maximum number of connections used for remote archival
_max_shrink_obj_stats 0 number of segments for which shrink stats will be maintained
_max_sleep_holding_latch 4 max time to sleep while holding a latch
_media_recovery_read_batch 128 media recovery block read batch
_media_recovery_reap_time 3 media recovery reap time
_mem_annotation_pr_lev 0 private memory annotation collection level
_mem_annotation_scale 1 memory annotation pre-allocation scaling
_mem_annotation_sh_lev 0 shared memory annotation collection level
_mem_annotation_store FALSE memory annotation in-memory store
_mem_std_extent_size 4096 standard extent size for fixed-size-extent heaps
_memory_broker_log_stat_entries 5 memory broker num stat entries
_memory_broker_shrink_heaps 15 memory broker allow policy to shrink shared pool
_memory_broker_shrink_java_heaps 900 memory broker allow policy to shrink java pool
_memory_broker_shrink_streams_po 900 memory broker allow policy to shrink streams pool
ol
_memory_broker_shrink_timeout 60000000 memory broker policy to timeout shrink shared/java pool
_memory_broker_stat_interval 30 memory broker statistics gathering interval
_memory_management_tracing 0 trace memory management activity
_memory_sanity_check 0 partial granule sanity check
_messages 300 message queue resources - dependent on # processes & # buffers
_minimal_stats_aggregation TRUE prohibit stats aggregation at compile/partition maintenance time
_minimum_blocks_to_shrink 0 minimum number freeable blocks for shrink to be present
_minimum_extents_to_shrink 1 minimum number freeable extents for shrink to be present
_minimum_giga_scn 0 Minimum SCN to start with in 2^30 units
_mirror_redo_buffers FALSE Save buffers for debugging redo corruptions
_mmv_query_rewrite_enabled TRUE allow rewrites with multiple MVs and/or base tables
_multi_join_key_table_lookup TRUE TRUE iff multi-join-key table lookup prefetch is enabled
_multiple_instance_recovery FALSE use multiple instances for media recovery
_mv_refresh_ana 0 what percent to analyze after complete/PCT refresh
_mv_refresh_costing rule refresh decision based on cost or on rules
_mv_refresh_delta_fraction 10 delta mv as fractional percentage of size of mv
_mv_refresh_eut TRUE refresh materialized views using EUT(partition)-based algorithm
_mv_refresh_force_parallel_query 0 force materialized view refreshes to use parallel query
_mv_refresh_new_setup_disabled FALSE materialized view MV refresh new setup disabling
_mv_refresh_rebuild_percentage 10 minimum percentage change required in MV to force an index rebuild
_mv_refresh_selections TRUE create materialized views with selections and fast refresh
_mv_refresh_use_stats TRUE pass cardinality hints to refresh queries
_mv_refsched_timeincr 300000 proportionality constant for dop vs. time in MV refresh
_mv_rolling_inv FALSE create/alter mv uses rolling cursor invalidation instead of immediate
_mwin_schedule TRUE Enable/disable Maintenance Window Schedules
_nchar_imp_cnv TRUE NLS allow Implicit Conversion between CHAR and NCHAR
_nchar_imp_conv TRUE should implicit conversion bewteen clob and nclob be allowed
_ncmb_readahead_enabled 0 enable multi-block readahead for an index scan
_ncmb_readahead_tracing 0 turn on multi-block readahead tracing
_nested_loop_fudge 100 nested loop fudge
_nested_mav_fast_oncommit_enable TRUE nested MAV refresh fast on commit allowed
d
_new_initial_join_orders TRUE enable initial join orders based on new ordering heuristics
_new_sort_cost_estimate TRUE enables the use of new cost estimate for sort
_newsort_enabled TRUE controls whether new sorts can be used as system sort
_newsort_ordered_pct 63 controls when new sort avoids sorting ordered input
_newsort_type 0 specifies options for the new sort algorithm
_no_objects FALSE no object features are used
_no_or_expansion FALSE OR expansion during optimization disabled
_no_recovery_through_resetlogs FALSE no recovery through this resetlogs operation
_notify_crs FALSE notify cluster ready services of startup and shutdown
_ns_max_flush_wt 1 Flush wait time for NetServer to flush oustanding writes
_ns_max_send_delay 15 Data Loss Time Bound for NetServer
_num_longop_child_latches 2 number of child latches for long op array
_number_cached_attributes 10 maximum number of cached attributes per instance
_object_statistics TRUE enable the object level statistics collection
_offline_rollback_segments offline undo segment list
_ogms_home GMS home directory
_olap_aggregate_buffer_size 1048576 OLAP Aggregate max buffer size
_olap_aggregate_flags 0 OLAP Aggregate debug flags
_olap_aggregate_function_cache_e TRUE OLAP Aggregate function cache enabler
nabled
_olap_aggregate_function_merge_t 529 OLAP Aggregate function merge threshold
hreshold
_olap_aggregate_max_thread_tuple 5000 OLAP Aggregate max thread tuples creation
s
_olap_aggregate_min_buffer_size 1024 OLAP Aggregate min buffer size
_olap_aggregate_min_thread_statu 64 OLAP Aggregate minimum cardinality of dimensions for thread
s
_olap_aggregate_multipath_hier FALSE OLAP Aggregate Multi-path Hierarhies enabled
_olap_aggregate_statlen_thresh 1024 OLAP Aggregate status array usage threshold
_olap_aggregate_store_probabilit 100 OLAP Aggregate function storeback probability
y
_olap_aggregate_work_per_thread 1024 OLAP Aggregate max work parents
_olap_aggregate_worklist_max 5000 OLAP Aggregate max worklists generated at once
_olap_allocate_errorlog_format %8p %8y %8z %e (%n) OLAP Allocate Errorlog Format
_olap_allocate_errorlog_header Dim Source Basis OLAP Allocate Errorlog Header format
%-8d %-8s %-8b Descripti
on
-------- -------- ------
-- -----------
_olap_continuous_trace_file FALSE Specify TRUE to enable continuous OLAP tracing - otherwise only except
ional events will be logged
_olap_dbgoutfile_echo_to_eventlo FALSE OLAP DbgOutfile copy output to event log (tracefile)
g
_olap_dimension_corehash_class 1 OLAP Dimension In-Core Hash Table Class
_olap_dimension_corehash_max 10000 OLAP Dimension In-Core Hash Table Maximum Size
_olap_eif_export_lob_size 2147483647 OLAP EIF Export BLOB size
_olap_lmgen_dim_size 100 Limitmap generator dimension column size
_olap_lmgen_meas_size 1000 Limitmap generator measure column size
_olap_object_hash_class 2 OLAP Object Hash Table Class
_olap_page_pool_expand_rate 20 OLAP Page Pool Expand Rate
_olap_page_pool_hi 50 OLAP Page Pool High Watermark
_olap_page_pool_hit_target 100 OLAP Page Pool Hit Target
_olap_page_pool_low 262144 OLAP Page Pool Low Watermark
_olap_page_pool_pressure 90 OLAP Page Pool Pressure Threshold
_olap_page_pool_shrink_rate 50 OLAP Page Pool Shrink Rate
_olap_parallel_update_small_grou 400 OLAP parallel update pagespace by group
p
_olap_parallel_update_small_thre 1000 OLAP parallel update threshold for number of small pagespaces
shold
_olap_parallel_update_threshold 1000 OLAP parallel update threshold in pages
_olap_poutlog_echo_to_eventlog FALSE OLAP POutLog copy output to event log (tracefile)
_olap_sesscache_enabled TRUE OLAP Session Cache knob
_olap_sort_buffer_size 262144 OLAP Sort Buffer Size
_olap_statbool_corebits 20000000 OLAP Status Boolean max incore bits
_olap_statbool_threshold 8100 OLAP Status Boolean CBM threshold
_olap_table_function_statistics FALSE Specify TRUE to output OLAP table function timed statistics trace
_olap_wrap_errors FALSE Wrap error messages to OLAP outfile
_olapi_history_retention FALSE enable olapi history retention
_olapi_iface_object_history 1000 enable olapi interface object history collection
_olapi_iface_object_history_rete FALSE enable olapi interface object history retention
ntion
_olapi_iface_operation_history_r FALSE enable olapi interface operation history retention
etention
_olapi_interface_operation_histo 1000 enable olapi interface operation history collection
ry
_olapi_memory_operation_history 1000 enable olapi memory alloc/free history collection
_olapi_memory_operation_history_ 0 enable olapi memory alloc/free history collection pausing
pause_at_seqno
_olapi_memory_operation_history_ FALSE enable olapi memory operation history retention
retention
_olapi_session_history 300 enable olapi session history collection
_olapi_session_history_retention FALSE enable olapi session history retention
_old_connect_by_enabled FALSE enable/disable old connect by
_ols_cleanup_task TRUE Clean up unnecessary entries in OLS sessinfo table
_omf enabled enable/disable OMF
_oneside_colstat_for_equijoins TRUE sanity check on default selectivity for like/range predicate
_optim_adjust_for_part_skews TRUE adjust stats for skews across partitions
_optim_dict_stats_at_db_cr_upg TRUE enable/disable dictionary stats gathering at db create/upgrade
_optim_enhance_nnull_detection TRUE TRUE to enable index [fast] full scan more often
_optim_new_default_join_sel TRUE improves the way default equijoin selectivity are computed
_optim_peek_user_binds TRUE enable peeking of user binds
_optimizer_adjust_for_nulls TRUE adjust selectivity for null values
_optimizer_autostats_job TRUE enable/disable auto stats collection job
_optimizer_better_inlist_costing ALL enable improved costing of index access using in-list(s)
_optimizer_block_size 8192 standard block size used by optimizer
_optimizer_cache_stats FALSE cost with cache statistics
_optimizer_cartesian_enabled TRUE optimizer cartesian join enabled
_optimizer_cbqt_factor 50 cost factor for cost-based query transformation
_optimizer_cbqt_no_size_restrict TRUE disable cost based transformation query size restriction
ion
_optimizer_ceil_cost TRUE CEIL cost in CBO
_optimizer_choose_permutation 0 force the optimizer to use the specified permutation
_optimizer_complex_pred_selectiv TRUE enable selectivity estimation for builtin functions
ity
_optimizer_compute_index_stats TRUE force index stats collection on index creation/rebuild
_optimizer_correct_sq_selectivit TRUE force correct computation of subquery selectivity
y
_optimizer_cost_based_transforma LINEAR enables cost-based query transformation
tion
_optimizer_cost_filter_pred FALSE enables costing of filter predicates in IO cost model
_optimizer_cost_hjsmj_multimatch TRUE add cost of generating result set when #rows per key > 1
_optimizer_cost_model CHOOSE optimizer cost model
_optimizer_degree 0 force the optimizer to use the same degree of parallelism
_optimizer_dim_subq_join_sel TRUE use join selectivity in choosing star transformation dimensions
_optimizer_disable_strans_sanity 0 disable star transformation sanity checks
_checks
_optimizer_dyn_smp_blks 32 number of blocks for optimizer dynamic sampling
_optimizer_enhanced_filter_push TRUE push filters before trying cost-based query transformation
_optimizer_extended_cursor_shari UDO optimizer extended cursor sharing
ng
_optimizer_filter_pred_pullup TRUE use cost-based flter predicate pull up transformation
_optimizer_ignore_hints FALSE enables the embedded hints to be ignored
_optimizer_invalidation_period 18000 time window for invalidation of cursors of analyzed objects
_optimizer_join_elimination_enab TRUE optimizer join elimination enabled
led
_optimizer_join_order_control 3 controls the optimizer join order search algorithm
_optimizer_join_sel_sanity_check TRUE enable/disable sanity check for multi-column join selectivity
_optimizer_max_permutations 2000 optimizer maximum join permutations per query block
_optimizer_min_cache_blocks 10 set minimum cached blocks
_optimizer_mjc_enabled TRUE enable merge join cartesian
_optimizer_mode_force TRUE force setting of optimizer mode for user recursive SQL also
_optimizer_multiple_cenv generate and run plans using several compilation environments
_optimizer_new_join_card_computa TRUE compute join cardinality using non-rounded input values
tion
_optimizer_or_expansion DEPTH control or expansion approach used
_optimizer_order_by_elimination_ TRUE Eliminates order bys from views before query transformation
enabled
_optimizer_outer_to_anti_enabled TRUE Enable transformation of outer-join to anti-join if possible
_optimizer_percent_parallel 101 optimizer percent parallel
_optimizer_push_down_distinct 0 push down distinct from query block to table
_optimizer_push_pred_cost_based TRUE use cost-based query transformation for push pred optimization
_optimizer_random_plan 0 optimizer seed value for random plans
_optimizer_rownum_pred_based_fkr TRUE enable the use of first K rows due to rownum predicate
_optimizer_save_stats TRUE enable/disable saving old versions of optimizer stats
_optimizer_search_limit 5 optimizer search limit
_optimizer_self_induced_cache_co FALSE account for self-induced caching
st
_optimizer_skip_scan_enabled TRUE enable/disable index skip scan
_optimizer_sortmerge_join_enable TRUE enable/disable sort-merge join method
d
_optimizer_squ_bottomup TRUE enables unnesting of subquery in a bottom-up manner
_optimizer_star_tran_in_with_cla TRUE enable/disable star transformation in with clause queries
use
_optimizer_starplan_enabled TRUE optimizer star plan enabled
_optimizer_system_stats_usage TRUE system statistics usage
_optimizer_trace none optimizer trace parameter
_optimizer_transitivity_retain TRUE retain equi-join pred upon transitive equality pred generation
_optimizer_undo_changes FALSE undo changes to query optimizer
_optimizer_undo_cost_change 10.2.0.1 optimizer undo cost change
_or_expand_nvl_predicate TRUE enable OR expanded plan for NVL/DECODE predicate
_oradebug_force FALSE force target processes to execute oradebug commands?
_ordered_nested_loop TRUE enable ordered nested loop costing
_ordered_semijoin TRUE enable ordered semi-join subquery
_os_sched_high_priority 1 OS high priority level
_other_wait_event_exclusion exclude event names from _other_wait_threshold calculations
_other_wait_threshold 0 threshold wait percentage for event wait class Other
_outline_bitmap_tree TRUE BITMAP_TREE hint enabled in outline
_parallel_adaptive_max_users 2 maximum number of users running with default DOP
_parallel_broadcast_enabled TRUE enable broadcasting of small inputs to hash and sort merge joins
_parallel_default_max_instances 1 default maximum number of instances for parallel query
_parallel_execution_message_alig FALSE Alignment of PX buffers to OS page boundary
n
_parallel_fake_class_pct 0 fake db-scheduler percent used for testing
_parallel_fixwrite_bucket 1000 Number of buckets for each round of fix write
_parallel_load_bal_unit 0 number of threads to allocate per instance
_parallel_load_balancing TRUE parallel execution load balanced slave allocation
_parallel_min_message_pool 902160 minimum size of shared pool memory to reserve for pq servers
_parallel_recovery_stopat 32767 stop at -position- to step through SMON
_parallel_replay_msg_limit 4000 Number of messages for each round of parallel replay
_parallel_server_idle_time 30000 idle time before parallel query server dies (in 1/100 sec)
_parallel_server_sleep_time 10 sleep time between dequeue timeouts (in 1/100ths)
_parallel_slave_acquisition_wait 1 time(in seconds) to wait before retrying slave acquisition
_parallel_txn_global FALSE enable parallel_txn hint with updates and deletes
_parallelism_cost_fudge_factor 350 set the parallelism cost fudge factor
_parameter_table_block_size 1024 parameter table block size
_partial_pwise_join_enabled TRUE enable partial partition-wise join when TRUE
_partition_view_enabled TRUE enable/disable partitioned views
_passwordfile_enqueue_timeout 900 password file enqueue timeout in seconds
_pct_refresh_double_count_preven TRUE materialized view PCT refreshes avoid double counting
ted
_pdml_gim_sampling 5000 control separation of global index maintenance for PDML
_pdml_gim_staggered FALSE slaves start on different index when doing index maint
_pdml_slaves_diff_part TRUE slaves start on different partition when doing index maint
_percent_flashback_buf_partial_f 50 Percent of flashback buffer filled to be considered partial full
ull
_pga_large_extent_size 1048576 PGA large extent size
_pga_max_size 209715200 Maximum size of the PGA memory for one process
_ping_level 3 fusion ping level
_pkt_enable FALSE enable progressive kill test
_pkt_pmon_interval 50 PMON process clean-up interval (cs)
_pkt_start FALSE start progressive kill test instrumention
_plan_outline_data TRUE explain plan outline data enabled
_plsql_anon_block_code_type INTERPRETED PL/SQL anonymous block code-type
_plsql_cache_enable TRUE PL/SQL Function Cache Enabled
_plsql_dump_buffer_events conditions upon which the PL/SQL circular buffer is dumped
_plsql_minimum_cache_hit_percent 20 plsql minimum cache hit percentage required to keep caching active
_plsql_nvl_optimize FALSE PL/SQL NVL optimize
_pmon_load_constants 300,192,64,3,10,10,0,0 server load balancing constants (S,P,D,I,L,C,M)
_pre_rewrite_push_pred TRUE push predicates into views before rewrite
_precompute_gid_values TRUE precompute gid values and copy them before returning a row
_pred_move_around TRUE enables predicate move-around
_predicate_elimination_enabled TRUE allow predicate elimination if set to TRUE
_prescomm FALSE presume commit of IMU transactions
_print_refresh_schedule false enable dbms_output of materialized view refresh schedule
_private_memory_address Start address of large extent memory segment
_project_view_columns TRUE enable projecting out unreferenced columns of a view
_projection_pushdown TRUE projection pushdown
_projection_pushdown_debug 0 level for projection pushdown debugging
_push_join_predicate TRUE enable pushing join predicate inside a view
_push_join_union_view TRUE enable pushing join predicate inside a union all view
_push_join_union_view2 TRUE enable pushing join predicate inside a union view
_px_async_getgranule FALSE asynchronous get granule in the slave
_px_broadcast_fudge_factor 100 set the tq broadcasting fudge factor percentage
_px_buffer_ttl 30 ttl for px mesg buffers in seconds
_px_compilation_debug 0 debug level for parallel compilation
_px_compilation_trace 0 tracing level for parallel compilation
_px_dynamic_opt TRUE turn off/on restartable qerpx dynamic optimization
_px_dynamic_sample_size 50 num of samples for restartable qerpx dynamic optimization
_px_granule_size 100000 default size of a rowid range granule (in KB)
_px_index_sampling 200 parallel query sampling for index create (100000 = 100%)
_px_kxib_tracing 0 turn on kxib tracing
_px_load_publish_interval 200 interval at which LMON will check whether to publish PX load
_px_loc_msg_cost 1000 CPU cost to send a PX message via shared memory
_px_max_granules_per_slave 100 maximum number of rowid range granules to generate per slave
_px_min_granules_per_slave 13 minimum number of rowid range granules to generate per slave
_px_minus_intersect TRUE enables pq for minus/interect operators
_px_net_msg_cost 10000 CPU cost to send a PX message over the internconnect
_px_no_granule_sort FALSE prevent parallel partition granules to be sorted on size
_px_no_stealing FALSE prevent parallel granule stealing in shared nothing environment
_px_nss_planb TRUE enables or disables NSS Plan B reparse with outline
_px_proc_constrain TRUE reduce parallel_max_servers if greater than (processes - fudge)
_px_pwg_enabled TRUE parallel partition wise group by enabled
_px_rownum_pd TRUE turn off/on parallel rownum pushdown optimization
_px_send_timeout 300 IPC message send timeout value in seconds
_px_slaves_share_cursors 0 slaves share cursors with QC
_px_trace none px trace parameter
_px_xtgranule_size 10000 default size of a external table granule (in KB)
_qa_control 0 Oracle internal parameter to control QA
_qa_lrg_type 0 Oracle internal parameter to specify QA lrg type
_query_cost_rewrite TRUE perform. the cost based rewrite with materialized views
_query_execution_cache_max_size 65536 max size of query execution cache
_query_rewrite_1 TRUE perform. query rewrite before&after or only before view merging
_query_rewrite_2 TRUE perform. query rewrite before&after or only after view merging
_query_rewrite_drj TRUE mv rewrite and drop redundant joins
_query_rewrite_expression TRUE rewrite with cannonical form. for expressions
_query_rewrite_fpc TRUE mv rewrite fresh partition containment
_query_rewrite_fudge 90 cost based query rewrite with MVs fudge factor
_query_rewrite_jgmigrate TRUE mv rewrite with jg migration
_query_rewrite_maxdisjunct 257 query rewrite max disjuncts
_query_rewrite_or_error FALSE allow query rewrite, if referenced tables are not dataless
_query_rewrite_setopgrw_enable TRUE perform. general rewrite using set operator summaries
_query_rewrite_vop_cleanup TRUE prune frocol chain before rewrite after view-merging
_rcfg_parallel_fixwrite TRUE if TRUE enables parallel fixwrite at reconfiguration
_rcfg_parallel_replay TRUE if TRUE enables parallel replay and cleanup at reconfiguration
_rcfg_parallel_verify TRUE if TRUE enables parallel verify at reconfiguration
_real_time_apply_arch_delay 0 Archival delay with real time apply
_real_time_apply_sim 0 Simulation value with real time apply
_realfree_heap_max_size 32768 minimum max total heap size, in Kbytes
_realfree_heap_mode 0 mode flags for real-free heap
_realfree_heap_pagesize_hint 65536 hint for real-free page size in bytes
_recoverable_recovery_batch_perc 50 Recoverable recovery batch size (percentage of buffer cache)
ent
_recovery_asserts FALSE if TRUE, enable expensive integrity checks
_recovery_percentage 50 recovery buffer cache percentage
_recovery_verify_writes FALSE enable thread recovery write verify
_recursive_imu_transactions FALSE recursive transactions may be IMU
_redo_compatibility_check FALSE general and redo/undo compatibility sanity check
_release_insert_threshold 5 maximum number of unusable blocks to unlink from freelist
_reliable_block_sends FALSE if TRUE, block sends across interconnect are reliable
_remove_aggr_subquery TRUE enables removal of subsumed aggregated subquery
_resource_manager_always_on TRUE enable the resource manager always
_restore_spfile restore spfile to this location
_reuse_index_loop 5 number of blocks being examine for index block reuse
_right_outer_hash_enable TRUE Right Outer/Semi/Anti Hash Enabled
_rman_io_priority 3 priority at which rman backup i/o's are done
_rollback_segment_count 0 number of undo segments
_rollback_segment_initial 1 starting undo segment number
_rollback_stopat 0 stop at -position to step rollback
_row_cache_cursors 20 number of cached cursors for row cache management
_row_cr TRUE enable row cr for all sql
_row_locking always row-locking
_rowsource_execution_statistics FALSE if TRUE, Oracle will collect rowsource statistics
_rowsource_statistics_sampfreq 128 frequency of rowsource statistic sampling (must be a power of 2)
_rowsrc_trace_level 0 Row source tree tracing level
_sample_rows_per_block 4 number of rows per block used for sampling IO optimization
_second_spare_parameter second spare parameter - integer
_selfjoin_mv_duplicates TRUE control rewrite self-join algorithm
_selftune_checkpoint_write_pct 3 Percentage of total physical i/os for self-tune ckpt
_selftune_checkpointing_lag 300 Self-tune checkpointing lag the tail of the redo log
_send_ast_to_foreground TRUE if TRUE, send ast message to foreground
_send_close_with_block TRUE if TRUE, send close with block even with direct sends
_send_requests_to_pi TRUE if TRUE, try to send CR requests to PI buffers
_serial_direct_read FALSE enable direct read in serial
_serial_recovery FALSE force serial recovery or parallel recovery
_serializable FALSE serializable
_session_cached_instantiations 60 Number of pl/sql instantiations to cache in a session.
_session_context_size 10000 session app context size
_session_idle_bit_latches 0 one latch per session or a latch per group of sessions
_session_idle_check_interval 60 Resource Manager session idle limit check interval in seconds
_session_kept_cursor_pins 0 Number of cursors pins to keep in a session
_session_wait_history 10 enable session wait history collection
_seventh_spare_parameter seventh spare parameter - string list
_shared_pool_max_size 0 shared pool maximum size when auto SGA enabled
_shared_pool_reserved_min_alloc 4400 minimum allocation size in bytes for reserved area of shared pool
_shared_pool_reserved_pct 5 percentage memory of the shared pool allocated for the reserved area
_short_stack_timeout_ms 30000 short stack timeout in ms
_shrunk_aggs_disable_threshold 60 percentage of exceptions at which to switch to full length aggs
_shrunk_aggs_enabled TRUE enable use of variable sized buffers for non-distinct aggregates
_side_channel_batch_size 200 number of messages to batch in a side channel message (DFS)
_side_channel_batch_timeout 6 timeout before shipping out the batched side channelmessages
_simple_view_merging TRUE control simple view merging performed by the optimizer
_simulator_bucket_mindelta 8192 LRU bucket minimum delta
_simulator_internal_bound 10 simulator internal bound percent
_simulator_lru_rebalance_sizthr 2 LRU list rebalance threshold (size)
_simulator_lru_rebalance_thresh 10240 LRU list rebalance threshold (count)
_simulator_lru_scan_count 8 LRU scan count
_simulator_pin_inval_maxcnt 16 maximum count of invalid chunks on pin list
_simulator_reserved_heap_count 4096 simulator reserved heap count
_simulator_reserved_obj_count 1024 simulator reserved object count
_simulator_sampling_factor 2 sampling factor for the simulator
_simulator_upper_bound_multiple 2 upper bound multiple of pool size
_single_process FALSE run without detached processes
_sixth_spare_parameter sixth spare parameter - string list
_skgxp_reaping 1000 tune skgxp OSD reaping limit
_skgxp_udp_ach_reaping_time 120 time in minutes before idle ach's are reaped
_skgxp_udp_hiwat_warn 1000 ach hiwat mark warning interval
_skgxp_udp_interface_detection_t 60 time in seconds between interface detection checks
ime_secs
_skgxp_udp_keep_alive_ping_timer 300 connection idle time in seconds before keep alive is initiated. min: 3
_secs 0 sec max: 1800 sec default: 300 sec
_skgxp_udp_timed_wait_buffering 1024 diagnostic log buffering space (in bytes) for timed wait (0 means unbu
fferd
_skgxp_udp_timed_wait_seconds 5 time in seconds before timed wait is invoked
_skip_assume_msg TRUE if TRUE, skip assume message for consigns at the master
_slave_mapping_enabled TRUE enable slave mapping when TRUE
_slave_mapping_group_size 0 force the number of slave group in a slave mapper
_small_table_threshold 968 threshold level of table size for direct reads
_smm_advice_enabled TRUE if TRUE, enable v$pga_advice
_smm_advice_log_size 0 overwrites default size of the PGA advice workarea history log
_smm_auto_cost_enabled TRUE if TRUE, use the AUTO size policy cost functions
_smm_auto_max_io_size 248 Maximum IO size (in KB) used by sort/hash-join in auto mode
_smm_auto_min_io_size 56 Minimum IO size (in KB) used by sort/hash-join in auto mode
_smm_bound 0 overwrites memory manager automatically computed bound
_smm_control 0 provides controls on the memory manager
_smm_freeable_retain 5120 value in KB of the instance freeable PGA memory to retain
_smm_isort_cap 102400 maximum work area for insertion sort(v1)
_smm_max_size 39526 maximum work area size in auto mode (serial)
_smm_min_size 197 minimum work area size in auto mode
_smm_px_max_size 98816 maximum work area size in auto mode (global)
_smm_retain_size 0 work area retain size in SGA for shared server sessions (0 for AUTO)
_smm_trace 0 Turn on/off tracing for SQL memory manager
_smon_internal_errlimit 100 limit of SMON internal errors
_smu_debug_mode 0 - set debug event for testing SMU operations
_smu_error_simulation_site 0 site ID of error simulation in KTU code
_smu_error_simulation_type 0 error type for error simulation in KTU code
_smu_timeouts comma-separated *AND double-quoted* list of AUM timeouts: mql, tur, se
ss_exprn, qry_exprn, slot_intvl
_sort_elimination_cost_ratio 0 cost ratio for sort eimination under first_rows mode
_sort_multiblock_read_count 2 multi-block read count for sort
_spin_count 2000 Amount to spin waiting for a latch
_spr_max_rules 10000 maximum number of rules in sql spreadsheet
_spr_push_pred_refspr TRUE push predicates through reference spreadsheet
_spr_use_AW_AS TRUE enable AW for hash table in spreadsheet
_spr_use_hash_table FALSE use hash table for spreadsheet
_sql_connect_capability_override 0 SQL Connect Capability Table Override
_sql_connect_capability_table SQL Connect Capability Table (testing only)
_sql_hash_debug 0 Hash value of the SQL statement to debug
_sql_model_unfold_forloops RUN_TIME specifies compile-time unfolding of sql model forloops
_sqlexec_progression_cost 1000 sql execution progression monitoring cost threshold
_sqltune_category_parsed DEFAULT Parsed category qualifier for applying hintsets
_sta_control 0 SQL Tuning Advisory control parameter
_stack_guard_level 0 stack guard level
_static_backgrounds static backgrounds
_stn_trace 0 SQL tracing parameter
_streams_pool_max_size 0 streams pool maximum size when auto SGA enabled
_subquery_pruning_cost_factor 20 subquery pruning cost factor
_subquery_pruning_enabled TRUE enable the use of subquery predicates to perform. pruning
_subquery_pruning_mv_enabled FALSE enable the use of subquery predicates with MVs to perform. pruning
_subquery_pruning_reduction 50 subquery pruning reduction factor
_swrf_metric_frequent_mode FALSE Enable/disable SWRF Metric Frequent Mode Collection
_swrf_mmon_dbfus TRUE Enable/disable SWRF MMON DB Feature Usage
_swrf_mmon_flush TRUE Enable/disable SWRF MMON FLushing
_swrf_mmon_metrics TRUE Enable/disable SWRF MMON Metrics Collection
_swrf_on_disk_enabled TRUE Parameter to enable/disable SWRF
_swrf_test_action 0 test action parameter for SWRF
_swrf_test_dbfus FALSE Enable/disable DB Feature Usage Testing
_synonym_repoint_tracing FALSE whether to trace metadata comparisons for synonym repointing
_sysaux_test_param 1 test parameter for SYSAUX
_system_index_caching 0 optimizer percent system index caching
_system_trig_enabled TRUE are system triggers enabled
_ta_lns_wait_for_arch_log 20 LNS Wait time for arhcived version of online log
_table_lookup_prefetch_size 40 table lookup prefetch vector size
_table_lookup_prefetch_thresh 2 table lookup prefetch threshold
_table_scan_cost_plus_one TRUE bump estimated full table scan and index ffs cost by one
_target_rba_max_lag_percentage 90 target rba max log lag percentage
_tdb_debug_mode 16 set debug mode for testing transportable database
_temp_tran_block_threshold 100 number of blocks for a dimension before we temp transform
_temp_tran_cache TRUE determines if temp table is created with cache option
_test_ksusigskip 5 test the function ksusigskip
_test_param_1 25 test 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_5 25 test parmeter 5 - deprecated integer
_test_param_6 0 test parmeter 6 - size (ub8)
_third_spare_parameter third spare parameter - integer
_threshold_alerts_enable 1 if 1, issue threshold-based alerts
_total_large_extent_memory 0 Total memory for allocating large extents
_tq_dump_period 0 time period for duping of TQ statistics (s)
_trace_archive FALSE start DIAG process
_trace_buffer_flushes FALSE trace buffer flushes if otrace cacheIO event is set
_trace_buffer_gets FALSE trace kcb buffer gets if otrace cacheIO event is set
_trace_buffer_wait_timeouts 0 trace buffer busy wait timeouts
_trace_buffer_wrap_timestamp TRUE enable KST timestamp on trace buffer wrap
_trace_buffers ALL:256 trace buffer sizes per process
_trace_cr_buffer_creates FALSE trace cr buffer creates if otrace cacheIO event is set
_trace_events trace events enabled at startup
_trace_file_size 65536 maximum size of trace file (in bytes)
_trace_files_public FALSE Create publicly accessible trace files
_trace_flush_processes ALL trace data archived by DIAG for these processes
_trace_multi_block_reads FALSE trace multi_block reads if otrace cacheIO event is set
_trace_navigation_scope global enabling trace navigation linking
_trace_options text,multiple trace data flush options
_trace_pin_time 0 trace how long a current pin is held
_trace_processes ALL enable KST tracing in process
_transaction_auditing TRUE transaction auditing records generated in the redo log
_transaction_recovery_servers 0 max number of parallel recovery slaves that may be used
_truncate_optimization_enabled TRUE do truncate optimization if set to TRUE
_tsm_connect_string TSM test connect string
_tsm_disable_auto_cleanup 1 Disable TSM auto cleanup actions
_tts_allow_charset_mismatch FALSE allow plugging in a tablespace with an incompatible character set
_two_pass TRUE enable two-pass thread recovery
_two_pass_reverse_polish_enabled TRUE uses two-pass reverse polish alg. to generate canonical forms
_uga_cga_large_extent_size 262144 UGA/CGA large extent size
_ultrafast_latch_statistics TRUE maintain fast-path statistics for ultrafast latches
_undo_autotune TRUE enable auto tuning of undo_retention
_undo_debug_mode 0 debug flag for undo related operations
_undo_debug_usage 0 invoke undo usage functions for testing
_union_rewrite_for_gs YES_GSET_MVS expand queries with GSets into UNIONs for rewrite
_unnest_subquery TRUE enables unnesting of correlated subqueries
_unused_block_compression FALSE enable unused block compression
_use_column_stats_for_function TRUE enable the use of column statistics for DDP functions
_use_ism TRUE Enable Shared Page Tables - ISM
_use_ism_for_pga TRUE Use ISM for allocating large extents
_use_nosegment_indexes FALSE use nosegment indexes in explain plan
_use_realfree_heap TRUE use real-free based allocator for PGA memory
_use_seq_process_cache TRUE whether to use process local seq cache
_use_vector_post TRUE use vector post
_validate_flashback_database FALSE Scan database to validate result of flashback database
_vendor_lib_loc Vendor library search root directory
_verify_flashback_redo TRUE Verify that the redo logs needed for flashback are available
_verify_undo_quota FALSE TRUE - verify consistency of undo quota statistics
_very_large_partitioned_table 1024 very_large_partitioned_table
_wait_for_sync TRUE wait for sync on commit MUST BE ALWAYS TRUE
_walk_insert_threshold 0 maximum number of unusable blocks to walk across freelist
_watchpoint_on FALSE is the watchpointing feature turned on?
_windowfunc_optimization_setting 0 settings for window function optimizations
s
_write_clones 3 write clones flag
_xpl_peeked_binds_log_size 8192 maximum bytes for logging peeked bind values for V$SQL_PLAN (0 = OFF)
_xpl_trace 0 Explain Plan tracing parameter
_xsolapi_auto_materialization_bo 20 OLAP API lower bound for auto materialization.
und
_xsolapi_auto_materialization_ty PRED_AND_RC OLAP API behavior. for auto materialization
pe
_xsolapi_debug_output OLAP API debug output disposition
_xsolapi_densify_cubes TABULAR OLAP API cube densification
_xsolapi_dimension_group_creatio OVERFETCH OLAP API symmetric overfetch
n
_xsolapi_fetch_type PARTIAL OLAP API fetch type
_xsolapi_load_at_process_start NEVER When to load OLAP API library at server process start
_xsolapi_materialization_rowcach 1 OLAP API min number of rows required to use rowcache in query material
e_min_rows_for_use ization
_xsolapi_materialize_sources TRUE OLAP API Enable source materialization
_xsolapi_source_trace FALSE OLAP API output Source definitions to trace file
_xsolapi_sql_all_multi_join_non_ OLAP API multi-join non-base hints
base_hints
_xsolapi_sql_all_non_base_hints OLAP API non-base hints
_xsolapi_sql_auto_dimension_hint FALSE OLAP API enable automatic dimension hints
s
_xsolapi_sql_auto_measure_hints TRUE OLAP API enable automatic measure hints
_xsolapi_sql_dimension_hints OLAP API dimension hints
_xsolapi_sql_hints OLAP API generic hints
_xsolapi_sql_measure_hints OLAP API measure hints
_xsolapi_sql_optimize TRUE OLAP API enable optimization
_xsolapi_sql_prepare_stmt_cache_ 16 OLAP API prepare statement cache size
size
_xsolapi_sql_remove_columns TRUE OLAP API enable remove unused columns optimizations
_xsolapi_sql_result_set_cache_si 32 OLAP API result set cache size
ze
_xsolapi_sql_symmetric_predicate TRUE OLAP API enable symmetric predicate for dimension groups
_xsolapi_sql_top_dimension_hints OLAP API top dimension hints
_xsolapi_sql_top_measure_hints OLAP API top measure hints
_xsolapi_sql_use_bind_variables TRUE OLAP API enable bind variables optimization
_xt_coverage none external tables code coverage parameter
_xt_trace none external tables trace parameter
_xtbuffer_size 0 buffer size in KB needed for populate/query operation
_xtts_allow_pre10 FALSE allow cross platform. for pre10 compatible tablespace
_xtts_set_platform_info FALSE set cross platform. info during file header read
_yield_check_interval 100000 interval to check whether actses should yield
active_instance_count number of active instances in the cluster database
aq_tm_processes 0 number of AQ Time Managers to start
archive_lag_target 0 Maximum number of seconds of redos the standby could lose
asm_diskgroups disk groups to mount automatically
asm_diskstring disk set locations for discovery
asm_power_limit 1 number of processes for disk rebalancing
audit_file_dest C:\ORACLE\PRODUCT\10.2.0 Directory in which auditing files are to reside
\ADMIN\CHIC\ADUMP
audit_sys_operations FALSE enable sys auditing
audit_trail NONE enable system auditing
background_core_dump partial Core Size for Background Processes
background_dump_dest C:\ORACLE\PRODUCT\10.2.0 Detached process dump directory
\ADMIN\CHIC\BDUMP
backup_tape_io_slaves FALSE BACKUP Tape I/O slaves
bitmap_merge_area_size 1048576 maximum memory allow for BITMAP MERGE
blank_trimming FALSE blank trimming semantics parameter
buffer_pool_keep Number of database blocks/latches in keep buffer pool
buffer_pool_recycle Number of database blocks/latches in recycle buffer pool
circuits max number of circuits
cluster_database FALSE if TRUE startup in cluster database mode
cluster_database_instances 1 number of instances to use for sizing cluster db SGA structures
cluster_interconnects interconnects for RAC use
commit_point_strength 1 Bias this node has toward not preparing in a two-phase commit
commit_write transaction commit log write behaviour
compatible 10.2.0.1.0 Database will be completely compatible with this software version
control_file_record_keep_time 7 control file record keep time in days
control_files C:\ORACLE\PRODUCT\10.2.0 control file names list
\ORADATA\CHIC\CONTROL01.
CTL, C:\ORACLE\PRODUCT\1
0.2.0\ORADATA\CHIC\CONTR
OL02.CTL, C:\ORACLE\PROD
UCT\10.2.0\ORADATA\CHIC\
CONTROL03.CTL
core_dump_dest C:\ORACLE\PRODUCT\10.2.0 Core dump directory
\ADMIN\CHIC\CDUMP
cpu_count 2 number of CPUs for this instance
create_bitmap_area_size 8388608 size of create bitmap buffer for bitmap index
create_stored_outlines create stored outlines for DML statements
cursor_sharing EXACT cursor sharing mode
cursor_space_for_time FALSE use more memory in order to get faster execution
db_16k_cache_size 0 Size of cache for 16K buffers
db_2k_cache_size 0 Size of cache for 2K buffers
db_32k_cache_size 0 Size of cache for 32K buffers
db_4k_cache_size 0 Size of cache for 4K buffers
db_8k_cache_size 0 Size of cache for 8K buffers
db_block_buffers 0 Number of database blocks cached in memory
db_block_checking FALSE header checking and data and index block checking
db_block_checksum TRUE store checksum in db blocks and check during reads
db_block_size 8192 Size of database block in bytes
db_cache_advice ON Buffer cache sizing advisory
db_cache_size 0 Size of DEFAULT buffer pool for standard block size buffers
db_create_file_dest default database location
db_create_online_log_dest_1 online log/controlfile destination #1
db_create_online_log_dest_2 online log/controlfile destination #2
db_create_online_log_dest_3 online log/controlfile destination #3
db_create_online_log_dest_4 online log/controlfile destination #4
db_create_online_log_dest_5 online log/controlfile destination #5
db_domain directory part of global database name stored with CREATE DATABASE
db_file_multiblock_read_count 16 db block to be read each IO
db_file_name_convert datafile name convert patterns and strings for standby/clone db
db_files 200 max allowable # db files
db_flashback_retention_target 1440 Maximum Flashback Database log retention time in minutes.
db_keep_cache_size 0 Size of KEEP buffer pool for standard block size buffers
db_name chic database name specified in CREATE DATABASE
db_recovery_file_dest c:\oracle\product\10.2.0 default database recovery file location
/flash_recovery_area
db_recovery_file_dest_size 2147483648 database recovery files size limit
db_recycle_cache_size 0 Size of RECYCLE buffer pool for standard block size buffers
db_unique_name chic Database Unique Name
db_writer_processes 1 number of background database writer processes to start
dbwr_io_slaves 0 DBWR I/O slaves
ddl_wait_for_locks FALSE Disable NOWAIT DML lock acquisitions
dg_broker_config_file1 C:\ORACLE\PRODUCT\10.2.0 data guard broker configuration file #1
\DB_1\DATABASE\DR1CHIC.D
AT
dg_broker_config_file2 C:\ORACLE\PRODUCT\10.2.0 data guard broker configuration file #2
\DB_1\DATABASE\DR2CHIC.D
AT
dg_broker_start FALSE start Data Guard broker framework (DMON process)
disk_asynch_io TRUE Use asynch I/O for random access devices
dispatchers (PROTOCOL=TCP) (SERVICE= specifications of dispatchers
chicXDB)
distributed_lock_timeout 60 number of seconds a distributed transaction waits for a lock
dml_locks 748 dml locks - one for each table modified in a transaction
drs_start FALSE start DG Broker monitor (DMON process)
event debug event control - default null string
fal_client FAL client
fal_server FAL server list
fast_start_io_target 0 Upper bound on recovery reads
fast_start_mttr_target 0 MTTR target of forward crash recovery in seconds
fast_start_parallel_rollback LOW max number of parallel recovery slaves that may be used
file_mapping FALSE enable file mapping
fileio_network_adapters Network Adapters for File I/O
filesystemio_options IO operations on filesystem files
fixed_date fixed SYSDATE value
gc_files_to_locks mapping between file numbers and global cache locks
gcs_server_processes 0 number of background gcs server processes to start
global_context_pool_size Global Application Context Pool Size in Bytes
global_names FALSE enforce that database links have same name as remote database
hash_area_size 131072 size of in-memory hash work area
hi_shared_memory_address 0 SGA starting address (high order 32-bits on 64-bit platforms)
hs_autoregister TRUE enable automatic server DD updates in HS agent self-registration
ifile include file in init.ora
instance_groups list of instance group names
instance_name chic instance name supported by the instance
instance_number 0 instance number
instance_type RDBMS type of instance to be executed
java_max_sessionspace_size 0 max allowed size in bytes of a Java sessionspace
java_pool_size 0 size in bytes of java pool
java_soft_sessionspace_limit 0 warning limit on size in bytes of a Java sessionspace
job_queue_processes 10 number of job queue slave processes
large_pool_size 0 size in bytes of large pool
ldap_directory_access NONE RDBMS's LDAP access option
license_max_sessions 0 maximum number of non-system user sessions allowed
license_max_users 0 maximum number of named users that can be created in the database
license_sessions_warning 0 warning level for number of non-system user sessions
local_listener local listener
lock_name_space lock name space used for generating lock names for standby/clone datab
ase
lock_sga FALSE Lock entire SGA in physical memory
log_archive_config log archive config parameter
log_archive_dest archival destination text string
log_archive_dest_1 archival destination #1 text string
log_archive_dest_10 archival destination #10 text string
log_archive_dest_2 archival destination #2 text string
log_archive_dest_3 archival destination #3 text string
log_archive_dest_4 archival destination #4 text string
log_archive_dest_5 archival destination #5 text string
log_archive_dest_6 archival destination #6 text string
log_archive_dest_7 archival destination #7 text string
log_archive_dest_8 archival destination #8 text string
log_archive_dest_9 archival destination #9 text string
log_archive_dest_state_1 enable archival destination #1 state text string
log_archive_dest_state_10 enable archival destination #10 state text string
log_archive_dest_state_2 enable archival destination #2 state text string
log_archive_dest_state_3 enable archival destination #3 state text string
log_archive_dest_state_4 enable archival destination #4 state text string
log_archive_dest_state_5 enable archival destination #5 state text string
log_archive_dest_state_6 enable archival destination #6 state text string
log_archive_dest_state_7 enable archival destination #7 state text string
log_archive_dest_state_8 enable archival destination #8 state text string
log_archive_dest_state_9 enable archival destination #9 state text string
log_archive_duplex_dest duplex archival destination text string
log_archive_format ARC%S_%R.%T archival destination format
log_archive_local_first TRUE Establish EXPEDITE attribute default value
log_archive_max_processes 2 maximum number of active ARCH processes
log_archive_min_succeed_dest 1 minimum number of archive destinations that must succeed
log_archive_start FALSE start archival process on SGA initialization
log_archive_trace 0 Establish archivelog operation tracing level
log_buffer 7024640 redo circular buffer size
log_checkpoint_interval 0 # redo blocks checkpoint threshold
log_checkpoint_timeout 1800 Maximum time interval between checkpoints in seconds
log_checkpoints_to_alert FALSE log checkpoint begin/end to alert file
log_file_name_convert logfile name convert patterns and strings for standby/clone db
logmnr_max_persistent_sessions 1 maximum number of threads to mine
max_commit_propagation_delay 0 Max age of new snapshot in .01 seconds
max_dispatchers max number of dispatchers
max_dump_file_size UNLIMITED Maximum size (blocks) of dump file
max_enabled_roles 150 max number of roles a user can have enabled
max_shared_servers max number of shared servers
nls_calendar NLS calendar system name
nls_comp NLS comparison
nls_currency NLS local currency symbol
nls_date_format NLS Oracle date format
nls_date_language NLS date language name
nls_dual_currency Dual currency symbol
nls_iso_currency NLS ISO currency territory name
nls_language AMERICAN NLS language name
nls_length_semantics BYTE create columns using byte or char semantics by default
nls_nchar_conv_excp FALSE NLS raise an exception instead of allowing implicit conversion
nls_numeric_characters NLS numeric characters
nls_sort NLS linguistic definition name
nls_territory AMERICA NLS territory name
nls_time_format time format
nls_time_tz_format time with timezone format
nls_timestamp_format time stamp format
nls_timestamp_tz_format timestampe with timezone format
object_cache_max_size_percent 10 percentage of maximum size over optimal of the user session's object c
ache
object_cache_optimal_size 102400 optimal size of the user session's object cache in bytes
olap_page_pool_size 0 size of the olap page pool in bytes
open_cursors 300 max # cursors per session
open_links 4 max # open links per session
open_links_per_instance 4 max # open links per instance
optimizer_dynamic_sampling 2 optimizer dynamic sampling
optimizer_features_enable 10.2.0.1 optimizer plan compatibility parameter
optimizer_index_caching 0 optimizer percent index caching
optimizer_index_cost_adj 100 optimizer index cost adjustment
optimizer_mode ALL_ROWS optimizer mode
optimizer_secure_view_merging TRUE optimizer secure view merging and predicate pushdown/movearound
os_authent_prefix OPS$ prefix for auto-logon accounts
os_roles FALSE retrieve roles from the operating system
parallel_adaptive_multi_user TRUE enable adaptive setting of degree for multiple user streams
parallel_automatic_tuning FALSE enable intelligent defaults for parallel execution parameters
parallel_execution_message_size 2148 message buffer size for parallel execution
parallel_instance_group instance group to use for all parallel operations
parallel_max_servers 40 maximum parallel query servers per instance
parallel_min_percent 0 minimum percent of threads required for parallel query
parallel_min_servers 0 minimum parallel query servers per instance
parallel_server FALSE if TRUE startup in parallel server mode
parallel_server_instances 1 number of instances to use for sizing OPS SGA structures
parallel_threads_per_cpu 2 number of parallel execution threads per CPU
pga_aggregate_target 202375168 Target size for the aggregate PGA memory consumed by the instance
plsql_ccflags PL/SQL ccflags
plsql_code_type INTERPRETED PL/SQL code-type
plsql_compiler_flags INTERPRETED, NON_DEBUG PL/SQL compiler flags
plsql_debug FALSE PL/SQL debug
plsql_native_library_dir plsql native library dir
plsql_native_library_subdir_coun 0 plsql native library number of subdirectories
t
plsql_optimize_level 2 PL/SQL optimize level
plsql_v2_compatibility FALSE PL/SQL version 2.x compatibility flag
plsql_warnings DISABLE:ALL PL/SQL compiler warnings settings
pre_page_sga FALSE pre-page sga for process
processes 150 user processes
query_rewrite_enabled TRUE allow rewrite of queries using materialized views if enabled
query_rewrite_integrity enforced perform. rewrite using materialized views with desired integrity
rdbms_server_dn RDBMS's Distinguished Name
read_only_open_delayed FALSE if TRUE delay opening of read only files until first access
recovery_parallelism 0 number of server processes to use for parallel recovery
recyclebin on recyclebin processing
remote_archive_enable true remote archival enable setting
remote_dependencies_mode TIMESTAMP remote-procedure-call dependencies mode parameter
remote_listener remote listener
remote_login_passwordfile EXCLUSIVE password file usage parameter
remote_os_authent FALSE allow non-secure remote clients to use auto-logon accounts
remote_os_roles FALSE allow non-secure remote clients to use os roles
replication_dependency_tracking TRUE tracking dependency for Replication parallel propagation
resource_limit FALSE master switch for resource limit
resource_manager_plan resource mgr top plan
resumable_timeout 0 set resumable_timeout
rollback_segments undo segment list
serial_reuse disable reuse the frame. segments
service_names chic service names supported by the instance
session_cached_cursors 20 Number of cursors to cache in a session.
session_max_open_files 10 maximum number of open files allowed per session
sessions 170 user and system sessions
sga_max_size 612368384 max total SGA size
sga_target 612368384 Target size of SGA
shadow_core_dump partial Core Size for Shadow Processes
shared_memory_address 0 SGA starting address (low order 32-bits on 64-bit platforms)
shared_pool_reserved_size 9437184 size in bytes of reserved area of shared pool
shared_pool_size 0 size in bytes of shared pool
shared_server_sessions max number of shared server sessions
shared_servers 1 number of shared servers to start up
skip_unusable_indexes TRUE skip unusable indexes if set to TRUE
smtp_out_server utl_smtp server and port configuration parameter
sort_area_retained_size 0 size of in-memory sort work area retained between fetch calls
sort_area_size 65536 size of in-memory sort work area
spfile C:\ORACLE\PRODUCT\10.2.0 server parameter file
\DB_1\DBS\SPFILECHIC.ORA
sql92_security FALSE require select privilege for searched update/delete
sql_trace FALSE enable SQL trace
sql_version NATIVE sql language version parameter for compatibility issues
sqltune_category DEFAULT Category qualifier for applying hintsets
standby_archive_dest %ORACLE_HOME%\RDBMS standby database archivelog destination text string
standby_file_management MANUAL if auto then files are created/dropped automatically on standby
star_transformation_enabled FALSE enable the use of star transformation
statistics_level TYPICAL statistics level
streams_pool_size 0 size in bytes of the streams pool
tape_asynch_io TRUE Use asynch I/O requests for tape devices
thread 0 Redo thread to mount
timed_os_statistics 0 internal os statistic gathering interval in seconds
timed_statistics TRUE maintain internal timing statistics
trace_enabled TRUE enable KST tracing
tracefile_identifier trace file custom identifier
transactions 187 max. number of concurrent active transactions
transactions_per_rollback_segmen 5 number of active transactions per rollback segment
t
undo_management AUTO instance runs in SMU mode if TRUE, else in RBU mode
undo_retention 900 undo retention in seconds
undo_tablespace UNDOTBS1 use/switch undo tablespace
use_indirect_data_buffers FALSE Enable indirect data buffers (very large SGA on 32-bit platforms)
user_dump_dest C:\ORACLE\PRODUCT\10.2.0 User process dump directory
\ADMIN\CHIC\UDUMP
utl_file_dir utl_file accessible directories list
workarea_size_policy AUTO policy used to size SQL working areas (MANUAL/AUTO)
已选择1381行。
SQL>
----------------------
以上。
来自 “ ITPUB博客 ” ,链接:http://blog.itpub.net/20335819/viewspace-713519/,如需转载,请注明出处,否则将追究法律责任。
转载于:http://blog.itpub.net/20335819/viewspace-713519/