/* * Procedure that wraps a bunch of boilerplate GUC options appropriate for all * the options used in this extension. */ static void optionalGucGet(char **dest, const char *name, const char *shortDesc) { DefineCustomStringVariable( name, shortDesc, "", dest, "", PGC_SIGHUP, GUC_NOT_IN_SAMPLE, NULL, gucOnAssignCloseInvalidate, NULL); }
/* * Entrypoint of this module. * * We register more than one worker process here, to demonstrate how that can * be done. */ void _PG_init(void) { struct BackgroundWorker worker = { "restgres master" }; /* get the configuration */ DefineCustomStringVariable("http.listen_addresses", "Addresses to listen on; see PostgreSQL listen_addresses", NULL, &restgres_listen_addresses, "*", PGC_SIGHUP, 0, NULL, NULL, NULL); DefineCustomIntVariable("http.port", "Port to listen on (default: any available port)", NULL, &restgres_listen_port, restgres_listen_port, 0, 32768, PGC_SIGHUP, 0, NULL, NULL, NULL); DefineCustomIntVariable("http.max_connections", "Maximum number of connections to serve at once (additional connections will have to wait or be rejected)", NULL, &restgres_max_connections, 100, 0, INT_MAX, PGC_SIGHUP, 0, NULL, NULL, NULL); DefineCustomIntVariable("http.max_concurrency", "Maximum number of connections to serve at once (additional connections will have to wait or be rejected)", NULL, &restgres_max_concurrency, 100, 0, INT_MAX, PGC_SIGHUP, 0, NULL, NULL, NULL); /* set up common data for all our workers */ worker.bgw_flags = BGWORKER_SHMEM_ACCESS | BGWORKER_BACKEND_DATABASE_CONNECTION; worker.bgw_restart_time = BGW_DEFAULT_RESTART_INTERVAL; worker.bgw_start_time = BgWorkerStart_RecoveryFinished; worker.bgw_main = restgres_main; worker.bgw_notify_pid = 0; RegisterBackgroundWorker(&worker); }
void _PG_init(void) { /* Define custom GUC variables. */ DefineCustomStringVariable("eudc.fallback_character", "Character used for EUDC. Or, use linear mapping when empty.", NULL, &eudc_fallback_character, NULL, PGC_USERSET, 0, #if PG_VERSION_NUM >= 90100 (GucStringCheckHook)&eudc_fallback_character_check_hook, (GucStringAssignHook)&eudc_fallback_character_assign_hook, #else eudc_fallback_character_assign_hook, #endif NULL); #if PG_VERSION_NUM >= 80400 DefineCustomEnumVariable("eudc.log_level", "Level to log EUDC characters.", NULL, &eudc_log_level, DEBUG2, log_level_options, PGC_USERSET, 0, #if PG_VERSION_NUM >= 90100 NULL, #endif NULL, NULL); #endif EmitWarningsOnPlaceholders("eudc"); }
/* Declare the parameters */ static void DefineGUCs(void) { DefineCustomBoolVariable("pg_hibernator.enabled", "Enable/disable automatic hibernation.", NULL, &guc_enabled, guc_enabled, PGC_SIGHUP, 0, NULL, NULL, NULL); DefineCustomBoolVariable("pg_hibernator.parallel", "Enable/disable restoring databases in parallel.", NULL, &guc_parallel_enabled, guc_parallel_enabled, PGC_SIGHUP, 0, NULL, NULL, NULL); DefineCustomStringVariable("pg_hibernator.default_database", "Database to connect to, by default.", "Postgres Hibernator will connect to this database when saving buffers, and when reading blocks of global objects.", &guc_default_database, guc_default_database, PGC_POSTMASTER, 0, NULL, NULL, NULL); }
/* Module load callback */ void _PG_init(void) { char *env_postgis_gdal_enabled_drivers = NULL; char *boot_postgis_gdal_enabled_drivers = NULL; char *env_postgis_enable_outdb_rasters = NULL; bool boot_postgis_enable_outdb_rasters = false; /* use POSTGIS_GDAL_ENABLED_DRIVERS to set the bootValue of GUC postgis.gdal_enabled_drivers */ env_postgis_gdal_enabled_drivers = getenv("POSTGIS_GDAL_ENABLED_DRIVERS"); if (env_postgis_gdal_enabled_drivers == NULL) { boot_postgis_gdal_enabled_drivers = palloc( sizeof(char) * (strlen(GDAL_DISABLE_ALL) + 1) ); sprintf(boot_postgis_gdal_enabled_drivers, "%s", GDAL_DISABLE_ALL); } else { boot_postgis_gdal_enabled_drivers = rtpg_trim( env_postgis_gdal_enabled_drivers ); } POSTGIS_RT_DEBUGF( 4, "boot_postgis_gdal_enabled_drivers = %s", boot_postgis_gdal_enabled_drivers ); /* use POSTGIS_ENABLE_OUTDB_RASTERS to set the bootValue of GUC postgis.enable_outdb_rasters */ env_postgis_enable_outdb_rasters = getenv("POSTGIS_ENABLE_OUTDB_RASTERS"); if (env_postgis_enable_outdb_rasters != NULL) { char *env = rtpg_trim(env_postgis_enable_outdb_rasters); /* out of memory */ if (env == NULL) { elog(ERROR, "_PG_init: Cannot process environmental variable: POSTGIS_ENABLE_OUTDB_RASTERS"); return; } if (strcmp(env, "1") == 0) boot_postgis_enable_outdb_rasters = true; pfree(env); } POSTGIS_RT_DEBUGF( 4, "boot_postgis_enable_outdb_rasters = %s", boot_postgis_enable_outdb_rasters ? "TRUE" : "FALSE" ); /* Install liblwgeom handlers */ pg_install_lwgeom_handlers(); /* TODO: Install raster callbacks (see rt_init_allocators)??? */ /* Define custom GUC variables. */ DefineCustomStringVariable( "postgis.gdal_datapath", /* name */ "Path to GDAL data files.", /* short_desc */ "Physical path to directory containing GDAL data files (sets the GDAL_DATA config option).", /* long_desc */ &gdal_datapath, /* valueAddr */ NULL, /* bootValue */ PGC_SUSET, /* GucContext context */ 0, /* int flags */ #if POSTGIS_PGSQL_VERSION >= 91 NULL, /* GucStringCheckHook check_hook */ #endif rtpg_assignHookGDALDataPath, /* GucStringAssignHook assign_hook */ NULL /* GucShowHook show_hook */ ); DefineCustomStringVariable( "postgis.gdal_enabled_drivers", /* name */ "Enabled GDAL drivers.", /* short_desc */ "List of enabled GDAL drivers by short name. To enable/disable all drivers, use 'ENABLE_ALL' or 'DISABLE_ALL' (sets the GDAL_SKIP config option).", /* long_desc */ &gdal_enabled_drivers, /* valueAddr */ boot_postgis_gdal_enabled_drivers, /* bootValue */ PGC_SUSET, /* GucContext context */ 0, /* int flags */ #if POSTGIS_PGSQL_VERSION >= 91 NULL, /* GucStringCheckHook check_hook */ #endif rtpg_assignHookGDALEnabledDrivers, /* GucStringAssignHook assign_hook */ NULL /* GucShowHook show_hook */ ); DefineCustomBoolVariable( "postgis.enable_outdb_rasters", /* name */ "Enable Out-DB raster bands", /* short_desc */ "If true, rasters can access data located outside the database", /* long_desc */ &enable_outdb_rasters, /* valueAddr */ boot_postgis_enable_outdb_rasters, /* bootValue */ PGC_SUSET, /* GucContext context */ 0, /* int flags */ #if POSTGIS_PGSQL_VERSION >= 91 NULL, /* GucStringCheckHook check_hook */ #endif rtpg_assignHookEnableOutDBRasters, /* GucBoolAssignHook assign_hook */ NULL /* GucShowHook show_hook */ ); /* free memory allocations */ pfree(boot_postgis_gdal_enabled_drivers); }
/* Register Citus configuration variables. */ static void RegisterCitusConfigVariables(void) { DefineCustomStringVariable( "citus.worker_list_file", gettext_noop("Sets the server's \"worker_list\" configuration file."), NULL, &WorkerListFileName, NULL, PGC_POSTMASTER, GUC_SUPERUSER_ONLY, NULL, NULL, NULL); NormalizeWorkerListPath(); DefineCustomBoolVariable( "citus.binary_master_copy_format", gettext_noop("Use the binary master copy format."), gettext_noop("When enabled, data is copied from workers to the master " "in PostgreSQL's binary serialization format."), &BinaryMasterCopyFormat, false, PGC_USERSET, 0, NULL, NULL, NULL); DefineCustomBoolVariable( "citus.binary_worker_copy_format", gettext_noop("Use the binary worker copy format."), gettext_noop("When enabled, data is copied from workers to workers " "in PostgreSQL's binary serialization format when " "joining large tables."), &BinaryWorkerCopyFormat, false, PGC_SIGHUP, 0, NULL, NULL, NULL); DefineCustomBoolVariable( "citus.expire_cached_shards", gettext_noop("Enables shard cache expiration if a shard's size on disk has " "changed."), gettext_noop("When appending to an existing shard, old data may still be cached " "on other workers. This configuration entry activates automatic " "expiration, but should not be used with manual updates to shards."), &ExpireCachedShards, false, PGC_SIGHUP, 0, NULL, NULL, NULL); DefineCustomBoolVariable( "citus.subquery_pushdown", gettext_noop("Enables supported subquery pushdown to workers."), NULL, &SubqueryPushdown, false, PGC_USERSET, 0, NULL, NULL, NULL); DefineCustomBoolVariable( "citus.log_multi_join_order", gettext_noop("Logs the distributed join order to the server log."), gettext_noop("We use this private configuration entry as a debugging aid. " "If enabled, we print the distributed join order."), &LogMultiJoinOrder, false, PGC_USERSET, GUC_NO_SHOW_ALL, NULL, NULL, NULL); DefineCustomBoolVariable( "citus.explain_multi_logical_plan", gettext_noop("Enables Explain to print out distributed logical plans."), gettext_noop("We use this private configuration entry as a debugging aid. " "If enabled, the Explain command prints out the optimized " "logical plan for distributed queries."), &ExplainMultiLogicalPlan, false, PGC_USERSET, GUC_NO_SHOW_ALL, NULL, NULL, NULL); DefineCustomBoolVariable( "citus.explain_multi_physical_plan", gettext_noop("Enables Explain to print out distributed physical plans."), gettext_noop("We use this private configuration entry as a debugging aid. " "If enabled, the Explain command prints out the physical " "plan for distributed queries."), &ExplainMultiPhysicalPlan, false, PGC_USERSET, GUC_NO_SHOW_ALL, NULL, NULL, NULL); DefineCustomBoolVariable( "citus.explain_distributed_queries", gettext_noop("Enables Explain for distributed queries."), gettext_noop("When enabled, the Explain command shows remote and local " "plans when used with a distributed query. It is enabled " "by default, but can be disabled for regression tests."), &ExplainDistributedQueries, true, PGC_USERSET, GUC_NO_SHOW_ALL, NULL, NULL, NULL); DefineCustomBoolVariable( "citus.explain_all_tasks", gettext_noop("Enables showing output for all tasks in Explain."), gettext_noop("The Explain command for distributed queries shows " "the remote plan for a single task by default. When " "this configuration entry is enabled, the plan for " "all tasks is shown, but the Explain takes longer."), &ExplainAllTasks, false, PGC_USERSET, 0, NULL, NULL, NULL); DefineCustomBoolVariable( "citus.all_modifications_commutative", gettext_noop("Bypasses commutativity checks when enabled"), NULL, &AllModificationsCommutative, false, PGC_USERSET, 0, NULL, NULL, NULL); DefineCustomBoolVariable( "citus.enable_ddl_propagation", gettext_noop("Enables propagating DDL statements to worker shards"), NULL, &EnableDDLPropagation, true, PGC_USERSET, 0, NULL, NULL, NULL); DefineCustomIntVariable( "citus.shard_replication_factor", gettext_noop("Sets the replication factor for shards."), gettext_noop("Shards are replicated across nodes according to this " "replication factor. Note that shards read this " "configuration value at sharded table creation time, " "and later reuse the initially read value."), &ShardReplicationFactor, 2, 1, 100, PGC_USERSET, 0, NULL, NULL, NULL); DefineCustomIntVariable( "citus.shard_max_size", gettext_noop("Sets the maximum size a shard will grow before it gets split."), gettext_noop("Shards store table and file data. When the source " "file's size for one shard exceeds this configuration " "value, the database ensures that either a new shard " "gets created, or the current one gets split. Note that " "shards read this configuration value at sharded table " "creation time, and later reuse the initially read value."), &ShardMaxSize, 1048576, 256, INT_MAX, /* max allowed size not set to MAX_KILOBYTES on purpose */ PGC_USERSET, GUC_UNIT_KB, NULL, NULL, NULL); DefineCustomIntVariable( "citus.max_worker_nodes_tracked", gettext_noop("Sets the maximum number of worker nodes that are tracked."), gettext_noop("Worker nodes' network locations, their membership and " "health status are tracked in a shared hash table on " "the master node. This configuration value limits the " "size of the hash table, and consequently the maximum " "number of worker nodes that can be tracked."), &MaxWorkerNodesTracked, 2048, 8, INT_MAX, PGC_POSTMASTER, 0, NULL, NULL, NULL); DefineCustomIntVariable( "citus.remote_task_check_interval", gettext_noop("Sets the frequency at which we check job statuses."), gettext_noop("The master node assigns tasks to workers nodes, and " "then regularly checks with them about each task's " "progress. This configuration value sets the time " "interval between two consequent checks."), &RemoteTaskCheckInterval, 10, 1, REMOTE_NODE_CONNECT_TIMEOUT, PGC_USERSET, GUC_UNIT_MS, NULL, NULL, NULL); DefineCustomIntVariable( "citus.task_tracker_delay", gettext_noop("Task tracker sleep time between task management rounds."), gettext_noop("The task tracker process wakes up regularly, walks over " "all tasks assigned to it, and schedules and executes these " "tasks. Then, the task tracker sleeps for a time period " "before walking over these tasks again. This configuration " "value determines the length of that sleeping period."), &TaskTrackerDelay, 200, 10, 100000, PGC_SIGHUP, GUC_UNIT_MS, NULL, NULL, NULL); DefineCustomIntVariable( "citus.max_assign_task_batch_size", gettext_noop("Sets the maximum number of tasks to assign per round."), gettext_noop("The master node synchronously assigns tasks to workers in " "batches. Bigger batches allow for faster task assignment, " "but it may take longer for all workers to get tasks " "if the number of workers is large. This configuration " "value controls the maximum batch size."), &MaxAssignTaskBatchSize, 64, 1, INT_MAX, PGC_USERSET, 0, NULL, NULL, NULL); DefineCustomIntVariable( "citus.max_tracked_tasks_per_node", gettext_noop("Sets the maximum number of tracked tasks per node."), gettext_noop("The task tracker processes keeps all assigned tasks in " "a shared hash table, and schedules and executes these " "tasks as appropriate. This configuration value limits " "the size of the hash table, and therefore the maximum " "number of tasks that can be tracked at any given time."), &MaxTrackedTasksPerNode, 1024, 8, INT_MAX, PGC_POSTMASTER, 0, NULL, NULL, NULL); DefineCustomIntVariable( "citus.max_running_tasks_per_node", gettext_noop("Sets the maximum number of tasks to run concurrently per node."), gettext_noop("The task tracker process schedules and executes the tasks " "assigned to it as appropriate. This configuration value " "sets the maximum number of tasks to execute concurrently " "on one node at any given time."), &MaxRunningTasksPerNode, 8, 1, INT_MAX, PGC_SIGHUP, 0, NULL, NULL, NULL); DefineCustomIntVariable( "citus.partition_buffer_size", gettext_noop("Sets the buffer size to use for partition operations."), gettext_noop("Worker nodes allow for table data to be repartitioned " "into multiple text files, much like Hadoop's Map " "command. This configuration value sets the buffer size " "to use per partition operation. After the buffer fills " "up, we flush the repartitioned data into text files."), &PartitionBufferSize, 8192, 0, (INT_MAX / 1024), /* result stored in int variable */ PGC_USERSET, GUC_UNIT_KB, NULL, NULL, NULL); DefineCustomIntVariable( "citus.large_table_shard_count", gettext_noop("The shard count threshold over which a table is considered large."), gettext_noop("A distributed table is considered to be large if it has " "more shards than the value specified here. This largeness " "criteria is then used in picking a table join order during " "distributed query planning."), &LargeTableShardCount, 4, 1, 10000, PGC_USERSET, 0, NULL, NULL, NULL); DefineCustomIntVariable( "citus.limit_clause_row_fetch_count", gettext_noop("Number of rows to fetch per task for limit clause optimization."), gettext_noop("Select queries get partitioned and executed as smaller " "tasks. In some cases, select queries with limit clauses " "may need to fetch all rows from each task to generate " "results. In those cases, and where an approximation would " "produce meaningful results, this configuration value sets " "the number of rows to fetch from each task."), &LimitClauseRowFetchCount, -1, -1, INT_MAX, PGC_USERSET, 0, NULL, NULL, NULL); DefineCustomRealVariable( "citus.count_distinct_error_rate", gettext_noop("Desired error rate when calculating count(distinct) " "approximates using the postgresql-hll extension. " "0.0 disables approximations for count(distinct); 1.0 " "provides no guarantees about the accuracy of results."), NULL, &CountDistinctErrorRate, 0.0, 0.0, 1.0, PGC_USERSET, 0, NULL, NULL, NULL); DefineCustomEnumVariable( "citus.multi_shard_commit_protocol", gettext_noop("Sets the commit protocol for commands modifying multiple shards."), gettext_noop("When a failure occurs during commands that modify multiple " "shards (currently, only COPY on distributed tables modifies more " "than one shard), two-phase commit is required to ensure data is " "never lost. Change this setting to '2pc' from its default '1pc' to " "enable 2 PC. You must also set max_prepared_transactions on the " "worker nodes. Recovery from failed 2PCs is currently manual."), &MultiShardCommitProtocol, COMMIT_PROTOCOL_1PC, multi_shard_commit_protocol_options, PGC_USERSET, 0, NULL, NULL, NULL); DefineCustomEnumVariable( "citus.task_assignment_policy", gettext_noop("Sets the policy to use when assigning tasks to worker nodes."), gettext_noop("The master node assigns tasks to worker nodes based on shard " "locations. This configuration value specifies the policy to " "use when making these assignments. The greedy policy aims to " "evenly distribute tasks across worker nodes, first-replica just " "assigns tasks in the order shard placements were created, " "and the round-robin policy assigns tasks to worker nodes in " "a round-robin fashion."), &TaskAssignmentPolicy, TASK_ASSIGNMENT_GREEDY, task_assignment_policy_options, PGC_USERSET, 0, NULL, NULL, NULL); DefineCustomEnumVariable( "citus.task_executor_type", gettext_noop("Sets the executor type to be used for distributed queries."), gettext_noop("The master node chooses between two different executor types " "when executing a distributed query.The real-time executor is " "optimal for simple key-value lookup queries and queries that " "involve aggregations and/or co-located joins on multiple shards. " "The task-tracker executor is optimal for long-running, complex " "queries that touch thousands of shards and/or that involve table " "repartitioning."), &TaskExecutorType, MULTI_EXECUTOR_REAL_TIME, task_executor_type_options, PGC_USERSET, 0, NULL, NULL, NULL); DefineCustomEnumVariable( "citus.shard_placement_policy", gettext_noop("Sets the policy to use when choosing nodes for shard placement."), gettext_noop("The master node chooses which worker nodes to place new shards " "on. This configuration value specifies the policy to use when " "selecting these nodes. The local-node-first policy places the " "first replica on the client node and chooses others randomly. " "The round-robin policy aims to distribute shards evenly across " "the cluster by selecting nodes in a round-robin fashion." "The random policy picks all workers randomly."), &ShardPlacementPolicy, SHARD_PLACEMENT_ROUND_ROBIN, shard_placement_policy_options, PGC_USERSET, 0, NULL, NULL, NULL); /* warn about config items in the citus namespace that are not registered above */ EmitWarningsOnPlaceholders("citus"); }
/* * Entrypoint of this module. * * We register more than one worker process here, to demonstrate how that can * be done. */ void _PG_init(void) { BackgroundWorker worker; unsigned int i; /* Define wich database to attach */ DefineCustomStringVariable("wed_worker.db_name", "WED-flow database to attach", NULL, &wed_worker_db_name, __DB_NAME__, PGC_SIGHUP, 0, NULL, NULL, NULL); /* get the configuration */ DefineCustomIntVariable("wed_worker.naptime", "Duration between each check (in seconds).", NULL, &wed_worker_naptime, 10, 1, INT_MAX, PGC_SIGHUP, 0, NULL, NULL, NULL); if (!process_shared_preload_libraries_in_progress) return; DefineCustomIntVariable("wed_worker.total_workers", "Number of workers.", NULL, &wed_worker_total_workers, 1, 1, 100, PGC_POSTMASTER, 0, NULL, NULL, NULL); /* set up common data for all our workers */ worker.bgw_flags = BGWORKER_SHMEM_ACCESS | BGWORKER_BACKEND_DATABASE_CONNECTION; worker.bgw_start_time = BgWorkerStart_RecoveryFinished; worker.bgw_restart_time = BGW_NEVER_RESTART; worker.bgw_main = wed_worker_main; worker.bgw_notify_pid = 0; /* * Now fill in worker-specific data, and do the actual registrations. */ for (i = 1; i <= wed_worker_total_workers; i++) { snprintf(worker.bgw_name, BGW_MAXLEN, "ww[%s] %d", wed_worker_db_name, i); worker.bgw_main_arg = Int32GetDatum(i); RegisterBackgroundWorker(&worker); } }
/* * Entrypoint of this module. * * We register more than one worker process here, to demonstrate how that can * be done. */ void _PG_init(void) { BackgroundWorker worker; if (!process_shared_preload_libraries_in_progress) return; /* get the configuration */ DefineCustomIntVariable("pg_keeper.keepalives_time", "Specific time between polling to primary server", NULL, &keeper_keepalives_time, 5, 1, INT_MAX, PGC_SIGHUP, 0, NULL, NULL, NULL); DefineCustomIntVariable("pg_keeper.keepalives_count", "Specific retry count until promoting standby server", NULL, &keeper_keepalives_count, 1, 1, INT_MAX, PGC_SIGHUP, 0, NULL, NULL, NULL); DefineCustomStringVariable("pg_keeper.node1_conninfo", "Connection information for node1 server (first master server)", NULL, &keeper_node1_conninfo, NULL, PGC_POSTMASTER, 0, NULL, NULL, NULL); DefineCustomStringVariable("pg_keeper.node2_conninfo", "Connection information for node2 server (first standby server)", NULL, &keeper_node2_conninfo, NULL, PGC_POSTMASTER, 0, NULL, NULL, NULL); DefineCustomStringVariable("pg_keeper.after_command", "Shell command that will be called after promoted", NULL, &keeper_after_command, NULL, PGC_SIGHUP, GUC_NOT_IN_SAMPLE, NULL, NULL, NULL); /* set up common data for all our workers */ worker.bgw_flags = BGWORKER_SHMEM_ACCESS | BGWORKER_BACKEND_DATABASE_CONNECTION; worker.bgw_start_time = BgWorkerStart_ConsistentState; worker.bgw_restart_time = BGW_NEVER_RESTART; worker.bgw_main = KeeperMain; worker.bgw_notify_pid = 0; /* * Now fill in worker-specific data, and do the actual registrations. */ snprintf(worker.bgw_name, BGW_MAXLEN, "pg_keeper"); worker.bgw_main_arg = Int32GetDatum(1); RegisterBackgroundWorker(&worker); }
void _PG_init(void) { MemoryContext old_ctxt; globals.pg_ctxt = AllocSetContextCreate(TopMemoryContext, "pgmemcache global context", ALLOCSET_SMALL_MINSIZE, ALLOCSET_SMALL_INITSIZE, ALLOCSET_SMALL_MAXSIZE); old_ctxt = MemoryContextSwitchTo(globals.pg_ctxt); globals.mc = memcached_create(NULL); if (memcached_set_memory_allocators(globals.mc, (memcached_malloc_fn) pgmemcache_malloc, (memcached_free_fn) pgmemcache_free, (memcached_realloc_fn) pgmemcache_realloc, (memcached_calloc_fn) pgmemcache_calloc, NULL) != MEMCACHED_SUCCESS) { elog(ERROR, "pgmemcache: unable to set memory allocators"); } MemoryContextSwitchTo(old_ctxt); DefineCustomStringVariable("pgmemcache.default_servers", "Comma-separated list of memcached servers to connect to.", "Specified as a comma-separated list of host:port (port is optional).", &memcache_default_servers, NULL, PGC_USERSET, GUC_LIST_INPUT, #if defined(PG_VERSION_NUM) && (PG_VERSION_NUM >= 90100) (GucStringCheckHook) check_default_guc, #endif (GucStringAssignHook) assign_default_servers_guc, (GucShowHook) show_default_servers_guc); DefineCustomStringVariable ("pgmemcache.default_behavior", "Comma-separated list of memcached behavior (optional).", "Specified as a comma-separated list of behavior_flag:behavior_data.", &memcache_default_behavior, NULL, PGC_USERSET, GUC_LIST_INPUT, #if defined(PG_VERSION_NUM) && (PG_VERSION_NUM >= 90100) (GucStringCheckHook) check_default_guc, #endif (GucStringAssignHook) assign_default_behavior_guc, (GucShowHook) show_default_behavior_guc); DefineCustomStringVariable ("pgmemcache.sasl_authentication_username", "pgmemcache SASL user authentication username", "Simple string pgmemcache.sasl_authentication_username = '******'", &memcache_sasl_authentication_username, NULL, PGC_USERSET, GUC_LIST_INPUT, #if defined(PG_VERSION_NUM) && (PG_VERSION_NUM >= 90100) (GucStringCheckHook) check_default_guc, #endif NULL, (GucShowHook) show_memcache_sasl_authentication_username_guc); DefineCustomStringVariable ("pgmemcache.sasl_authentication_password", "pgmemcache SASL user authentication username", "Simple string pgmemcache.sasl_authentication_password = '******'", &memcache_sasl_authentication_password, NULL, PGC_USERSET, GUC_LIST_INPUT, #if defined(PG_VERSION_NUM) && (PG_VERSION_NUM >= 90100) (GucStringCheckHook) check_default_guc, #endif NULL, (GucShowHook) show_memcache_sasl_authentication_password_guc); #if 0 if ((memcache_sasl_authentication_username != "" && memcache_sasl_authentication_password != "") || (memcache_sasl_authentication_username != NULL && memcache_sasl_authentication_password != NULL)) { if (sasl_client_init(NULL) != SASL_OK) elog(ERROR, "Failed to initialize SASL library!"); memcached_set_sasl_callbacks(globals.mc, sasl_callbacks); } #endif }
/* * Module load callback */ void _PG_init(void) { /* can be preloaded only from postgresql.conf */ if (!process_shared_preload_libraries_in_progress) return; /* Define custom GUC variables. */ DefineCustomStringVariable("query_recorder.filename", "Base filename to write the recorded queries.", NULL, &base_filename, false, PGC_BACKEND, 0, #if (PG_VERSION_NUM >= 90100) NULL, #endif NULL, NULL); DefineCustomIntVariable("query_recorder.max_files", "How many files will be rotated.", NULL, &max_files, 100, 1, 1000, PGC_BACKEND, 0, #if (PG_VERSION_NUM >= 90100) NULL, #endif NULL, NULL); DefineCustomIntVariable("query_recorder.size_limit", "File size limit (will create multiple files .000 - .999)", NULL, &max_file_size, 1024*1024*1024/BLCKSZ, /* 1GB */ 1024*1024/BLCKSZ, 1024*1024*1024/BLCKSZ, /* 1MB - 1GB */ PGC_BACKEND, GUC_UNIT_BLOCKS, #if (PG_VERSION_NUM >= 90100) NULL, #endif NULL, NULL); DefineCustomIntVariable("query_recorder.buffer_size", "Size of the buffer used to collect queries.", NULL, &buffer_size, 1024*1024/BLCKSZ, /* 1MB */ 1, 16*1024*1024/BLCKSZ, /* 1 block - 16MB */ PGC_BACKEND, GUC_UNIT_BLOCKS, #if (PG_VERSION_NUM >= 90100) NULL, #endif NULL, NULL); /* Define custom GUC variables. */ DefineCustomBoolVariable("query_recorder.normalize", "Replace line breaks and carriage returns with spaces.", NULL, &normalize, false, PGC_BACKEND, 0, #if (PG_VERSION_NUM >= 90100) NULL, #endif &set_enabled, NULL); /* Define custom GUC variables. */ DefineCustomBoolVariable("query_recorder.enabled", "Enable or disable recording of queries.", NULL, &enabled, false, PGC_SUSET, 0, #if (PG_VERSION_NUM >= 90100) NULL, #endif &set_enabled, (GucShowHook)(&show_enabled)); EmitWarningsOnPlaceholders("query_recorder"); /* * Request additional shared resources. (These are no-ops if we're not in * the postmaster process.) We'll allocate or attach to the shared * resources in pg_record_shmem_startup(). */ RequestAddinShmemSpace(SEGMENT_SIZE); RequestAddinLWLocks(1); /* Install hooks. */ prev_shmem_startup_hook = shmem_startup_hook; shmem_startup_hook = pg_record_shmem_startup; prev_ExecutorStart = ExecutorStart_hook; ExecutorStart_hook = explain_ExecutorStart; prev_ExecutorRun = ExecutorRun_hook; ExecutorRun_hook = explain_ExecutorRun; #if (PG_VERSION_NUM >= 90100) prev_ExecutorFinish = ExecutorFinish_hook; ExecutorFinish_hook = explain_ExecutorFinish; #endif prev_ExecutorEnd = ExecutorEnd_hook; ExecutorEnd_hook = explain_ExecutorEnd; prev_ProcessUtility = ProcessUtility_hook; ProcessUtility_hook = pg_record_ProcessUtility; }
/* * _PG_init * Entry point loading hooks */ void _PG_init(void) { /* Set up GUCs */ DefineCustomStringVariable("redislog.host", "Redis server host name or IP address.", NULL, &Redislog_host, "127.0.0.1", PGC_SIGHUP, GUC_NOT_IN_SAMPLE | GUC_SUPERUSER_ONLY, NULL, &guc_on_assign_reopen_string, NULL); DefineCustomIntVariable("redislog.port", "Redis server port number.", NULL, &Redislog_port, 6379, 0, 65535, PGC_SIGHUP, GUC_NOT_IN_SAMPLE | GUC_SUPERUSER_ONLY, NULL, &guc_on_assign_reopen_int, NULL); DefineCustomIntVariable("redislog.connection_timeout", "Redis server connection timeout.", NULL, &Redislog_timeout, 1000, 1, INT_MAX, PGC_SIGHUP, GUC_NOT_IN_SAMPLE | GUC_SUPERUSER_ONLY | GUC_UNIT_MS, NULL, NULL, NULL); DefineCustomStringVariable("redislog.key", "Redis server key name.", NULL, &Redislog_key, "postgres", PGC_SIGHUP, GUC_NOT_IN_SAMPLE | GUC_SUPERUSER_ONLY, NULL, NULL, NULL); DefineCustomEnumVariable("redislog.min_error_statement", "Controls which SQL statements that cause an error condition are " "recorded in the server log.", "Each level includes all the levels that follow it. The later " "the level, the fewer messages are sent.", &Redislog_min_error_statement, log_min_error_statement, server_message_level_options, PGC_SUSET, GUC_NOT_IN_SAMPLE, NULL, NULL, NULL); DefineCustomEnumVariable("redislog.min_messages", "Set the message levels that are logged.", "Each level includes all the levels that follow it. The higher " "the level, the fewer messages are sent.", &Redislog_min_messages, WARNING, server_message_level_options, PGC_SUSET, GUC_NOT_IN_SAMPLE, NULL, NULL, NULL); DefineCustomBoolVariable("redislog.ship_to_redis_only", "Send log messages to Redis only.", "If set to true, send log messages to Redis only and skip " "journaling them into the main PostgreSQL log. Use the " "PostgreSQL main logger facility for fallback purposes only, " "in case no Redis service is available. " "By default it is set to false.", &Redislog_ship_to_redis_only, FALSE, PGC_SUSET, GUC_NOT_IN_SAMPLE, NULL, NULL, NULL); prev_log_hook = emit_log_hook; emit_log_hook = redis_log_hook; EmitWarningsOnPlaceholders("redislog"); }
void _PG_init(void) { MemoryContext old_ctxt; globals.pg_ctxt = AllocSetContextCreate(TopMemoryContext, "pgmemcache global context", ALLOCSET_SMALL_MINSIZE, ALLOCSET_SMALL_INITSIZE, ALLOCSET_SMALL_MAXSIZE); old_ctxt = MemoryContextSwitchTo(globals.pg_ctxt); globals.mc = memcached_create(NULL); if (memcached_set_memory_allocators(globals.mc, (memcached_malloc_fn) pgmemcache_malloc, (memcached_free_fn) pgmemcache_free, (memcached_realloc_fn) pgmemcache_realloc, (memcached_calloc_fn) pgmemcache_calloc, NULL) != MEMCACHED_SUCCESS) { elog(ERROR, "pgmemcache: unable to set memory allocators"); } MemoryContextSwitchTo(old_ctxt); DefineCustomStringVariable("pgmemcache.default_servers", "Comma-separated list of memcached servers to connect to.", "Specified as a comma-separated list of host:port (port is optional).", &memcache_default_servers, NULL, PGC_USERSET, GUC_LIST_INPUT, #if defined(PG_VERSION_NUM) && (PG_VERSION_NUM >= 90100) NULL, #endif assign_default_servers_guc, show_default_servers_guc); DefineCustomStringVariable ("pgmemcache.default_behavior", "Comma-separated list of memcached behavior (optional).", "Specified as a comma-separated list of behavior_flag:behavior_data.", &memcache_default_behavior, NULL, PGC_USERSET, GUC_LIST_INPUT, #if defined(PG_VERSION_NUM) && (PG_VERSION_NUM >= 90100) NULL, #endif assign_default_behavior_guc, show_default_behavior_guc); DefineCustomStringVariable ("pgmemcache.sasl_authentication_username", "pgmemcache SASL user authentication username", "Simple string pgmemcache.sasl_authentication_username = '******'", &memcache_sasl_authentication_username, NULL, PGC_USERSET, GUC_LIST_INPUT, #if defined(PG_VERSION_NUM) && (PG_VERSION_NUM >= 90100) NULL, #endif NULL, show_memcache_sasl_authentication_username_guc); DefineCustomStringVariable ("pgmemcache.sasl_authentication_password", "pgmemcache SASL user authentication password", "Simple string pgmemcache.sasl_authentication_password = '******'", &memcache_sasl_authentication_password, NULL, PGC_USERSET, GUC_LIST_INPUT, #if defined(PG_VERSION_NUM) && (PG_VERSION_NUM >= 90100) NULL, #endif NULL, show_memcache_sasl_authentication_password_guc); #if LIBMEMCACHED_WITH_SASL_SUPPORT if ((strlen(memcache_sasl_authentication_username) > 0 && strlen(memcache_sasl_authentication_password) > 0) || (memcache_sasl_authentication_username != NULL && memcache_sasl_authentication_password != NULL)) { rc = memcached_set_sasl_auth_data(globals.mc, memcache_sasl_authentication_username, memcache_sasl_authentication_password); if (rc != MEMCACHED_SUCCESS) { elog(ERROR, "%s ", memcached_strerror(globals.mc, rc)); } _init_sasl(); } #endif }
/* * Module load callback */ void _PG_init(void) { if (pgscws_scws) return; pgscws_init(); DefineCustomBoolVariable("scws.dict_in_memory", "load dicts into memory", NULL, &pgscws_dict_in_memory, false, PGC_BACKEND, 0, NULL, pgscws_assign_dict_in_memory, NULL); DefineCustomStringVariable("scws.charset", "charset", NULL, &pgscws_charset, "utf8", PGC_USERSET, 0, pgscws_check_charset, pgscws_assign_charset, NULL); DefineCustomStringVariable("scws.rules", "rules to load", NULL, &pgscws_rules, "rules.utf8.ini", PGC_USERSET, 0, pgscws_check_rules, pgscws_assign_rules, NULL); DefineCustomStringVariable("scws.extra_dicts", "extra dicts files to load", NULL, &pgscws_extra_dicts, "dict.utf8.xdb", PGC_USERSET, 0, pgscws_check_extra_dicts, pgscws_assign_extra_dicts, NULL); DefineCustomBoolVariable("scws.punctuation_ignore", "set if scws ignores the puncuation", "set if scws ignores the puncuation, except \\r and \\n", &pgscws_punctuation_ignore, false, PGC_USERSET, 0, NULL, NULL, NULL); DefineCustomBoolVariable("scws.seg_with_duality", "segment words with duality", NULL, &pgscws_seg_with_duality, false, PGC_USERSET, 0, NULL, NULL, NULL); DefineCustomStringVariable("scws.multi_mode", "set multi mode", "\"none\" for none\n" "\"short\" for prefer short words\n" "\"duality\" for prefer duality\n" "\"zmain\" prefer most important element" "\"zall\" prefer prefer all element", &pgscws_multi_mode_string, "none", PGC_USERSET, 0, pgscws_check_multi_mode, pgscws_assign_multi_mode, NULL); }
/* * _PG_init() - library load-time initialization * * DO NOT make this static nor change its name! * * Init the module, all we have to do here is getting our GUC */ void _PG_init(void) { char sharepath[MAXPGPATH]; char *default_control_directory; get_share_path(my_exec_path, sharepath); default_control_directory = (char *) palloc(MAXPGPATH); snprintf(default_control_directory, MAXPGPATH, "%s/extension", sharepath); DefineCustomStringVariable("pginstall.archive_dir", "Path where to download extension archives.", "", &pginstall_archive_dir, "", PGC_SUSET, GUC_NOT_IN_SAMPLE, NULL, NULL, NULL); DefineCustomStringVariable("pginstall.control_dir", "Path where to install extension control files.", "", &pginstall_control_dir, default_control_directory, PGC_SUSET, GUC_NOT_IN_SAMPLE, NULL, NULL, NULL); DefineCustomStringVariable("pginstall.extension_dir", "Path where to install extension contents.", "", &pginstall_extension_dir, "", PGC_SUSET, GUC_NOT_IN_SAMPLE, NULL, NULL, NULL); DefineCustomStringVariable("pginstall.repository", "Extension Repository URL", "", &pginstall_repository, "", PGC_SUSET, GUC_NOT_IN_SAMPLE, NULL, NULL, NULL); DefineCustomStringVariable("pginstall.custom_path", "Directory where to load custom scripts from", "", &pginstall_custom_path, "", PGC_SUSET, GUC_NOT_IN_SAMPLE, NULL, NULL, NULL); DefineCustomStringVariable("pginstall.whitelist", "List of extensions that are whitelisted", "Separated by comma", &pginstall_whitelist, "", PGC_SUSET, GUC_NOT_IN_SAMPLE, NULL, NULL, NULL); DefineCustomBoolVariable("pginstall.sudo", "Allow privilege escalation to install extensions", "", &pginstall_sudo, false, PGC_SUSET, GUC_NOT_IN_SAMPLE, NULL, NULL, NULL); DefineCustomBoolVariable("pginstall.serve_from_archive_dir", "Avoid contacting the repository server when the needed archive file is already available locally", "", &pginstall_serve_from_archive_dir, false, PGC_SUSET, GUC_NOT_IN_SAMPLE, NULL, NULL, NULL); prev_ProcessUtility = ProcessUtility_hook; ProcessUtility_hook = pginstall_ProcessUtility; }
static void registerGUCOptions(void) { char pathbuf[MAXPGPATH]; DefineCustomStringVariable( "pljava.libjvm_location", "Path to the libjvm (.so, .dll, etc.) file in Java's jre/lib area", NULL, /* extended description */ &libjvmlocation, #if PG_VERSION_NUM >= 80400 "libjvm", #endif PGC_SUSET, #if PG_VERSION_NUM >= 80400 0, /* flags */ #endif #if PG_VERSION_NUM >= 90100 check_libjvm_location, #endif assign_libjvm_location, NULL); /* show hook */ DefineCustomStringVariable( "pljava.vmoptions", "Options sent to the JVM when it is created", NULL, /* extended description */ &vmoptions, #if PG_VERSION_NUM >= 80400 NULL, /* boot value */ #endif PGC_SUSET, #if PG_VERSION_NUM >= 80400 0, /* flags */ #endif #if PG_VERSION_NUM >= 90100 check_vmoptions, #endif assign_vmoptions, NULL); /* show hook */ DefineCustomStringVariable( "pljava.classpath", "Classpath used by the JVM", NULL, /* extended description */ &classpath, #if PG_VERSION_NUM >= 80400 InstallHelper_defaultClassPath(pathbuf), /* boot value */ #endif PGC_SUSET, #if PG_VERSION_NUM >= 80400 0, /* flags */ #endif #if PG_VERSION_NUM >= 90100 check_classpath, #endif assign_classpath, NULL); /* show hook */ DefineCustomBoolVariable( "pljava.debug", "Stop the backend to attach a debugger", NULL, /* extended description */ &pljavaDebug, #if PG_VERSION_NUM >= 80400 false, /* boot value */ #endif PGC_USERSET, #if PG_VERSION_NUM >= 80400 0, /* flags */ #endif #if PG_VERSION_NUM >= 90100 NULL, /* check hook */ #endif NULL, NULL); /* assign hook, show hook */ DefineCustomIntVariable( "pljava.statement_cache_size", "Size of the prepared statement MRU cache", NULL, /* extended description */ &statementCacheSize, #if PG_VERSION_NUM >= 80400 11, /* boot value */ #endif 0, 512, /* min, max values */ PGC_USERSET, #if PG_VERSION_NUM >= 80400 0, /* flags */ #endif #if PG_VERSION_NUM >= 90100 NULL, /* check hook */ #endif NULL, NULL); /* assign hook, show hook */ DefineCustomBoolVariable( "pljava.release_lingering_savepoints", "If true, lingering savepoints will be released on function exit. " "If false, they will be rolled back", NULL, /* extended description */ &pljavaReleaseLingeringSavepoints, #if PG_VERSION_NUM >= 80400 false, /* boot value */ #endif PGC_USERSET, #if PG_VERSION_NUM >= 80400 0, /* flags */ #endif #if PG_VERSION_NUM >= 90100 NULL, /* check hook */ #endif NULL, NULL); /* assign hook, show hook */ DefineCustomBoolVariable( "pljava.enable", "If off, the Java virtual machine will not be started until set on.", "This is mostly of use on PostgreSQL versions < 9.2, where option " "settings changed before LOADing PL/Java may be rejected, so they must " "be made after LOAD, but before the virtual machine is started.", &pljavaEnabled, #if PG_VERSION_NUM >= 90200 true, /* boot value */ #elif PG_VERSION_NUM >= 80400 false, /* boot value */ #endif PGC_USERSET, #if PG_VERSION_NUM >= 80400 0, /* flags */ #endif #if PG_VERSION_NUM >= 90100 check_enabled, /* check hook */ #endif assign_enabled, NULL); /* show hook */ DefineCustomStringVariable( "pljava.implementors", "Implementor names recognized in deployment descriptors", NULL, /* extended description */ &implementors, #if PG_VERSION_NUM >= 80400 "postgresql", /* boot value */ #endif PGC_USERSET, #if PG_VERSION_NUM >= 80400 GUC_LIST_INPUT | GUC_LIST_QUOTE, #endif #if PG_VERSION_NUM >= 90100 NULL, /* check hook */ #endif NULL, NULL); /* assign hook, show hook */ EmitWarningsOnPlaceholders("pljava"); }
/* * Module load callback */ void _PG_init(void) { if (zhprs_scws) return; zhprs_init(); DefineCustomBoolVariable("zhparser.dict_in_memory", "load dicts into memory", NULL, &zhprs_dict_in_memory, false, PGC_BACKEND, 0, NULL, zhprs_assign_dict_in_memory, NULL); DefineCustomStringVariable("zhparser.charset", "charset", NULL, &zhprs_charset, "utf8", PGC_USERSET, 0, zhprs_check_charset, zhprs_assign_charset, NULL); DefineCustomStringVariable("zhparser.rules", "rules to load", NULL, &zhprs_rules, "rules.utf8.ini", PGC_USERSET, 0, zhprs_check_rules, zhprs_assign_rules, NULL); DefineCustomStringVariable("zhparser.extra_dicts", "extra dicts files to load", NULL, &zhprs_extra_dicts, "dict.utf8.xdb", PGC_USERSET, 0, zhprs_check_extra_dicts, zhprs_assign_extra_dicts, NULL); DefineCustomBoolVariable("zhparser.punctuation_ignore", "set if zhparser ignores the puncuation", "set if zhparser ignores the puncuation, except \\r and \\n", &zhprs_punctuation_ignore, false, PGC_USERSET, 0, NULL, NULL, NULL); DefineCustomBoolVariable("zhparser.seg_with_duality", "segment words with duality", NULL, &zhprs_seg_with_duality, false, PGC_USERSET, 0, NULL, NULL, NULL); DefineCustomStringVariable("zhparser.multi_mode", "set multi mode", "short for prefer short words\n" "duality for prefer duality\n" "zmain prefer most important element" "zall prefer prefer all element", &zhprs_multi_mode_string, NULL, PGC_USERSET, 0, zhprs_check_multi_mode, zhprs_assign_multi_mode, NULL); }
void _PG_init(void) { /* * In order to create our shared memory area, we have to be loaded via * shared_preload_libraries. If not, fall out without hooking into any of * the main system. (We don't throw error here because it seems useful to * allow the cs_* functions to be created even when the * module isn't active. The functions must protect themselves against * being called then, however.) */ if (!process_shared_preload_libraries_in_progress) return; DefineCustomIntVariable( "multimaster.workers", "Number of multimaster executor workers per node", NULL, &MMWorkers, 8, 1, INT_MAX, PGC_BACKEND, 0, NULL, NULL, NULL ); DefineCustomIntVariable( "multimaster.queue_size", "Multimaster queue size", NULL, &MMQueueSize, 1024*1024, 1024, INT_MAX, PGC_BACKEND, 0, NULL, NULL, NULL ); DefineCustomIntVariable( "multimaster.local_xid_reserve", "Number of XIDs reserved by node for local transactions", NULL, &DtmLocalXidReserve, 100, 1, INT_MAX, PGC_BACKEND, 0, NULL, NULL, NULL ); DefineCustomIntVariable( "multimaster.buffer_size", "Size of sockhub buffer for connection to DTM daemon, if 0, then direct connection will be used", NULL, &DtmBufferSize, 0, 0, INT_MAX, PGC_BACKEND, 0, NULL, NULL, NULL ); DefineCustomStringVariable( "multimaster.arbiters", "The comma separated host:port pairs where arbiters reside", NULL, &Arbiters, "127.0.0.1:5431", PGC_BACKEND, // context 0, // flags, NULL, // GucStringCheckHook check_hook, NULL, // GucStringAssignHook assign_hook, NULL // GucShowHook show_hook ); DefineCustomStringVariable( "multimaster.conn_strings", "Multimaster node connection strings separated by commas, i.e. 'replication=database dbname=postgres host=localhost port=5001,replication=database dbname=postgres host=localhost port=5002'", NULL, &MMConnStrs, "", PGC_BACKEND, // context 0, // flags, NULL, // GucStringCheckHook check_hook, NULL, // GucStringAssignHook assign_hook, NULL // GucShowHook show_hook ); DefineCustomIntVariable( "multimaster.node_id", "Multimaster node ID", NULL, &MMNodeId, 1, 1, INT_MAX, PGC_BACKEND, 0, NULL, NULL, NULL ); /* * Request additional shared resources. (These are no-ops if we're not in * the postmaster process.) We'll allocate or attach to the shared * resources in dtm_shmem_startup(). */ RequestAddinShmemSpace(DTM_SHMEM_SIZE + MMQueueSize); RequestAddinLWLocks(2); MMNodes = MMStartReceivers(MMConnStrs, MMNodeId); if (MMNodes < 2) { elog(ERROR, "Multimaster should have at least two nodes"); } BgwPoolStart(MMWorkers, MMPoolConstructor); ArbitersCopy = strdup(Arbiters); if (DtmBufferSize != 0) { ArbiterConfig(Arbiters, Unix_socket_directories); RegisterBackgroundWorker(&DtmWorker); } else ArbiterConfig(Arbiters, NULL); /* * Install hooks. */ PreviousShmemStartupHook = shmem_startup_hook; shmem_startup_hook = DtmShmemStartup; PreviousExecutorFinishHook = ExecutorFinish_hook; ExecutorFinish_hook = MMExecutorFinish; PreviousProcessUtilityHook = ProcessUtility_hook; ProcessUtility_hook = MMProcessUtility; }