schema
stringclasses 471
values | key
stringlengths 0
203
| description
stringlengths 0
4.37k
| object
stringlengths 2
322k
|
---|---|---|---|
3.0.schema.json | jobs | JOBS plugin | {"type": "object", "properties": {"num_pollers": {"type": "integer", "examples": [10, 32]}, "timeout": {"type": "integer", "default": 60}, "pipeline_size": {"type": "integer", "default": 1000000}, "consume": {"type": "array", "items": {"type": "string"}}, "pool": {"type": "object"}, "pipelines": {"type": "object", "properties": {"driver": {"type": "array", "items": {"type": "string", "enum": ["amqp", "sqs", "beanstalk", "boltdb", "memory", "nats", "kafka"]}}, "config": {"type": "object", "patternProperties": {"^[a-zA-Z0-9._-]+$": {"type": "object", "maxProperties": 1, "oneOf": [{"properties": {"priority": {"type": "integer", "default": 10}, "prefetch": {"type": "integer", "default": 100000}, "permissions": {"type": "integer", "default": 777}, "file": {"type": "string", "default": "rr.db"}}}, {"properties": {"priority": {"type": "integer", "default": 10}, "prefetch": {"type": "integer", "default": 100000}, "consume_all": {"type": "boolean", "default": false}, "queue": {"type": "string", "default": "default"}, "exchange": {"type": "string", "default": "amqp.default"}, "redial_timeout": {"type": "integer", "default": 60}, "exchange_durable": {"type": "boolean", "default": false}, "consumer_id": {"type": "string", "default": "roadrunner+uuid"}, "exchange_auto_deleted": {"type": "boolean", "default": false}, "queue_auto_deleted": {"type": "boolean", "default": false}, "exchange_type": {"type": "string", "default": "direct"}, "routing_key": {"type": "string", "default": null}, "exclusive": {"type": "boolean", "default": false}, "multiple_ack": {"type": "boolean", "default": false}, "requeue_on_fail": {"type": "boolean", "default": false}, "queue_headers": {"default": null}}}, {"properties": {"priority": {"type": "integer", "default": 10}, "auto_create_topics_enable": {"type": "boolean", "default": false}, "producer_options": {"type": "object", "properties": {"disable_idempotent": {"type": "boolean", "default": false}, "required_acks": {"type": "string", "default": "AllISRAcks", "enum": ["NoAck", "LeaderAck", "AllISRAck"]}, "max_message_bytes": {"type": "integer", "default": 1000012}, "request_timeout": {"default": 10, "type": "integer"}, "compression_codec": {"type": "string", "default": "none", "enum": ["none", "gzip", "snappy", "lz4", "zstd"]}, "delivery_timeout": {"type": "integer", "default": null}, "transaction_timeout": {"type": "boolean", "default": false}}}, "group_options": {"properties": {"group_id": {"type": "string", "default": null}, "block_rebalance_on_poll": {"type": "boolean", "default": false}}}, "consumer_options": {"type": "object", "properties": {"topics": {"type": "array", "default": null}, "consume_regexp": {"type": "boolean", "default": false}, "max_fetch_message_size": {"type": "integer", "default": 50000}, "min_fetch_message_size": {"type": "integer", "default": 1}, "consume_offset": {"type": "object", "properties": {"type": {"type": "string", "default": null, "enum": ["AtEnd", "At", "AfterMilli", "AtStart", "Relative", "WithEpoch"]}, "value": {"type": "integer", "default": 0}}}, "consume_partitions": {"patternProperties": {"^[a-zA-Z0-9._-]+$": {"type": "string", "default": null, "patternProperties": {"^[0-9]+$": {"type": "integer", "default": null, "properties": {"type": {"type": "string", "default": null, "enum": ["AtEnd", "At", "AfterMilli", "AtStart", "Relative", "WithEpoch"]}, "value": {"type": "integer", "default": 0}}}}}}}}}}}, {"properties": {"priority": {"type": "integer", "default": 10}, "prefetch": {"type": "integer", "default": 100000}}}, {"properties": {"priority": {"type": "integer", "default": 10}, "prefetch": {"type": "integer", "default": 100000}, "consume_all": {"type": "boolean", "default": false}, "tube_priority": {"type": "integer", "default": 1}, "tube": {"type": "string", "default": "default"}, "reserve_timeout": {"default": "5s"}}}, {"properties": {"priority": {"type": "integer", "default": 10}, "prefetch": {"type": "integer", "default": 100000}, "skip_queue_declaration": {"type": "boolean", "default": false}, "consume_all": {"type": "boolean", "default": false}, "visibility_timeout": {"type": "integer", "default": 0}, "wait_time_seconds": {"type": "integer", "default": 0}, "queue": {"type": "string", "default": "default"}, "attributes": {"type": "array", "items": {"type": "object", "additionalProperties": {"type": "number"}}}, "tags": {"type": "array", "items": {"type": "object", "additionalProperties": {"type": "string"}}}}}, {"properties": {"priority": {"type": "integer", "default": 10}, "prefetch": {"type": "integer", "default": 100000}, "consume_all": {"type": "boolean", "default": false}, "subject": {"type": "string", "default": "default"}, "stream": {"type": "string", "default": "default-stream"}, "deliver_new": {"type": "string", "default": "default-stream"}, "rate_limit": {"type": "integer", "default": 1000}, "delete_stream_on_stop": {"type": "boolean", "default": false}, "delete_after_ack": {"type": "boolean", "default": false}}}]}}}}}}} |
3.0.schema.json | num_pollers | Number of threads which will try to obtain the job from the priority queue. Default is the number of workers+1 | {"type": "integer", "examples": [10, 32]} |
3.0.schema.json | timeout | JOBS Push operation timeout in seconds | {"type": "integer", "default": 60} |
3.0.schema.json | pipeline_size | Size of the internal priority queue, if the internal PQ reach the max number of elements, the Push operation will be blocked | {"type": "integer", "default": 1000000} |
3.0.schema.json | consume | list of pipelines to be consumed by the server automatically at the start, keep empty if you want to start consuming manually | {"type": "array", "items": {"type": "string"}} |
3.0.schema.json | pool | JOBS workers pool | {"type": "object"} |
3.0.schema.json | pipelines | List of broker pipelines associated with the drivers. This option is not required since you can declare pipelines in the runtime. Pipeline driver should exist. | {"type": "object", "properties": {"driver": {"type": "array", "items": {"type": "string", "enum": ["amqp", "sqs", "beanstalk", "boltdb", "memory", "nats", "kafka"]}}, "config": {"type": "object", "patternProperties": {"^[a-zA-Z0-9._-]+$": {"type": "object", "maxProperties": 1, "oneOf": [{"properties": {"priority": {"type": "integer", "default": 10}, "prefetch": {"type": "integer", "default": 100000}, "permissions": {"type": "integer", "default": 777}, "file": {"type": "string", "default": "rr.db"}}}, {"properties": {"priority": {"type": "integer", "default": 10}, "prefetch": {"type": "integer", "default": 100000}, "consume_all": {"type": "boolean", "default": false}, "queue": {"type": "string", "default": "default"}, "exchange": {"type": "string", "default": "amqp.default"}, "redial_timeout": {"type": "integer", "default": 60}, "exchange_durable": {"type": "boolean", "default": false}, "consumer_id": {"type": "string", "default": "roadrunner+uuid"}, "exchange_auto_deleted": {"type": "boolean", "default": false}, "queue_auto_deleted": {"type": "boolean", "default": false}, "exchange_type": {"type": "string", "default": "direct"}, "routing_key": {"type": "string", "default": null}, "exclusive": {"type": "boolean", "default": false}, "multiple_ack": {"type": "boolean", "default": false}, "requeue_on_fail": {"type": "boolean", "default": false}, "queue_headers": {"default": null}}}, {"properties": {"priority": {"type": "integer", "default": 10}, "auto_create_topics_enable": {"type": "boolean", "default": false}, "producer_options": {"type": "object", "properties": {"disable_idempotent": {"type": "boolean", "default": false}, "required_acks": {"type": "string", "default": "AllISRAcks", "enum": ["NoAck", "LeaderAck", "AllISRAck"]}, "max_message_bytes": {"type": "integer", "default": 1000012}, "request_timeout": {"default": 10, "type": "integer"}, "compression_codec": {"type": "string", "default": "none", "enum": ["none", "gzip", "snappy", "lz4", "zstd"]}, "delivery_timeout": {"type": "integer", "default": null}, "transaction_timeout": {"type": "boolean", "default": false}}}, "group_options": {"properties": {"group_id": {"type": "string", "default": null}, "block_rebalance_on_poll": {"type": "boolean", "default": false}}}, "consumer_options": {"type": "object", "properties": {"topics": {"type": "array", "default": null}, "consume_regexp": {"type": "boolean", "default": false}, "max_fetch_message_size": {"type": "integer", "default": 50000}, "min_fetch_message_size": {"type": "integer", "default": 1}, "consume_offset": {"type": "object", "properties": {"type": {"type": "string", "default": null, "enum": ["AtEnd", "At", "AfterMilli", "AtStart", "Relative", "WithEpoch"]}, "value": {"type": "integer", "default": 0}}}, "consume_partitions": {"patternProperties": {"^[a-zA-Z0-9._-]+$": {"type": "string", "default": null, "patternProperties": {"^[0-9]+$": {"type": "integer", "default": null, "properties": {"type": {"type": "string", "default": null, "enum": ["AtEnd", "At", "AfterMilli", "AtStart", "Relative", "WithEpoch"]}, "value": {"type": "integer", "default": 0}}}}}}}}}}}, {"properties": {"priority": {"type": "integer", "default": 10}, "prefetch": {"type": "integer", "default": 100000}}}, {"properties": {"priority": {"type": "integer", "default": 10}, "prefetch": {"type": "integer", "default": 100000}, "consume_all": {"type": "boolean", "default": false}, "tube_priority": {"type": "integer", "default": 1}, "tube": {"type": "string", "default": "default"}, "reserve_timeout": {"default": "5s"}}}, {"properties": {"priority": {"type": "integer", "default": 10}, "prefetch": {"type": "integer", "default": 100000}, "skip_queue_declaration": {"type": "boolean", "default": false}, "consume_all": {"type": "boolean", "default": false}, "visibility_timeout": {"type": "integer", "default": 0}, "wait_time_seconds": {"type": "integer", "default": 0}, "queue": {"type": "string", "default": "default"}, "attributes": {"type": "array", "items": {"type": "object", "additionalProperties": {"type": "number"}}}, "tags": {"type": "array", "items": {"type": "object", "additionalProperties": {"type": "string"}}}}}, {"properties": {"priority": {"type": "integer", "default": 10}, "prefetch": {"type": "integer", "default": 100000}, "consume_all": {"type": "boolean", "default": false}, "subject": {"type": "string", "default": "default"}, "stream": {"type": "string", "default": "default-stream"}, "deliver_new": {"type": "string", "default": "default-stream"}, "rate_limit": {"type": "integer", "default": 1000}, "delete_stream_on_stop": {"type": "boolean", "default": false}, "delete_after_ack": {"type": "boolean", "default": false}}}]}}}}} |
3.0.schema.json | driver | JOBS plugin driver | {"type": "array", "items": {"type": "string", "enum": ["amqp", "sqs", "beanstalk", "boltdb", "memory", "nats", "kafka"]}} |
3.0.schema.json | config | driver configurations | {"type": "object", "patternProperties": {"^[a-zA-Z0-9._-]+$": {"type": "object", "maxProperties": 1, "oneOf": [{"properties": {"priority": {"type": "integer", "default": 10}, "prefetch": {"type": "integer", "default": 100000}, "permissions": {"type": "integer", "default": 777}, "file": {"type": "string", "default": "rr.db"}}}, {"properties": {"priority": {"type": "integer", "default": 10}, "prefetch": {"type": "integer", "default": 100000}, "consume_all": {"type": "boolean", "default": false}, "queue": {"type": "string", "default": "default"}, "exchange": {"type": "string", "default": "amqp.default"}, "redial_timeout": {"type": "integer", "default": 60}, "exchange_durable": {"type": "boolean", "default": false}, "consumer_id": {"type": "string", "default": "roadrunner+uuid"}, "exchange_auto_deleted": {"type": "boolean", "default": false}, "queue_auto_deleted": {"type": "boolean", "default": false}, "exchange_type": {"type": "string", "default": "direct"}, "routing_key": {"type": "string", "default": null}, "exclusive": {"type": "boolean", "default": false}, "multiple_ack": {"type": "boolean", "default": false}, "requeue_on_fail": {"type": "boolean", "default": false}, "queue_headers": {"default": null}}}, {"properties": {"priority": {"type": "integer", "default": 10}, "auto_create_topics_enable": {"type": "boolean", "default": false}, "producer_options": {"type": "object", "properties": {"disable_idempotent": {"type": "boolean", "default": false}, "required_acks": {"type": "string", "default": "AllISRAcks", "enum": ["NoAck", "LeaderAck", "AllISRAck"]}, "max_message_bytes": {"type": "integer", "default": 1000012}, "request_timeout": {"default": 10, "type": "integer"}, "compression_codec": {"type": "string", "default": "none", "enum": ["none", "gzip", "snappy", "lz4", "zstd"]}, "delivery_timeout": {"type": "integer", "default": null}, "transaction_timeout": {"type": "boolean", "default": false}}}, "group_options": {"properties": {"group_id": {"type": "string", "default": null}, "block_rebalance_on_poll": {"type": "boolean", "default": false}}}, "consumer_options": {"type": "object", "properties": {"topics": {"type": "array", "default": null}, "consume_regexp": {"type": "boolean", "default": false}, "max_fetch_message_size": {"type": "integer", "default": 50000}, "min_fetch_message_size": {"type": "integer", "default": 1}, "consume_offset": {"type": "object", "properties": {"type": {"type": "string", "default": null, "enum": ["AtEnd", "At", "AfterMilli", "AtStart", "Relative", "WithEpoch"]}, "value": {"type": "integer", "default": 0}}}, "consume_partitions": {"patternProperties": {"^[a-zA-Z0-9._-]+$": {"type": "string", "default": null, "patternProperties": {"^[0-9]+$": {"type": "integer", "default": null, "properties": {"type": {"type": "string", "default": null, "enum": ["AtEnd", "At", "AfterMilli", "AtStart", "Relative", "WithEpoch"]}, "value": {"type": "integer", "default": 0}}}}}}}}}}}, {"properties": {"priority": {"type": "integer", "default": 10}, "prefetch": {"type": "integer", "default": 100000}}}, {"properties": {"priority": {"type": "integer", "default": 10}, "prefetch": {"type": "integer", "default": 100000}, "consume_all": {"type": "boolean", "default": false}, "tube_priority": {"type": "integer", "default": 1}, "tube": {"type": "string", "default": "default"}, "reserve_timeout": {"default": "5s"}}}, {"properties": {"priority": {"type": "integer", "default": 10}, "prefetch": {"type": "integer", "default": 100000}, "skip_queue_declaration": {"type": "boolean", "default": false}, "consume_all": {"type": "boolean", "default": false}, "visibility_timeout": {"type": "integer", "default": 0}, "wait_time_seconds": {"type": "integer", "default": 0}, "queue": {"type": "string", "default": "default"}, "attributes": {"type": "array", "items": {"type": "object", "additionalProperties": {"type": "number"}}}, "tags": {"type": "array", "items": {"type": "object", "additionalProperties": {"type": "string"}}}}}, {"properties": {"priority": {"type": "integer", "default": 10}, "prefetch": {"type": "integer", "default": 100000}, "consume_all": {"type": "boolean", "default": false}, "subject": {"type": "string", "default": "default"}, "stream": {"type": "string", "default": "default-stream"}, "deliver_new": {"type": "string", "default": "default-stream"}, "rate_limit": {"type": "integer", "default": 1000}, "delete_stream_on_stop": {"type": "boolean", "default": false}, "delete_after_ack": {"type": "boolean", "default": false}}}]}}} |
3.0.schema.json | priority | Pipeline priority. If the job pushed to the pipeline has priority set to 0, it will inherit the pipeline's priority | {"type": "integer", "default": 10} |
3.0.schema.json | prefetch | Number of job to prefetch from the driver | {"type": "integer", "default": 100000} |
3.0.schema.json | permissions | Permissions for the boltdb database file | {"type": "integer", "default": 777} |
3.0.schema.json | file | BoldDB file to create or DB to use | {"type": "string", "default": "rr.db"} |
3.0.schema.json | priority | Pipeline priority. If the job pushed to the pipeline has priority set to 0, it will inherit the pipeline's priority | {"type": "integer", "default": 10} |
3.0.schema.json | prefetch | Number of job to prefetch from the driver | {"type": "integer", "default": 100000} |
3.0.schema.json | consume_all | Consume all payloads, even not Job structured | {"type": "boolean", "default": false} |
3.0.schema.json | queue | Queue name | {"type": "string", "default": "default"} |
3.0.schema.json | exchange | Exchange name | {"type": "string", "default": "amqp.default"} |
3.0.schema.json | redial_timeout | Redial timeout (in seconds). How long to try to reconnect to the AMQP server | {"type": "integer", "default": 60} |
3.0.schema.json | exchange_durable | Durable exchange (rabbitmq option: https://www.rabbitmq.com/tutorials/amqp-concepts.html#exchanges) | {"type": "boolean", "default": false} |
3.0.schema.json | consumer_id | The consumer_id is identified by a string that is unique and scoped for all consumers on this channel | {"type": "string", "default": "roadrunner+uuid"} |
3.0.schema.json | exchange_auto_deleted | Auto-delete (exchange is deleted when last queue is unbound from it): https://www.rabbitmq.com/tutorials/amqp-concepts.html#exchanges | {"type": "boolean", "default": false} |
3.0.schema.json | queue_auto_deleted | Auto-delete (queue that has had at least one consumer is deleted when last consumer unsubscribes) | {"type": "boolean", "default": false} |
3.0.schema.json | exchange_type | Exchange type | {"type": "string", "default": "direct"} |
3.0.schema.json | routing_key | Routing key for the queue | {"type": "string", "default": null} |
3.0.schema.json | exclusive | Declare a queue exclusive at the exchange | {"type": "boolean", "default": false} |
3.0.schema.json | multiple_ack | When multiple is true, this delivery and all prior unacknowledged deliveries on the same channel will be acknowledged. This is useful for batch processing of deliveries | {"type": "boolean", "default": false} |
3.0.schema.json | requeue_on_fail | Use rabbitmq mechanism to requeue the job on fail | {"type": "boolean", "default": false} |
3.0.schema.json | queue_headers | Queue declare args, associated array (hashmap, key:val) | {"default": null} |
3.0.schema.json | priority | Pipeline priority. If the job pushed to the pipeline has priority set to 0, it will inherit the pipeline's priority | {"type": "integer", "default": 10} |
3.0.schema.json | auto_create_topics_enable | Auto create topic for the consumer/producer | {"type": "boolean", "default": false} |
3.0.schema.json | producer_options | Kafka producer options | {"type": "object", "properties": {"disable_idempotent": {"type": "boolean", "default": false}, "required_acks": {"type": "string", "default": "AllISRAcks", "enum": ["NoAck", "LeaderAck", "AllISRAck"]}, "max_message_bytes": {"type": "integer", "default": 1000012}, "request_timeout": {"default": 10, "type": "integer"}, "compression_codec": {"type": "string", "default": "none", "enum": ["none", "gzip", "snappy", "lz4", "zstd"]}, "delivery_timeout": {"type": "integer", "default": null}, "transaction_timeout": {"type": "boolean", "default": false}}} |
3.0.schema.json | disable_idempotent | Disable_idempotent disables idempotent produce requests, opting out of Kafka server-side deduplication in the face of reissued requests due to transient network problems. Idempotent production is strictly a win, but does require the IDEMPOTENT_WRITE permission on CLUSTER (pre Kafka 3.0), and not all clients can have that permission. | {"type": "boolean", "default": false} |
3.0.schema.json | required_acks | Sets the required acks for produced records | {"type": "string", "default": "AllISRAcks", "enum": ["NoAck", "LeaderAck", "AllISRAck"]} |
3.0.schema.json | request_timeout | The maximum duration in seconds the broker will wait the receipt of the number of required_acks. | {"default": 10, "type": "integer"} |
3.0.schema.json | delivery_timeout | The level of compression to use on messages. | {"type": "integer", "default": null} |
3.0.schema.json | transaction_timeout | If enabled, the producer will ensure that exactly one copy of each message is written. | {"type": "boolean", "default": false} |
3.0.schema.json | group_options | group_options sets the consumer group for the client to join and consume in. This option is required if using any other group options. | {"properties": {"group_id": {"type": "string", "default": null}, "block_rebalance_on_poll": {"type": "boolean", "default": false}}} |
3.0.schema.json | group_id | Kafka group ID | {"type": "string", "default": null} |
3.0.schema.json | block_rebalance_on_poll | Switches the client to block rebalances whenever you poll | {"type": "boolean", "default": false} |
3.0.schema.json | consumer_options | Kafka consumer options | {"type": "object", "properties": {"topics": {"type": "array", "default": null}, "consume_regexp": {"type": "boolean", "default": false}, "max_fetch_message_size": {"type": "integer", "default": 50000}, "min_fetch_message_size": {"type": "integer", "default": 1}, "consume_offset": {"type": "object", "properties": {"type": {"type": "string", "default": null, "enum": ["AtEnd", "At", "AfterMilli", "AtStart", "Relative", "WithEpoch"]}, "value": {"type": "integer", "default": 0}}}, "consume_partitions": {"patternProperties": {"^[a-zA-Z0-9._-]+$": {"type": "string", "default": null, "patternProperties": {"^[0-9]+$": {"type": "integer", "default": null, "properties": {"type": {"type": "string", "default": null, "enum": ["AtEnd", "At", "AfterMilli", "AtStart", "Relative", "WithEpoch"]}, "value": {"type": "integer", "default": 0}}}}}}}}} |
3.0.schema.json | topics | List of the topics to consume. Regex also supported | {"type": "array", "default": null} |
3.0.schema.json | consume_regexp | consume_regexp sets the client to parse all topics passed to `topics` as regular expressions. When consuming via regex, every metadata request loads *all* topics, so that all topics can be passed to any regular expressions. Every topic is evaluated only once ever across all regular expressions; either it permanently is known to match, or is permanently known to not match. | {"type": "boolean", "default": false} |
3.0.schema.json | consume_offset | consumer_offset sets the offset to start consuming from, or if OffsetOutOfRange is seen while fetching, to restart consuming from. | {"type": "object", "properties": {"type": {"type": "string", "default": null, "enum": ["AtEnd", "At", "AfterMilli", "AtStart", "Relative", "WithEpoch"]}, "value": {"type": "integer", "default": 0}}} |
3.0.schema.json | type | Partition offset type | {"type": "string", "default": null, "enum": ["AtEnd", "At", "AfterMilli", "AtStart", "Relative", "WithEpoch"]} |
3.0.schema.json | value | Value for the: At, AfterMilli, Relative and WithEpoch offsets | {"type": "integer", "default": 0} |
3.0.schema.json | ^[a-zA-Z0-9._-]+$ | Topic to consume | {"type": "string", "default": null, "patternProperties": {"^[0-9]+$": {"type": "integer", "default": null, "properties": {"type": {"type": "string", "default": null, "enum": ["AtEnd", "At", "AfterMilli", "AtStart", "Relative", "WithEpoch"]}, "value": {"type": "integer", "default": 0}}}}} |
3.0.schema.json | ^[0-9]+$ | Partition number | {"type": "integer", "default": null, "properties": {"type": {"type": "string", "default": null, "enum": ["AtEnd", "At", "AfterMilli", "AtStart", "Relative", "WithEpoch"]}, "value": {"type": "integer", "default": 0}}} |
3.0.schema.json | type | Partition offset type | {"type": "string", "default": null, "enum": ["AtEnd", "At", "AfterMilli", "AtStart", "Relative", "WithEpoch"]} |
3.0.schema.json | value | Value for the: At, AfterMilli, Relative and WithEpoch offsets | {"type": "integer", "default": 0} |
3.0.schema.json | priority | Pipeline priority. If the job pushed to the pipeline has priority set to 0, it will inherit the pipeline's priority | {"type": "integer", "default": 10} |
3.0.schema.json | prefetch | Number of job to prefetch from the driver until ACK/NACK | {"type": "integer", "default": 100000} |
3.0.schema.json | priority | Pipeline priority. If the job pushed to the pipeline has priority set to 0, it will inherit the pipeline's priority | {"type": "integer", "default": 10} |
3.0.schema.json | prefetch | Number of job to prefetch from the driver | {"type": "integer", "default": 100000} |
3.0.schema.json | consume_all | Consume all payloads, even not Job structured | {"type": "boolean", "default": false} |
3.0.schema.json | tube_priority | Beanstalk internal tube priority | {"type": "integer", "default": 1} |
3.0.schema.json | tube | Tube name | {"type": "string", "default": "default"} |
3.0.schema.json | reserve_timeout | If no job is available before this timeout has passed, Reserve returns a ConnError recording ErrTimeout | {"default": "5s"} |
3.0.schema.json | priority | Pipeline priority. If the job pushed to the pipeline has priority set to 0, it will inherit the pipeline's priority | {"type": "integer", "default": 10} |
3.0.schema.json | prefetch | Number of job to prefetch from the driver until ACK/NACK | {"type": "integer", "default": 100000} |
3.0.schema.json | skip_queue_declaration | Get queue URL instead of declaring it | {"type": "boolean", "default": false} |
3.0.schema.json | consume_all | Consume all payloads, even not Job structured | {"type": "boolean", "default": false} |
3.0.schema.json | visibility_timeout | The duration (in seconds) for which the call waits for a message to arrive in the queue before returning. If a message is available, the call returns sooner than WaitTimeSeconds. If no messages are available and the wait time expires, the call returns successfully with an empty list of messages. | {"type": "integer", "default": 0} |
3.0.schema.json | wait_time_seconds | The duration (in seconds) for which the call waits for a message to arrive in the queue before returning. If a message is available, the call returns sooner than WaitTimeSeconds. If no messages are available and the wait time expires, the call returns successfully with an empty list of messages | {"type": "integer", "default": 0} |
3.0.schema.json | queue | Queue name | {"type": "string", "default": "default"} |
3.0.schema.json | priority | Pipeline priority. If the job pushed to the pipeline has priority set to 0, it will inherit the pipeline's priority | {"type": "integer", "default": 10} |
3.0.schema.json | prefetch | Number of job to prefetch from the driver | {"type": "integer", "default": 100000} |
3.0.schema.json | consume_all | Consume all payloads, even not Job structured | {"type": "boolean", "default": false} |
3.0.schema.json | subject | NATS subject | {"type": "string", "default": "default"} |
3.0.schema.json | stream | NATS stream | {"type": "string", "default": "default-stream"} |
3.0.schema.json | deliver_new | The consumer will only start receiving messages that were created after the consumer was created | {"type": "string", "default": "default-stream"} |
3.0.schema.json | rate_limit | Consumer rate-limiter in bytes https://docs.nats.io/jetstream/concepts/consumers#ratelimit | {"type": "integer", "default": 1000} |
3.0.schema.json | delete_stream_on_stop | Delete the stream when after pipeline was stopped | {"type": "boolean", "default": false} |
3.0.schema.json | delete_after_ack | Delete message from the stream after successful acknowledge | {"type": "boolean", "default": false} |
3.0.schema.json | tcp | Plugin to handle RAW TCP packets, available since RR 2.6.0 | {"type": "object", "properties": {"servers": {"type": "object", "minProperties": 1, "patternProperties": {"^[a-zA-Z0-9._-]+$": {"allOf": [{"type": "object"}]}}}, "pool": {"type": "object"}}} |
3.0.schema.json | servers | TCP servers to allocate | {"type": "object", "minProperties": 1, "patternProperties": {"^[a-zA-Z0-9._-]+$": {"allOf": [{"type": "object"}]}}} |
3.0.schema.json | ^[a-zA-Z0-9._-]+$ | User defined TCP servers | {"type": "object"} |
3.0.schema.json | pool | PHP static workers pool | {"type": "object"} |
3.0.schema.json | grpc | GRPC plugin | {"type": "object", "properties": {"listen": {"type": "string"}, "proto": {"type": "array", "items": {"type": "string"}}, "tls": {"type": "object", "properties": {"key": {"type": "string", "default": null}, "cert": {"type": "string", "default": null}, "root_ca": {"type": "string", "default": null}, "client_auth_type": {"type": "string", "default": "no_client_certs", "enum": ["request_client_cert", "require_any_client_cert", "verify_client_cert_if_given", "no_client_certs", "require_and_verify_client_cert"]}}}, "max_send_msg_size": {"type": "integer", "default": 50}, "max_recv_msg_size": {"default": 50, "type": "integer"}, "max_connection_idle": {}, "max_connection_age": {}, "max_connection_age_grace": {}, "max_concurrent_streams": {"type": "integer", "default": 10}, "ping_time": {}, "timeout": {}, "pool": {"type": "object"}}} |
3.0.schema.json | listen | GRPC address to listen | {"type": "string"} |
3.0.schema.json | proto | Proto file to use, multiply files supported [SINCE 2.6]. As of [v2023.1.4], wilcards are allowed in the proto field | {"type": "array", "items": {"type": "string"}} |
3.0.schema.json | tls | GRPC TLS configuration | {"type": "object", "properties": {"key": {"type": "string", "default": null}, "cert": {"type": "string", "default": null}, "root_ca": {"type": "string", "default": null}, "client_auth_type": {"type": "string", "default": "no_client_certs", "enum": ["request_client_cert", "require_any_client_cert", "verify_client_cert_if_given", "no_client_certs", "require_and_verify_client_cert"]}}} |
3.0.schema.json | key | Path to the key file | {"type": "string", "default": null} |
3.0.schema.json | cert | Path to the certificate | {"type": "string", "default": null} |
3.0.schema.json | root_ca | Path to the CA certificate | {"type": "string", "default": null} |
3.0.schema.json | client_auth_type | Client auth type | {"type": "string", "default": "no_client_certs", "enum": ["request_client_cert", "require_any_client_cert", "verify_client_cert_if_given", "no_client_certs", "require_and_verify_client_cert"]} |
3.0.schema.json | max_send_msg_size | Maximum send message size | {"type": "integer", "default": 50} |
3.0.schema.json | max_recv_msg_size | Maximum receive message size | {"default": 50, "type": "integer"} |
3.0.schema.json | max_connection_idle | MaxConnectionIdle is a duration for the amount of time after which an idle connection would be closed by sending a GoAway. Idleness duration is defined since the most recent time the number of outstanding RPCs became zero or the connection establishment | {} |
3.0.schema.json | max_connection_age | MaxConnectionAge is a duration for the maximum amount of time a connection may exist before it will be closed by sending a GoAway. A random jitter of +/-10% will be added to MaxConnectionAge to spread out connection storms | {} |
3.0.schema.json | max_connection_age_grace | MaxConnectionAgeGrace is an additive period after MaxConnectionAge after which the connection will be forcibly closed | {} |
3.0.schema.json | max_concurrent_streams | MaxConnectionAgeGrace is an additive period after MaxConnectionAge after which the connection will be forcibly closed | {"type": "integer", "default": 10} |
3.0.schema.json | ping_time | After a duration of this time if the server doesn't see any activity it pings the client to see if the transport is still alive. If set below 1s, a minimum value of 1s will be used instead | {} |
3.0.schema.json | timeout | After having pinged for keepalive check, the server waits for a duration of Timeout and if no activity is seen even after that the connection is closed | {} |
3.0.schema.json | pool | GRPC workers pool | {"type": "object"} |
3.0.schema.json | fileserver | [SINCE 2.6] File server to serve static files | {"type": "object", "properties": {"address": {}, "calculate_etag": {}, "weak": {}, "stream_request_body": {}, "serve": {"type": "array", "minItems": 1, "items": {"type": "object", "properties": {"prefix": {"type": "string", "examples": ["/foo", "/bar/baz"]}, "root": {"default": ".", "type": "string"}, "compress": {"type": "boolean", "default": false}, "cache_duration": {"type": "integer", "default": 10}, "max_age": {"type": "integer", "default": 10}, "bytes_range": {"type": "boolean", "default": false}}, "required": ["prefix"]}}}} |
3.0.schema.json | prefix | HTTP prefix | {"type": "string", "examples": ["/foo", "/bar/baz"]} |
3.0.schema.json | root | Directory to serve | {"default": ".", "type": "string"} |
3.0.schema.json | compress | When set to true, the server tries minimizing CPU usage by caching compressed files | {"type": "boolean", "default": false} |
3.0.schema.json | cache_duration | Expiration duration for inactive file handlers. Units: seconds. Use negative number to disable | {"type": "integer", "default": 10} |
Subsets and Splits
No community queries yet
The top public SQL queries from the community will appear here once available.