[][src]Crate pulsar_sys

Structs

__fsid_t
_pulsar_authentication
_pulsar_client
_pulsar_client_configuration
_pulsar_consumer
_pulsar_consumer_configuration
_pulsar_message
_pulsar_message_id
_pulsar_producer
_pulsar_producer_configuration
_pulsar_reader
_pulsar_reader_configuration
_pulsar_string_list
_pulsar_string_map
_pulsar_topic_metadata
max_align_t

Constants

INT8_MAX
INT8_MIN
INT16_MAX
INT16_MIN
INT32_MAX
INT32_MIN
INTPTR_MAX
INTPTR_MIN
INT_FAST8_MAX
INT_FAST8_MIN
INT_FAST16_MAX
INT_FAST16_MIN
INT_FAST32_MAX
INT_FAST32_MIN
INT_LEAST8_MAX
INT_LEAST8_MIN
INT_LEAST16_MAX
INT_LEAST16_MIN
INT_LEAST32_MAX
INT_LEAST32_MIN
PTRDIFF_MAX
PTRDIFF_MIN
SIG_ATOMIC_MAX
SIG_ATOMIC_MIN
SIZE_MAX
UINT8_MAX
UINT16_MAX
UINT32_MAX
UINTPTR_MAX
UINT_FAST8_MAX
UINT_FAST16_MAX
UINT_FAST32_MAX
UINT_LEAST8_MAX
UINT_LEAST16_MAX
UINT_LEAST32_MAX
WINT_MAX
WINT_MIN
_ATFILE_SOURCE
_BITS_STDINT_INTN_H
_BITS_STDINT_UINTN_H
_BITS_TIME64_H
_BITS_TYPESIZES_H
_BITS_TYPES_H
_BITS_WCHAR_H
_DEFAULT_SOURCE
_FEATURES_H
_POSIX_C_SOURCE
_POSIX_SOURCE
_STDC_PREDEF_H
_STDINT_H
_SYS_CDEFS_H
__FD_SETSIZE
__GLIBC_MINOR__
__GLIBC_USE_DEPRECATED_GETS
__GLIBC_USE_DEPRECATED_SCANF
__GLIBC_USE_IEC_60559_BFP_EXT
__GLIBC_USE_IEC_60559_BFP_EXT_C2X
__GLIBC_USE_IEC_60559_FUNCS_EXT
__GLIBC_USE_IEC_60559_FUNCS_EXT_C2X
__GLIBC_USE_IEC_60559_TYPES_EXT
__GLIBC_USE_ISOC2X
__GLIBC_USE_LIB_EXT2
__GLIBC__
__GNU_LIBRARY__
__HAVE_GENERIC_SELECTION
__INO_T_MATCHES_INO64_T
__LONG_DOUBLE_USES_FLOAT128
__OFF_T_MATCHES_OFF64_T
__RLIM_T_MATCHES_RLIM64_T
__STATFS_MATCHES_STATFS64
__STDC_IEC_559_COMPLEX__
__STDC_IEC_559__
__STDC_ISO_10646__
__SYSCALL_WORDSIZE
__TIMESIZE
__USE_ATFILE
__USE_FORTIFY_LEVEL
__USE_ISOC11
__USE_ISOC95
__USE_ISOC99
__USE_MISC
__USE_POSIX
__USE_POSIX2
__USE_POSIX199309
__USE_POSIX199506
__USE_POSIX_IMPLICITLY
__USE_XOPEN2K
__USE_XOPEN2K8
__WORDSIZE
__WORDSIZE_TIME64_COMPAT32
__glibc_c99_flexarr_available
initial_position_initial_position_earliest

the earliest position which means the start consuming position will be the first message

initial_position_initial_position_latest

the latest position which means the start consuming position will be the last message

pulsar_compression_type_pulsar_CompressionLZ4
pulsar_compression_type_pulsar_CompressionNone
pulsar_compression_type_pulsar_CompressionSNAPPY
pulsar_compression_type_pulsar_CompressionZLib
pulsar_compression_type_pulsar_CompressionZSTD
pulsar_consumer_type_pulsar_ConsumerExclusive

There can be only 1 consumer on the same topic with the same consumerName

pulsar_consumer_type_pulsar_ConsumerFailover

Only one consumer is active on the subscription; Subscription can have N consumers connected one of which will get promoted to master if the current master becomes inactive

