PostgreSQL Source Code
git master
|
Go to the source code of this file.
Functions | |
StringInfo | makeStringInfo (void) |
void | initStringInfo (StringInfo str) |
void | resetStringInfo (StringInfo str) |
void | appendStringInfo (StringInfo str, const char *fmt,...) |
int | appendStringInfoVA (StringInfo str, const char *fmt, va_list args) |
void | appendStringInfoString (StringInfo str, const char *s) |
void | appendStringInfoChar (StringInfo str, char ch) |
void | appendStringInfoSpaces (StringInfo str, int count) |
void | appendBinaryStringInfo (StringInfo str, const char *data, int datalen) |
void | appendBinaryStringInfoNT (StringInfo str, const char *data, int datalen) |
void | enlargeStringInfo (StringInfo str, int needed) |
void appendBinaryStringInfo | ( | StringInfo | str, |
const char * | data, | ||
int | datalen | ||
) |
Definition at line 227 of file stringinfo.c.
References Assert, StringInfoData::data, enlargeStringInfo(), and StringInfoData::len.
Referenced by add_indent(), appendStringInfoRegexpSubstr(), appendStringInfoString(), appendStringInfoText(), apply_handle_stream_commit(), auth_peer(), buf_add_txid(), buf_init(), bytea_string_agg_transfn(), config_enum_get_options(), CopyReadLineText(), CopySendData(), CopySendString(), database_to_xml_internal(), DeadLockReport(), deparseFromExprForRel(), ExecBuildSlotPartitionKeyDescription(), ExecBuildSlotValueDescription(), flattenJsonPathParseItem(), get_from_clause(), get_target_list(), HandleParallelMessages(), hstore_to_json(), hstore_to_json_loose(), hstore_to_jsonb_loose(), int8_avg_deserialize(), json_lex_string(), jsonb_put_escaped_value(), JsonbToCStringWorker(), jsonPathToCstring(), log_line_prefix(), map_sql_identifier_to_xml_name(), map_xml_name_to_sql_identifier(), multirange_recv(), numeric_avg_deserialize(), numeric_deserialize(), numeric_poly_deserialize(), parse_fcall_arguments(), pg_decode_message(), pg_decode_stream_message(), pg_get_functiondef(), plpgsql_append_source_text(), pq_sendbytes(), pq_sendtext(), print_function_rettype(), printJsonPathItem(), process_pipe_input(), range_recv(), rebuildInsertSql(), replace_text(), replace_text_regexp(), reserveSpaceForItemPointer(), RI_FKey_cascade_upd(), ri_set(), schema_to_xml_internal(), unaccent_lexize(), write_csvlog(), XLogInsertRecord(), XLogWalRcvProcessMsg(), xml_is_document(), xml_send(), and xmlconcat().
void appendBinaryStringInfoNT | ( | StringInfo | str, |
const char * | data, | ||
int | datalen | ||
) |
Definition at line 253 of file stringinfo.c.
References Assert, StringInfoData::data, enlargeStringInfo(), and StringInfoData::len.
Referenced by appendStringInfoStringQuoted(), pq_sendcountedtext(), and pq_sendstring().
void appendStringInfo | ( | StringInfo | str, |
const char * | fmt, | ||
... | |||
) |
Definition at line 91 of file stringinfo.c.
References appendStringInfoVA(), generate_unaccent_rules::args, and enlargeStringInfo().
Referenced by _outConstraint(), _outForeignKeyOptInfo(), _outList(), _outPathTarget(), _outValue(), add_cast_to(), AddFileToBackupManifest(), appendFunctionName(), appendStringInfoStringQuoted(), array_to_text_internal(), auth_peer(), BackendInitialize(), bqarr_in(), brin_bloom_summary_out(), brin_desc(), brin_minmax_multi_summary_out(), btree_desc(), build_tuplestore_recursively(), BuildIndexValueDescription(), BuildParamLogString(), checkSharedDependencies(), clog_desc(), commit_ts_desc(), copy_table(), create_cursor(), database_to_xml_internal(), datum_to_json(), dbase_desc(), dblink_close(), dblink_fdw_validator(), dblink_fetch(), dblink_open(), DeadLockReport(), decompile_column_index_array(), deparseAnalyzeSizeSql(), deparseArrayExpr(), deparseBoolExpr(), deparseColumnRef(), deparseConst(), deparseDirectDeleteSql(), deparseDirectUpdateSql(), deparseFromExprForRel(), deparseFuncExpr(), deparseInsertSql(), deparseLockingClause(), deparseOperatorName(), deparseRangeTblRef(), deparseRelabelType(), deparseRelation(), deparseScalarArrayOpExpr(), deparseSortGroupClause(), deparseTruncateSql(), deparseUpdateSql(), deparseVar(), desc_recompress_leaf(), DescribeLockTag(), do_analyze_rel(), do_pg_start_backup(), escape_json(), ExecBuildSlotPartitionKeyDescription(), ExecEvalXmlExpr(), execute_extension_script(), ExplainIndexScanDetails(), ExplainNode(), ExplainOpenGroup(), ExplainOpenWorker(), ExplainPrintJIT(), ExplainPrintSettings(), ExplainProperty(), ExplainPropertyList(), ExplainTargetRel(), ExportSnapshot(), fetch_remote_table_info(), file_fdw_validator(), flatten_set_variable_args(), format_expr_params(), format_node_dump(), format_operator_extended(), format_preparedparamsdata(), format_procedure_extended(), FreePageManagerDump(), FreePageManagerDumpBtree(), FreePageManagerDumpSpans(), fsm_page_contents(), funcname_signature_string(), generate_operator_clause(), generate_operator_name(), generic_desc(), get_agg_expr(), get_coercion_expr(), get_connect_string(), get_const_collation(), get_const_expr(), get_delete_query_def(), get_from_clause_coldeflist(), get_from_clause_item(), get_func_expr(), get_func_sql_syntax(), get_insert_query_def(), get_opclass_name(), get_oper_expr(), get_parameter(), get_reloptions(), get_rule_expr(), get_rule_expr_funccall(), get_rule_orderby(), get_rule_sortgroupclause(), get_rule_windowclause(), get_select_query_def(), get_sql_delete(), get_sql_insert(), get_sql_update(), get_sublink_expr(), get_tablefunc(), get_tablesample_def(), get_target_list(), get_tuple_of_interest(), get_update_query_def(), get_utility_query_def(), get_variable(), get_windowfunc_expr(), get_with_clause(), getObjectDescription(), getObjectIdentityParts(), getOpFamilyDescription(), getOpFamilyIdentity(), getRelationDescription(), gin_desc(), hash_desc(), heap2_desc(), heap_desc(), heap_vacuum_rel(), incompatible_module_error(), initialize_worker_spi(), KnownAssignedXidsDisplay(), lazy_scan_heap(), libpqrcv_create_slot(), libpqrcv_startstreaming(), log_line_prefix(), logicalmsg_desc(), logicalrep_report_missing_attrs(), LogRecoveryConflict(), make_ruledef(), make_temptable_name_n(), map_multipart_sql_identifier_to_xml_name(), map_sql_catalog_to_xmlschema_types(), map_sql_identifier_to_xml_name(), map_sql_schema_to_xmlschema_types(), map_sql_table_to_xmlschema(), map_sql_type_to_xml_name(), map_sql_type_to_xmlschema_type(), map_sql_typecoll_to_xmlschema_types(), multixact_desc(), mxid_to_string(), op_signature_string(), out_gistxlogDelete(), out_gistxlogPageDelete(), out_gistxlogPageReuse(), out_gistxlogPageSplit(), out_member(), outBitmapset(), outDatum(), packArcInfoCmp(), pair_encode(), PerformAuthentication(), pg_decode_commit_prepared_txn(), pg_decode_commit_txn(), pg_decode_message(), pg_decode_prepare_txn(), pg_decode_rollback_prepared_txn(), pg_decode_stream_abort(), pg_decode_stream_change(), pg_decode_stream_commit(), pg_decode_stream_message(), pg_decode_stream_prepare(), pg_decode_stream_stop(), pg_decode_stream_truncate(), pg_dependencies_out(), pg_get_constraintdef_worker(), pg_get_functiondef(), pg_get_indexdef_worker(), pg_get_partkeydef_worker(), pg_get_statisticsobj_worker(), pg_get_triggerdef_worker(), pg_ndistinct_out(), pg_output_begin(), pg_output_stream_start(), pg_snapshot_out(), pgp_armor_encode(), PLy_traceback(), populate_array_report_expected_array(), postgres_fdw_validator(), postgresAcquireSampleRowsFunc(), postgresExplainForeignScan(), postgresImportForeignSchema(), postgresql_fdw_validator(), pretty_format_node_dump(), print_function_arguments(), print_function_trftypes(), print_literal(), printJsonPathItem(), printRemoteParam(), printRemotePlaceholder(), process_queued_fetch_requests(), processIndirection(), ProcSleep(), query_to_xml_internal(), quote_object_name(), quote_qualified_identifier(), rebuildInsertSql(), refresh_by_match_merge(), relmap_desc(), ReplicationSlotDropAtPubNode(), replorigin_desc(), report_triggers(), reportDependentObjects(), ri_Check_Pk_Match(), RI_FKey_cascade_del(), RI_FKey_cascade_upd(), RI_FKey_check(), ri_GenerateQual(), ri_GenerateQualCollation(), RI_Initial_Check(), RI_PartitionRemove_Check(), ri_restrict(), ri_set(), schema_get_xml_visible_tables(), schema_to_xml_internal(), send_message_to_frontend(), send_message_to_server_log(), sepgsql_attribute_post_create(), sepgsql_audit_log(), sepgsql_proc_post_create(), sepgsql_relation_post_create(), sepgsql_schema_post_create(), seq_desc(), serialize_deflist(), set_backtrace(), show_buffer_usage(), show_hash_info(), show_hashagg_info(), show_incremental_sort_group_info(), show_resultcache_info(), show_sort_info(), show_sortorder_options(), show_tablesample(), show_tidbitmap_info(), show_wal_usage(), ShowTransactionStateRec(), ShowUsage(), smgr_desc(), spg_desc(), SPI_sql_row_to_xmlelement(), standby_desc(), standby_desc_invalidations(), standby_desc_running_xacts(), StartupXLOG(), storeObjectDescription(), table_to_xml_internal(), tblspc_desc(), write_csvlog(), xact_desc(), xact_desc_abort(), xact_desc_assignment(), xact_desc_commit(), xact_desc_prepare(), xact_desc_relations(), xact_desc_subxacts(), xlog_block_info(), xlog_desc(), xlog_outdesc(), xlog_redo(), XLogInsertRecord(), xml_is_document(), xmldata_root_element_end(), xmldata_root_element_start(), xmlpi(), xpath_table(), and xsd_schema_element_start().
void appendStringInfoChar | ( | StringInfo | str, |
char | ch | ||
) |
Definition at line 188 of file stringinfo.c.
References StringInfoData::data, enlargeStringInfo(), StringInfoData::len, and StringInfoData::maxlen.
Referenced by _outAExpr(), _outList(), _outValue(), AddFileToBackupManifest(), appendConditions(), appendContextKeyword(), appendStringInfoRegexpSubstr(), appendTypeNameToBuffer(), array_dim_to_json(), auth_peer(), brin_bloom_summary_out(), brin_minmax_multi_summary_out(), brin_page_items(), BuildIndexValueDescription(), BuildRestoreCommand(), CheckSCRAMAuth(), circle_out(), composite_to_json(), cube_out(), cursor_to_xml(), database_to_xml_internal(), DeadLockReport(), deparseAggref(), deparseArrayExpr(), deparseBoolExpr(), deparseColumnRef(), deparseDistinctExpr(), deparseFromExprForRel(), deparseFuncExpr(), deparseInsertSql(), deparseNullTest(), deparseOpExpr(), deparseRangeTblRef(), deparseScalarArrayOpExpr(), deparseSortGroupClause(), deparseStringLiteral(), deparseSubscriptingRef(), do_analyze_rel(), do_pg_start_backup(), escape_param_str(), exec_stmt_raise(), ExecBuildSlotPartitionKeyDescription(), ExecBuildSlotValueDescription(), ExplainBeginOutput(), ExplainCloseGroup(), ExplainJSONLineEnding(), ExplainNode(), ExplainOpenGroup(), ExplainProperty(), ExplainPropertyList(), ExplainPropertyListNested(), ExplainSeparatePlans(), ExplainXMLTag(), ExplainYAMLLineStarting(), fetch_table_list(), flattenJsonPathParseItem(), format_procedure_extended(), FreePageManagerDumpBtree(), FreePageManagerDumpSpans(), funcname_signature_string(), generate_operator_name(), get_agg_expr(), get_basic_select_query(), get_coercion_expr(), get_column_alias_list(), get_delete_query_def(), get_from_clause_coldeflist(), get_from_clause_item(), get_func_expr(), get_func_sql_syntax(), get_insert_query_def(), get_oper_expr(), get_parameter(), get_range_partbound_string(), get_rule_expr(), get_rule_expr_paren(), get_rule_groupingset(), get_rule_sortgroupclause(), get_rule_windowspec(), get_setop_query(), get_special_variable(), get_sql_insert(), get_sublink_expr(), get_tablefunc(), get_tablesample_def(), get_update_query_def(), get_update_query_targetlist_def(), get_values_def(), get_variable(), get_windowfunc_expr(), get_with_clause(), heap_vacuum_rel(), hstore_to_json(), hstore_to_json_loose(), incompatible_module_error(), InteractiveBackend(), json_agg_transfn(), json_build_array(), json_build_object(), json_lex_string(), json_object(), json_object_two_arg(), libpqrcv_startstreaming(), log_line_prefix(), make_ruledef(), make_viewdef(), merge_children(), multirange_out(), mxid_to_string(), NameListToQuotedString(), NameListToString(), outBitmapset(), outDatum(), outNode(), outToken(), packArcInfoCmp(), path_encode(), pg_be_scram_get_mechanisms(), pg_decode_change(), pg_dependencies_out(), pg_get_constraintdef_worker(), pg_get_functiondef(), pg_get_indexdef_worker(), pg_get_partkeydef_worker(), pg_get_statisticsobj_worker(), pg_get_triggerdef_worker(), pg_ndistinct_out(), pg_snapshot_out(), pg_split_opts(), pgp_armor_encode(), postgresExplainForeignScan(), postgresImportForeignSchema(), pq_send_ascii_string(), print_function_arguments(), print_function_rettype(), print_function_sqlbody(), print_function_trftypes(), print_literal(), printJsonPathItem(), printSubscripts(), process_queued_fetch_requests(), query_to_xml_internal(), range_bound_escape(), range_deparse(), range_parse_bound(), rebuildInsertSql(), record_in(), record_out(), reportDependentObjects(), RI_Initial_Check(), RI_PartitionRemove_Check(), run_ssl_passphrase_command(), schema_to_xml_internal(), send_message_to_frontend(), send_message_to_server_log(), sepgsql_proc_post_create(), serialize_deflist(), show_buffer_usage(), show_hashagg_info(), show_incremental_sort_info(), show_modifytable_info(), show_tablesample(), show_tidbitmap_info(), show_wal_usage(), simple_quote_literal(), SPI_sql_row_to_xmlelement(), storeObjectDescription(), stringlist_to_identifierstr(), tuple_to_stringinfo(), TypeNameListToString(), unistr(), uuid_out(), write_csvlog(), xlog_outdesc(), xml_is_document(), and xmlpi().
void appendStringInfoSpaces | ( | StringInfo | str, |
int | count | ||
) |
Definition at line 206 of file stringinfo.c.
References StringInfoData::data, enlargeStringInfo(), and StringInfoData::len.
Referenced by appendContextKeyword(), ExplainCloseGroup(), ExplainDummyGroup(), ExplainIndentText(), ExplainOpenGroup(), ExplainProperty(), ExplainPropertyList(), ExplainPropertyListNested(), ExplainXMLTag(), ExplainYAMLLineStarting(), flattenJsonPathParseItem(), jsonPathFromCstring(), log_line_prefix(), merge_children(), show_incremental_sort_group_info(), and text_format_append_string().
void appendStringInfoString | ( | StringInfo | str, |
const char * | s | ||
) |
Definition at line 176 of file stringinfo.c.
References appendBinaryStringInfo().
Referenced by _outAConst(), _outAExpr(), _outBoolExpr(), _outConst(), _outConstraint(), _outCustomPath(), _outCustomScan(), _outForeignKeyOptInfo(), _outPathInfo(), _outPathTarget(), _outQuery(), _outValue(), AddFileToBackupManifest(), appendAggOrderBy(), appendConditions(), appendContextKeyword(), appendFunctionName(), appendGroupByClause(), appendLimitClause(), appendOrderByClause(), appendTypeNameToBuffer(), array_dim_to_json(), array_to_json_internal(), array_to_text_internal(), auth_peer(), brin_page_items(), build_tuplestore_recursively(), BuildIndexValueDescription(), BuildParamLogString(), BuildRestoreCommand(), composite_to_json(), concat_internal(), config_enum_get_options(), copy_table(), cube_out(), database_to_xmlschema_internal(), datum_to_json(), dbase_desc(), decompile_column_index_array(), deparseAggref(), deparseAnalyzeSizeSql(), deparseAnalyzeSql(), deparseArrayExpr(), deparseBoolExpr(), deparseColumnRef(), deparseConst(), deparseDeleteSql(), deparseDirectDeleteSql(), deparseDirectUpdateSql(), deparseDistinctExpr(), deparseExplicitTargetList(), deparseFromExpr(), deparseFromExprForRel(), deparseFuncExpr(), deparseInsertSql(), deparseLockingClause(), deparseNullTest(), deparseOperatorName(), deparseRangeTblRef(), deparseSelectSql(), deparseSelectStmtForRel(), deparseSubqueryTargetList(), deparseTargetList(), deparseTruncateSql(), deparseUpdateSql(), do_analyze_rel(), ecpg_start_test(), escape_json(), escape_xml(), estimate_path_cost_size(), exec_stmt_raise(), ExecBuildSlotPartitionKeyDescription(), ExecBuildSlotValueDescription(), execute_extension_script(), ExplainBeginOutput(), ExplainDummyGroup(), ExplainEndOutput(), ExplainFlushWorkersState(), ExplainIndexScanDetails(), ExplainNode(), ExplainOneUtility(), ExplainOpenGroup(), ExplainPrintJIT(), ExplainPrintSettings(), ExplainProperty(), ExplainPropertyList(), ExplainPropertyListNested(), ExplainQuery(), ExplainTargetRel(), ExplainXMLTag(), ExportSnapshot(), fetch_table_list(), flatten_set_variable_args(), format_expr_params(), format_operator_extended(), format_preparedparamsdata(), format_procedure_extended(), FreePageManagerDump(), funcname_signature_string(), generate_operator_clause(), generate_operator_name(), get_agg_expr(), get_basic_select_query(), get_column_alias_list(), get_const_expr(), get_from_clause(), get_from_clause_coldeflist(), get_from_clause_item(), get_func_expr(), get_func_sql_syntax(), get_insert_query_def(), get_parameter(), get_query_def(), get_range_partbound_string(), get_reloptions(), get_rule_expr(), get_rule_expr_funccall(), get_rule_groupingset(), get_rule_orderby(), get_rule_windowclause(), get_rule_windowspec(), get_select_query_def(), get_setop_query(), get_sql_delete(), get_sql_insert(), get_sql_update(), get_sublink_expr(), get_tablefunc(), get_tablesample_def(), get_target_list(), get_tuple_of_interest(), get_update_query_def(), get_update_query_targetlist_def(), get_utility_query_def(), get_values_def(), get_variable(), get_windowfunc_expr(), get_with_clause(), getConstraintTypeDescription(), getObjectIdentityParts(), getObjectTypeDescription(), getProcedureTypeDescription(), getRelationIdentity(), getRelationTypeDescription(), gin_desc(), heap_desc(), heap_vacuum_rel(), hstore_to_json(), hstore_to_json_loose(), incompatible_module_error(), json_agg_transfn(), json_build_array(), json_build_object(), json_lex_string(), json_object(), json_object_agg_transfn(), json_object_two_arg(), jsonb_put_escaped_value(), libpqrcv_create_slot(), libpqrcv_startstreaming(), log_line_prefix(), make_ruledef(), make_temptable_name_n(), map_multipart_sql_identifier_to_xml_name(), map_sql_catalog_to_xmlschema_types(), map_sql_identifier_to_xml_name(), map_sql_schema_to_xmlschema_types(), map_sql_table_to_xmlschema(), map_sql_type_to_xml_name(), map_sql_type_to_xmlschema_type(), map_sql_value_to_xml_value(), map_xml_name_to_sql_identifier(), multirange_out(), NameListToQuotedString(), NameListToString(), op_signature_string(), out_infobits(), out_member(), outDatum(), outNode(), outToken(), packArcInfoCmp(), pg_be_scram_get_mechanisms(), pg_decode_change(), pg_decode_commit_txn(), pg_decode_stream_abort(), pg_decode_stream_change(), pg_decode_stream_commit(), pg_decode_stream_stop(), pg_decode_stream_truncate(), pg_decode_truncate(), pg_dependencies_out(), pg_extension_update_paths(), pg_get_constraintdef_worker(), pg_get_functiondef(), pg_get_indexdef_worker(), pg_get_partkeydef_worker(), pg_get_statisticsobj_worker(), pg_get_triggerdef_worker(), pg_ndistinct_out(), pg_output_begin(), pg_output_stream_start(), pgp_armor_encode(), PLy_traceback(), postgresExplainForeignScan(), postgresImportForeignSchema(), print_function_arguments(), print_function_rettype(), print_function_sqlbody(), print_function_trftypes(), print_literal(), printJsonPathItem(), quote_object_name(), quote_qualified_identifier(), range_deparse(), rebuildInsertSql(), refresh_by_match_merge(), replace_string(), report_triggers(), ri_Check_Pk_Match(), RI_FKey_check(), RI_Initial_Check(), RI_PartitionRemove_Check(), ri_ReportViolation(), ri_restrict(), run_ssl_passphrase_command(), schema_to_xmlschema_internal(), send_message_to_frontend(), send_message_to_server_log(), sepgsql_audit_log(), sepgsql_database_post_create(), sepgsql_proc_post_create(), serialize_deflist(), set_backtrace(), show_buffer_usage(), show_hashagg_info(), show_incremental_sort_group_info(), show_modifytable_info(), show_resultcache_info(), show_sort_group_keys(), show_sortorder_options(), show_tablesample(), show_tidbitmap_info(), show_wal_usage(), ShowUsage(), single_encode(), smgr_desc(), sn_scalar(), spg_desc(), SPI_sql_row_to_xmlelement(), standby_desc_invalidations(), standby_desc_running_xacts(), StartupXLOG(), stringlist_to_identifierstr(), text_format_append_string(), transform_string_values_scalar(), tuple_to_stringinfo(), unistr(), write_auto_conf_file(), write_csvlog(), xact_desc_abort(), xact_desc_assignment(), xact_desc_commit(), xact_desc_prepare(), xact_desc_subxacts(), xlog_block_info(), xlog_desc(), xlog_outdesc(), XLogInsertRecord(), xml_is_document(), xml_out_internal(), xmlcomment(), xmlconcat(), xmldata_root_element_start(), xmlpi(), xmlroot(), xsd_schema_element_end(), and xsd_schema_element_start().
int appendStringInfoVA | ( | StringInfo | str, |
const char * | fmt, | ||
va_list | args | ||
) |
Definition at line 133 of file stringinfo.c.
References Assert, StringInfoData::data, StringInfoData::len, StringInfoData::maxlen, and pvsnprintf().
Referenced by appendStringInfo(), and PLy_elog_impl().
void enlargeStringInfo | ( | StringInfo | str, |
int | needed | ||
) |
Definition at line 283 of file stringinfo.c.
References _, StringInfoData::data, elog, ereport, errcode(), errdetail(), errmsg(), ERROR, EXIT_FAILURE, fprintf, StringInfoData::len, MaxAllocSize, StringInfoData::maxlen, and repalloc().
Referenced by AddFileToBackupManifest(), appendBinaryStringInfo(), appendBinaryStringInfoNT(), appendStringInfo(), appendStringInfoChar(), appendStringInfoSpaces(), CopyReadAttributesCSV(), CopyReadAttributesText(), CopyReadBinaryAttribute(), JsonbToCStringWorker(), jsonPathFromCstring(), jsonPathToCstring(), logicalrep_write_tuple(), pg_get_line_append(), pgp_armor_decode(), pgp_armor_encode(), PLy_elog_impl(), pq_getmessage(), pq_sendint16(), pq_sendint32(), pq_sendint64(), pq_sendint8(), read_binary_file(), reserveFromBuffer(), SendRowDescriptionMessage(), and XLogSendPhysical().
void initStringInfo | ( | StringInfo | str | ) |
Definition at line 59 of file stringinfo.c.
References StringInfoData::data, StringInfoData::maxlen, palloc(), and resetStringInfo().
Referenced by AddFileToBackupManifest(), apply_handle_stream_commit(), array_to_text_internal(), auth_peer(), BackendInitialize(), BeginCopyFrom(), bind_param_error_callback(), bmsToString(), bqarr_in(), brin_bloom_summary_out(), brin_minmax_multi_summary_out(), brin_page_items(), build_tuplestore_recursively(), BuildIndexValueDescription(), BuildParamLogString(), BuildRestoreCommand(), CheckSCRAMAuth(), checkSharedDependencies(), circle_out(), concat_internal(), config_enum_get_options(), convert_sourcefiles_in(), convertToJsonb(), copy_table(), create_cursor(), cube_out(), cursor_to_xml(), dblink_close(), dblink_fdw_validator(), dblink_fetch(), dblink_open(), DeadLockReport(), deparse_expression_pretty(), deparseAnalyzeSizeSql(), deparseFromExprForRel(), do_analyze_rel(), do_pg_start_backup(), ecpg_filter_source(), ecpg_filter_stderr(), ecpg_start_test(), escape_param_str(), escape_xml(), estimate_path_cost_size(), exec_replication_command(), exec_stmt_raise(), ExecBuildSlotPartitionKeyDescription(), ExecBuildSlotValueDescription(), ExecEvalXmlExpr(), execute_extension_script(), execute_foreign_modify(), ExplainOpenWorker(), ExplainPrintSettings(), ExportSnapshot(), fetch_remote_table_info(), fetch_table_list(), file_fdw_validator(), flatten_reloptions(), flatten_set_variable_args(), format_expr_params(), format_node_dump(), format_operator_extended(), format_preparedparamsdata(), format_procedure_extended(), FreePageManagerDump(), fsm_page_contents(), funcname_signature_string(), generate_opclass_name(), generate_operator_name(), get_connect_string(), get_from_clause(), get_sql_delete(), get_sql_insert(), get_sql_update(), get_target_list(), get_tuple_of_interest(), getObjectDescription(), getObjectIdentityParts(), getObjectTypeDescription(), HandleParallelMessages(), heap_vacuum_rel(), hstore_to_json(), hstore_to_json_loose(), hstore_to_jsonb_loose(), incompatible_module_error(), init_libpq_source(), initialize_worker_spi(), int8_avg_deserialize(), json_object(), json_object_two_arg(), JsonbValueAsText(), jsonpath_send(), jsonPathFromCstring(), jsonPathToCstring(), KnownAssignedXidsDisplay(), lazy_scan_heap(), libpqrcv_create_slot(), libpqrcv_startstreaming(), logicalrep_report_missing_attrs(), LogRecoveryConflict(), make_temptable_name_n(), makeStringInfo(), map_multipart_sql_identifier_to_xml_name(), map_sql_catalog_to_xmlschema_types(), map_sql_identifier_to_xml_name(), map_sql_schema_to_xmlschema_types(), map_sql_table_to_xmlschema(), map_sql_type_to_xml_name(), map_sql_type_to_xmlschema_type(), map_sql_typecoll_to_xmlschema_types(), map_sql_value_to_xml_value(), map_xml_name_to_sql_identifier(), merge_children(), multirange_out(), multirange_recv(), mxid_to_string(), NameListToQuotedString(), NameListToString(), nodeToString(), numeric_avg_deserialize(), numeric_deserialize(), numeric_poly_deserialize(), op_signature_string(), packArcInfoCmp(), parse_fcall_arguments(), parseServiceFile(), path_encode(), PerformAuthentication(), pg_armor(), pg_dearmor(), pg_dependencies_out(), pg_extension_update_paths(), pg_get_constraintdef_worker(), pg_get_function_arguments(), pg_get_function_identity_arguments(), pg_get_function_result(), pg_get_function_sqlbody(), pg_get_functiondef(), pg_get_indexdef_worker(), pg_get_line(), pg_get_partkeydef_worker(), pg_get_ruledef_worker(), pg_get_statisticsobj_worker(), pg_get_triggerdef_worker(), pg_get_viewdef_worker(), pg_ndistinct_out(), pg_snapshot_out(), pg_split_opts(), PLy_elog_impl(), PLy_traceback(), populate_array_report_expected_array(), populate_scalar(), postgres_fdw_validator(), postgresAcquireSampleRowsFunc(), postgresAnalyzeForeignTable(), postgresBeginForeignInsert(), postgresExecForeignTruncate(), postgresGetForeignPlan(), postgresImportForeignSchema(), PostgresMain(), postgresPlanDirectModify(), postgresPlanForeignModify(), postgresql_fdw_validator(), pq_beginmessage(), pq_begintypsend(), pretty_format_node_dump(), print_function_rettype(), printtup_startup(), process_pipe_input(), ProcSleep(), quote_object_name(), quote_qualified_identifier(), range_bound_escape(), range_deparse(), range_parse_bound(), range_recv(), read_binary_file(), readfile(), record_in(), record_out(), recv_password_packet(), refresh_by_match_merge(), replace_text(), replace_text_regexp(), ReplicationSlotDropAtPubNode(), reportDependentObjects(), ri_Check_Pk_Match(), RI_FKey_cascade_del(), RI_FKey_cascade_upd(), RI_FKey_check(), RI_Initial_Check(), RI_PartitionRemove_Check(), ri_ReportViolation(), ri_restrict(), ri_set(), rm_redo_error_callback(), run_ssl_passphrase_command(), schema_get_xml_visible_tables(), send_message_to_frontend(), send_message_to_server_log(), sepgsql_attribute_post_create(), sepgsql_audit_log(), sepgsql_database_post_create(), sepgsql_proc_post_create(), sepgsql_relation_post_create(), sepgsql_schema_post_create(), serialize_deflist(), set_backtrace(), show_incremental_sort_group_info(), show_resultcache_info(), show_sort_group_keys(), ShowTransactionStateRec(), ShowUsage(), SortTocFromFile(), StartupXLOG(), stringlist_to_identifierstr(), table_to_xml_internal(), text_format(), tokenize_file(), tsearch_readline_begin(), TypeNameListToString(), TypeNameToString(), unaccent_lexize(), unistr(), uuid_out(), WalReceiverMain(), write_auto_conf_file(), write_csvlog(), XLogDumpDisplayRecord(), XLogInsertRecord(), xml_is_document(), xml_out_internal(), xmlcomment(), xmlconcat(), xmlpi(), xmlroot(), XmlTableGetValue(), and xpath_table().
StringInfo makeStringInfo | ( | void | ) |
Definition at line 41 of file stringinfo.c.
References initStringInfo(), and palloc().
Referenced by array_to_json(), array_to_json_pretty(), buf_init(), copy_table(), database_to_xml_internal(), database_to_xmlschema_internal(), do_pg_start_backup(), DoCopyTo(), get_range_partbound_string(), json_agg_transfn(), json_build_array(), json_build_object(), json_object_agg_transfn(), json_strip_nulls(), jsonb_pretty(), jsonb_send(), JsonbToCStringWorker(), makeJsonLexContextCstringLen(), makeStringAggState(), multirange_send(), NewExplainState(), perform_base_backup(), pg_start_backup(), postgresExplainForeignScan(), query_to_xml_internal(), range_send(), ReceiveCopyBegin(), row_to_json(), row_to_json_pretty(), schema_to_xml_internal(), schema_to_xmlschema_internal(), send_feedback(), StartupDecodingContext(), to_json(), transform_json_string_values(), triggered_change_notification(), and xml_is_document().
void resetStringInfo | ( | StringInfo | str | ) |
Definition at line 75 of file stringinfo.c.
References StringInfoData::cursor, StringInfoData::data, and StringInfoData::len.
Referenced by apply_handle_stream_commit(), build_tuplestore_recursively(), CopyReadAttributesCSV(), CopyReadAttributesText(), CopyReadBinaryAttribute(), CopyReadLine(), CopySendEndOfRow(), DeadLockReport(), fetch_remote_table_info(), get_target_list(), hstore_to_json(), hstore_to_json_loose(), hstore_to_jsonb_loose(), initialize_worker_spi(), initStringInfo(), InteractiveBackend(), json_lex_string(), LogicalOutputPrepareWrite(), multirange_recv(), parse_fcall_arguments(), pg_get_line_buf(), pg_split_opts(), postgresImportForeignSchema(), pq_beginmessage_reuse(), pq_getmessage(), print_function_rettype(), process_queued_fetch_requests(), ProcessRepliesIfAny(), record_in(), refresh_by_match_merge(), send_feedback(), sepgsql_database_post_create(), sepgsql_relation_post_create(), show_sort_group_keys(), tokenize_file(), WalSndKeepalive(), WalSndPrepareWrite(), WalSndWriteData(), write_auto_conf_file(), XLogSendPhysical(), XLogWalRcvProcessMsg(), XLogWalRcvSendHSFeedback(), and XLogWalRcvSendReply().