greenplum 服务器参数详细信息

SQL命令SHOW允许您查看当前服务器配置参数设置。例如,可查看所有参数的设置:

$ psql -c 'SHOW ALL;'

 

namesettingdescription
add_missing_fromoffAutomatically adds missing table references to FROM clauses.
application_name Sets the application name to be reported in statistics and logs.
archive_modeoffAllows archiving of WAL files using archive_command.
array_nullsonEnable input of NULL elements in arrays.
authentication_timeout1minSets the maximum allowed time to complete client authentication.
autovacuum_max_workers3Sets the maximum number of simultaneously running autovacuum worker processes.
autovacuum_max_workers3Sets the maximum number of simultaneously running autovacuum worker processes.
backslash_quotesafe_encodingSets whether "\'" is allowed in string literals.
block_size32768Shows the size of a disk block.
bonjour_name Sets the Bonjour broadcast service name.
bytea_outputescapeSets the output format for bytea.
check_function_bodiesonCheck function bodies during CREATE FUNCTION.
checkpoint_completion_target0.5Time spent flushing dirty buffers during checkpoint, as fraction of checkpoint interval.
client_encodingUNICODESets the client's character set encoding.
client_min_messagesnoticeSets the message levels that are sent to the client.
cpu_index_tuple_cost0.005Sets the planner's estimate of the cost of processing each index entry during an index scan.
cpu_operator_cost0.0025Sets the planner's estimate of the cost of processing each operator or function call.
cpu_tuple_cost0.01Sets the planner's estimate of the cost of processing each tuple (row).
cursor_tuple_fraction1Sets the planner's estimate of the fraction of a cursor's rows that will be retrieved.
custom_variable_classes Sets the list of known custom variable classes.
data_checksumsonShows whether data checksums are turned on for this cluster
DateStyleISO, MDYSets the display format for date and time values.
db_user_namespaceoffEnables per-database user names.
deadlock_timeout1sSets the time to wait on a lock before checking for deadlock.
debug_assertionsoffTurns on various assertion checks.
debug_pretty_printoffIndents parse and plan tree displays.
debug_print_parseoffPrints the parse tree to the server log.
debug_print_planoffPrints the execution plan to server log.
debug_print_prelim_planoffPrints the preliminary execution plan to server log.
debug_print_rewrittenoffPrints the parse tree after rewriting to server log.
debug_print_slice_tableoffPrints the slice table to server log.
default_statistics_target100Sets the default statistics target.
default_tablespace Sets the default tablespace to create tables and indexes in.
default_text_search_configpg_catalog.englishSets default text search configuration.
default_transaction_isolationread committedSets the transaction isolation level of each new transaction.
default_transaction_read_onlyoffSets the default read-only status of new transactions.
dynamic_library_path$libdirSets the path for dynamically loadable modules.
effective_cache_size512MBSets the planner's assumption about the size of the disk cache.
enable_bitmapscanonEnables the planner's use of bitmap-scan plans.
enable_groupaggonEnables the planner's use of grouping aggregation plans.
enable_hashaggonEnables the planner's use of hashed aggregation plans.
enable_hashjoinonEnables the planner's use of hash join plans.
enable_indexscanonEnables the planner's use of index-scan plans.
enable_mergejoinoffEnables the planner's use of merge join plans.
enable_nestloopoffEnables the planner's use of nested-loop join plans.
enable_seqscanonEnables the planner's use of sequential-scan plans.
enable_sortonEnables the planner's use of explicit sort steps.
enable_tidscanonEnables the planner's use of TID scan plans.
escape_string_warningonWarn about backslash escapes in ordinary string literals.
explain_memory_verbositysuppressExperimental feature: show memory account usage in EXPLAIN ANALYZE.
explain_pretty_printonUses the indented output format for EXPLAIN VERBOSE.
extra_float_digits0Sets the number of digits displayed for floating-point values.
from_collapse_limit20Sets the FROM-list size beyond which subqueries are not collapsed.
gp_adjust_selectivity_for_outerjoinsonAdjust selectivity of null tests over outer joins.
gp_analyze_relative_error0.25target relative error fraction for row sampling during analyze
gp_appendonly_compaction_threshold10Threshold of the ratio of dirty data in a segment file over which the file will be compacted during lazy vacuum.
gp_autostats_modeON_NO_STATSSets the autostats mode.
gp_autostats_mode_in_functionsNONESets the autostats mode for statements in procedural language functions.
gp_autostats_on_change_threshold2147483647Threshold for number of tuples added to table by CTAS or Insert-to to trigger autostats in on_change mode. See gp_autostats_mode.
gp_backup_directIOoffEnable direct IO dump
gp_backup_directIO_read_chunk_mb20Size of read Chunk buffer in directIO dump (in MB)
gp_cached_segworkers_threshold5Sets the maximum number of segment workers to cache between statements.
gp_command_count3Shows the number of commands received from the client in this session.
gp_connection_send_timeout3600Timeout for sending data to unresponsive clients (seconds)
gp_connections_per_thread0Sets the number of client connections handled in each thread.
gp_contentid-1The contentid used by this server.
gp_create_table_random_default_distributionoffSet the default distribution of a table to RANDOM.
gp_dbid1The dbid used by this server.
gp_debug_linger0Number of seconds for QD/QE process to linger upon fatal internal error.
gp_default_storage_optionsappendonly=false,blocksize=32768,compresstype=none,checksum=true,orientation=rowDefault options for appendonly storage.
gp_dynamic_partition_pruningonThis guc enables plans that can dynamically eliminate scanning of partitions.
gp_email_connect_avoid_duration7200Sets the amount of time (in secs) to avoid connecting to SMTP server
gp_email_connect_failures5Sets the number of consecutive connect failures before declaring SMTP server as unavailable
gp_email_connect_timeout15Sets the amount of time (in secs) after which SMTP sockets would timeout
gp_email_from Sets email address of the sender of email alerts (our email id).
gp_email_smtp_password Sets the password used for the SMTP server, if required.
gp_email_smtp_serverlocalhost:25Sets the SMTP server and port used to send email alerts.
gp_email_smtp_userid Sets the userid used for the SMTP server, if required.
gp_email_to Sets email address(es) to send alerts to.  May be multiple email addresses separated by semi-colon.
gp_enable_agg_distinctonEnable 2-phase aggregation to compute a single distinct-qualified aggregate.
gp_enable_agg_distinct_pruningonEnable 3-phase aggregation and join to compute distinct-qualified aggregates.
gp_enable_direct_dispatchonEnable dispatch for single-row-insert targetted mirror-pairs.
gp_enable_exchange_default_partitionoffAllow DDL that will exchange default partitions.
gp_enable_fallback_planonPlan types which are not enabled may be used when a query would be infeasible without them.
gp_enable_fast_srionEnable single-slice single-row inserts.
gp_enable_gpperfmononEnable gpperfmon monitoring.
gp_enable_groupext_distinct_gatheronEnable gathering data to a single node to compute distinct-qualified aggregates on grouping extention queries.
gp_enable_groupext_distinct_pruningonEnable 3-phase aggregation and join to compute distinct-qualified aggregates on grouping extention queries.
gp_enable_multiphase_aggonEnables the planner's use of two- or three-stage parallel aggregation plans.
gp_enable_predicate_propagationonWhen two expressions are equivalent (such as with equijoined keys) then the planner applies predicates on one expression to the other expression.
gp_enable_preuniqueonEnable 2-phase duplicate removal.
gp_enable_query_metricsonEnable all query metrics collection.
gp_enable_relsize_collectionoffThis guc enables relsize collection when stats are not present. If disabled and stats are not present a default value is used.
gp_enable_sequential_window_plansonExperimental feature: Enable non-parallel window plans.
gp_enable_sort_distinctonEnable duplicate removal to be performed while sorting.
gp_enable_sort_limitonEnable LIMIT operation to be performed while sorting.
gp_external_enable_execonEnable selecting from an external table with an EXECUTE clause.
gp_external_max_segs64Maximum number of segments that connect to a single gpfdist URL.
gp_filerep_ct_batch_size65536Maximum number of blocks from changetracking log that a filerep resync worker processes at one time.
gp_filerep_tcp_keepalives_count2Maximum number of TCP keepalive retransmits for FileRep connection.
gp_filerep_tcp_keepalives_idle1minSeconds between issuing TCP keepalives for FileRep connection.
gp_filerep_tcp_keepalives_interval30sSeconds between TCP keepalive retransmits for FileRep connection.
gp_fts_probe_interval1minA complete probe of all segments starts each time a timer with this period expires.
gp_fts_probe_threadcount16Use this number of threads for probing the segments.
gp_fts_probe_timeout20sMaximum time (in seconds) allowed for FTS to complete probing a segment.
gp_gpperfmon_send_interval1Interval in seconds between sending messages to gpperfmon.
gp_hadoop_home/data/hadoop/hadoop-2.7.5The location where Hadoop is installed in each segment.
gp_hadoop_target_versionhadoopThe distro/version of Hadoop that external table is connecting to.
gp_hashjoin_tuples_per_bucket5Target density of hashtable used by Hashjoin during execution
gp_idf_deduplicateautoSets the mode to control inverse distribution function's de-duplicate strategy.
gp_initial_bad_row_limit1000Stops processing when number of the first bad rows exceeding this value
gp_instrument_shmem_size5MBSets the size of shmem allocated for instrumentation.
gp_interconnect_cache_future_packetsonControl whether future packets are cached.
gp_interconnect_debug_retry_interval10Sets the interval by retry times to record a debug message for retry.
gp_interconnect_default_rtt20msSets the default rtt (in ms) for UDP interconnect
gp_interconnect_fc_methodLOSSSets the flow control method used for UDP interconnect.
gp_interconnect_hash_multiplier2Sets the number of hash buckets used by the UDP interconnect to track connections (the number of buckets is given by the product of the segment count and the hash multipliers).
gp_interconnect_min_retries_before_timeout100Sets the min retries before reporting a transmit timeout in the interconnect.
gp_interconnect_min_rto20msSets the min rto (in ms) for UDP interconnect
gp_interconnect_queue_depth4Sets the maximum size of the receive queue for each connection in the UDP interconnect
gp_interconnect_setup_timeout2hTimeout (in seconds) on interconnect setup that occurs at query start
gp_interconnect_snd_queue_depth2Sets the maximum size of the send queue for each connection in the UDP interconnect
gp_interconnect_tcp_listener_backlog128Size of the listening queue for each TCP interconnect socket
gp_interconnect_timer_checking_period20msSets the timer checking period (in ms) for UDP interconnect
gp_interconnect_timer_period5msSets the timer period (in ms) for UDP interconnect
gp_interconnect_transmit_timeout1hTimeout (in seconds) on interconnect to transmit a packet
gp_interconnect_typeUDPIFCSets the protocol used for inter-node communication.
gp_log_formatcsvSets the format for log files.
gp_max_csv_line_length1048576Maximum allowed length of a csv input data row in bytes
gp_max_databases16Sets the maximum number of databases.
gp_max_filespaces8Sets the maximum number of filespaces.
gp_max_local_distributed_cache1024Sets the number of local-distributed transactions to cache for optimizing visibility processing by backends.
gp_max_packet_size8192Sets the max packet size for the Interconnect.
gp_max_partition_level0Sets the maximum number of levels allowed when creating a partitioned table.
gp_max_plan_size0Sets the maximum size of a plan to be dispatched.
gp_max_tablespaces16Sets the maximum number of tablespaces.
gp_motion_cost_per_row0Sets the planner's estimate of the cost of moving a row between worker processes.
gp_num_contents_in_cluster24Sets the number of segments in the cluster.
gp_reject_percent_threshold300Reject limit in percent starts calculating after this number of rows processed
gp_reraise_signalonDo we attempt to dump core when a serious problem occurs.
gp_resgroup_memory_policyeager_freeSets the policy for memory allocation of queries.
gp_resource_group_cpu_limit0.9Maximum percentage of CPU resources assigned to a cluster.
gp_resource_group_cpu_priority10Sets the cpu priority for postgres processes when resource group is enabled.
gp_resource_group_memory_limit0.7Maximum percentage of memory resources assigned to a cluster.
gp_resource_managerqueueSets the type of resource manager.
gp_resqueue_memory_policyeager_freeSets the policy for memory allocation of queries.
gp_resqueue_priorityonEnables priority scheduling.
gp_resqueue_priority_cpucores_per_segment4Number of processing units associated with a segment.
gp_resqueue_priority_sweeper_interval1000Frequency (in ms) at which sweeper process re-evaluates CPU shares.
gp_roledispatchSets the role for the session.
gp_safefswritesize0Minimum FS safe write size.
gp_segment_connect_timeout10minMaximum time (in seconds) allowed for a new worker process to start or a mirror to respond.
gp_segments_for_planner0If >0, number of segment dbs for the planner to assume in its cost and size estimates.
gp_server_version5.7.0 build commit:f7c6eb5cc61b25a7ff9c5a657d6f903befbae013Shows the Greenplum server version.
gp_server_version_num50000Shows the Greenplum server version as an integer.
gp_session_id1603459Global ID used to uniquely identify a particular session in an Greenplum Database array
gp_set_proc_affinityoffOn postmaster startup, attempt to bind postmaster to a processor
gp_snmp_communitypublicSets SNMP community name to send alerts (inform or trap messages) to.
gp_snmp_monitor_address Sets the network address to send SNMP alerts (inform or trap messages) to.
gp_snmp_use_inform_or_traptrapIf 'inform', we send alerts as SNMP v2c inform messages, if 'trap', we use SNMP v2 trap messages..
gp_standby_dbid0Sets DBID of standby master.
gp_statistics_pullup_from_child_partitiononThis guc enables the planner to utilize statistics from partitions in planning queries on the parent.
gp_statistics_use_fkeysonThis guc enables the planner to utilize statistics derived from foreign key relationships.
gp_subtrans_warn_limit16777216Sets the warning limit on number of subtransactions in a transaction.
gp_udp_bufsize_k0Sets recv buf size of UDP interconnect, for testing.
gp_vmem_idle_resource_timeout18sSets the time a session can be idle (in milliseconds) before we release gangs on the segment DBs to free resources.
gp_vmem_protect_limit4800Virtual memory limit (in MB) of Greenplum memory protection.
gp_vmem_protect_segworker_cache_limit500Max virtual memory limit (in MB) for a segworker to be cachable.
gp_workfile_checksummingonEnable checksumming on the executor work files in order to catch possible faulty writes caused by your disk drivers.
gp_workfile_compress_algorithmnoneSpecify the compression algorithm that work files in the query executor use.
gp_workfile_limit_files_per_query100000Maximum number of workfiles allowed per query per segment.
gp_workfile_limit_per_query0Maximum disk space (in KB) used for workfiles per query per segment.
gp_workfile_limit_per_segment0Maximum disk space (in KB) used for workfiles per segment.
gpcc.enable_send_query_infoonEnable query info metrics collection.
gpcc.query_metrics_port9898Sets the port number of sending query metrics.
gpcc.query_tags Custom session metadata as key-value pairs
gpperfmon_log_alert_levelwarningSpecify the log alert level used by gpperfmon.
gpperfmon_port8888Sets the port number of gpperfmon.
ignore_checksum_failureoffContinues processing after a checksum failure.
integer_datetimesonDatetimes are integer based.
IntervalStylepostgresSets the display format for interval values.
join_collapse_limit20Sets the FROM-list size beyond which JOIN constructs are not flattened.
krb_caseins_usersoffSets whether Kerberos and GSSAPI user names should be treated as case-insensitive.
krb_server_keyfileFILE:/usr/local/greenplum-db-devel/etc/postgresql/krb5.keytabSets the location of the Kerberos server key file.
krb_srvnamepostgresSets the name of the Kerberos service.
lc_collateen_US.utf8Shows the collation order locale.
lc_ctypeen_US.utf8Shows the character classification and case conversion locale.
lc_messagesen_US.utf8Sets the language in which messages are displayed.
lc_monetaryen_US.utf8Sets the locale for formatting monetary amounts.
lc_numericen_US.utf8Sets the locale for formatting numbers.
lc_timeen_US.utf8Sets the locale for formatting date and time values.
listen_addresses*Sets the host name or IP address(es) to listen to.
local_preload_libraries Lists shared libraries to preload into each backend.
log_autostatsoffLogs details of auto-stats issued ANALYZEs.
log_autovacuum_min_duration-1Sets the minimum execution time above which autovacuum actions will be logged.
log_checkpointsoffLogs each checkpoint.
log_connectionsoffLogs each successful connection.
log_count_recovered_files_batch1000Logs the total number of files shipped to the mirror after every batch of size specified by this value
log_disconnectionsoffLogs end of a session, including duration.
log_dispatch_statsoffWrites dispatcher performance statistics to the server log.
log_durationoffLogs the duration of each completed SQL statement.
log_error_verbositydefaultSets the verbosity of logged messages.
log_executor_statsoffWrites executor performance statistics to the server log.
log_hostnameoffLogs the host name in the connection logs.
log_lock_waitsoffLogs long lock waits.
log_min_duration_statement-1Sets the minimum execution time above which statements will be logged.
log_min_error_statementerrorCauses all statements generating error at or above this level to be logged.
log_min_messageswarningSets the message levels that are logged.
log_parser_statsoffWrites parser performance statistics to the server log.
log_planner_statsoffWrites planner performance statistics to the server log.
log_rotation_age1dAutomatic log file rotation will occur after N minutes.
log_rotation_size0Automatic log file rotation will occur after N kilobytes.
log_statementallSets the type of statements logged.
log_statement_statsoffWrites cumulative performance statistics to the server log.
log_temp_files-1Log the use of temporary files larger than this number of kilobytes.
log_timezoneAsia/ShanghaiSets the time zone to use in log messages.
log_truncate_on_rotationoffTruncate existing log files of same name during log rotation.
logging_collectoronDefunct: Start a subprocess to capture stderr output and/or csvlogs into log files.
maintenance_work_mem64MBSets the maximum memory to be used for maintenance operations.
max_appendonly_tables10000Maximum number of different (unrelated) append only tables that can participate in writing data concurrently.
max_connections250Sets the maximum number of concurrent connections.
max_files_per_process1000Sets the maximum number of simultaneously open files for each server process.
max_fsm_pages200000Sets the maximum number of disk pages for which free space is tracked.
max_fsm_relations1000Sets the maximum number of tables and indexes for which free space is tracked.
max_function_args100Shows the maximum number of function arguments.
max_identifier_length63Shows the maximum identifier length.
max_index_keys32Shows the maximum number of index keys.
max_locks_per_transaction128Sets the maximum number of locks per transaction.
max_prepared_transactions250Sets the maximum number of simultaneously prepared transactions.
max_resource_portals_per_transaction64Maximum number of resource queues.
max_resource_queues9Maximum number of resource queues.
max_stack_depth2MBSets the maximum stack depth, in kilobytes.
max_statement_mem2000MBSets the maximum value for statement_mem setting.
memory_spill_ratio20Sets the memory_spill_ratio for resource group.
optimizeronEnable Pivotal Query Optimizer.
optimizer_analyze_root_partitiononEnable statistics collection on root partitions during ANALYZE
optimizer_controlonAllow/disallow turning the optimizer on or off.
optimizer_enable_associativityoffEnables Join Associativity in optimizer
optimizer_join_arity_for_associativity_commutativity18Maximum number of children n-ary-join have without disabling commutativity and associativity transform
optimizer_join_orderexhaustiveSet optimizer join heuristic model.
optimizer_join_order_threshold10Maximum number of join children to use dynamic programming based join ordering algorithm.
optimizer_mdcache_size16MBSets the size of MDCache.
optimizer_metadata_cachingonThis guc enables the optimizer to cache and reuse metadata.
optimizer_minidumponerrorGenerate optimizer minidump.
optimizer_parallel_unionoffEnable parallel execution for UNION/UNION ALL queries.
password_encryptiononEncrypt passwords.
password_hash_algorithmMD5The cryptograph hash algorithm to apply to passwords before storing them.
pgstat_track_activity_query_size1024Maximum length of the query to be displayed in pg_stat_activity
pljava_classpathexamples.jar:chinadaas-data-security-1.0.jarclasspath used by the the JVM
pljava_classpath_insecureoffAllow pljava_classpath to be set by user per session
pljava_release_lingering_savepointsoffIf true, lingering savepoints will be released on function exit; if false, they will be rolled back
pljava_statement_cache_size0Size of the prepared statement MRU cache
pljava_vmoptions Options sent to the JVM when it is created
port2345Sets the TCP port the server listens on.
random_page_cost100Sets the planner's estimate of the cost of a nonsequentially fetched disk page.
readable_external_table_timeout0Cancel the query if no data read within N seconds.
regex_flavoradvancedSets the regular expression "flavor".
repl_catchup_within_range1Sets the maximum number of xlog segments allowed to lag when the backends can start blocking despite the WAL sender being in catchup phase. (Master Mirroring)
replication_timeout1minSets the maximum time to wait for WAL replication (Master Mirroring)
resource_cleanup_gangs_on_waitonEnable idle gang cleanup before resource lockwait.
resource_scheduleronEnable resource scheduling.
resource_select_onlyoffEnable resource locking of SELECT only.
runaway_detector_activation_percent90The runaway detector activates if the used vmem exceeds this percentage of the vmem quota. Set to 100 to disable runaway detection.
search_path$user,publicSets the schema search order for names that are not schema-qualified.
seq_page_cost1Sets the planner's estimate of the cost of a sequentially fetched disk page.
server_encodingUTF8Sets the server (database) character set encoding.
server_version8.3.23Shows the server version.
server_version_num80323Shows the server version as an integer.
session_replication_roleoriginSets the session's behavior for triggers and rewrite rules.
shared_buffers125MBSets the number of shared memory buffers used by the server.
shared_preload_libraries$libdir/metrics_collector,$libdir/gp_wlmLists shared libraries to preload into server.
ssloffEnables SSL connections.
ssl_ciphersALL:!ADH:!LOW:!EXP:!MD5:@STRENGTHSets the list of allowed SSL ciphers.
ssl_renegotiation_limit512MBSet the amount of traffic to send and receive before renegotiating the encryption keys.
standard_conforming_stringsonCauses '...' strings to treat backslashes literally.
statement_mem125MBSets the memory to be reserved for a statement.
statement_timeout0Sets the maximum allowed duration of any statement.
stats_queue_leveloffCollects resource queue-level statistics on database activity.
superuser_reserved_connections3Sets the number of connection slots reserved for superusers.
synchronize_seqscansonEnable synchronized sequential scans.
synchronous_commitonSets immediate fsync at commit.
tcp_keepalives_count9Maximum number of TCP keepalive retransmits.
tcp_keepalives_idle7200Time between issuing TCP keepalives.
tcp_keepalives_interval75Time between TCP keepalive retransmits.
temp_buffers1024Sets the maximum number of temporary buffers used by each session.
TimeZonePRCSets the time zone for displaying and interpreting time stamps.
timezone_abbreviationsAsiaSelects a file of time zone abbreviations.
track_activitiesonCollects information about executing commands.
track_countsonCollects statistics on database activity.
transaction_isolationread committedSets the current transaction's isolation level.
transaction_read_onlyoffSets the current transaction's read-only status.
transform_null_equalsoffTreats "expr=NULL" as "expr IS NULL".
unix_socket_directory Sets the directory where the Unix-domain socket will be created.
unix_socket_group Sets the owning group of the Unix-domain socket.
unix_socket_permissions511Sets the access permissions of the Unix-domain socket.
update_process_titleonUpdates the process title to show the active SQL command.
vacuum_cost_delay0Vacuum cost delay in milliseconds.
vacuum_cost_limit200Vacuum cost amount available before napping.
vacuum_cost_page_dirty20Vacuum cost for a page dirtied by vacuum.
vacuum_cost_page_hit1Vacuum cost for a page found in the buffer cache.
vacuum_cost_page_miss10Vacuum cost for a page not found in the buffer cache.
vacuum_freeze_min_age100000000Minimum age at which VACUUM should freeze a table row.
wal_buffers256kBSets the number of disk-page buffers in shared memory for WAL.
wal_receiver_status_interval10sSets the maximum interval between WAL receiver status reports to the primary. (Master Mirroring)
wal_writer_delay200msWAL writer sleep time between WAL flushes.
work_mem32MBSets the maximum memory to be used for query workspaces.
writable_external_table_bufsize64kBBuffer size in kilo bytes for writable external table before writing data to gpfdist.
xmlbinarybase64Sets how binary values are to be encoded in XML.
xmloptioncontentSets whether XML data in implicit parsing and serialization operations is to be considered as documents or content fragments.
  • 1
    点赞
  • 3
    收藏
    觉得还不错? 一键收藏
  • 打赏
    打赏
  • 0
    评论
评论
添加红包

请填写红包祝福语或标题

红包个数最小为10个

红包金额最低5元

当前余额3.43前往充值 >
需支付:10.00
成就一亿技术人!
领取后你会自动成为博主和红包主的粉丝 规则
hope_wisdom
发出的红包

打赏作者

盒马coding

你的支持是我最大的动力

¥1 ¥2 ¥4 ¥6 ¥10 ¥20
扫码支付:¥1
获取中
扫码支付

您的余额不足,请更换扫码支付或充值

打赏作者

实付
使用余额支付
点击重新获取
扫码支付
钱包余额 0

抵扣说明:

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

余额充值