pulsar_consumer_type_pulsar_ConsumerKeyShared

Multiple consumer will be able to use the same subscription and all messages with the same key will be dispatched to only one consumer

pulsar_consumer_type_pulsar_ConsumerShared

Multiple consumers will be able to use the same consumerName and the messages will be dispatched according to a round-robin rotation between the connected consumers

pulsar_hashing_scheme_pulsar_BoostHash
pulsar_hashing_scheme_pulsar_JavaStringHash
pulsar_hashing_scheme_pulsar_Murmur3_32Hash
pulsar_logger_level_t_pulsar_DEBUG
pulsar_logger_level_t_pulsar_ERROR
pulsar_logger_level_t_pulsar_INFO
pulsar_logger_level_t_pulsar_WARN
pulsar_partitions_routing_mode_pulsar_CustomPartition
pulsar_partitions_routing_mode_pulsar_RoundRobinDistribution
pulsar_partitions_routing_mode_pulsar_UseSinglePartition
pulsar_result_pulsar_result_AlreadyClosed

Producer/Consumer is not currently connected to broker

pulsar_result_pulsar_result_AuthenticationError

Failed to read from socket

pulsar_result_pulsar_result_AuthorizationError

Authentication failed on broker

pulsar_result_pulsar_result_BrokerMetadataError

Client cannot find authorization data

pulsar_result_pulsar_result_BrokerPersistenceError

Broker failed in updating metadata

pulsar_result_pulsar_result_ChecksumError

Broker failed to persist entry

pulsar_result_pulsar_result_ConnectError

Broker lookup failed

pulsar_result_pulsar_result_ConsumerBusy

Corrupt message checksum failure

pulsar_result_pulsar_result_ConsumerNotFound

Subscription not found

pulsar_result_pulsar_result_ConsumerNotInitialized

Error in publishing an already used message

pulsar_result_pulsar_result_CryptoError

Topic was already terminated

pulsar_result_pulsar_result_ErrorGettingAuthenticationData

Client is not authorized to create producer/consumer

pulsar_result_pulsar_result_InvalidConfiguration

Unknown error happened on broker

pulsar_result_pulsar_result_InvalidMessage

Producer/Consumer is already closed and not accepting any operation

pulsar_result_pulsar_result_InvalidTopicName

Too Many concurrent LookupRequest

pulsar_result_pulsar_result_InvalidUrl

Invalid topic name

pulsar_result_pulsar_result_LookupError

Operation timed out

pulsar_result_pulsar_result_MessageTooBig

Producer queue is full

pulsar_result_pulsar_result_NotConnected

Exclusive consumer is already connected

pulsar_result_pulsar_result_Ok
pulsar_result_pulsar_result_OperationNotSupported

Service Unit unloaded between client did lookup and producer/consumer got created

pulsar_result_pulsar_result_ProducerBlockedQuotaExceededError

Service Unit unloaded between client did lookup and producer/consumer got created

pulsar_result_pulsar_result_ProducerBlockedQuotaExceededException

Producer is blocked

pulsar_result_pulsar_result_ProducerNotInitialized

Consumer is not initialized

pulsar_result_pulsar_result_ProducerQueueIsFull

Producer is getting exception

pulsar_result_pulsar_result_ReadError

Failed to connect to broker

pulsar_result_pulsar_result_ServiceUnitNotReady

Client Initialized with Invalid Broker Url (VIP Url passed to Client Constructor)

pulsar_result_pulsar_result_SubscriptionNotFound

Topic not found

pulsar_result_pulsar_result_Timeout

Invalid configuration

pulsar_result_pulsar_result_TooManyLookupRequestException

Producer is not initialized

pulsar_result_pulsar_result_TopicNotFound

Trying to send a messages exceeding the max size

pulsar_result_pulsar_result_TopicTerminated

Error when an older client/version doesn't support a required feature

pulsar_result_pulsar_result_UnknownError

Operation successful

pulsar_result_pulsar_result_UnsupportedVersionError

Consumer not found

