queue.type |
TB_QUEUE_TYPE |
kafka |
kafka (Apache Kafka) or aws-sqs (AWS SQS) or pubsub (PubSub) or service-bus (Azure Service Bus) or rabbitmq (RabbitMQ) |
queue.prefix |
TB_QUEUE_PREFIX |
|
Global queue prefix. If specified, prefix is added before default topic name: 'prefix.default_topic_name'. Prefix is applied to all topics (and consumer groups for kafka). |
queue.kafka.bootstrap.servers |
TB_KAFKA_SERVERS |
localhost:9092 |
Kafka Bootstrap Servers |
queue.kafka.ssl.enabled |
TB_KAFKA_SSL_ENABLED |
false |
Enable/Disable SSL Kafka communication |
queue.kafka.ssl.truststore.location |
TB_KAFKA_SSL_TRUSTSTORE_LOCATION |
|
The location of the trust store file |
queue.kafka.ssl.truststore.password |
TB_KAFKA_SSL_TRUSTSTORE_PASSWORD |
|
The password of trust store file if specified |
queue.kafka.ssl.keystore.location |
TB_KAFKA_SSL_KEYSTORE_LOCATION |
|
The location of the key store file. This is optional for the client and can be used for two-way authentication for the client |
queue.kafka.ssl.keystore.password |
TB_KAFKA_SSL_KEYSTORE_PASSWORD |
|
The store password for the key store file. This is optional for the client and only needed if ‘ssl.keystore.location’ is configured. Key store password is not supported for PEM format |
queue.kafka.ssl.key.password |
TB_KAFKA_SSL_KEY_PASSWORD |
|
The password of the private key in the key store file or the PEM key specified in ‘keystore.key’ |
queue.kafka.acks |
TB_KAFKA_ACKS |
all |
The number of acknowledgments the producer requires the leader to have received before considering a request complete. This controls the durability of records that are sent. The following settings are allowed:0,1 and all |
queue.kafka.retries |
TB_KAFKA_RETRIES |
1 |
Number of retries. Resend any record whose send fails with a potentially transient error |
queue.kafka.compression.type |
TB_KAFKA_COMPRESSION_TYPE |
none |
none or gzip |
queue.kafka.batch.size |
TB_KAFKA_BATCH_SIZE |
16384 |
Default batch size. This setting gives the upper bound of the batch size to be sent |
queue.kafka.linger.ms |
TB_KAFKA_LINGER_MS |
1 |
This variable creates a small amount of artificial delay—that is, rather than immediately sending out a record |
queue.kafka.max.request.size |
TB_KAFKA_MAX_REQUEST_SIZE |
1048576 |
The maximum size of a request in bytes. This setting will limit the number of record batches the producer will send in a single request to avoid sending huge requests |
queue.kafka.max.in.flight.requests.per.connection |
TB_KAFKA_MAX_IN_FLIGHT_REQUESTS_PER_CONNECTION |
5 |
The maximum number of unacknowledged requests the client will send on a single connection before blocking |
queue.kafka.buffer.memory |
TB_BUFFER_MEMORY |
33554432 |
The total bytes of memory the producer can use to buffer records waiting to be sent to the server |
queue.kafka.replication_factor |
TB_QUEUE_KAFKA_REPLICATION_FACTOR |
1 |
The multiple copies of data over the multiple brokers of Kafka |
queue.kafka.max_poll_interval_ms |
TB_QUEUE_KAFKA_MAX_POLL_INTERVAL_MS |
300000 |
The maximum delay between invocations of poll() when using consumer group management. This places an upper bound on the amount of time that the consumer can be idle before fetching more records |
queue.kafka.max_poll_records |
TB_QUEUE_KAFKA_MAX_POLL_RECORDS |
8192 |
The maximum number of records returned in a single call to poll() |
queue.kafka.max_partition_fetch_bytes |
TB_QUEUE_KAFKA_MAX_PARTITION_FETCH_BYTES |
16777216 |
The maximum amount of data per-partition the server will return. Records are fetched in batches by the consumer |
queue.kafka.fetch_max_bytes |
TB_QUEUE_KAFKA_FETCH_MAX_BYTES |
134217728 |
The maximum amount of data the server will return. Records are fetched in batches by the consumer |
queue.kafka.request.timeout.ms |
TB_QUEUE_KAFKA_REQUEST_TIMEOUT_MS |
30000 |
(30 seconds) |
queue.kafka.session.timeout.ms |
TB_QUEUE_KAFKA_SESSION_TIMEOUT_MS |
10000 |
(10 seconds) |
queue.kafka.use_confluent_cloud |
TB_QUEUE_KAFKA_USE_CONFLUENT_CLOUD |
false |
Enable/Disable using of Confluent Cloud |
queue.kafka.confluent.ssl.algorithm |
TB_QUEUE_KAFKA_CONFLUENT_SSL_ALGORITHM |
https |
The endpoint identification algorithm used by clients to validate server hostname. The default value is https |
queue.kafka.confluent.sasl.mechanism |
TB_QUEUE_KAFKA_CONFLUENT_SASL_MECHANISM |
PLAIN |
The mechanism used to authenticate Schema Registry requests. SASL/PLAIN should only be used with TLS/SSL as a transport layer to ensure that clear passwords are not transmitted on the wire without encryption |
queue.kafka.confluent.sasl.config |
TB_QUEUE_KAFKA_CONFLUENT_SASL_JAAS_CONFIG |
org.apache.kafka.common.security.plain.PlainLoginModule required username=\"CLUSTER_API_KEY\" password=\"CLUSTER_API_SECRET\"; |
Using JAAS Configuration for specifying multiple SASL mechanisms on a broker |
queue.kafka.confluent.security.protocol |
TB_QUEUE_KAFKA_CONFLUENT_SECURITY_PROTOCOL |
SASL_SSL |
Protocol used to communicate with brokers. Valid values are: PLAINTEXT, SSL, SASL_PLAINTEXT, SASL_SSL |
queue.kafka.consumer-properties-per-topic.tb_ota_package.key |
|
max.poll.records |
Key-value properties for Kafka consumer per specific topic, e.g. tb_ota_package is a topic name for ota, tb_rule_engine.sq is a topic name for default SequentialByOriginator queue. Check TB_QUEUE_CORE_OTA_TOPIC and TB_QUEUE_RE_SQ_TOPIC params |
queue.kafka.consumer-properties-per-topic.tb_ota_package.key.value |
TB_QUEUE_KAFKA_OTA_MAX_POLL_RECORDS |
10 |
Example of specific consumer properties value per topic |
queue.kafka.other-inline |
TB_QUEUE_KAFKA_OTHER_PROPERTIES |
|
In this section you can specify custom parameters (semicolon separated) for Kafka consumer/producer/admin |
queue.kafka.topic-properties.rule-engine |
TB_QUEUE_KAFKA_RE_TOPIC_PROPERTIES |
retention.ms:604800000;segment.bytes:52428800;retention.bytes:1048576000;partitions:1;min.insync.replicas:1 |
Kafka properties for Rule Engine |
queue.kafka.topic-properties.core |
TB_QUEUE_KAFKA_CORE_TOPIC_PROPERTIES |
retention.ms:604800000;segment.bytes:52428800;retention.bytes:1048576000;partitions:1;min.insync.replicas:1 |
Kafka properties for Core topics |
queue.kafka.topic-properties.transport-api |
TB_QUEUE_KAFKA_TA_TOPIC_PROPERTIES |
retention.ms:604800000;segment.bytes:52428800;retention.bytes:1048576000;partitions:10;min.insync.replicas:1 |
Kafka properties for Transport Api topics |
queue.kafka.topic-properties.notifications |
TB_QUEUE_KAFKA_NOTIFICATIONS_TOPIC_PROPERTIES |
retention.ms:604800000;segment.bytes:52428800;retention.bytes:1048576000;partitions:1;min.insync.replicas:1 |
Kafka properties for Notifications topics |
queue.kafka.topic-properties.js-executor |
TB_QUEUE_KAFKA_JE_TOPIC_PROPERTIES |
retention.ms:604800000;segment.bytes:52428800;retention.bytes:104857600;partitions:100;min.insync.replicas:1 |
Kafka properties for JS Executor topics |
queue.kafka.topic-properties.integration-api |
TB_QUEUE_KAFKA_INTEGRATION_TOPIC_PROPERTIES |
retention.ms:604800000;segment.bytes:52428800;retention.bytes:1048576000;partitions:10;min.insync.replicas:1 |
Kafka properties for Integration Api topics |
queue.kafka.topic-properties.housekeeper |
TB_QUEUE_KAFKA_HOUSEKEEPER_TOPIC_PROPERTIES |
retention.ms:604800000;segment.bytes:52428800;retention.bytes:1048576000;partitions:10;min.insync.replicas:1 |
Kafka properties for Housekeeper tasks topic |
queue.kafka.consumer-stats.enabled |
TB_QUEUE_KAFKA_CONSUMER_STATS_ENABLED |
true |
Prints lag between consumer group offset and last messages offset in Kafka topics |
queue.kafka.consumer-stats.print-interval-ms |
TB_QUEUE_KAFKA_CONSUMER_STATS_MIN_PRINT_INTERVAL_MS |
60000 |
Statistics printing interval for Kafka's consumer-groups stats |
queue.kafka.consumer-stats.kafka-response-timeout-ms |
TB_QUEUE_KAFKA_CONSUMER_STATS_RESPONSE_TIMEOUT_MS |
1000 |
Time to wait for the stats-loading requests to Kafka to finis |
queue.aws_sqs.use_default_credential_provider_chain |
TB_QUEUE_AWS_SQS_USE_DEFAULT_CREDENTIAL_PROVIDER_CHAIN |
false |
Use the default credentials provider for AWS SQS |
queue.aws_sqs.access_key_id |
TB_QUEUE_AWS_SQS_ACCESS_KEY_ID |
YOUR_KEY |
Access key ID from AWS IAM user |
queue.aws_sqs.secret_access_key |
TB_QUEUE_AWS_SQS_SECRET_ACCESS_KEY |
YOUR_SECRET |
Secret access key from AWS IAM user |
queue.aws_sqs.region |
TB_QUEUE_AWS_SQS_REGION |
YOUR_REGION |
Region from AWS account |
queue.aws_sqs.threads_per_topic |
TB_QUEUE_AWS_SQS_THREADS_PER_TOPIC |
1 |
Number of threads per each AWS SQS queue in consumer |
queue.aws_sqs.producer_thread_pool_size |
TB_QUEUE_AWS_SQS_EXECUTOR_THREAD_POOL_SIZE |
50 |
Thread pool size for aws_sqs queue producer executor provider. Default value equals to AmazonSQSAsyncClient.DEFAULT_THREAD_POOL_SIZE |
queue.aws_sqs.queue-properties.rule-engine |
TB_QUEUE_AWS_SQS_RE_QUEUE_PROPERTIES |
VisibilityTimeout:30;MaximumMessageSize:262144;MessageRetentionPeriod:604800 |
AWS SQS queue properties. VisibilityTimeout in seconds;MaximumMessageSize in bytes;MessageRetentionPeriod in seconds |
queue.aws_sqs.queue-properties.core |
TB_QUEUE_AWS_SQS_CORE_QUEUE_PROPERTIES |
VisibilityTimeout:30;MaximumMessageSize:262144;MessageRetentionPeriod:604800 |
AWS SQS queue properties. VisibilityTimeout in seconds;MaximumMessageSize in bytes;MessageRetentionPeriod in seconds |
queue.aws_sqs.queue-properties.transport-api |
TB_QUEUE_AWS_SQS_TA_QUEUE_PROPERTIES |
VisibilityTimeout:30;MaximumMessageSize:262144;MessageRetentionPeriod:604800 |
AWS SQS queue properties. VisibilityTimeout in seconds;MaximumMessageSize in bytes;MessageRetentionPeriod in seconds |
queue.aws_sqs.queue-properties.notifications |
TB_QUEUE_AWS_SQS_NOTIFICATIONS_QUEUE_PROPERTIES |
VisibilityTimeout:30;MaximumMessageSize:262144;MessageRetentionPeriod:604800 |
AWS SQS queue properties. VisibilityTimeout in seconds;MaximumMessageSize in bytes;MessageRetentionPeriod in seconds |
queue.aws_sqs.queue-properties.js-executor |
TB_QUEUE_AWS_SQS_JE_QUEUE_PROPERTIES |
VisibilityTimeout:30;MaximumMessageSize:262144;MessageRetentionPeriod:604800 |
VisibilityTimeout:30;MaximumMessageSize:262144;MessageRetentionPeriod:604800 |
queue.aws_sqs.queue-properties.integration-api |
TB_QUEUE_AWS_SQS_INTEGRATION_QUEUE_PROPERTIES |
VisibilityTimeout:30;MaximumMessageSize:262144;MessageRetentionPeriod:604800 |
VisibilityTimeout in seconds;MaximumMessageSize in bytes;MessageRetentionPeriod in seconds |
queue.pubsub.project_id |
TB_QUEUE_PUBSUB_PROJECT_ID |
YOUR_PROJECT_ID |
Project ID from Google Cloud |
queue.pubsub.service_account |
TB_QUEUE_PUBSUB_SERVICE_ACCOUNT |
YOUR_SERVICE_ACCOUNT |
API Credentials in JSON format |
queue.pubsub.max_msg_size |
TB_QUEUE_PUBSUB_MAX_MSG_SIZE |
1048576 |
in bytes |
queue.pubsub.max_messages |
TB_QUEUE_PUBSUB_MAX_MESSAGES |
1000 |
Number of messages per consumer |
queue.pubsub.executor_thread_pool_size |
TB_QUEUE_PUBSUB_EXECUTOR_THREAD_POOL_SIZE |
0 |
Thread pool size for pubsub queue executor provider. If set to 0 - default pubsub executor provider value will be used (5 * number of available processors) |
queue.pubsub.queue-properties.rule-engine |
TB_QUEUE_PUBSUB_RE_QUEUE_PROPERTIES |
ackDeadlineInSec:30;messageRetentionInSec:604800 |
Pub/Sub properties for Rule Engine subscribers, messages which will commit after ackDeadlineInSec period can be consumed again |
queue.pubsub.queue-properties.core |
TB_QUEUE_PUBSUB_CORE_QUEUE_PROPERTIES |
ackDeadlineInSec:30;messageRetentionInSec:604800 |
Pub/Sub properties for Core subscribers, messages which will commit after ackDeadlineInSec period can be consumed again |
queue.pubsub.queue-properties.transport-api |
TB_QUEUE_PUBSUB_TA_QUEUE_PROPERTIES |
ackDeadlineInSec:30;messageRetentionInSec:604800 |
Pub/Sub properties for Transport API subscribers, messages which will commit after ackDeadlineInSec period can be consumed again |
queue.pubsub.queue-properties.notifications |
TB_QUEUE_PUBSUB_NOTIFICATIONS_QUEUE_PROPERTIES |
ackDeadlineInSec:30;messageRetentionInSec:604800 |
Pub/Sub properties for Version Control subscribers, messages which will commit after ackDeadlineInSec period can be consumed again |
queue.pubsub.queue-properties.js-executor |
TB_QUEUE_PUBSUB_JE_QUEUE_PROPERTIES |
ackDeadlineInSec:30;messageRetentionInSec:604800 |
PubSub queue properties |
queue.pubsub.queue-properties.integration-api |
TB_QUEUE_PUBSUB_INTEGRATION_QUEUE_PROPERTIES |
ackDeadlineInSec:30;messageRetentionInSec:604800 |
Pub/Sub properties for Transport Api subscribers, messages which will commit after ackDeadlineInSec period can be consumed again |
queue.service_bus.namespace_name |
TB_QUEUE_SERVICE_BUS_NAMESPACE_NAME |
YOUR_NAMESPACE_NAME |
Azure namespace |
queue.service_bus.sas_key_name |
TB_QUEUE_SERVICE_BUS_SAS_KEY_NAME |
YOUR_SAS_KEY_NAME |
Azure Service Bus Shared Access Signatures key name |
queue.service_bus.sas_key |
TB_QUEUE_SERVICE_BUS_SAS_KEY |
YOUR_SAS_KEY |
Azure Service Bus Shared Access Signatures key |
queue.service_bus.max_messages |
TB_QUEUE_SERVICE_BUS_MAX_MESSAGES |
1000 |
Number of messages per a consumer |
queue.service_bus.queue-properties.rule-engine |
TB_QUEUE_SERVICE_BUS_RE_QUEUE_PROPERTIES |
lockDurationInSec:30;maxSizeInMb:1024;messageTimeToLiveInSec:604800 |
Azure Service Bus properties for Rule Engine queues |
queue.service_bus.queue-properties.core |
TB_QUEUE_SERVICE_BUS_CORE_QUEUE_PROPERTIES |
lockDurationInSec:30;maxSizeInMb:1024;messageTimeToLiveInSec:604800 |
Azure Service Bus properties for Core queues |
queue.service_bus.queue-properties.transport-api |
TB_QUEUE_SERVICE_BUS_TA_QUEUE_PROPERTIES |
lockDurationInSec:30;maxSizeInMb:1024;messageTimeToLiveInSec:604800 |
Azure Service Bus properties for Transport Api queues |
queue.service_bus.queue-properties.notifications |
TB_QUEUE_SERVICE_BUS_NOTIFICATIONS_QUEUE_PROPERTIES |
lockDurationInSec:30;maxSizeInMb:1024;messageTimeToLiveInSec:604800 |
Azure Service Bus properties for Notification queues |
queue.service_bus.queue-properties.js-executor |
TB_QUEUE_SERVICE_BUS_JE_QUEUE_PROPERTIES |
lockDurationInSec:30;maxSizeInMb:1024;messageTimeToLiveInSec:604800 |
Azure Service Bus queue properties |
queue.service_bus.queue-properties.integration-api |
TB_QUEUE_SERVICE_BUS_INTEGRATION_QUEUE_PROPERTIES |
lockDurationInSec:30;maxSizeInMb:1024;messageTimeToLiveInSec:604800 |
Azure Service Bus properties for Integration Api queues |
queue.rabbitmq.exchange_name |
TB_QUEUE_RABBIT_MQ_EXCHANGE_NAME |
|
By default empty |
queue.rabbitmq.host |
TB_QUEUE_RABBIT_MQ_HOST |
localhost |
RabbitMQ host used to establish connection |
queue.rabbitmq.port |
TB_QUEUE_RABBIT_MQ_PORT |
5672 |
RabbitMQ host used to establish a connection |
queue.rabbitmq.virtual_host |
TB_QUEUE_RABBIT_MQ_VIRTUAL_HOST |
/ |
Virtual hosts provide logical grouping and separation of resources |
queue.rabbitmq.username |
TB_QUEUE_RABBIT_MQ_USERNAME |
YOUR_USERNAME |
Username for RabbitMQ user account |
queue.rabbitmq.password |
TB_QUEUE_RABBIT_MQ_PASSWORD |
YOUR_PASSWORD |
User password for RabbitMQ user account |
queue.rabbitmq.automatic_recovery_enabled |
TB_QUEUE_RABBIT_MQ_AUTOMATIC_RECOVERY_ENABLED |
false |
Network connection between clients and RabbitMQ nodes can fail. RabbitMQ Java client supports automatic recovery of connections and topology (queues, exchanges, bindings, and consumers) |
queue.rabbitmq.connection_timeout |
TB_QUEUE_RABBIT_MQ_CONNECTION_TIMEOUT |
60000 |
The connection timeout for the RabbitMQ connection factory |
queue.rabbitmq.handshake_timeout |
TB_QUEUE_RABBIT_MQ_HANDSHAKE_TIMEOUT |
10000 |
RabbitMQ has a timeout for connection handshake. When clients run in heavily constrained environments, it may be necessary to increase the timeout |
queue.rabbitmq.queue-properties.rule-engine |
TB_QUEUE_RABBIT_MQ_RE_QUEUE_PROPERTIES |
x-max-length-bytes:1048576000;x-message-ttl:604800000 |
RabbitMQ properties for Rule Engine queues |
queue.rabbitmq.queue-properties.core |
TB_QUEUE_RABBIT_MQ_CORE_QUEUE_PROPERTIES |
x-max-length-bytes:1048576000;x-message-ttl:604800000 |
RabbitMQ properties for Core queues |
queue.rabbitmq.queue-properties.transport-api |
TB_QUEUE_RABBIT_MQ_TA_QUEUE_PROPERTIES |
x-max-length-bytes:1048576000;x-message-ttl:604800000 |
RabbitMQ properties for Transport API queues |
queue.rabbitmq.queue-properties.notifications |
TB_QUEUE_RABBIT_MQ_NOTIFICATIONS_QUEUE_PROPERTIES |
x-max-length-bytes:1048576000;x-message-ttl:604800000 |
RabbitMQ properties for Notification queues |
queue.rabbitmq.queue-properties.js-executor |
TB_QUEUE_RABBIT_MQ_JE_QUEUE_PROPERTIES |
x-max-length-bytes:1048576000;x-message-ttl:604800000 |
RabbitMQ queue properties |
queue.rabbitmq.queue-properties.integration-api |
TB_QUEUE_RABBIT_MQ_INTEGRATION_QUEUE_PROPERTIES |
x-max-length-bytes:1048576000;x-message-ttl:604800000 |
RabbitMQ properties for Integration Api queues |
queue.partitions.hash_function_name |
TB_QUEUE_PARTITIONS_HASH_FUNCTION_NAME |
murmur3_128 |
murmur3_32, murmur3_128 or sha256 |
queue.transport_api.requests_topic |
TB_QUEUE_TRANSPORT_API_REQUEST_TOPIC |
tb_transport.api.requests |
Topic used to consume api requests from transport microservices |
queue.transport_api.responses_topic |
TB_QUEUE_TRANSPORT_API_RESPONSE_TOPIC |
tb_transport.api.responses |
Topic used to produce api responses to transport microservices |
queue.transport_api.max_pending_requests |
TB_QUEUE_TRANSPORT_MAX_PENDING_REQUESTS |
10000 |
Maximum pending api requests from transport microservices to be handled by server |
queue.transport_api.max_requests_timeout |
TB_QUEUE_TRANSPORT_MAX_REQUEST_TIMEOUT |
10000 |
Maximum timeout in milliseconds to handle api request from transport microservice by server |
queue.transport_api.max_callback_threads |
TB_QUEUE_TRANSPORT_MAX_CALLBACK_THREADS |
100 |
Amount of threads used to invoke callbacks |
queue.transport_api.request_poll_interval |
TB_QUEUE_TRANSPORT_REQUEST_POLL_INTERVAL_MS |
25 |
Interval in milliseconds to poll api requests from transport microservices |
queue.transport_api.response_poll_interval |
TB_QUEUE_TRANSPORT_RESPONSE_POLL_INTERVAL_MS |
25 |
Interval in milliseconds to poll api response from transport microservices |
queue.core.topic |
TB_QUEUE_CORE_TOPIC |
tb_core |
Default topic name of Kafka, RabbitMQ, etc. queue |
queue.core.poll-interval |
TB_QUEUE_CORE_POLL_INTERVAL_MS |
25 |
Interval in milliseconds to poll messages by Core microservices |
queue.core.partitions |
TB_QUEUE_CORE_PARTITIONS |
10 |
Amount of partitions used by Core microservices |
queue.core.pack-processing-timeout |
TB_QUEUE_CORE_PACK_PROCESSING_TIMEOUT_MS |
2000 |
Timeout for processing a message pack by Core microservices |
queue.core.ota.topic |
TB_QUEUE_CORE_OTA_TOPIC |
tb_ota_package |
Default topic name for OTA updates |
queue.core.ota.pack-interval-ms |
TB_QUEUE_CORE_OTA_PACK_INTERVAL_MS |
60000 |
The interval of processing the OTA updates for devices. Used to avoid any harm to the network due to many parallel OTA updates |
queue.core.ota.pack-size |
TB_QUEUE_CORE_OTA_PACK_SIZE |
100 |
The size of OTA updates notifications fetched from the queue. The queue stores pairs of firmware and device ids |
queue.core.usage-stats-topic |
TB_QUEUE_US_TOPIC |
tb_usage_stats |
Stats topic name for queue Kafka, RabbitMQ, etc. |
queue.core.stats.enabled |
TB_QUEUE_CORE_STATS_ENABLED |
true |
Enable/disable statistics for Core microservices |
queue.core.stats.print-interval-ms |
TB_QUEUE_CORE_STATS_PRINT_INTERVAL_MS |
60000 |
Statistics printing interval for Core microservices |
queue.core.housekeeper.topic |
TB_HOUSEKEEPER_TOPIC |
tb_housekeeper |
Topic name for Housekeeper tasks |
queue.js.request_topic |
REMOTE_JS_EVAL_REQUEST_TOPIC |
js_eval.requests |
JS Eval request topic |
queue.js.response_topic_prefix |
REMOTE_JS_EVAL_RESPONSE_TOPIC |
js_eval.responses |
JS Eval responses topic prefix that is combined with node id |
queue.js.max_pending_requests |
REMOTE_JS_MAX_PENDING_REQUESTS |
10000 |
JS Eval max pending requests |
queue.js.max_eval_requests_timeout |
REMOTE_JS_MAX_EVAL_REQUEST_TIMEOUT |
60000 |
JS Eval max request timeout |
queue.js.max_requests_timeout |
REMOTE_JS_MAX_REQUEST_TIMEOUT |
10000 |
JS max request timeout |
queue.js.response_poll_interval |
REMOTE_JS_RESPONSE_POLL_INTERVAL_MS |
25 |
JS response poll interval |
queue.rule-engine.topic |
TB_QUEUE_RULE_ENGINE_TOPIC |
tb_rule_engine |
Deprecated. It will be removed in the nearest releases |
queue.rule-engine.poll-interval |
TB_QUEUE_RULE_ENGINE_POLL_INTERVAL_MS |
25 |
Interval in milliseconds to poll messages by Rule Engine |
queue.rule-engine.pack-processing-timeout |
TB_QUEUE_RULE_ENGINE_PACK_PROCESSING_TIMEOUT_MS |
2000 |
Timeout for processing a message pack of Rule Engine |
queue.rule-engine.stats.enabled |
TB_QUEUE_RULE_ENGINE_STATS_ENABLED |
true |
Enable/disable statistics for Rule Engine |
queue.rule-engine.stats.print-interval-ms |
TB_QUEUE_RULE_ENGINE_STATS_PRINT_INTERVAL_MS |
60000 |
Statistics printing interval for Rule Engine |
queue.rule-engine.queues.name |
TB_QUEUE_RE_SQ_QUEUE_NAME |
SequentialByOriginator |
queue name |
queue.rule-engine.queues.name.topic |
TB_QUEUE_RE_SQ_TOPIC |
tb_rule_engine.sq |
queue topic |
queue.rule-engine.queues.name.poll-interval |
TB_QUEUE_RE_SQ_POLL_INTERVAL_MS |
25 |
poll interval |
queue.rule-engine.queues.name.partitions |
TB_QUEUE_RE_SQ_PARTITIONS |
10 |
number queue partitions |
queue.rule-engine.queues.name.consumer-per-partition |
TB_QUEUE_RE_SQ_CONSUMER_PER_PARTITION |
true |
if true - use for each customer different partition |
queue.rule-engine.queues.name.pack-processing-timeout |
TB_QUEUE_RE_SQ_PACK_PROCESSING_TIMEOUT_MS |
2000 |
Timeout for processing a message pack |
queue.rule-engine.queues.name.submit-strategy.type |
TB_QUEUE_RE_SQ_SUBMIT_STRATEGY_TYPE |
SEQUENTIAL_BY_ORIGINATOR |
BURST, BATCH, SEQUENTIAL_BY_ORIGINATOR, SEQUENTIAL_BY_TENANT, SEQUENTIAL |
queue.rule-engine.queues.name.submit-strategy.batch-size |
TB_QUEUE_RE_SQ_SUBMIT_STRATEGY_BATCH_SIZE |
100 |
Maximum number of messages in batch |
queue.rule-engine.queues.name.processing-strategy.type |
TB_QUEUE_RE_SQ_PROCESSING_STRATEGY_TYPE |
RETRY_FAILED_AND_TIMED_OUT |
SKIP_ALL_FAILURES, SKIP_ALL_FAILURES_AND_TIMED_OUT, RETRY_ALL, RETRY_FAILED, RETRY_TIMED_OUT, RETRY_FAILED_AND_TIMED_OUT |
queue.rule-engine.queues.name.processing-strategy.retries |
TB_QUEUE_RE_SQ_PROCESSING_STRATEGY_RETRIES |
3 |
Number of retries, 0 is unlimited |
queue.rule-engine.queues.name.processing-strategy.failure-percentage |
TB_QUEUE_RE_SQ_PROCESSING_STRATEGY_FAILURE_PERCENTAGE |
0 |
Skip retry if failures or timeouts are less then X percentage of messages; |
queue.rule-engine.queues.name.processing-strategy.pause-between-retries |
TB_QUEUE_RE_SQ_PROCESSING_STRATEGY_RETRY_PAUSE |
5 |
Time in seconds to wait in consumer thread before retries; |
queue.rule-engine.queues.name.processing-strategy.max-pause-between-retries |
TB_QUEUE_RE_SQ_PROCESSING_STRATEGY_MAX_RETRY_PAUSE |
5 |
Max allowed time in seconds for pause between retries. |
queue.integration.partitions |
TB_QUEUE_INTEGRATION_PARTITIONS |
3 |
Name of hash function used for consistent hash ring in Cluster Mode. See architecture docs for more details. Valid values - murmur3_32, murmur3_128 or sha256 |
queue.integration.notifications_topic |
TB_QUEUE_INTEGRATION_NOTIFICATIONS_TOPIC |
tb_ie.notifications |
Default notification topic name used by queue |
queue.integration.downlink_topic |
TB_QUEUE_INTEGRATION_DOWNLINK_TOPIC |
tb_ie.downlink |
Default downlink topic name used by queue |
queue.integration.uplink_topic |
TB_QUEUE_INTEGRATION_UPLINK_TOPIC |
tb_ie.uplink |
Default uplink topic name used by queue |
queue.integration.poll_interval |
TB_QUEUE_INTEGRATION_POLL_INTERVAL_MS |
25 |
Interval in milliseconds to poll messages by integrations |
queue.integration.pack-processing-timeout |
TB_QUEUE_INTEGRATION_PACK_PROCESSING_TIMEOUT_MS |
10000 |
Timeout for processing a message pack by integrations |
queue.integration_api.requests_topic |
TB_QUEUE_INTEGRATION_EXECUTOR_API_REQUEST_TOPIC |
tb_ie.api.requests |
Default Integration Api request topic name used by queue |
queue.integration_api.responses_topic |
TB_QUEUE_INTEGRATION_EXECUTOR_API_RESPONSE_TOPIC |
tb_ie.api.responses |
Default Integration Api response topic name used by queue |
queue.integration_api.max_pending_requests |
TB_QUEUE_INTEGRATION_EXECUTOR_MAX_PENDING_REQUESTS |
10000 |
Maximum pending api requests from integration executor to be handled by server< |
queue.integration_api.max_requests_timeout |
TB_QUEUE_INTEGRATION_EXECUTOR_MAX_REQUEST_TIMEOUT |
10000 |
Maximum timeout in milliseconds to handle api request from integration executor microservice by server |
queue.integration_api.max_callback_threads |
TB_QUEUE_INTEGRATION_EXECUTOR_MAX_CALLBACK_THREADS |
10 |
Amount of threads used to invoke callbacks |
queue.integration_api.request_poll_interval |
TB_QUEUE_INTEGRATION_EXECUTOR_REQUEST_POLL_INTERVAL_MS |
25 |
Interval in milliseconds to poll api requests from integration executor microservices |
queue.integration_api.response_poll_interval |
TB_QUEUE_INTEGRATION_EXECUTOR_RESPONSE_POLL_INTERVAL_MS |
25 |
Interval in milliseconds to poll api response from integration executor microservices |