struct NATS::JetStream::ConsumerConfig
- NATS::JetStream::ConsumerConfig
- NATS::JetStream::Entity
- Struct
- Value
- Object
Defined in:
jetstream/consumer_config.crConstructors
- .new(pull : JSON::PullParser)
- .new(deliver_subject : Nil | String = nil, durable_name : Nil | String = nil, ack_policy : AckPolicy = :explicit, deliver_policy : DeliverPolicy = :all, replay_policy : ReplayPolicy = :instant, ack_wait : Time::Span | Nil = nil, filter_subject : Nil | String = nil, max_deliver = nil, opt_start_seq : Int64 | Nil = nil, sample_frequency : Nil | String = nil, opt_start_time : Time | Nil = nil, rate_limit_bps : UInt64 | Nil = nil, max_ack_pending : Int | Nil = nil, max_waiting : Int | Nil = nil, idle_heartbeat : Time::Span | Nil = nil, flow_control : Bool | Nil = nil, deliver_group : Nil | String = durable_name, max_request_batch : Int32 | Nil = nil, max_request_expires : Time::Span | Nil = nil, max_request_max_bytes : Int32 | Nil = nil, replicas : Int32 = 0, memory_storage : Bool | Nil = nil, inactive_threshold : Time::Span | Nil = nil)
Instance Method Summary
- 
        #ack_policy : AckPolicy
        
          How messages should be acknowledged: none, all, or explicit 
- #ack_wait : Time::Span | Nil
- #deliver_group : String | Nil
- 
        #deliver_policy : DeliverPolicy
        
          The initial starting mode of the consumer: all, last, new, by-start_sequence or by_start_time 
- 
        #deliver_subject : String | Nil
        
          The subject to deliver observed messages, when not set, a pull-based Consumer is created 
- #description : String | Nil
- 
        #durable_name : String | Nil
        
          The name of the Consumer, specifying this will persist the consumer to the NATS server 
- 
        #filter_subject : String | Nil
        
          When consuming from a Stream with many subjects, or wildcards, select only a specific incoming subjects, supports wildcards 
- #flow_control? : Bool
- #headers_only? : Bool
- #idle_heartbeat : Time::Span | Nil
- #inactive_threshold : Time::Span | Nil
- 
        #max_ack_pending : Int64 | Nil
        
          The maximum number of messages without acknowledgement that can be outstanding, once this limit is reached message delivery will be suspended 
- 
        #max_deliver : Int64 | Nil
        
          Maximum number of times a message will be delivered via this consumer. 
- #max_request_batch : Int32 | Nil
- #max_request_expires : Time::Span | Nil
- #max_request_max_bytes : Int32 | Nil
- #max_waiting : Int64 | Nil
- #memory_storage? : Bool | Nil
- 
        #opt_start_seq : Int64 | Nil
        
          When first consuming messages from the Stream start at this particular message in the set 
- 
        #opt_start_time : Time | Nil
        
          OptStartTime When first consuming messages from the Stream start with messages on or after this time 
- 
        #rate_limit_bps : UInt64 | Nil
        
          The rate of message delivery in bits per second 
- 
        #replay_policy : ReplayPolicy
        
          How messages are sent: instant(default) ororiginal
- #replicas : Int32
- 
        #sample_frequency : String | Nil
        
          What percentage of acknowledgements should be samples for observability, 0-100 
Constructor methods inherited from struct NATS::JetStream::Entity
  
  
    
      new(pull : JSON::PullParser)
    new
    
  
    
  
    
    
    
  
    
    
    
  
    
    
    
  
    
    
    
  
Constructor Detail
Instance Method Detail
How messages should be acknowledged: none, all, or explicit
The initial starting mode of the consumer: all, last, new, by-start_sequence or by_start_time
The subject to deliver observed messages, when not set, a pull-based Consumer is created
The name of the Consumer, specifying this will persist the consumer to the NATS server
When consuming from a Stream with many subjects, or wildcards, select only a specific incoming subjects, supports wildcards
The maximum number of messages without acknowledgement that can be outstanding, once this limit is reached message delivery will be suspended
Maximum number of times a message will be delivered via this consumer. Use this to avoid poison pills crashing all your services forever.
When first consuming messages from the Stream start at this particular message in the set
OptStartTime When first consuming messages from the Stream start with messages on or after this time
What percentage of acknowledgements should be samples for observability, 0-100