pulsar_schema_type_pulsar_AutoConsume
pulsar_schema_type_pulsar_AutoPublish
pulsar_schema_type_pulsar_Avro
pulsar_schema_type_pulsar_Boolean
pulsar_schema_type_pulsar_Bytes
pulsar_schema_type_pulsar_Float32
pulsar_schema_type_pulsar_Float64
pulsar_schema_type_pulsar_Int8
pulsar_schema_type_pulsar_Int16
pulsar_schema_type_pulsar_Int32
pulsar_schema_type_pulsar_Int64
pulsar_schema_type_pulsar_Json
pulsar_schema_type_pulsar_KeyValue
pulsar_schema_type_pulsar_None
pulsar_schema_type_pulsar_Protobuf
pulsar_schema_type_pulsar_String

Functions

pulsar_authentication_athenz_create
pulsar_authentication_create
pulsar_authentication_free
pulsar_authentication_oauth2_create
pulsar_authentication_tls_create
pulsar_authentication_token_create
pulsar_authentication_token_create_with_supplier
pulsar_client_close
pulsar_client_close_async
pulsar_client_configuration_create
pulsar_client_configuration_free
pulsar_client_configuration_get_concurrent_lookup_request

@return Get configured total allowed concurrent lookup-request.

pulsar_client_configuration_get_io_threads

@return the number of IO threads to use

pulsar_client_configuration_get_message_listener_threads

@return the number of IO threads to use

pulsar_client_configuration_get_operation_timeout_seconds

@return the client operations timeout in seconds

pulsar_client_configuration_get_stats_interval_in_seconds
pulsar_client_configuration_get_tls_trust_certs_file_path
pulsar_client_configuration_is_tls_allow_insecure_connection
pulsar_client_configuration_is_use_tls
pulsar_client_configuration_is_validate_hostname
pulsar_client_configuration_set_auth

Set the authentication method to be used with the broker

pulsar_client_configuration_set_concurrent_lookup_request

Number of concurrent lookup-requests allowed on each broker-connection to prevent overload on broker. (default: 50000) It should be configured with higher value only in case of it requires to produce/subscribe on thousands of topic using created {@link PulsarClient}

pulsar_client_configuration_set_io_threads

Set the number of IO threads to be used by the Pulsar client. Default is 1 thread.

pulsar_client_configuration_set_logger
pulsar_client_configuration_set_message_listener_threads

Set the number of threads to be used by the Pulsar client when delivering messages through message listener. Default is 1 thread per Pulsar client.

pulsar_client_configuration_set_operation_timeout_seconds

Set timeout on client operations (subscribe, create producer, close, unsubscribe) Default is 30 seconds.

pulsar_client_configuration_set_stats_interval_in_seconds
pulsar_client_configuration_set_tls_allow_insecure_connection
pulsar_client_configuration_set_tls_trust_certs_file_path
pulsar_client_configuration_set_use_tls
pulsar_client_configuration_set_validate_hostname
pulsar_client_create

Create a Pulsar client object connecting to the specified cluster address and using the specified configuration.

pulsar_client_create_producer

Create a producer with default configuration

pulsar_client_create_producer_async
pulsar_client_create_reader

Create a topic reader with given {@code ReaderConfiguration} for reading messages from the specified topic.

pulsar_client_create_reader_async
pulsar_client_free
pulsar_client_get_topic_partitions
pulsar_client_get_topic_partitions_async
pulsar_client_subscribe
pulsar_client_subscribe_async
pulsar_client_subscribe_multi_topics_async
pulsar_client_subscribe_pattern_async
pulsar_configure_get_ack_grouping_max_size

Get max number of grouped messages within one grouping time window.

pulsar_configure_get_ack_grouping_time_ms

Get grouping time window in milliseconds.

pulsar_configure_get_negative_ack_redelivery_delay_ms

Get the configured delay to wait before re-delivering messages that have failed to be process.

pulsar_configure_set_ack_grouping_max_size

Set max number of grouped messages within one grouping time window. If it's set to a non-positive value, number of grouped messages is not limited. Default is 1000.

pulsar_configure_set_ack_grouping_time_ms

Set time window in milliseconds for grouping message ACK requests. An ACK request is not sent to broker until the time window reaches its end, or the number of grouped messages reaches limit. Default is 100 milliseconds. If it's set to a non-positive value, ACK requests will be directly sent to broker without grouping.

pulsar_configure_set_negative_ack_redelivery_delay_ms

Set the delay to wait before re-delivering messages that have failed to be process.

pulsar_consumer_acknowledge

Acknowledge the reception of a single message.

pulsar_consumer_acknowledge_async

Asynchronously acknowledge the reception of a single message.

pulsar_consumer_acknowledge_async_id
pulsar_consumer_acknowledge_cumulative

