Oracle 10g R2 ±£¤·¥Ñ¥é¥á¡¼¥¿°ìÍ÷
ºÇ¶á oracle 10g ¤Î¥Ñ¥é¥á¡¼¥¿¼þ¤ê¤Ç¤¤¤í¤¤¤íÄ´¤Ù¤ë¤³¤È¤¬¤¢¤Ã¤¿¤Î¤Ç¤½¤ÎÈ÷˺Ͽ¡£oracle ¤Ë¤Ï¤¢¤é¤«¤¸¤áÊØÍø¤Ê view ¤¬´ö¤Ä¤«ÍѰդµ¤ì¤Æ¤¤¤ë¤Î¤Ç¡¢view ¤Î̾Á°¤ÈÄêµÁ¤Ë¤Ä¤¤¤ÆÄ´¤Ù¤ë SQL ¤Ë¤Ä¤¤¤Æ¡£
select view_name, view_definition from v$fixed_view_definition
oracle 10.2.0 ¤Ç 770 ¤â¤Î view ¤ÎÄêµÁ¤¬É½¼¨¤µ¤ì¤Þ¤¹¡£¼«Ê¬¤ÎÃΤé¤Ê¤¤°Ê³°¤ÈÊØÍø¤½¤¦¤Ê view ¤¬±£¤µ¤ì¤Æ¤¤¤ë¤«¤â¤·¤ì¤Ê¤¤¤Î¤Ç°ìÅÙ¸«¤Æ¤ª¤¯¤È»²¹Í¤Ë¤Ê¤ë¤«¤â¡£¼¡¤Ë¡¢oracle ¤Îúì¥Ñ¥é¥á¡¼¥¿¤òɽ¼¨¤¹¤ë SQL ¤Ë¤Ä¤¤¤Æ¡£
select KSPPINM name, KSPPDESC description from X$KSPPI where substr(KSPPINM,1,1) = '_' order by KSPPINM;
ÅöÁ³¤Ê¤¬¤é¡¢oracle ¤Ï±£¤·¥Ñ¥é¥á¡¼¥¿¤Î»ÈÍѤϿ侩¤·¤Æ¤¤¤Þ¤»¤ó¡£¤¬¡¢¼ÂºÝ¤Ï oracle ¤Î¥Á¥å¡¼¥Ë¥ó¥°¥Ù¥ó¥À¡¼¤¬¤¤¤í¤¤¤íÀßÄꤹ¤ë¤È¤¤Ë¤Ï±£¤·¥Ñ¥é¥á¡¼¥¿¤òÍøÍѤ¹¤ë¤³¤È¤â¤è¤¯¤¢¤ê¤Þ¤¹¡£¤Ã¤Æ¤³¤È¤Ç¡¢oracle 10.2.0 ¤Î±£¤·¥Ñ¥é¥á¡¼¥¿¤Î°ìÍ÷¤È¤¤¤¦¤³¤È¤Ç¡¢Àè¤Û¤É¤Î SQL ¤Î¼Â¹Ô·ë²Ì¤Ï¤³¤Á¤é¡£
| NAME | DESCRIPTION |
| _4031_dump_bitvec | bitvec to specify dumps prior to 4031 error |
| _4031_dump_interval | Dump 4031 error once for each n-second interval |
| _4031_max_dumps | Maximum number of 4031 dumps for this process |
| _4031_sga_dump_interval | Dump 4031 SGA heapdump error once for each n-second interval |
| _4031_sga_max_dumps | Maximum number of SGA heapdumps |
| _NUMA_instance_mapping | Set of nodes that this instance should run on |
| _NUMA_pool_size | aggregate size in bytes of NUMA pool |
| _PX_use_large_pool | Use Large Pool as source of PX buffers |
| __db_cache_size | Actual size of DEFAULT buffer pool for standard block size buffers |
| __dg_broker_service_names | service names for broker use |
| __java_pool_size | Actual size in bytes of java pool |
| __large_pool_size | Actual size in bytes of large pool |
| __shared_pool_size | Actual size in bytes of shared pool |
| __streams_pool_size | Actual size in bytes of streams pool |
| _abort_recovery_on_join | if TRUE, abort recovery on join reconfigurations |
| _accept_versions | List of parameters for rolling operation |
| _active_standby_fast_reconfiguration | if TRUE optimize dlm reconfiguration for active/standby OPS |
| _adaptive_direct_read | Adaptive Direct Read |
| _adaptive_fetch_enabled | enable/disable adaptive fetch in parallel group by |
| _add_stale_mv_to_dependency_list | add stale mv to dependency list |
| _addm_auto_enable | governs whether ADDM gets run automatically after every AWR snapshot |
| _addm_skiprules | comma-separated list of ADDM nodes to skip |
| _addm_version_check | governs whether ADDM checks the input AWR snapshot version |
| _adjust_literal_replacement | If TRUE, we will adjust the SQL/PLUS output |
| _affinity_on | enable/disable affinity at run time |
| _aiowait_timeouts | Number of aiowait timeouts before error is reported |
| _alert_expiration | seconds before an alert message is moved to exception queue |
| _alert_message_cleanup | Enable Alert Message Cleanup |
| _alert_message_purge | Enable Alert Message Purge |
| _alert_post_background | Enable Background Alert Posting |
| _all_shared_dblinks | treat all dblinks as shared |
| _allocate_creation_order | should files be examined in creation order during allocation |
| _allocation_update_interval | interval at which successful search in L1 should be updated |
| _allow_commutativity | allow for commutativity of +, * when comparing expressions |
| _allow_error_simulation | Allow error simulation for testing |
| _allow_level_without_connect_by | allow level without connect by |
| _allow_read_only_corruption | allow read-only open even if database is corrupt |
| _allow_resetlogs_corruption | allow resetlogs even if it will cause corruption |
| _allow_terminal_recovery_corruption | Finish terminal recovery even if it may cause corruption |
| _alternate_iot_leaf_block_split_points | enable alternate index-organized table leaf-block split-points |
| _always_anti_join | always use this method for anti-join when possible |
| _always_semi_join | always use this method for semi-join when possible |
| _always_star_transformation | always favor use of star transformation |
| _app_ctx_vers | enable app ctx versioning |
| _aq_tm_scanlimit | scan limit for Time Managers to clean up IOT |
| _arch_io_slaves | ARCH I/O slaves |
| _array_update_vector_read_enabled | Enable array update vector read |
| _ash_disk_filter_ratio | Ratio of the number of in-memory samples to the number of samples actually written to disk |
| _ash_disk_write_enable | To enable or disable Active Session History flushing |
| _ash_dummy_test_param | Oracle internal dummy ASH parameter used ONLY for testing! |
| _ash_eflush_trigger | The percentage above which if the in-memory ASH is full the emergency flusher will be triggered |
| _ash_enable | To enable or disable Active Session sampling and flushing |
| _ash_sample_all | To enable or disable sampling every connected session including ones waiting for idle waits |
| _ash_sampling_interval | Time interval between two successive Active Session samples in millisecs |
| _ash_size | To set the size of the in-memory Active Session History buffers |
| _asm_acd_chunks | initial ACD chunks created |
| _asm_allow_only_raw_disks | Discovery only raw devices |
| _asm_allow_resilver_corruption | Enable disk resilvering for external redundancy |
| _asm_ausize | allocation unit size |
| _asm_blksize | metadata block size |
| _asm_disk_repair_time | seconds to wait before dropping a failing disk |
| _asm_droptimeout | timeout before offlined disks get dropped (in 3s ticks) |
| _asm_emulmax | max number of concurrent disks to emulate I/O errors |
| _asm_emultimeout | timeout before emulation begins (in 3s ticks) |
| _asm_kfdpevent | KFDP event |
| _asm_libraries | library search order for discovery |
| _asm_maxio | Maximum size of individual I/O request |
| _asm_stripesize | ASM file stripe size |
| _asm_stripewidth | ASM file stripe width |
| _asm_wait_time | Max/imum time to wait before asmb exits |
| _asmlib_test | Osmlib test event |
| _asmsid | ASM instance id |
| _assm_default | ASSM default |
| _async_recovery_claims | if TRUE, issue recovery claims asynchronously |
| _async_recovery_reads | if TRUE, issue recovery reads asynchronously |
| _avoid_prepare | if TRUE, do not prepare a buffer when the master is local |
| _awr_corrupt_mode | AWR Corrupt Mode |
| _awr_disabled_flush_tables | Disable flushing of specified AWR tables |
| _awr_flush_threshold_metrics | Enable/Disable Flushing AWR Workload Metrics |
| _awr_flush_workload_metrics | Enable/Disable Flushing AWR Workload Metrics |
| _awr_mmon_cpuusage | Enable/disable AWR MMON CPU Usage Tracking |
| _awr_restrict_mode | AWR Restrict Mode |
| _awr_sql_child_limit | Setting for AWR SQL Child Limit |
| _b_tree_bitmap_plans | enable the use of bitmap plans for tables w. only B-tree indexes |
| _backup_disk_io_slaves | BACKUP Disk I/O slaves |
| _backup_io_pool_size | memory to reserve from the large pool |
| _backup_kgc_bufsz | specifies buffer size to be used for kgc compression |
| _backup_kgc_niters | specifies number of iterations used for kgc compression |
| _backup_kgc_type | specifies compression type used for kgc compression |
| _backup_ksfq_bufcnt | number of the ksfq buffers used for backup/restore |
| _backup_ksfq_bufsz | size of the ksfq buffer used for backup/restore |
| _backup_max_gap_size | largest gap in an incremental/optimized backup buffer, in bytes |
| _bct_bitmaps_per_file | number of bitmaps to store for each datafile |
| _bct_buffer_allocation_max | maximum size of all change tracking buffer allocations, in bytes |
| _bct_buffer_allocation_min_extents | mininum number of extents to allocate per buffer allocation |
| _bct_buffer_allocation_size | size of one change tracking buffer allocation, in bytes |
| _bct_chunk_size | change tracking datafile chunk size, in bytes |
| _bct_crash_reserve_size | change tracking reserved crash recovery SGA space, in bytes |
| _bct_file_block_size | block size of change tracking file, in bytes |
| _bct_file_extent_size | extent size of change tracking file, in bytes |
| _bct_fixtab_file | change tracking file for fixed tables |
| _bct_initial_private_dba_buffer_size | initial number of entries in the private change tracking dba buffers |
| _bct_public_dba_buffer_size | total size of all public change tracking dba buffers, in bytes |
| _bitmap_or_improvement_enabled | controls extensions to partition pruning for general predicates |
| _block_change_tracking | change tracking possible |
| _blocks_per_cache_server | number of consecutive blocks per global cache server |
| _bloom_filter_debug | debug level for bloom filtering |
| _bloom_filter_enabled | enables or disables bloom filter |
| _bt_mmv_query_rewrite_enabled | allow rewrites with multiple MVs and base tables |
| _buffer_busy_wait_timeout | buffer busy wait time in centiseconds |
| _bufq_flow_control_thrsh | flow control threshold value |
| _bufq_max_msg_sz | maximum size of the message allowed in memory |
| _bufq_stop_flow_control | Stop enforcing flow control for buffered queues |
| _build_deferred_mv_skipping_mvlog_update | DEFERRED MV creation skipping MV log setup update |
| _bump_highwater_mark_count | how many blocks should we allocate per free list on advancing HWM |
| _bwr_for_flushed_pi | if TRUE, generate a BWR for a flushed PI |
| _cache_stats_monitor | if TRUE, enable cache stats monitoring |
| _cgs_reconfig_timeout | CGS reconfiguration timeout interval |
| _cgs_send_timeout | CGS send timeout value |
| _check_block_after_checksum | perform block check after checksum if both are turned on |
| _check_ts_threshold | check tablespace thresholds |
| _cleanup_rollback_entries | no. of undo entries to apply per transaction cleanup |
| _close_cached_open_cursors | close cursors cached by PL/SQL at each commit |
| _cluster_library | cluster library selection |
| _collapse_wait_history | collapse wait history |
| _collect_undo_stats | Collect Statistics v$undostat |
| _column_compression_factor | Column compression ratio |
| _column_elimination_off | turn off predicate-only column elimination |
| _column_tracking_level | column usage tracking |
| _compilation_call_heap_extent_size | Size of the compilation call heaps extents |
| _complex_view_merging | enable complex view merging |
| _controlfile_block_size | control file block size in bytes |
| _controlfile_enqueue_dump | dump the system states after controlfile enqueue timeout |
| _controlfile_enqueue_timeout | 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 | controlfile update sanity check |
| _convert_set_to_join | enables conversion of set operator to join |
| _coord_message_buffer | parallel recovery coordinator side extra message buffer size |
| _corrupted_rollback_segments | corrupted undo segment list |
| _cost_equality_semi_join | enables costing of equality semi-join |
| _cpu_to_io | divisor for converting CPU cost to I/O cost |
| _cr_grant_global_role | if TRUE, grant lock for CR requests when block is in global role |
| _cr_grant_local_role | turn 3-way CR grants off, make it automatic, or turn it on |
| _cr_server_log_flush | if TRUE, flush redo log before serving a CR buffer |
| _ctas_hwm_brokered_loads | Enable HWM brokered CTAS |
| _cursor_bind_capture_area_size | maximum size of the cursor bind capture area |
| _cursor_bind_capture_interval | interval (in seconds) between two bind capture for a cursor |
| _cursor_cache_frame_bind_memory | frame & bind buffer caching |
| _cursor_db_buffers_pinned | additional number of buffers a cursor can pin at once |
| _cursor_plan_enabled | enable collection and display of cursor plans |
| _cursor_plan_hash_version | version of cursor plan hash value |
| _cursor_plan_unparse_enabled | enables/disables using unparse to build projection/predicates |
| _cursor_stats_bucket | Hash table buckets for cursor stats (2^). |
| _cursor_stats_heap | Heaps/latches for cursor stats. |
| _db_aging_cool_count | Touch count set when buffer cooled |
| _db_aging_freeze_cr | Make CR buffers always be too cold to keep in cache |
| _db_aging_hot_criteria | Touch count which sends a buffer to head of replacement list |
| _db_aging_stay_count | Touch count set when buffer moved to head of replacement list |
| _db_aging_touch_time | Touch count which sends a buffer to head of replacement list |
| _db_always_check_system_ts | Always perform block check and checksum for System tablespace |
| _db_block_adjcheck | adjacent cache buffer checks - low blkchk overwrite parameter |
| _db_block_adjchk_level | adjacent cache buffer check level |
| _db_block_align_direct_read | Align Direct Reads |
| _db_block_buffers | Number of database blocks cached in memory: hidden parameter |
| _db_block_cache_clone | Always clone data blocks on get (for debugging) |
| _db_block_cache_history | buffer header tracing (non-zero only when debugging) |
| _db_block_cache_history_level | buffer header tracing level |
| _db_block_cache_num_umap | number of unmapped buffers (for tracking swap calls on blocks) |
| _db_block_cache_protect | protect database blocks (true only when debugging) |
| _db_block_cache_protect_internal | protect database blocks (for strictly internal use only) |
| _db_block_check_for_debug | Check more and dump block before image for debugging |
| _db_block_check_objtyp | check objd and typ on cache disk read |
| _db_block_do_full_mbreads | do full block read even if some blocks are in cache |
| _db_block_hash_buckets | Number of database block hash buckets |
| _db_block_hash_latches | Number of database block hash latches |
| _db_block_hi_priority_batch_size | Fraction of writes for high priority reasons |
| _db_block_known_clean_pct | Initial Percentage of buffers to maintain known clean |
| _db_block_lru_latches | number of lru latches |
| _db_block_max_cr_dba | Maximum Allowed Number of CR buffers per dba |
| _db_block_max_scan_pct | Percentage of buffers to inspect when looking for free |
| _db_block_med_priority_batch_size | Fraction of writes for medium priority reasons |
| _db_block_numa | Number of NUMA nodes |
| _db_block_prefetch_limit | Prefetch limit in blocks |
| _db_block_prefetch_quota | Prefetch quota as a percent of cache size |
| _db_block_table_scan_buffer_size | Size of shared table scan read buffer |
| _db_block_temp_redo | generate redo for temp blocks |
| _db_block_trace_protect | trace buffer protect calls |
| _db_cache_advice_batch_size | cache advisory simulation batch size |
| _db_cache_advice_sample_factor | cache advisory sampling factor |
| _db_cache_crx_check | check for costly crx examination functions |
| _db_cache_pre_warm | 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 | enable db change notification |
| _db_fast_obj_check | enable fast object drop sanity check |
| _db_fast_obj_ckpt | enable fast object checkpoint |
| _db_fast_obj_truncate | enable fast object truncate |
| _db_file_direct_io_count | Sequential I/O buf size |
| _db_file_exec_read_count | multiblock read count for regular clients |
| _db_file_format_io_buffers | Block formatting I/O buf count |
| _db_file_noncontig_mblock_read_count | number of noncontiguous db blocks to be prefetched |
| _db_file_optimizer_read_count | multiblock read count for regular clients |
| _db_handles | System-wide simultaneous buffer operations |
| _db_handles_cached | Buffer handles cached each process |
| _db_hot_block_tracking | track hot blocks for hash latch contention |
| _db_index_block_checking | index block checking override parameter |
| _db_large_dirty_queue | Number of buffers which force dirty queue to be written |
| _db_lost_write_checking | Enable scn based lost write detection mechanism |
| _db_mttr_advice | MTTR advisory |
| _db_mttr_partitions | number of partitions for MTTR advisory |
| _db_mttr_sample_factor | MTTR simulation sampling factor |
| _db_mttr_sim_target | MTTR simulation targets |
| _db_mttr_sim_trace_size | MTTR simulation trace size |
| _db_mttr_trace_to_alert | dump trace entries to alert file |
| _db_obj_ckpt_ordered | fast object checkpoint ordered by lrba |
| _db_obj_enable_ksr | enable ksr in object checkpoint/reuse |
| _db_percent_hot_default | Percent of default buffer pool considered hot |
| _db_percent_hot_keep | Percent of keep buffer pool considered hot |
| _db_percent_hot_recycle | Percent of recycle buffer pool considered hot |
| _db_percpu_create_cachesize | 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 | row overlap checking override parameter for data/index blocks |
| _db_todefer_cache_create | buffer cache deferred create |
| _db_writer_chunk_writes | Number of writes DBWR should wait for |
| _db_writer_coalesce_area_size | Size of memory allocated to dbwriter for coalescing writes |
| _db_writer_coalesce_write_limit | Limit on size of coalesced write |
| _db_writer_flush_imu | If FALSE, DBWR will not downgrade IMU txns for AGING |
| _db_writer_histogram_statistics | maintain dbwr histogram statistics in x$kcbbhs |
| _db_writer_max_writes | Max number of outstanding DB Writer IOs |
| _db_writer_verify_writes | Enable lost write detection mechanism |
| _dbg_proc_startup | debug process startup |
| _dbwr_async_io | Enable dbwriter asynchronous writes |
| _dbwr_scan_interval | dbwriter scan interval |
| _dbwr_tracing | Enable dbwriter tracing |
| _dead_process_scan_interval | PMON dead process scan interval |
| _dedicated_server_poll_count | dedicated server poll count |
| _dedicated_server_post_wait | dedicated server post/wait |
| _dedicated_server_post_wait_call | dedicated server post/wait call |
| _default_encrypt_alg | default encryption algorithm |
| _default_non_equality_sel_check | sanity check on default selectivity for like/range predicate |
| _delay_index_maintain | delays index maintenance until after MV is refreshed |
| _diag_daemon | start DIAG daemon |
| _diag_diagnostics | Turn off diag diagnostics |
| _dimension_skip_null | control dimension skip when null feature |
| _disable_adaptive_shrunk_aggregation | adaptive shrunk aggregation |
| _disable_datalayer_sampling | disable datalayer sampling |
| _disable_duplex_link | Turn off connection duplexing |
| _disable_fast_aggregation | fast aggregation |
| _disable_file_locks | disable file locks for control, data, redo log files |
| _disable_function_based_index | disable function-based index matching |
| _disable_health_check | Disable Health Check |
| _disable_image_check | Disable Oracle executable image checking |
| _disable_incremental_checkpoints | Disable incremental checkpoints for thread recovery |
| _disable_incremental_recovery_ckpt | Disable incremental recovery checkpoint mechanism |
| _disable_instance_params_check | disable instance type check for ksp |
| _disable_interface_checking | disable interface checking at startup |
| _disable_kcbhxor_osd | disable kcbh(c)xor OSD functionality |
| _disable_latch_free_SCN_writes_via_32cas | disable latch-free SCN writes using 32-bit compare & swap |
| _disable_latch_free_SCN_writes_via_64cas | disable latch-free SCN writes using 64-bit compare & swap |
| _disable_logging | Disable logging |
| _disable_multiple_block_sizes | disable multiple block size support (for debugging) |
| _disable_odm | disable odm feature |
| _disable_recoverable_recovery | Disable the new recoverable recovery mechanism |
| _disable_recovery_read_skip | Disable the read optimization during media recovery |
| _disable_sample_io_optim | disable row sampling IO optimization |
| _disable_savepoint_reset | disable the fix for bug 1402161 |
| _disable_selftune_checkpointing | Disable self-tune checkpointing |
| _disable_streams_pool_auto_tuning | disable streams pool auto tuning |
| _disable_sun_rsm | Disable IPC OSD support for Sun RSMAPI |
| _disable_system_state | disable system state dump |
| _disable_txn_alert | disable txn layer alert |
| _discrete_transactions_enabled | 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 | enables unnesting of in subquery into distinct view |
| _distributed_recovery_connection_hold_time | number of seconds RECO holds outbound connections open |
| _dlm_send_timeout | DLM send timeout value |
| _dlmtrace | Trace string of global enqueue type(s) |
| _dm_max_shared_pool_pct | max percentage of the shared pool to use for a mining model |
| _dml_monitoring_enabled | enable modification monitoring |
| _domain_index_batch_size | maximum number of rows from one call to domain index fetch routine |
| _domain_index_dml_batch_size | maximum number of rows for one call to domain index dml routines |
| _drop_table_granule | drop_table_granule |
| _drop_table_optimization_enabled | reduce SGA memory use during drop of a partitioned table |
| _ds_iocount_iosize | Dynamic Sampling Service defaults: #IOs and IO Size |
| _dss_cache_flush | enable full cache flush for parallel execution |
| _dtree_area_size | size of Decision Tree Classification work area |
| _dtree_binning_enabled | Decision Tree Binning Enabled |
| _dtree_bintest_id | Decision Tree Binning Test ID |
| _dtree_compressbmp_enabled | Decision Tree Using Compressed Bitmaps Enabled |
| _dtree_max_surrogates | maximum number of surrogates |
| _dtree_pruning_enabled | Decision Tree Pruning Enabled |
| _dummy_instance | dummy instance started by RMAN |
| _dump_common_subexpressions | dump common subexpressions |
| _dump_connect_by_loop_data | dump connect by loop error message into trc file |
| _dump_cursor_heap_sizes | dump comp/exec heap sizes to tryace file |
| _dump_interval_limit | trace dump time interval limit (in seconds) |
| _dump_max_limit | max number of dump within dump interval |
| _dump_qbc_tree | dump top level query parse tree to trace |
| _dump_rcvr_ipc | if TRUE enables IPC dump at instance eviction time |
| _dump_system_state_scope | scope of sysstate dump during instance termination |
| _dump_trace_scope | scope of trace dump during a process crash |
| _dynamic_rls_policies | rls policies are dynamic |
| _dynamic_stats_threshold | delay threshold (in seconds) between sending statistics messages |
| _eliminate_common_subexpr | enables elimination of common sub-expressions |
| _enable_NUMA_optimization | Enable NUMA specific optimizations |
| _enable_block_level_transaction_recovery | enable block level recovery |
| _enable_cscn_caching | enable commit SCN caching for all transactions |
| _enable_default_affinity | to enable default implementation of affinity osds |
| _enable_dml_lock_escalation | enable dml lock escalation against partitioned tables if TRUE |
| _enable_exchange_validation_using_check | use check constraints on the table for validation |
| _enable_fast_ref_after_mv_tbs | enable fast refresh after move tablespace |
| _enable_hash_overflow | TRUE - enable hash cluster overflow based on SIZE |
| _enable_hwm_sync | enable HWM synchronization |
| _enable_kgh_policy | temporary to disable/enable kgh policy |
| _enable_list_io | Enable List I/O |
| _enable_nativenet_tcpip | Enable skgxp driver usage for native net |
| _enable_refresh_schedule | enable or disable MV refresh scheduling (revert to 9.2 behavior) |
| _enable_reliable_latch_waits | Enable reliable latch waits |
| _enable_rlb | enable RLB metrics processing |
| _enable_tablespace_alerts | enable tablespace alerts |
| _enable_type_dep_selectivity | enable type dependent selectivity estimates |
| _enqueue_debug_multi_instance | debug enqueue multi instance |
| _enqueue_hash | enqueue hash table length |
| _enqueue_hash_chain_latches | enqueue hash chain latches |
| _enqueue_locks | locks for managed enqueues |
| _enqueue_resources | resources for enqueues |
| _expand_aggregates | expand aggregates |
| _explain_rewrite_mode | allow additional messages to be generated during explain rewrite |
| _extended_pruning_enabled | do runtime pruning in iterator if set to TRUE |
| _fair_remote_cvt | if TRUE enables fair remote convert |
| _fairness_threshold | number of times to CR serve before downgrading lock |
| _fast_dual_enabled | enable/disable fast dual |
| _fast_full_scan_enabled | enable/disable index fast full scan |
| _fast_start_instance_recovery_target | cluster availability target time in RAC environment |
| _fic_algorithm_set | Set Frequent Itemset Counting Algorithm |
| _fic_area_size | size of Frequent Itemset Counting work area |
| _fic_max_length | Frequent Itemset Counting Maximum Itemset Length |
| _fic_min_bmsize | Frequent Itemset Counting Minimum BITMAP Size |
| _fic_outofmem_candidates | 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 | Allow enabling flashback on noarchivelog database |
| _flashback_barrier_interval | Flashback barrier interval in seconds |
| _flashback_copy_latches | Number of flashback copy latches |
| _flashback_fuzzy_barrier | Use flashback fuzzy barrier |
| _flashback_generation_buffer_size | flashback generation buffer size |
| _flashback_hint_barrier_percent | Flashback hint barrier percent |
| _flashback_log_io_error_behavior | Specify Flashback log I/O error behavior |
| _flashback_log_min_size | Minimum flashback log size |
| _flashback_log_size | Flashback log size |
| _flashback_logfile_enqueue_timeout | flashback logfile enqueue timeout for opens |
| _flashback_max_log_size | Maximum flashback log size in bytes (OS limit) |
| _flashback_max_n_log_per_thread | Maximum number of flashback logs per flashback thread |
| _flashback_n_log_per_thread | Desired number of flashback logs per flashback thread |
| _flashback_standby_barrier_interval | Flashback standby barrier interval in seconds |
| _flashback_verbose_info | Print verbose information about flashback database |
| _flashback_write_size_qm | Desired flashback write size in quarter MB |
| _force_datefold_trunc | force use of trunc for datefolding rewrite |
| _force_rewrite_enable | control new query rewrite features |
| _force_temptables_for_gsets | executes concatenation of rollups using temp tables |
| _fourth_spare_parameter | fourth spare parameter - string |
| _full_pwise_join_enabled | enable full partition-wise join when TRUE |
| _gby_hash_aggregation_enabled | enable group-by and aggregation using hash scheme |
| _gby_onekey_enabled | enable use of one comparison of all group by keys |
| _gc_affinity_limit | dynamic affinity limit |
| _gc_affinity_minimum | dynamic affinity minimum activity per minute |
| _gc_affinity_time | if non zero, enable dynamic object affinity |
| _gc_check_bscn | if TRUE, check for stale blocks |
| _gc_coalesce_recovery_reads | if TRUE, coalesce recovery reads |
| _gc_defer_time | how long to defer down converts for hot buffers |
| _gc_dynamic_affinity_locks | if TRUE, get dynamic affinity locks |
| _gc_element_percent | global cache element percent |
| _gc_global_lru | turn global lru off, make it automatic, or turn it on |
| _gc_integrity_checks | set the integrity check level |
| _gc_keep_recovery_buffers | if TRUE, make recovery buffers current |
| _gc_latches | number of latches per LMS process |
| _gc_maximum_bids | maximum number of bids which can be prepared |
| _gc_statistics | if TRUE, kcl statistics are maintained |
| _gc_undo_affinity | if TRUE, enable dynamic undo affinity |
| _gc_undo_affinity_locks | if TRUE, get affinity locks for undo |
| _gc_use_cr | if TRUE, allow CR pins on PI and WRITING buffers |
| _gc_vector_read | if TRUE, vector read current buffers |
| _gcs_fast_reconfig | if TRUE, enable fast reconfiguration for gcs locks |
| _gcs_latches | number of gcs resource hash latches to be allocated per LMS process |
| _gcs_process_in_recovery | 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 | controls extensions to partition pruning for general predicates |
| _ges_dd_debug | if TRUE enables GES deadlock detection debug diagnostics |
| _ges_diagnostics | if TRUE enables GES diagnostics |
| _ges_health_check | if greater than 0 enables GES system health check |
| _groupby_nopushdown_cut_ratio | groupby nopushdown cut ratio |
| _groupby_orderby_combine | groupby/orderby don't combine threshold |
| _gs_anti_semi_join_allowed | enable anti/semi join for the GS query |
| _hang_analysis_num_call_stacks | hang analysis num call stacks |
| _hang_detection | Hang Management detection interval |
| _hard_protection | if TRUE enable H.A.R.D specific format changes |
| _hash_join_enabled | enable/disable hash join |
| _hash_multiblock_io_count | number of blocks hash join will read/write at once |
| _high_server_threshold | high server thresholds |
| _hj_bit_filter_threshold | hash-join bit filtering threshold (0 always enabled) |
| _hwm_sync_threshold | HWM synchronization threshold in percentage |
| _idl_conventional_index_maintenance | enable conventional index maintenance for insert direct load |
| _idxrb_rowincr | proportionality constant for dop vs. rows in index rebuild |
| _ignore_desc_in_index | ignore DESC in indexes, sort those columns ascending anyhow |
| _immediate_commit_propagation | if TRUE, propagate commit SCN immediately |
| _improved_outerjoin_card | improved outer-join cardinality calculation |
| _improved_row_length_enabled | enable the improvements for computing the average row length |
| _imr_active | Activate Instance Membership Recovery feature |
| _imr_disk_voting_interval | Maximum wait for IMR disk voting (seconds) |
| _imr_max_reconfig_delay | Maximum Reconfiguration delay (seconds) |
| _imr_splitbrain_res_wait | Maximum wait for split-brain resolution (seconds) |
| _imu_pools | in memory undo pools |
| _in_memory_undo | Make in memory undo for top level transactions |
| _incremental_recovery_ckpt_min_batch | Minimum number of writes for incremental recovery ckpt every 3 sec |
| _index_join_enabled | enable the use of index joins |
| _index_prefetch_factor | index prefetching factor |
| _init_granule_interval | number of granules to process for deferred cache |
| _init_sql_file | File containing SQL statements to execute upon database creation |
| _inject_startup_fault | inject fault in the startup code |
| _insert_enable_hwm_brokered | during parallel inserts high water marks are brokered |
| _inst_locking_period | period an instance can retain a newly acquired level1 bitmap |
| _interconnect_checksum | if TRUE, checksum interconnect blocks |
| _intrapart_pdml_enabled | Enable intra-partition updates/deletes |
| _intrapart_pdml_randomlocal_enabled | Enable intra-partition updates/deletes with random local dist |
| _io_shared_pool_size | Size of I/O buffer pool from SGA |
| _io_slaves_disabled | Do not use I/O slaves |
| _ior_serialize_fault | inject fault in the ior serialize code |
| _ioslave_batch_count | Per attempt IOs picked |
| _ioslave_issue_count | IOs issued before completion check |
| _ipc_fail_network | Simulate cluster network failer |
| _ipc_test_failover | Test transparent cluster network failover |
| _ipc_test_mult_nets | simulate multiple cluster networks |
| _job_queue_interval | Wakeup interval in seconds for job queue co-ordinator |
| _kcl_commit | if TRUE, call kjbcommit |
| _kcl_conservative_log_flush | if TRUE, conservatively log flush before CR serving |
| _kcl_debug | if TRUE, record le history |
| _kcl_index_split | if TRUE, reject pings on blocks in middle of a split |
| _kcl_undo_grouping | grouping for undo block locks |
| _kcl_undo_locks | number of locks per undo segment |
| _kdbl_enable_post_allocation | allocate dbas after populating data buffers |
| _keep_remote_column_size | remote column size does not get modified |
| _kernel_message_network_driver | kernel message network driver |
| _kffmap_hash_size | size of kffmap_hash table |
| _kffmop_hash_size | size of kffmop_hash table |
| _kghdsidx_count | max kghdsidx count |
| _kgl_bucket_count | index to the bucket count array |
| _kgl_fixed_extents | fixed extent size for library cache memory allocations |
| _kgl_hash_collision | whether KGL hash collision is possible |
| _kgl_heap_size | extent size for library cache heap 0 |
| _kgl_keep_cache_pct | KGL keep cache minimum threshold |
| _kgl_keep_cache_retain_pct | KGL keep cache retain threshold |
| _kgl_large_heap_warning_threshold | maximum heap size before KGL writes warnings to the alert log |
| _kgl_latch_count | number of library cache latches |
| _kgl_multi_instance_invalidation | whether KGL to support multi-instance invalidations |
| _kgl_multi_instance_lock | whether KGL to support multi-instance locks |
| _kgl_multi_instance_pin | whether KGL to support multi-instance pins |
| _kgl_session_cached_objects | maximum length of the KGL object cache lru |
| _kgl_time_to_wait_for_locks | time to wait for locks and pins before timing out |
| _kglsim_maxmem_percent | max percentage of shared pool size to be used for KGL advice |
| _kgx_latches | # of mutex latches if CAS is not supported. |
| _kill_java_threads_on_eoc | Kill Java threads and do sessionspace migration at end of call |
| _kkfi_trace | trace expression substitution |
| _kks_use_mutex_pin | Turning on this will make KKS use mutex for cursor pins. |
| _kolfuseslf | allow kolf to use slffopen |
| _kql_subheap_trace | tracing level for library cache subheap level pins |
| _ksd_test_param | KSD test parmeter |
| _ksdxdocmd_default_timeout_ms | default timeout for internal oradebug commands |
| _ksdxw_cini_flg | ksdxw context initialization flag |
| _ksdxw_nbufs | ksdxw number of buffers in buffered mode |
| _ksdxw_num_pgw | number of watchpoints on a per-process basis |
| _ksdxw_num_sgw | number of watchpoints to be shared by all processes |
| _ksdxw_stack_depth | number of PCs to collect in the stack when watchpoint is hit |
| _kse_die_timeout | amount of time a dying process is spared by PMON (in centi-secs) |
| _kse_pc_table_size | kse pc table cache size |
| _ksfd_verify_write | verify asynchronous writes issued through ksfd |
| _ksi_trace | KSI trace string of lock type(s) |
| _ksmg_granule_locking_status | granule locking status |
| _ksmg_granule_size | granule size in bytes |
| _ksmg_lock_check_interval | timeout action interval in minutes |
| _ksmg_lock_reacquire_count | repeat count for acquisition of locks |
| _ksu_diag_kill_time | number of seconds ksuitm waits before killing diag |
| _ksuitm_dont_kill_dumper | delay inst. termination to allow processes to dump |
| _ksxp_diagmode | set to OFF to disable automatic slowsend diagnostics |
| _ksxp_reporting_process | reporting process for KSXP |
| _ksxp_send_timeout | set timeout for sends queued with the inter-instance IPC |
| _ktc_debug | for ktc debug |
| _ktc_latches | number of ktc latches |
| _ktu_latches | number of KTU latches |
| _ku_trace | datapump trace parameter |
| _large_pool_min_alloc | minimum allocation size in bytes for the large allocation pool |
| _last_allocation_period | 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 | Sid of process for which to collect latch stats |
| _latch_recovery_alignment | align latch recovery structures |
| _ldr_io_size | size of write IOs used during a load operation |
| _left_nested_loops_random | enable random distribution method for left of nestedloops |
| _lgwr_async_broadcasts | LGWR Asynchronous Broadcasts enabling boolean flag |
| _lgwr_async_io | LGWR Asynchronous IO enabling boolean flag |
| _lgwr_delay_write | LGWR write delay for debugging |
| _lgwr_io_slaves | LGWR I/O slaves |
| _lgwr_max_ns_wt | Maximum wait time for lgwr to allow NetServer to progress |
| _lgwr_ns_nl_max | Variable to simulate network latency or buffer threshold |
| _lgwr_ns_nl_min | Variable to simulate network latency or buffer threshold |
| _lgwr_ns_sim_err | Variable to simulate errors lgwrns |
| _lgwr_ta_sim_err | Variable to simulate errors lgwr true async |
| _library_cache_advice | whether KGL advice should be turned on |
| _lightweight_hdrs | Lightweight headers for redo |
| _like_with_bind_as_equality | treat LIKE predicate with bind as an equality predicate |
| _lm_activate_lms_threshold | threshold value to activate an additional lms |
| _lm_cache_lvl0_cleanup | how often to cleanup level 0 cache res (in sec) |
| _lm_cache_res_cleanup | percentage of cached resources should be cleanup |
| _lm_cache_res_type | cache resource: string of lock types(s) |
| _lm_checksum_batch_msg | GES checksum batch messages |
| _lm_contiguous_res_count | number of contiguous blocks that will hash to the same HV bucket |
| _lm_dd_interval | dd time interval in seconds |
| _lm_dd_scan_interval | dd scan interval in seconds |
| _lm_drm_max_requests | dynamic remastering maximum affinity requests processed together |
| _lm_drm_window | dynamic remastering bucket window size |
| _lm_drm_xlatch | dynamic remastering forced exclusive latches |
| _lm_dynamic_lms | dynamic lms invocation |
| _lm_dynamic_load | dynamic load adjustment |
| _lm_dynamic_remastering | if TRUE enables dynamic remastering |
| _lm_enq_lock_freelist | Number of ges enqueue element freelist |
| _lm_enq_rcfg | if TRUE enables enqueue reconfiguration |
| _lm_enqueue_freelist | Number of enqueue freelist |
| _lm_file_affinity | mapping between file id and master instance number |
| _lm_global_posts | if TRUE deliver global posts to remote nodes |
| _lm_lmd_waittime | default wait time for lmd in centiseconds |
| _lm_lms | number of background gcs server processes to start |
| _lm_lms_waittime | default wait time for lms in centiseconds |
| _lm_locks | number of enqueues configured for cluster database |
| _lm_master_weight | master resource weight for this instance |
| _lm_max_lms | max. number of background global cache server processes |
| _lm_min_lms | min. number of background global cache server processes |
| _lm_msg_batch_size | GES batch message size |
| _lm_msg_cache_thresholds | GES message buffer caching threshold |
| _lm_msg_cleanup_interval | GES message buffer cleanup interval time |
| _lm_node_join_opt | cluster database node join optimization in reconfig |
| _lm_non_fault_tolerant | disable cluster database fault-tolerance mode |
| _lm_num_pcmhv_latches | number of latches covering the PCM HV buckets in cgs |
| _lm_num_pt_buckets | number of buckets in the object affinity hash table |
| _lm_num_pt_latches | number of latches in the object affinity hash table |
| _lm_proc_freeze_timeout | reconfiguration: process freeze timeout |
| _lm_process_batching | GES implicit process batching for IPC messages |
| _lm_procs | number of client processes configured for cluster database |
| _lm_rcfg_timeout | Reconfiguration timeout |
| _lm_rcv_buffer_size | the size of receive buffer |
| _lm_res_hash_bucket | number of resource hash buckets |
| _lm_res_part | number of resource partition configured for gcs |
| _lm_ress | number of resources configured for cluster database |
| _lm_send_buffers | number of cluster database send buffers |
| _lm_send_mode | GES send mode |
| _lm_send_queue_batching | GES send queue message batching |
| _lm_send_queue_length | GES send queue maximum length |
| _lm_sendproxy_reserve | GES percentage of send proxy reserve of send tickets |
| _lm_share_lock_opt | if TRUE enables share lock optimization |
| _lm_sq_batch_factor | GES send queue minimum batching factor |
| _lm_sq_batch_type | GES send queue batching mechanism |
| _lm_sq_batch_waittick | 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 | GES messaging tickets |
| _lm_tx_delta | TX lock localization delta |
| _lm_validate_resource_type | if TRUE enables resource name validation |
| _lm_xids | number of transaction IDs configured for cluster database |
| _load_without_compile | Load PL/SQL or Database objects without compilation |
| _local_communication_costing_enabled | enable local communication costing when TRUE |
| _local_communication_ratio | set the ratio between global and local communication (0..100) |
| _lock_sga_areas | Lock specified areas of the SGA in physical memory |
| _log_archive_avoid_memcpy | log archive avoid memcpy |
| _log_archive_buffer_size | Size of each archival buffer in log file blocks |
| _log_archive_buffers | Number of buffers to allocate for archiving |
| _log_archive_callout | archival callout |
| _log_archive_compress_enable | Bypass database rules for enabling archivelog compression |
| _log_archive_delta_sync_wait | iterative sleep time in centiseconds seconds when SYNC=PARALLEL |
| _log_archive_net_timeout | maximum network wait time in seconds when SYNC=PARALLEL |
| _log_archive_network_redo_size | Log archive network redo buffer size used by ARCH |
| _log_archive_prot_auto_demote | log archive protection auto demotion |
| _log_archive_security_enabled | log archive security enabled |
| _log_blocks_during_backup | log block images when changed during backup |
| _log_buffers_corrupt | corrupt redo buffers before write |
| _log_buffers_debug | debug redo buffers (slows things down) |
| _log_checkpoint_recovery_check | # redo blocks to verify after checkpoint |
| _log_committime_block_cleanout | Log commit-time block cleanout |
| _log_debug_multi_instance | debug redo multi instance code |
| _log_deletion_policy | archivelog deletion policy for mandatory/all destination |
| _log_io_size | automatically initiate log write if this many redo blocks in buffer |
| _log_parallelism | Number of log buffer strands |
| _log_parallelism_dynamic | Enable dynamic strands |
| _log_parallelism_max | Maximum number of log buffer strands |
| _log_private_mul | Private strand multiplier for log space preallocation |
| _log_private_parallelism | Number of private log buffer strands for zero-copy redo |
| _log_private_parallelism_mul | Active sessions multiplier to deduce number of private strands |
| _log_simultaneous_copies | number of simultaneous copies into redo buffer(# of copy latches) |
| _log_space_errors | should we report space errors to alert log |
| _log_switch_timeout | Maximum number of seconds redos in the current log could span |
| _longops_enabled | longops stats enabled |
| _low_server_threshold | low server thresholds |
| _master_direct_sends | direct sends for messages from master (DFS) |
| _mav_refresh_consistent_read | refresh materialized views using consistent read snapshot |
| _mav_refresh_double_count_prevented | materialized view MAV refreshes avoid double counting |
| _mav_refresh_opt | optimizations during refresh of materialized views |
| _mav_refresh_unionall_tables | # tables for union all expansion during materialized view refresh |
| _max_arch_lns_wait | Maximum wait by ARCH to allow NetServer to complete archival |
| _max_exponential_sleep | max sleep during exponential backoff |
| _max_lns_shutdown_archival_time | Maximum time spent by LNS to archive last log during shutdown |
| _max_protocol_support | Max occurrence protocols supported in a process |
| _max_rfs_connections | maximum number of connections used for remote archival |
| _max_shrink_obj_stats | number of segments for which shrink stats will be maintained |
| _max_sleep_holding_latch | max time to sleep while holding a latch |
| _media_recovery_read_batch | media recovery block read batch |
| _media_recovery_reap_time | media recovery reap time |
| _mem_annotation_pr_lev | private memory annotation collection level |
| _mem_annotation_scale | memory annotation pre-allocation scaling |
| _mem_annotation_sh_lev | shared memory annotation collection level |
| _mem_annotation_store | memory annotation in-memory store |
| _mem_std_extent_size | standard extent size for fixed-size-extent heaps |
| _memory_broker_log_stat_entries | memory broker num stat entries |
| _memory_broker_shrink_heaps | memory broker allow policy to shrink shared pool |
| _memory_broker_shrink_java_heaps | memory broker allow policy to shrink java pool |
| _memory_broker_shrink_streams_pool | memory broker allow policy to shrink streams pool |
| _memory_broker_shrink_timeout | memory broker policy to timeout shrink shared/java pool |
| _memory_broker_stat_interval | memory broker statistics gathering interval |
| _memory_management_tracing | trace memory management activity |
| _memory_sanity_check | partial granule sanity check |
| _messages | message queue resources - dependent on # processes & # buffers |
| _minimal_stats_aggregation | prohibit stats aggregation at compile/partition maintenance time |
| _minimum_blocks_to_shrink | minimum number freeable blocks for shrink to be present |
| _minimum_extents_to_shrink | minimum number freeable extents for shrink to be present |
| _minimum_giga_scn | Minimum SCN to start with in 2^30 units |
| _mirror_redo_buffers | Save buffers for debugging redo corruptions |
| _mmv_query_rewrite_enabled | allow rewrites with multiple MVs and/or base tables |
| _multi_join_key_table_lookup | TRUE iff multi-join-key table lookup prefetch is enabled |
| _multiple_instance_recovery | use multiple instances for media recovery |
| _mv_refresh_ana | what percent to analyze after complete/PCT refresh |
| _mv_refresh_costing | refresh decision based on cost or on rules |
| _mv_refresh_delta_fraction | delta mv as fractional percentage of size of mv |
| _mv_refresh_eut | refresh materialized views using EUT(partition)-based algorithm |
| _mv_refresh_force_parallel_query | force materialized view refreshes to use parallel query |
| _mv_refresh_new_setup_disabled | materialized view MV refresh new setup disabling |
| _mv_refresh_rebuild_percentage | minimum percentage change required in MV to force an index rebuild |
| _mv_refresh_selections | create materialized views with selections and fast refresh |
| _mv_refresh_use_stats | pass cardinality hints to refresh queries |
| _mv_refsched_timeincr | proportionality constant for dop vs. time in MV refresh |
| _mv_rolling_inv | create/alter mv uses rolling cursor invalidation instead of immediate |
| _mwin_schedule | Enable/disable Maintenance Window Schedules |
| _nchar_imp_cnv | NLS allow Implicit Conversion between CHAR and NCHAR |
| _nchar_imp_conv | should implicit conversion bewteen clob and nclob be allowed |
| _ncmb_readahead_enabled | enable multi-block readahead for an index scan |
| _ncmb_readahead_tracing | turn on multi-block readahead tracing |
| _nested_loop_fudge | nested loop fudge |
| _nested_mav_fast_oncommit_enabled | nested MAV refresh fast on commit allowed |
| _new_initial_join_orders | enable initial join orders based on new ordering heuristics |
| _new_sort_cost_estimate | enables the use of new cost estimate for sort |
| _newsort_enabled | controls whether new sorts can be used as system sort |
| _newsort_ordered_pct | controls when new sort avoids sorting ordered input |
| _newsort_type | specifies options for the new sort algorithm |
| _no_objects | no object features are used |
| _no_or_expansion | OR expansion during optimization disabled |
| _no_recovery_through_resetlogs | no recovery through this resetlogs operation |
| _notify_crs | notify cluster ready services of startup and shutdown |
| _ns_max_flush_wt | Flush wait time for NetServer to flush oustanding writes |
| _ns_max_send_delay | Data Loss Time Bound for NetServer |
| _num_longop_child_latches | number of child latches for long op array |
| _number_cached_attributes | maximum number of cached attributes per instance |
| _object_statistics | enable the object level statistics collection |
| _offline_rollback_segments | offline undo segment list |
| _ogms_home | GMS home directory |
| _olap_aggregate_buffer_size | OLAP Aggregate max buffer size |
| _olap_aggregate_flags | OLAP Aggregate debug flags |
| _olap_aggregate_function_cache_enabled | OLAP Aggregate function cache enabler |
| _olap_aggregate_function_merge_threshold | OLAP Aggregate function merge threshold |
| _olap_aggregate_max_thread_tuples | OLAP Aggregate max thread tuples creation |
| _olap_aggregate_min_buffer_size | OLAP Aggregate min buffer size |
| _olap_aggregate_min_thread_status | OLAP Aggregate minimum cardinality of dimensions for thread |
| _olap_aggregate_multipath_hier | OLAP Aggregate Multi-path Hierarhies enabled |
| _olap_aggregate_statlen_thresh | OLAP Aggregate status array usage threshold |
| _olap_aggregate_store_probability | OLAP Aggregate function storeback probability |
| _olap_aggregate_work_per_thread | OLAP Aggregate max work parents |
| _olap_aggregate_worklist_max | OLAP Aggregate max worklists generated at once |
| _olap_allocate_errorlog_format | OLAP Allocate Errorlog Format |
| _olap_allocate_errorlog_header | OLAP Allocate Errorlog Header format |
| _olap_continuous_trace_file | Specify TRUE to enable continuous OLAP tracing - otherwise only exceptional events will be logged |
| _olap_dbgoutfile_echo_to_eventlog | OLAP DbgOutfile copy output to event log (tracefile) |
| _olap_dimension_corehash_class | OLAP Dimension In-Core Hash Table Class |
| _olap_dimension_corehash_max | OLAP Dimension In-Core Hash Table Maximum Size |
| _olap_eif_export_lob_size | OLAP EIF Export BLOB size |
| _olap_lmgen_dim_size | Limitmap generator dimension column size |
| _olap_lmgen_meas_size | Limitmap generator measure column size |
| _olap_object_hash_class | OLAP Object Hash Table Class |
| _olap_page_pool_expand_rate | OLAP Page Pool Expand Rate |
| _olap_page_pool_hi | OLAP Page Pool High Watermark |
| _olap_page_pool_hit_target | OLAP Page Pool Hit Target |
| _olap_page_pool_low | OLAP Page Pool Low Watermark |
| _olap_page_pool_pressure | OLAP Page Pool Pressure Threshold |
| _olap_page_pool_shrink_rate | OLAP Page Pool Shrink Rate |
| _olap_parallel_update_small_group | OLAP parallel update pagespace by group |
| _olap_parallel_update_small_threshold | OLAP parallel update threshold for number of small pagespaces |
| _olap_parallel_update_threshold | OLAP parallel update threshold in pages |
| _olap_poutlog_echo_to_eventlog | OLAP POutLog copy output to event log (tracefile) |
| _olap_sesscache_enabled | OLAP Session Cache knob |
| _olap_sort_buffer_size | OLAP Sort Buffer Size |
| _olap_statbool_corebits | OLAP Status Boolean max incore bits |
| _olap_statbool_threshold | OLAP Status Boolean CBM threshold |
| _olap_table_function_statistics | Specify TRUE to output OLAP table function timed statistics trace |
| _olap_wrap_errors | Wrap error messages to OLAP outfile |
| _olapi_history_retention | enable olapi history retention |
| _olapi_iface_object_history | enable olapi interface object history collection |
| _olapi_iface_object_history_retention | enable olapi interface object history retention |
| _olapi_iface_operation_history_retention | enable olapi interface operation history retention |
| _olapi_interface_operation_history | enable olapi interface operation history collection |
| _olapi_memory_operation_history | enable olapi memory alloc/free history collection |
| _olapi_memory_operation_history_pause_at_seqno | enable olapi memory alloc/free history collection pausing |
| _olapi_memory_operation_history_retention | enable olapi memory operation history retention |
| _olapi_session_history | enable olapi session history collection |
| _olapi_session_history_retention | enable olapi session history retention |
| _old_connect_by_enabled | enable/disable old connect by |
| _ols_cleanup_task | Clean up unnecessary entries in OLS sessinfo table |
| _omf | enable/disable OMF |
| _oneside_colstat_for_equijoins | sanity check on default selectivity for like/range predicate |
| _optim_adjust_for_part_skews | adjust stats for skews across partitions |
| _optim_dict_stats_at_db_cr_upg | enable/disable dictionary stats gathering at db create/upgrade |
| _optim_enhance_nnull_detection | TRUE to enable index [fast] full scan more often |
| _optim_new_default_join_sel | improves the way default equijoin selectivity are computed |
| _optim_peek_user_binds | enable peeking of user binds |
| _optimizer_adjust_for_nulls | adjust selectivity for null values |
| _optimizer_autostats_job | enable/disable auto stats collection job |
| _optimizer_better_inlist_costing | enable improved costing of index access using in-list(s) |
| _optimizer_block_size | standard block size used by optimizer |
| _optimizer_cache_stats | cost with cache statistics |
| _optimizer_cartesian_enabled | optimizer cartesian join enabled |
| _optimizer_cbqt_factor | cost factor for cost-based query transformation |
| _optimizer_cbqt_no_size_restriction | disable cost based transformation query size restriction |
| _optimizer_ceil_cost | CEIL cost in CBO |
| _optimizer_choose_permutation | force the optimizer to use the specified permutation |
| _optimizer_complex_pred_selectivity | enable selectivity estimation for builtin functions |
| _optimizer_compute_index_stats | force index stats collection on index creation/rebuild |
| _optimizer_correct_sq_selectivity | force correct computation of subquery selectivity |
| _optimizer_cost_based_transformation | enables cost-based query transformation |
| _optimizer_cost_filter_pred | enables costing of filter predicates in IO cost model |
| _optimizer_cost_hjsmj_multimatch | add cost of generating result set when #rows per key > 1 |
| _optimizer_cost_model | optimizer cost model |
| _optimizer_degree | force the optimizer to use the same degree of parallelism |
| _optimizer_dim_subq_join_sel | use join selectivity in choosing star transformation dimensions |
| _optimizer_disable_strans_sanity_checks | disable star transformation sanity checks |
| _optimizer_dyn_smp_blks | number of blocks for optimizer dynamic sampling |
| _optimizer_enhanced_filter_push | push filters before trying cost-based query transformation |
| _optimizer_extended_cursor_sharing | optimizer extended cursor sharing |
| _optimizer_filter_pred_pullup | use cost-based flter predicate pull up transformation |
| _optimizer_ignore_hints | enables the embedded hints to be ignored |
| _optimizer_invalidation_period | time window for invalidation of cursors of analyzed objects |
| _optimizer_join_elimination_enabled | optimizer join elimination enabled |
| _optimizer_join_order_control | controls the optimizer join order search algorithm |
| _optimizer_join_sel_sanity_check | enable/disable sanity check for multi-column join selectivity |
| _optimizer_max_permutations | optimizer maximum join permutations per query block |
| _optimizer_min_cache_blocks | set minimum cached blocks |
| _optimizer_mjc_enabled | enable merge join cartesian |
| _optimizer_mode_force | 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_computation | compute join cardinality using non-rounded input values |
| _optimizer_or_expansion | control or expansion approach used |
| _optimizer_order_by_elimination_enabled | Eliminates order bys from views before query transformation |
| _optimizer_outer_to_anti_enabled | Enable transformation of outer-join to anti-join if possible |
| _optimizer_percent_parallel | optimizer percent parallel |
| _optimizer_push_down_distinct | push down distinct from query block to table |
| _optimizer_push_pred_cost_based | use cost-based query transformation for push pred optimization |
| _optimizer_random_plan | optimizer seed value for random plans |
| _optimizer_rownum_pred_based_fkr | enable the use of first K rows due to rownum predicate |
| _optimizer_save_stats | enable/disable saving old versions of optimizer stats |
| _optimizer_search_limit | optimizer search limit |
| _optimizer_self_induced_cache_cost | account for self-induced caching |
| _optimizer_skip_scan_enabled | enable/disable index skip scan |
| _optimizer_sortmerge_join_enabled | enable/disable sort-merge join method |
| _optimizer_squ_bottomup | enables unnesting of subquery in a bottom-up manner |
| _optimizer_star_tran_in_with_clause | enable/disable star transformation in with clause queries |
| _optimizer_starplan_enabled | optimizer star plan enabled |
| _optimizer_system_stats_usage | system statistics usage |
| _optimizer_trace | optimizer trace parameter |
| _optimizer_transitivity_retain | retain equi-join pred upon transitive equality pred generation |
| _optimizer_undo_changes | undo changes to query optimizer |
| _optimizer_undo_cost_change | optimizer undo cost change |
| _or_expand_nvl_predicate | enable OR expanded plan for NVL/DECODE predicate |
| _oradbg_pathname | path of oradbg script |
| _oradebug_force | force target processes to execute oradebug commands? |
| _ordered_nested_loop | enable ordered nested loop costing |
| _ordered_semijoin | enable ordered semi-join subquery |
| _os_sched_high_priority | OS high priority level |
| _other_wait_event_exclusion | exclude event names from _other_wait_threshold calculations |
| _other_wait_threshold | threshold wait percentage for event wait class Other |
| _outline_bitmap_tree | BITMAP_TREE hint enabled in outline |
| _parallel_adaptive_max_users | maximum number of users running with default DOP |
| _parallel_broadcast_enabled | enable broadcasting of small inputs to hash and sort merge joins |
| _parallel_default_max_instances | default maximum number of instances for parallel query |
| _parallel_execution_message_align | Alignment of PX buffers to OS page boundary |
| _parallel_fake_class_pct | fake db-scheduler percent used for testing |
| _parallel_fixwrite_bucket | Number of buckets for each round of fix write |
| _parallel_load_bal_unit | number of threads to allocate per instance |
| _parallel_load_balancing | parallel execution load balanced slave allocation |
| _parallel_min_message_pool | minimum size of shared pool memory to reserve for pq servers |
| _parallel_recovery_stopat | stop at -position- to step through SMON |
| _parallel_replay_msg_limit | Number of messages for each round of parallel replay |
| _parallel_server_idle_time | idle time before parallel query server dies (in 1/100 sec) |
| _parallel_server_sleep_time | sleep time between dequeue timeouts (in 1/100ths) |
| _parallel_slave_acquisition_wait | time(in seconds) to wait before retrying slave acquisition |
| _parallel_txn_global | enable parallel_txn hint with updates and deletes |
| _parallelism_cost_fudge_factor | set the parallelism cost fudge factor |
| _parameter_table_block_size | parameter table block size |
| _partial_pwise_join_enabled | enable partial partition-wise join when TRUE |
| _partition_view_enabled | enable/disable partitioned views |
| _passwordfile_enqueue_timeout | password file enqueue timeout in seconds |
| _pct_refresh_double_count_prevented | materialized view PCT refreshes avoid double counting |
| _pdml_gim_sampling | control separation of global index maintenance for PDML |
| _pdml_gim_staggered | slaves start on different index when doing index maint |
| _pdml_slaves_diff_part | slaves start on different partition when doing index maint |
| _percent_flashback_buf_partial_full | Percent of flashback buffer filled to be considered partial full |
| _pga_large_extent_size | PGA large extent size |
| _pga_max_size | Maximum size of the PGA memory for one process |
| _ping_level | fusion ping level |
| _pkt_enable | enable progressive kill test |
| _pkt_pmon_interval | PMON process clean-up interval (cs) |
| _pkt_start | start progressive kill test instrumention |
| _plan_outline_data | explain plan outline data enabled |
| _plsql_anon_block_code_type | PL/SQL anonymous block code-type |
| _plsql_cache_enable | PL/SQL Function Cache Enabled |
| _plsql_dump_buffer_events | conditions upon which the PL/SQL circular buffer is dumped |
| _plsql_minimum_cache_hit_percent | plsql minimum cache hit percentage required to keep caching active |
| _plsql_nvl_optimize | PL/SQL NVL optimize |
| _pmon_load_constants | server load balancing constants (S,P,D,I,L,C,M) |
| _pre_rewrite_push_pred | push predicates into views before rewrite |
| _precompute_gid_values | precompute gid values and copy them before returning a row |
| _pred_move_around | enables predicate move-around |
| _predicate_elimination_enabled | allow predicate elimination if set to TRUE |
| _prescomm | presume commit of IMU transactions |
| _print_refresh_schedule | enable dbms_output of materialized view refresh schedule |
| _private_memory_address | Start address of large extent memory segment |
| _project_view_columns | enable projecting out unreferenced columns of a view |
| _projection_pushdown | projection pushdown |
| _projection_pushdown_debug | level for projection pushdown debugging |
| _push_join_predicate | enable pushing join predicate inside a view |
| _push_join_union_view | enable pushing join predicate inside a union all view |
| _push_join_union_view2 | enable pushing join predicate inside a union view |
| _px_async_getgranule | asynchronous get granule in the slave |
| _px_broadcast_fudge_factor | set the tq broadcasting fudge factor percentage |
| _px_buffer_ttl | ttl for px mesg buffers in seconds |
| _px_compilation_debug | debug level for parallel compilation |
| _px_compilation_trace | tracing level for parallel compilation |
| _px_dynamic_opt | turn off/on restartable qerpx dynamic optimization |
| _px_dynamic_sample_size | num of samples for restartable qerpx dynamic optimization |
| _px_granule_size | default size of a rowid range granule (in KB) |
| _px_index_sampling | parallel query sampling for index create (100000 = 100%) |
| _px_kxib_tracing | turn on kxib tracing |
| _px_load_publish_interval | interval at which LMON will check whether to publish PX load |
| _px_loc_msg_cost | CPU cost to send a PX message via shared memory |
| _px_max_granules_per_slave | maximum number of rowid range granules to generate per slave |
| _px_min_granules_per_slave | minimum number of rowid range granules to generate per slave |
| _px_minus_intersect | enables pq for minus/interect operators |
| _px_net_msg_cost | CPU cost to send a PX message over the internconnect |
| _px_no_granule_sort | prevent parallel partition granules to be sorted on size |
| _px_no_stealing | prevent parallel granule stealing in shared nothing environment |
| _px_nss_planb | enables or disables NSS Plan B reparse with outline |
| _px_proc_constrain | reduce parallel_max_servers if greater than (processes - fudge) |
| _px_pwg_enabled | parallel partition wise group by enabled |
| _px_rownum_pd | turn off/on parallel rownum pushdown optimization |
| _px_send_timeout | IPC message send timeout value in seconds |
| _px_slaves_share_cursors | slaves share cursors with QC |
| _px_trace | px trace parameter |
| _px_xtgranule_size | default size of a external table granule (in KB) |
| _qa_control | Oracle internal parameter to control QA |
| _qa_lrg_type | Oracle internal parameter to specify QA lrg type |
| _query_cost_rewrite | perform the cost based rewrite with materialized views |
| _query_execution_cache_max_size | max size of query execution cache |
| _query_rewrite_1 | perform query rewrite before&after or only before view merging |
| _query_rewrite_2 | perform query rewrite before&after or only after view merging |
| _query_rewrite_drj | mv rewrite and drop redundant joins |
| _query_rewrite_expression | rewrite with cannonical form for expressions |
| _query_rewrite_fpc | mv rewrite fresh partition containment |
| _query_rewrite_fudge | cost based query rewrite with MVs fudge factor |
| _query_rewrite_jgmigrate | mv rewrite with jg migration |
| _query_rewrite_maxdisjunct | query rewrite max disjuncts |
| _query_rewrite_or_error | allow query rewrite, if referenced tables are not dataless |
| _query_rewrite_setopgrw_enable | perform general rewrite using set operator summaries |
| _query_rewrite_vop_cleanup | prune frocol chain before rewrite after view-merging |
| _rcfg_parallel_fixwrite | if TRUE enables parallel fixwrite at reconfiguration |
| _rcfg_parallel_replay | if TRUE enables parallel replay and cleanup at reconfiguration |
| _rcfg_parallel_verify | if TRUE enables parallel verify at reconfiguration |
| _real_time_apply_arch_delay | Archival delay with real time apply |
| _real_time_apply_sim | Simulation value with real time apply |
| _realfree_heap_max_size | minimum max total heap size, in Kbytes |
| _realfree_heap_mode | mode flags for real-free heap |
| _realfree_heap_pagesize_hint | hint for real-free page size in bytes |
| _recoverable_recovery_batch_percent | Recoverable recovery batch size (percentage of buffer cache) |
| _recovery_asserts | if TRUE, enable expensive integrity checks |
| _recovery_percentage | recovery buffer cache percentage |
| _recovery_verify_writes | enable thread recovery write verify |
| _recursive_imu_transactions | recursive transactions may be IMU |
| _redo_compatibility_check | general and redo/undo compatibility sanity check |
| _release_insert_threshold | maximum number of unusable blocks to unlink from freelist |
| _reliable_block_sends | if TRUE, block sends across interconnect are reliable |
| _remove_aggr_subquery | enables removal of subsumed aggregated subquery |
| _resource_manager_always_on | enable the resource manager always |
| _restore_spfile | restore spfile to this location |
| _reuse_index_loop | number of blocks being examine for index block reuse |
| _right_outer_hash_enable | Right Outer/Semi/Anti Hash Enabled |
| _rman_io_priority | priority at which rman backup i/o's are done |
| _rollback_segment_count | number of undo segments |
| _rollback_segment_initial | starting undo segment number |
| _rollback_stopat | stop at -position to step rollback |
| _row_cache_cursors | number of cached cursors for row cache management |
| _row_cr | enable row cr for all sql |
| _row_locking | row-locking |
| _rowsource_execution_statistics | if TRUE, Oracle will collect rowsource statistics |
| _rowsource_statistics_sampfreq | frequency of rowsource statistic sampling (must be a power of 2) |
| _rowsrc_trace_level | Row source tree tracing level |
| _sample_rows_per_block | number of rows per block used for sampling IO optimization |
| _second_spare_parameter | second spare parameter - integer |
| _selfjoin_mv_duplicates | control rewrite self-join algorithm |
| _selftune_checkpoint_write_pct | Percentage of total physical i/os for self-tune ckpt |
| _selftune_checkpointing_lag | Self-tune checkpointing lag the tail of the redo log |
| _send_ast_to_foreground | if TRUE, send ast message to foreground |
| _send_close_with_block | if TRUE, send close with block even with direct sends |
| _send_requests_to_pi | if TRUE, try to send CR requests to PI buffers |
| _serial_direct_read | enable direct read in serial |
| _serial_recovery | force serial recovery or parallel recovery |
| _serializable | serializable |
| _session_cached_instantiations | Number of pl/sql instantiations to cache in a session. |
| _session_context_size | session app context size |
| _session_idle_bit_latches | one latch per session or a latch per group of sessions |
| _session_idle_check_interval | Resource Manager session idle limit check interval in seconds |
| _session_kept_cursor_pins | Number of cursors pins to keep in a session |
| _session_wait_history | enable session wait history collection |
| _seventh_spare_parameter | seventh spare parameter - string list |
| _shared_pool_max_size | shared pool maximum size when auto SGA enabled |
| _shared_pool_reserved_min_alloc | minimum allocation size in bytes for reserved area of shared pool |
| _shared_pool_reserved_pct | percentage memory of the shared pool allocated for the reserved area |
| _short_stack_timeout_ms | short stack timeout in ms |
| _shrunk_aggs_disable_threshold | percentage of exceptions at which to switch to full length aggs |
| _shrunk_aggs_enabled | enable use of variable sized buffers for non-distinct aggregates |
| _side_channel_batch_size | number of messages to batch in a side channel message (DFS) |
| _side_channel_batch_timeout | timeout before shipping out the batched side channelmessages |
| _simple_view_merging | control simple view merging performed by the optimizer |
| _simulator_bucket_mindelta | LRU bucket minimum delta |
| _simulator_internal_bound | simulator internal bound percent |
| _simulator_lru_rebalance_sizthr | LRU list rebalance threshold (size) |
| _simulator_lru_rebalance_thresh | LRU list rebalance threshold (count) |
| _simulator_lru_scan_count | LRU scan count |
| _simulator_pin_inval_maxcnt | maximum count of invalid chunks on pin list |
| _simulator_reserved_heap_count | simulator reserved heap count |
| _simulator_reserved_obj_count | simulator reserved object count |
| _simulator_sampling_factor | sampling factor for the simulator |
| _simulator_upper_bound_multiple | upper bound multiple of pool size |
| _single_process | run without detached processes |
| _sixth_spare_parameter | sixth spare parameter - string list |
| _skgxp_reaping | tune skgxp OSD reaping limit |
| _skgxp_udp_ach_reaping_time | time in minutes before idle ach's are reaped |
| _skgxp_udp_hiwat_warn | ach hiwat mark warning interval |
| _skgxp_udp_interface_detection_time_secs | time in seconds between interface detection checks |
| _skgxp_udp_keep_alive_ping_timer_secs | connection idle time in seconds before keep alive is initiated. min: 30 sec max: 1800 sec default: 300 sec |
| _skgxp_udp_timed_wait_buffering | diagnostic log buffering space (in bytes) for timed wait (0 means unbufferd |
| _skgxp_udp_timed_wait_seconds | time in seconds before timed wait is invoked |
| _skip_assume_msg | if TRUE, skip assume message for consigns at the master |
| _slave_mapping_enabled | enable slave mapping when TRUE |
| _slave_mapping_group_size | force the number of slave group in a slave mapper |
| _small_table_threshold | threshold level of table size for direct reads |
| _smm_advice_enabled | if TRUE, enable v$pga_advice |
| _smm_advice_log_size | overwrites default size of the PGA advice workarea history log |
| _smm_auto_cost_enabled | if TRUE, use the AUTO size policy cost functions |
| _smm_auto_max_io_size | Maximum IO size (in KB) used by sort/hash-join in auto mode |
| _smm_auto_min_io_size | Minimum IO size (in KB) used by sort/hash-join in auto mode |
| _smm_bound | overwrites memory manager automatically computed bound |
| _smm_control | provides controls on the memory manager |
| _smm_freeable_retain | value in KB of the instance freeable PGA memory to retain |
| _smm_isort_cap | maximum work area for insertion sort(v1) |
| _smm_max_size | maximum work area size in auto mode (serial) |
| _smm_min_size | minimum work area size in auto mode |
| _smm_px_max_size | maximum work area size in auto mode (global) |
| _smm_retain_size | work area retain size in SGA for shared server sessions (0 for AUTO) |
| _smm_trace | Turn on/off tracing for SQL memory manager |
| _smon_internal_errlimit | limit of SMON internal errors |
| _smu_debug_mode | <debug-flag> - set debug event for testing SMU operations |
| _smu_error_simulation_site | site ID of error simulation in KTU code |
| _smu_error_simulation_type | error type for error simulation in KTU code |
| _smu_timeouts | comma-separated *AND double-quoted* list of AUM timeouts: mql, tur, sess_exprn, qry_exprn, slot_intvl |
| _sort_elimination_cost_ratio | cost ratio for sort eimination under first_rows mode |
| _sort_multiblock_read_count | multi-block read count for sort |
| _spin_count | Amount to spin waiting for a latch |
| _spr_max_rules | maximum number of rules in sql spreadsheet |
| _spr_push_pred_refspr | push predicates through reference spreadsheet |
| _spr_use_AW_AS | enable AW for hash table in spreadsheet |
| _spr_use_hash_table | use hash table for spreadsheet |
| _sql_connect_capability_override | SQL Connect Capability Table Override |
| _sql_connect_capability_table | SQL Connect Capability Table (testing only) |
| _sql_hash_debug | Hash value of the SQL statement to debug |
| _sql_model_unfold_forloops | specifies compile-time unfolding of sql model forloops |
| _sqlexec_progression_cost | sql execution progression monitoring cost threshold |
| _sqltune_category_parsed | Parsed category qualifier for applying hintsets |
| _sta_control | SQL Tuning Advisory control parameter |
| _stack_guard_level | stack guard level |
| _static_backgrounds | static backgrounds |
| _stn_trace | SQL tracing parameter |
| _streams_pool_max_size | streams pool maximum size when auto SGA enabled |
| _subquery_pruning_cost_factor | subquery pruning cost factor |
| _subquery_pruning_enabled | enable the use of subquery predicates to perform pruning |
| _subquery_pruning_mv_enabled | enable the use of subquery predicates with MVs to perform pruning |
| _subquery_pruning_reduction | subquery pruning reduction factor |
| _swrf_metric_frequent_mode | Enable/disable SWRF Metric Frequent Mode Collection |
| _swrf_mmon_dbfus | Enable/disable SWRF MMON DB Feature Usage |
| _swrf_mmon_flush | Enable/disable SWRF MMON FLushing |
| _swrf_mmon_metrics | Enable/disable SWRF MMON Metrics Collection |
| _swrf_on_disk_enabled | Parameter to enable/disable SWRF |
| _swrf_test_action | test action parameter for SWRF |
| _swrf_test_dbfus | Enable/disable DB Feature Usage Testing |
| _synonym_repoint_tracing | whether to trace metadata comparisons for synonym repointing |
| _sysaux_test_param | test parameter for SYSAUX |
| _system_index_caching | optimizer percent system index caching |
| _system_trig_enabled | are system triggers enabled |
| _ta_lns_wait_for_arch_log | LNS Wait time for arhcived version of online log |
| _table_lookup_prefetch_size | table lookup prefetch vector size |
| _table_lookup_prefetch_thresh | table lookup prefetch threshold |
| _table_scan_cost_plus_one | bump estimated full table scan and index ffs cost by one |
| _target_rba_max_lag_percentage | target rba max log lag percentage |
| _tdb_debug_mode | set debug mode for testing transportable database |
| _temp_tran_block_threshold | number of blocks for a dimension before we temp transform |
| _temp_tran_cache | determines if temp table is created with cache option |
| _test_ksusigskip | test the function ksusigskip |
| _test_param_1 | 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 | test parmeter 5 - deprecated integer |
| _test_param_6 | test parmeter 6 - size (ub8) |
| _third_spare_parameter | third spare parameter - integer |
| _threshold_alerts_enable | if 1, issue threshold-based alerts |
| _total_large_extent_memory | Total memory for allocating large extents |
| _tq_dump_period | time period for duping of TQ statistics (s) |
| _trace_archive | start DIAG process |
| _trace_buffer_flushes | trace buffer flushes if otrace cacheIO event is set |
| _trace_buffer_gets | trace kcb buffer gets if otrace cacheIO event is set |
| _trace_buffer_wait_timeouts | trace buffer busy wait timeouts |
| _trace_buffer_wrap_timestamp | enable KST timestamp on trace buffer wrap |
| _trace_buffers | trace buffer sizes per process |
| _trace_cr_buffer_creates | trace cr buffer creates if otrace cacheIO event is set |
| _trace_events | trace events enabled at startup |
| _trace_file_size | maximum size of trace file (in bytes) |
| _trace_files_public | Create publicly accessible trace files |
| _trace_flush_processes | trace data archived by DIAG for these processes |
| _trace_multi_block_reads | trace multi_block reads if otrace cacheIO event is set |
| _trace_navigation_scope | enabling trace navigation linking |
| _trace_options | trace data flush options |
| _trace_pin_time | trace how long a current pin is held |
| _trace_processes | enable KST tracing in process |
| _transaction_auditing | transaction auditing records generated in the redo log |
| _transaction_recovery_servers | max number of parallel recovery slaves that may be used |
| _truncate_optimization_enabled | do truncate optimization if set to TRUE |
| _tsm_connect_string | TSM test connect string |
| _tsm_disable_auto_cleanup | Disable TSM auto cleanup actions |
| _tts_allow_charset_mismatch | allow plugging in a tablespace with an incompatible character set |
| _two_pass | enable two-pass thread recovery |
| _two_pass_reverse_polish_enabled | uses two-pass reverse polish alg. to generate canonical forms |
| _uga_cga_large_extent_size | UGA/CGA large extent size |
| _ultrafast_latch_statistics | maintain fast-path statistics for ultrafast latches |
| _undo_autotune | enable auto tuning of undo_retention |
| _undo_debug_mode | debug flag for undo related operations |
| _undo_debug_usage | invoke undo usage functions for testing |
| _union_rewrite_for_gs | expand queries with GSets into UNIONs for rewrite |
| _unnest_subquery | enables unnesting of correlated subqueries |
| _unused_block_compression | enable unused block compression |
| _use_column_stats_for_function | enable the use of column statistics for DDP functions |
| _use_ism | Enable Shared Page Tables - ISM |
| _use_ism_for_pga | Use ISM for allocating large extents |
| _use_nosegment_indexes | use nosegment indexes in explain plan |
| _use_realfree_heap | use real-free based allocator for PGA memory |
| _use_seq_process_cache | whether to use process local seq cache |
| _use_vector_post | use vector post |
| _validate_flashback_database | Scan database to validate result of flashback database |
| _vendor_lib_loc | Vendor library search root directory |
| _verify_flashback_redo | Verify that the redo logs needed for flashback are available |
| _verify_undo_quota | TRUE - verify consistency of undo quota statistics |
| _very_large_partitioned_table | very_large_partitioned_table |
| _wait_for_sync | wait for sync on commit MUST BE ALWAYS TRUE |
| _walk_insert_threshold | maximum number of unusable blocks to walk across freelist |
| _watchpoint_on | is the watchpointing feature turned on? |
| _windowfunc_optimization_settings | settings for window function optimizations |
| _write_clones | write clones flag |
| _xpl_peeked_binds_log_size | maximum bytes for logging peeked bind values for V$SQL_PLAN (0 = OFF) |
| _xpl_trace | Explain Plan tracing parameter |
| _xsolapi_auto_materialization_bound | OLAP API lower bound for auto materialization. |
| _xsolapi_auto_materialization_type | OLAP API behavior for auto materialization |
| _xsolapi_debug_output | OLAP API debug output disposition |
| _xsolapi_densify_cubes | OLAP API cube densification |
| _xsolapi_dimension_group_creation | OLAP API symmetric overfetch |
| _xsolapi_fetch_type | OLAP API fetch type |
| _xsolapi_load_at_process_start | When to load OLAP API library at server process start |
| _xsolapi_materialization_rowcache_min_rows_for_use | OLAP API min number of rows required to use rowcache in query materialization |
| _xsolapi_materialize_sources | OLAP API Enable source materialization |
| _xsolapi_source_trace | OLAP API output Source definitions to trace file |
| _xsolapi_sql_all_multi_join_non_base_hints | OLAP API multi-join non-base hints |
| _xsolapi_sql_all_non_base_hints | OLAP API non-base hints |
| _xsolapi_sql_auto_dimension_hints | OLAP API enable automatic dimension hints |
| _xsolapi_sql_auto_measure_hints | 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 | OLAP API enable optimization |
| _xsolapi_sql_prepare_stmt_cache_size | OLAP API prepare statement cache size |
| _xsolapi_sql_remove_columns | OLAP API enable remove unused columns optimizations |
| _xsolapi_sql_result_set_cache_size | OLAP API result set cache size |
| _xsolapi_sql_symmetric_predicate | 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 | OLAP API enable bind variables optimization |
| _xt_coverage | external tables code coverage parameter |
| _xt_trace | external tables trace parameter |
| _xtbuffer_size | buffer size in KB needed for populate/query operation |
| _xtts_allow_pre10 | allow cross platform for pre10 compatible tablespace |
| _xtts_set_platform_info | set cross platform info during file header read |
| _yield_check_interval | interval to check whether actses should yield |
Êѹ¹¤¹¤ëºÝ¤Ë¤Ï¡¢³ºÅö¥Ñ¥é¥á¡¼¥¿¤Ë¤Ä¤¤¤Æ google ¤È¤«¤Ç¤è¤¯Ä´¤Ù¤Æ¤«¤é¤¬Îɤ¤¤«¤È»×¤¤¤Þ¤¹¡£¤è¤ê¾Ü¤·¤¯ÃΤë¤Ê¤é¤³¤Á¤é¤¬»²¹Í¤Ë¤Ê¤ë¤«¤È¡£
Rampant Tech Pr (2003/08/01)
Çä¤ê¾å¤²¥é¥ó¥¥ó¥°: 134437



¥³¥á¥ó¥È¤ä¥·¥§¥¢¤ò¤ª´ê¤¤¤·¤Þ¤¹¡ª