Acknowledge the reception of all the messages in the stream up to (and including) the provided message.

pulsar_consumer_acknowledge_cumulative_async

Asynchronously acknowledge the reception of all the messages in the stream up to (and including) the provided message.

pulsar_consumer_acknowledge_cumulative_async_id
pulsar_consumer_acknowledge_cumulative_id
pulsar_consumer_acknowledge_id
pulsar_consumer_close
pulsar_consumer_close_async
pulsar_consumer_configuration_create
pulsar_consumer_configuration_free
pulsar_consumer_configuration_get_consumer_type
pulsar_consumer_configuration_get_receiver_queue_size
pulsar_consumer_configuration_has_message_listener
pulsar_consumer_configuration_set_consumer_type

Specify the consumer type. The consumer type enables specifying the type of subscription. In Exclusive subscription, only a single consumer is allowed to attach to the subscription. Other consumers will get an error message. In Shared subscription, multiple consumers will be able to use the same subscription name and the messages will be dispatched in a round robin fashion. In Failover subscription, a primary-failover subscription model allows for multiple consumers to attach to a single subscription, though only one of them will be “master” at a given time. Only the primary consumer will receive messages. When the primary consumer gets disconnected, one among the failover consumers will be promoted to primary and will start getting messages.

pulsar_consumer_configuration_set_message_listener

A message listener enables your application to configure how to process and acknowledge messages delivered. A listener will be called in order for every message received.

pulsar_consumer_configuration_set_property
pulsar_consumer_configuration_set_receiver_queue_size

Sets the size of the consumer receive queue.

pulsar_consumer_configuration_set_schema_info
pulsar_consumer_free
pulsar_consumer_get_consumer_name
pulsar_consumer_get_max_total_receiver_queue_size_across_partitions

@return the configured max total receiver queue size across partitions

pulsar_consumer_get_subscription_initial_position
pulsar_consumer_get_subscription_name

@return the consumer name

pulsar_consumer_get_topic

@return the topic this consumer is subscribed to

pulsar_consumer_get_unacked_messages_timeout_ms

@return the configured timeout in milliseconds for unacked messages.

pulsar_consumer_is_encryption_enabled
pulsar_consumer_is_read_compacted
pulsar_consumer_negative_acknowledge

Acknowledge the failure to process a single message.

pulsar_consumer_negative_acknowledge_id

Acknowledge the failure to process a single message through its message id

pulsar_consumer_pause_message_listener
pulsar_consumer_receive

Receive a single message.

pulsar_consumer_receive_with_timeout

@param msg a non-const reference where the received message will be copied @param timeoutMs the receive timeout in milliseconds @return ResultOk if a message was received @return ResultTimeout if the receive timeout was triggered @return ResultInvalidConfiguration if a message listener had been set in the configuration

pulsar_consumer_redeliver_unacknowledged_messages

Redelivers all the unacknowledged messages. In Failover mode, the request is ignored if the consumer is not active for the given topic. In Shared mode, the consumers messages to be redelivered are distributed across all the connected consumers. This is a non blocking call and doesn't throw an exception. In case the connection breaks, the messages are redelivered after reconnect.

pulsar_consumer_seek
pulsar_consumer_seek_async
pulsar_consumer_set_consumer_name
pulsar_consumer_set_max_total_receiver_queue_size_across_partitions

Set the max total receiver queue size across partitons.

pulsar_consumer_set_read_compacted
pulsar_consumer_set_subscription_initial_position
pulsar_consumer_set_unacked_messages_timeout_ms

Set the timeout in milliseconds for unacknowledged messages, the timeout needs to be greater than 10 seconds. An Exception is thrown if the given value is less than 10000 (10 seconds). If a successful acknowledgement is not sent within the timeout all the unacknowledged messages are redelivered. @param timeout in milliseconds

pulsar_consumer_unsubscribe

Unsubscribe the current consumer from the topic.

pulsar_consumer_unsubscribe_async

Asynchronously unsubscribe the current consumer from the topic.

pulsar_message_create
pulsar_message_disable_replication

Do not replicate this message @param flag if true, disable replication, otherwise use default replication

pulsar_message_free
pulsar_message_get_data

Get the content of the message

pulsar_message_get_event_timestamp

Get the event timestamp associated with this message. It is set by the client producer.

pulsar_message_get_length

Get the length of the message

pulsar_message_get_message_id

Get the unique message ID associated with this message.

pulsar_message_get_orderingKey

Get the ordering key of the message for message dispatch in Key_Shared mode. Partition key Will be used if ordering key not specified

pulsar_message_get_partitionKey

Get the partition key for this message @return key string that is hashed to determine message's topic partition

pulsar_message_get_properties

Return the properties attached to the message. Properties are application defined key/value pairs that will be attached to the message

pulsar_message_get_property

Get the value of a specific property

pulsar_message_get_publish_timestamp

Get the UTC based timestamp in milliseconds referring to when the message was published by the client producer

pulsar_message_get_redelivery_count
pulsar_message_get_schemaVersion
pulsar_message_get_topic_name
pulsar_message_has_ordering_key
pulsar_message_has_partition_key
pulsar_message_has_property

Check whether the message has a specific property attached.

pulsar_message_has_schema_version
pulsar_message_id_deserialize

Deserialize a message id from a binary string

pulsar_message_id_earliest

MessageId representing the "earliest" or "oldest available" message stored in the topic

pulsar_message_id_free
pulsar_message_id_latest

MessageId representing the "latest" or "last published" message in the topic

pulsar_message_id_serialize

Serialize the message id into a binary string for storing

pulsar_message_id_str
pulsar_message_set_allocated_content

Set content of the message to a buffer already allocated by the caller. No copies of this buffer will be made. The caller is responsible to ensure the memory buffer is valid until the message has been persisted (or an error is returned).

pulsar_message_set_content

Builder

pulsar_message_set_deliver_after

Specify a delay for the delivery of the messages.

pulsar_message_set_deliver_at

Specify the this message should not be delivered earlier than the specified timestamp.

pulsar_message_set_event_timestamp

Set the event timestamp for the message.

pulsar_message_set_ordering_key

Sets the ordering key of the message for message dispatch in Key_Shared mode. @param the ordering key for the message

pulsar_message_set_partition_key

set partition key for the message routing @param hash of this key is used to determine message's topic partition

pulsar_message_set_property
pulsar_message_set_replication_clusters

override namespace replication clusters. note that it is the caller's responsibility to provide valid cluster names, and that all clusters have been previously configured as topics.

pulsar_message_set_schema_version
pulsar_message_set_sequence_id

Specify a custom sequence id for the message being published.

pulsar_producer_close

Close the producer and release resources allocated.

pulsar_producer_close_async

Close the producer and release resources allocated.

pulsar_producer_configuration_create
pulsar_producer_configuration_free
pulsar_producer_configuration_get_batching_enabled
pulsar_producer_configuration_get_batching_max_allowed_size_in_bytes
pulsar_producer_configuration_get_batching_max_messages
pulsar_producer_configuration_get_batching_max_publish_delay_ms
pulsar_producer_configuration_get_block_if_queue_full
pulsar_producer_configuration_get_compression_type
pulsar_producer_configuration_get_hashing_scheme
pulsar_producer_configuration_get_initial_sequence_id
pulsar_producer_configuration_get_max_pending_messages
pulsar_producer_configuration_get_max_pending_messages_across_partitions

@return the maximum number of pending messages allowed across all the partitions

pulsar_producer_configuration_get_partitions_routing_mode
pulsar_producer_configuration_get_producer_name
pulsar_producer_configuration_get_send_timeout
pulsar_producer_configuration_set_batching_enabled
pulsar_producer_configuration_set_batching_max_allowed_size_in_bytes
pulsar_producer_configuration_set_batching_max_messages
pulsar_producer_configuration_set_batching_max_publish_delay_ms
pulsar_producer_configuration_set_block_if_queue_full
pulsar_producer_configuration_set_compression_type
pulsar_producer_configuration_set_hashing_scheme
pulsar_producer_configuration_set_initial_sequence_id
pulsar_producer_configuration_set_max_pending_messages
pulsar_producer_configuration_set_max_pending_messages_across_partitions

Set the number of max pending messages across all the partitions

pulsar_producer_configuration_set_message_router
pulsar_producer_configuration_set_partitions_routing_mode
pulsar_producer_configuration_set_producer_name
pulsar_producer_configuration_set_property
pulsar_producer_configuration_set_schema_info
pulsar_producer_configuration_set_send_timeout
pulsar_producer_flush
pulsar_producer_flush_async
pulsar_producer_free
pulsar_producer_get_last_sequence_id

Get the last sequence id that was published by this producer.

pulsar_producer_get_producer_name

@return the producer name which could have been assigned by the system or specified by the client

pulsar_producer_get_topic

@return the topic to which producer is publishing to

pulsar_producer_send

Publish a message on the topic associated with this Producer.

pulsar_producer_send_async

Asynchronously publish a message on the topic associated with this Producer.

pulsar_reader_close
pulsar_reader_close_async
pulsar_reader_configuration_create
pulsar_reader_configuration_free
pulsar_reader_configuration_get_reader_name
pulsar_reader_configuration_get_receiver_queue_size
pulsar_reader_configuration_get_subscription_role_prefix
pulsar_reader_configuration_has_reader_listener
pulsar_reader_configuration_is_read_compacted
pulsar_reader_configuration_set_read_compacted
pulsar_reader_configuration_set_reader_listener

A message listener enables your application to configure how to process messages. A listener will be called in order for every message received.

pulsar_reader_configuration_set_reader_name
pulsar_reader_configuration_set_receiver_queue_size

Sets the size of the reader receive queue.

pulsar_reader_configuration_set_subscription_role_prefix
pulsar_reader_free
pulsar_reader_get_topic

@return the topic this reader is reading from

pulsar_reader_has_message_available
pulsar_reader_read_next

Read a single message.

pulsar_reader_read_next_with_timeout

Read a single message

pulsar_result_str
pulsar_string_list_append
pulsar_string_list_create
pulsar_string_list_free
pulsar_string_list_get
pulsar_string_list_size
pulsar_string_map_create
pulsar_string_map_free
pulsar_string_map_get
pulsar_string_map_get_key
pulsar_string_map_get_value
pulsar_string_map_put
pulsar_string_map_size
pulsar_topic_metadata_get_num_partitions
resume_message_listener

Type Definitions

__blkcnt64_t
__blkcnt_t
__blksize_t
__caddr_t
__clock_t
__clockid_t
__daddr_t
__dev_t
__fsblkcnt64_t
__fsblkcnt_t
__fsfilcnt64_t
__fsfilcnt_t
__fsword_t
__gid_t
__id_t
__ino64_t
__ino_t
__int8_t
__int16_t
__int32_t
__int64_t
__int_least8_t
__int_least16_t
__int_least32_t
__int_least64_t
__intmax_t
__intptr_t
__key_t
__loff_t
__mode_t
__nlink_t
__off64_t
__off_t
__pid_t
__quad_t
__rlim64_t
__rlim_t
__sig_atomic_t
__socklen_t
__ssize_t
__suseconds_t
__syscall_slong_t
__syscall_ulong_t
__time_t
__timer_t
__u_char
__u_int
__u_long
__u_quad_t
__u_short
__uid_t
__uint8_t
__uint16_t
__uint32_t
__uint64_t
__uint_least8_t
__uint_least16_t
__uint_least32_t
__uint_least64_t
__uintmax_t
__useconds_t
initial_position
int_fast8_t
int_fast16_t
int_fast32_t
int_fast64_t
int_least8_t
int_least16_t
int_least32_t
int_least64_t
intmax_t
pulsar_authentication_t
pulsar_client_configuration_t
pulsar_client_t
pulsar_close_callback
pulsar_compression_type
pulsar_consumer_configuration_t
pulsar_consumer_t
pulsar_consumer_type
pulsar_create_producer_callback
pulsar_flush_callback
pulsar_get_partitions_callback
pulsar_hashing_scheme
pulsar_logger
pulsar_logger_level_t
pulsar_message_id_t
pulsar_message_listener

Callback definition for MessageListener

pulsar_message_router
pulsar_message_t
pulsar_partitions_routing_mode
pulsar_producer_configuration_t
pulsar_producer_t
pulsar_reader_callback
pulsar_reader_configuration_t
pulsar_reader_listener
pulsar_reader_t
pulsar_result
pulsar_result_callback
pulsar_schema_type
pulsar_send_callback
pulsar_string_list_t
pulsar_string_map_t
pulsar_subscribe_callback
pulsar_topic_metadata_t
size_t
token_supplier
uint_fast8_t
uint_fast16_t
uint_fast32_t
uint_fast64_t
uint_least8_t
uint_least16_t
uint_least32_t
uint_least64_t
uintmax_t
wchar_t