Documentation ¶
Overview ¶
Package input defines consumers for aggregating data from a variety of sources. All consumer types must implement interface input.Type.
If the source of a consumer is given assurances of message receipt then the consumer must ensure that all messages read from a source are propagated to a reader before shutting down gracefully. For example, a ZMQ subscriber model based consumer would not need to provide such ensurance, a HTTP POST based consumer, however, would be expected to propagate any requests where a 200 OK message has been returned.
Index ¶
- Variables
- func Descriptions() string
- func OptLineReaderSetDelimiter(delimiter string) func(r *LineReader)
- func OptLineReaderSetMaxBuffer(maxBuffer int) func(r *LineReader)
- func OptLineReaderSetMultipart(multipart bool) func(r *LineReader)
- type AMQP
- type AMQPConfig
- type Config
- type FanInConfig
- type FileConfig
- type HTTPClient
- type HTTPClientConfig
- type HTTPServer
- type HTTPServerConfig
- type Kafka
- type KafkaBalanced
- type KafkaBalancedConfig
- type KafkaConfig
- type LineReader
- type NATS
- type NATSConfig
- type NATSStream
- type NATSStreamConfig
- type NSQ
- type NSQConfig
- type RedisPubSub
- type RedisPubSubConfig
- type STDINConfig
- type ScaleProto
- type ScaleProtoConfig
- type Type
- func New(conf Config, log log.Modular, stats metrics.Type, ...) (Type, error)
- func NewAMQP(conf Config, log log.Modular, stats metrics.Type) (Type, error)
- func NewFanIn(conf Config, log log.Modular, stats metrics.Type, ...) (Type, error)
- func NewFile(conf Config, log log.Modular, stats metrics.Type) (Type, error)
- func NewHTTPClient(conf Config, log log.Modular, stats metrics.Type) (Type, error)
- func NewHTTPServer(conf Config, log log.Modular, stats metrics.Type) (Type, error)
- func NewKafka(conf Config, log log.Modular, stats metrics.Type) (Type, error)
- func NewKafkaBalanced(conf Config, log log.Modular, stats metrics.Type) (Type, error)
- func NewLineReader(typeStr string, handleCtor func() (io.Reader, error), onClose func(), ...) (Type, error)
- func NewNATS(conf Config, log log.Modular, stats metrics.Type) (Type, error)
- func NewNATSStream(conf Config, log log.Modular, stats metrics.Type) (Type, error)
- func NewNSQ(conf Config, log log.Modular, stats metrics.Type) (Type, error)
- func NewRedisPubSub(conf Config, log log.Modular, stats metrics.Type) (Type, error)
- func NewSTDIN(conf Config, log log.Modular, stats metrics.Type) (Type, error)
- func NewScaleProto(conf Config, log log.Modular, stats metrics.Type) (Type, error)
- func WrapWithPipelines(in Type, pipeConstructors ...pipeline.ConstructorFunc) (Type, error)
- type WithPipeline
- type ZMQ4Config
Constants ¶
This section is empty.
Variables ¶
var ( // ErrFanInNoInputs is returned when creating a FanIn type with zero inputs. ErrFanInNoInputs = errors.New("attempting to create fan_in input type with no inputs") )
Functions ¶
func Descriptions ¶
func Descriptions() string
Descriptions returns a formatted string of descriptions for each type.
func OptLineReaderSetDelimiter ¶ added in v0.7.0
func OptLineReaderSetDelimiter(delimiter string) func(r *LineReader)
OptLineReaderSetDelimiter is a option func that sets the delimiter (default '\n') used to divide lines (message parts) in the stream of data.
func OptLineReaderSetMaxBuffer ¶ added in v0.7.0
func OptLineReaderSetMaxBuffer(maxBuffer int) func(r *LineReader)
OptLineReaderSetMaxBuffer is a option func that sets the maximum size of the line parsing buffers.
func OptLineReaderSetMultipart ¶ added in v0.7.0
func OptLineReaderSetMultipart(multipart bool) func(r *LineReader)
OptLineReaderSetMultipart is a option func that sets the boolean flag indicating whether lines should be parsed as multipart or not.
Types ¶
type AMQP ¶ added in v0.0.2
type AMQP struct {
// contains filtered or unexported fields
}
AMQP is an input type that reads messages via the AMQP 0.91 protocol.
func (*AMQP) CloseAsync ¶ added in v0.0.2
func (a *AMQP) CloseAsync()
CloseAsync shuts down the AMQP input and stops processing requests.
func (*AMQP) MessageChan ¶ added in v0.0.2
MessageChan returns the messages channel.
func (*AMQP) StartListening ¶ added in v0.0.2
StartListening sets the channel used by the input to validate message receipt.
type AMQPConfig ¶ added in v0.0.2
type AMQPConfig struct { URL string `json:"url" yaml:"url"` Exchange string `json:"exchange" yaml:"exchange"` ExchangeType string `json:"exchange_type" yaml:"exchange_type"` Queue string `json:"queue" yaml:"queue"` BindingKey string `json:"key" yaml:"key"` ConsumerTag string `json:"consumer_tag" yaml:"consumer_tag"` PrefetchCount int `json:"prefetch_count" yaml:"prefetch_count"` PrefetchSize int `json:"prefetch_size" yaml:"prefetch_size"` }
AMQPConfig is configuration for the AMQP input type.
func NewAMQPConfig ¶ added in v0.0.2
func NewAMQPConfig() AMQPConfig
NewAMQPConfig creates a new AMQPConfig with default values.
type Config ¶
type Config struct { Type string `json:"type" yaml:"type"` HTTPServer HTTPServerConfig `json:"http_server" yaml:"http_server"` HTTPClient HTTPClientConfig `json:"http_client" yaml:"http_client"` ScaleProto ScaleProtoConfig `json:"scalability_protocols" yaml:"scalability_protocols"` ZMQ4 *ZMQ4Config `json:"zmq4,omitempty" yaml:"zmq4,omitempty"` Kafka KafkaConfig `json:"kafka" yaml:"kafka"` KafkaBalanced KafkaBalancedConfig `json:"kafka_balanced" yaml:"kafka_balanced"` AMQP AMQPConfig `json:"amqp" yaml:"amqp"` NSQ NSQConfig `json:"nsq" yaml:"nsq"` NATS NATSConfig `json:"nats" yaml:"nats"` NATSStream NATSStreamConfig `json:"nats_stream" yaml:"nats_stream"` RedisPubSub RedisPubSubConfig `json:"redis_pubsub" yaml:"redis_pubsub"` File FileConfig `json:"file" yaml:"file"` STDIN STDINConfig `json:"stdin" yaml:"stdin"` FanIn FanInConfig `json:"fan_in" yaml:"fan_in"` Processors []processor.Config `json:"processors" yaml:"processors"` }
Config is the all encompassing configuration struct for all input types. Note that some configs are empty structs, as the type has no optional values but we want to list it as an option.
type FanInConfig ¶
type FanInConfig struct {
Inputs []interface{} `json:"inputs" yaml:"inputs"`
}
FanInConfig is configuration for the FanIn input type.
func NewFanInConfig ¶
func NewFanInConfig() FanInConfig
NewFanInConfig creates a new FanInConfig with default values.
type FileConfig ¶
type FileConfig struct { Path string `json:"path" yaml:"path"` Multipart bool `json:"multipart" yaml:"multipart"` MaxBuffer int `json:"max_buffer" yaml:"max_buffer"` CustomDelim string `json:"custom_delimiter" yaml:"custom_delimiter"` }
FileConfig is configuration values for the File input type.
func NewFileConfig ¶
func NewFileConfig() FileConfig
NewFileConfig creates a new FileConfig with default values.
type HTTPClient ¶ added in v0.7.0
type HTTPClient struct {
// contains filtered or unexported fields
}
HTTPClient is an output type that pushes messages to HTTPClient.
func (*HTTPClient) CloseAsync ¶ added in v0.7.0
func (h *HTTPClient) CloseAsync()
CloseAsync shuts down the HTTPClient output and stops processing messages.
func (*HTTPClient) MessageChan ¶ added in v0.7.0
func (h *HTTPClient) MessageChan() <-chan types.Message
MessageChan returns the messages channel.
func (*HTTPClient) StartListening ¶ added in v0.7.0
func (h *HTTPClient) StartListening(responses <-chan types.Response) error
StartListening sets the channel used by the input to validate message receipt.
func (*HTTPClient) WaitForClose ¶ added in v0.7.0
func (h *HTTPClient) WaitForClose(timeout time.Duration) error
WaitForClose blocks until the HTTPClient output has closed down.
type HTTPClientConfig ¶ added in v0.7.0
type HTTPClientConfig struct { URL string `json:"url" yaml:"url"` Verb string `json:"verb" yaml:"verb"` Payload string `json:"payload" yaml:"payload"` ContentType string `json:"content_type" yaml:"content_type"` Stream bool `json:"stream" yaml:"stream"` StreamMultipart bool `json:"stream_multipart" yaml:"stream_multipart"` StreamMaxBuffer int `json:"stream_max_buffer" yaml:"stream_max_buffer"` StreamCustomDelim string `json:"stream_custom_delimiter" yaml:"stream_custom_delimiter"` OAuth oauth.ClientConfig `json:"oauth" yaml:"oauth"` TimeoutMS int64 `json:"timeout_ms" yaml:"timeout_ms"` RetryMS int64 `json:"retry_period_ms" yaml:"retry_period_ms"` NumRetries int `json:"retries" yaml:"retries"` SkipCertVerify bool `json:"skip_cert_verify" yaml:"skip_cert_verify"` }
HTTPClientConfig is configuration for the HTTPClient output type.
func NewHTTPClientConfig ¶ added in v0.7.0
func NewHTTPClientConfig() HTTPClientConfig
NewHTTPClientConfig creates a new HTTPClientConfig with default values.
type HTTPServer ¶
type HTTPServer struct {
// contains filtered or unexported fields
}
HTTPServer is an input type that serves HTTPServer POST requests.
func (*HTTPServer) CloseAsync ¶
func (h *HTTPServer) CloseAsync()
CloseAsync shuts down the HTTPServer input and stops processing requests.
func (*HTTPServer) MessageChan ¶
func (h *HTTPServer) MessageChan() <-chan types.Message
MessageChan returns the messages channel.
func (*HTTPServer) StartListening ¶
func (h *HTTPServer) StartListening(responses <-chan types.Response) error
StartListening sets the channel used by the input to validate message receipt.
func (*HTTPServer) WaitForClose ¶
func (h *HTTPServer) WaitForClose(timeout time.Duration) error
WaitForClose blocks until the HTTPServer input has closed down.
type HTTPServerConfig ¶
type HTTPServerConfig struct { Address string `json:"address" yaml:"address"` Path string `json:"path" yaml:"path"` TimeoutMS int64 `json:"timeout_ms" yaml:"timeout_ms"` CertFile string `json:"cert_file" yaml:"cert_file"` KeyFile string `json:"key_file" yaml:"key_file"` }
HTTPServerConfig is configuration for the HTTPServer input type.
func NewHTTPServerConfig ¶
func NewHTTPServerConfig() HTTPServerConfig
NewHTTPServerConfig creates a new HTTPServerConfig with default values.
type Kafka ¶
type Kafka struct {
// contains filtered or unexported fields
}
Kafka is an input type that reads from a Kafka instance.
func (*Kafka) CloseAsync ¶
func (k *Kafka) CloseAsync()
CloseAsync shuts down the Kafka input and stops processing requests.
func (*Kafka) MessageChan ¶
MessageChan returns the messages channel.
func (*Kafka) StartListening ¶
StartListening sets the channel used by the input to validate message receipt.
type KafkaBalanced ¶ added in v0.4.1
type KafkaBalanced struct {
// contains filtered or unexported fields
}
KafkaBalanced is an input type that reads from a KafkaBalanced instance.
func (*KafkaBalanced) CloseAsync ¶ added in v0.4.1
func (k *KafkaBalanced) CloseAsync()
CloseAsync shuts down the KafkaBalanced input and stops processing requests.
func (*KafkaBalanced) MessageChan ¶ added in v0.4.1
func (k *KafkaBalanced) MessageChan() <-chan types.Message
MessageChan returns the messages channel.
func (*KafkaBalanced) StartListening ¶ added in v0.4.1
func (k *KafkaBalanced) StartListening(responses <-chan types.Response) error
StartListening sets the channel used by the input to validate message receipt.
func (*KafkaBalanced) WaitForClose ¶ added in v0.4.1
func (k *KafkaBalanced) WaitForClose(timeout time.Duration) error
WaitForClose blocks until the KafkaBalanced input has closed down.
type KafkaBalancedConfig ¶ added in v0.4.1
type KafkaBalancedConfig struct { Addresses []string `json:"addresses" yaml:"addresses"` ClientID string `json:"client_id" yaml:"client_id"` ConsumerGroup string `json:"consumer_group" yaml:"consumer_group"` Topics []string `json:"topics" yaml:"topics"` StartFromOldest bool `json:"start_from_oldest" yaml:"start_from_oldest"` }
KafkaBalancedConfig is configuration for the KafkaBalanced input type.
func NewKafkaBalancedConfig ¶ added in v0.4.1
func NewKafkaBalancedConfig() KafkaBalancedConfig
NewKafkaBalancedConfig creates a new KafkaBalancedConfig with default values.
type KafkaConfig ¶
type KafkaConfig struct { Addresses []string `json:"addresses" yaml:"addresses"` ClientID string `json:"client_id" yaml:"client_id"` ConsumerGroup string `json:"consumer_group" yaml:"consumer_group"` Topic string `json:"topic" yaml:"topic"` Partition int32 `json:"partition" yam:"partition"` StartFromOldest bool `json:"start_from_oldest" yaml:"start_from_oldest"` }
KafkaConfig is configuration for the Kafka input type.
func NewKafkaConfig ¶
func NewKafkaConfig() KafkaConfig
NewKafkaConfig creates a new KafkaConfig with default values.
type LineReader ¶ added in v0.7.0
type LineReader struct {
// contains filtered or unexported fields
}
LineReader is an input implementation that continuously reads line delimited messages from an io.Reader type.
func (*LineReader) CloseAsync ¶ added in v0.7.0
func (r *LineReader) CloseAsync()
CloseAsync shuts down the reader input and stops processing requests.
func (*LineReader) MessageChan ¶ added in v0.7.0
func (r *LineReader) MessageChan() <-chan types.Message
MessageChan returns the messages channel.
func (*LineReader) StartListening ¶ added in v0.7.0
func (r *LineReader) StartListening(responses <-chan types.Response) error
StartListening sets the channel used by the input to validate message receipt.
func (*LineReader) WaitForClose ¶ added in v0.7.0
func (r *LineReader) WaitForClose(timeout time.Duration) error
WaitForClose blocks until the reader input has closed down.
type NATS ¶ added in v0.2.2
type NATS struct {
// contains filtered or unexported fields
}
NATS is an input type that receives NATS messages.
func (*NATS) CloseAsync ¶ added in v0.2.2
func (n *NATS) CloseAsync()
CloseAsync shuts down the NATS input and stops processing requests.
func (*NATS) MessageChan ¶ added in v0.2.2
MessageChan returns the messages channel.
func (*NATS) StartListening ¶ added in v0.2.2
StartListening sets the channel used by the input to validate message receipt.
type NATSConfig ¶ added in v0.2.2
type NATSConfig struct { URLs []string `json:"urls" yaml:"urls"` Subject string `json:"subject" yaml:"subject"` }
NATSConfig is configuration for the NATS input type.
func NewNATSConfig ¶ added in v0.2.2
func NewNATSConfig() NATSConfig
NewNATSConfig creates a new NATSConfig with default values.
type NATSStream ¶ added in v0.4.10
type NATSStream struct {
// contains filtered or unexported fields
}
NATSStream is an input type that receives NATSStream messages.
func (*NATSStream) CloseAsync ¶ added in v0.4.10
func (n *NATSStream) CloseAsync()
CloseAsync shuts down the NATSStream input and stops processing requests.
func (*NATSStream) MessageChan ¶ added in v0.4.10
func (n *NATSStream) MessageChan() <-chan types.Message
MessageChan returns the messages channel.
func (*NATSStream) StartListening ¶ added in v0.4.10
func (n *NATSStream) StartListening(responses <-chan types.Response) error
StartListening sets the channel used by the input to validate message receipt.
func (*NATSStream) WaitForClose ¶ added in v0.4.10
func (n *NATSStream) WaitForClose(timeout time.Duration) error
WaitForClose blocks until the NATSStream input has closed down.
type NATSStreamConfig ¶ added in v0.4.10
type NATSStreamConfig struct { URLs []string `json:"urls" yaml:"urls"` ClusterID string `json:"cluster_id" yaml:"cluster_id"` ClientID string `json:"client_id" yaml:"client_id"` QueueID string `json:"queue" yaml:"queue"` DurableName string `json:"durable_name" yaml:"durable_name"` Subject string `json:"subject" yaml:"subject"` }
NATSStreamConfig is configuration for the NATSStream input type.
func NewNATSStreamConfig ¶ added in v0.4.10
func NewNATSStreamConfig() NATSStreamConfig
NewNATSStreamConfig creates a new NATSStreamConfig with default values.
type NSQ ¶ added in v0.1.1
type NSQ struct {
// contains filtered or unexported fields
}
NSQ is an input type that receives NSQ messages.
func (*NSQ) CloseAsync ¶ added in v0.1.1
func (n *NSQ) CloseAsync()
CloseAsync shuts down the NSQ input and stops processing requests.
func (*NSQ) HandleMessage ¶ added in v0.1.1
HandleMessage handles an NSQ message.
func (*NSQ) MessageChan ¶ added in v0.1.1
MessageChan returns the messages channel.
func (*NSQ) StartListening ¶ added in v0.1.1
StartListening sets the channel used by the input to validate message receipt.
type NSQConfig ¶ added in v0.1.1
type NSQConfig struct { Addresses []string `json:"nsqd_tcp_addresses" yaml:"nsqd_tcp_addresses"` LookupAddresses []string `json:"lookupd_http_addresses" yaml:"lookupd_http_addresses"` Topic string `json:"topic" yaml:"topic"` Channel string `json:"channel" yaml:"channel"` UserAgent string `json:"user_agent" yaml:"user_agent"` MaxInFlight int `json:"max_in_flight" yaml:"max_in_flight"` }
NSQConfig is configuration for the NSQ input type.
func NewNSQConfig ¶ added in v0.1.1
func NewNSQConfig() NSQConfig
NewNSQConfig creates a new NSQConfig with default values.
type RedisPubSub ¶ added in v0.6.0
type RedisPubSub struct {
// contains filtered or unexported fields
}
RedisPubSub is an input type that reads Redis Pub/Sub messages.
func (*RedisPubSub) CloseAsync ¶ added in v0.6.0
func (r *RedisPubSub) CloseAsync()
CloseAsync shuts down the RedisPubSub input and stops processing requests.
func (*RedisPubSub) MessageChan ¶ added in v0.6.0
func (r *RedisPubSub) MessageChan() <-chan types.Message
MessageChan returns the messages channel.
func (*RedisPubSub) StartListening ¶ added in v0.6.0
func (r *RedisPubSub) StartListening(responses <-chan types.Response) error
StartListening sets the channel used by the input to validate message receipt.
func (*RedisPubSub) WaitForClose ¶ added in v0.6.0
func (r *RedisPubSub) WaitForClose(timeout time.Duration) error
WaitForClose blocks until the RedisPubSub input has closed down.
type RedisPubSubConfig ¶ added in v0.6.0
type RedisPubSubConfig struct { URL string `json:"url" yaml:"url"` Channels []string `json:"channels" yaml:"channels"` }
RedisPubSubConfig is configuration for the RedisPubSub input type.
func NewRedisPubSubConfig ¶ added in v0.6.0
func NewRedisPubSubConfig() RedisPubSubConfig
NewRedisPubSubConfig creates a new RedisPubSubConfig with default values.
type STDINConfig ¶ added in v0.0.2
type STDINConfig struct { Multipart bool `json:"multipart" yaml:"multipart"` MaxBuffer int `json:"max_buffer" yaml:"max_buffer"` CustomDelim string `json:"custom_delimiter" yaml:"custom_delimiter"` }
STDINConfig contains config fields for the STDIN input type.
func NewSTDINConfig ¶ added in v0.0.2
func NewSTDINConfig() STDINConfig
NewSTDINConfig creates a STDINConfig populated with default values.
type ScaleProto ¶
type ScaleProto struct {
// contains filtered or unexported fields
}
ScaleProto is an input type that serves Scalability Protocols messages.
func (*ScaleProto) CloseAsync ¶
func (s *ScaleProto) CloseAsync()
CloseAsync shuts down the ScaleProto input and stops processing requests.
func (*ScaleProto) MessageChan ¶
func (s *ScaleProto) MessageChan() <-chan types.Message
MessageChan returns the messages channel.
func (*ScaleProto) StartListening ¶
func (s *ScaleProto) StartListening(responses <-chan types.Response) error
StartListening sets the channel used by the input to validate message receipt.
func (*ScaleProto) WaitForClose ¶
func (s *ScaleProto) WaitForClose(timeout time.Duration) error
WaitForClose blocks until the ScaleProto input has closed down.
type ScaleProtoConfig ¶
type ScaleProtoConfig struct { URLs []string `json:"urls" yaml:"urls"` Bind bool `json:"bind" yaml:"bind"` SocketType string `json:"socket_type" yaml:"socket_type"` SuccessStr string `json:"reply_success" yaml:"reply_success"` ErrorStr string `json:"reply_error" yaml:"reply_error"` SubFilters []string `json:"sub_filters" yaml:"sub_filters"` PollTimeoutMS int `json:"poll_timeout_ms" yaml:"poll_timeout_ms"` RepTimeoutMS int `json:"reply_timeout_ms" yaml:"reply_timeout_ms"` }
ScaleProtoConfig is configuration for the ScaleProto input type.
func NewScaleProtoConfig ¶
func NewScaleProtoConfig() ScaleProtoConfig
NewScaleProtoConfig creates a new ScaleProtoConfig with default values.
type Type ¶
Type is the standard interface of an input type.
func New ¶ added in v0.0.2
func New( conf Config, log log.Modular, stats metrics.Type, pipelines ...pipeline.ConstructorFunc, ) (Type, error)
New creates an input type based on an input configuration.
func NewFanIn ¶
func NewFanIn( conf Config, log log.Modular, stats metrics.Type, pipelines ...pipeline.ConstructorFunc, ) (Type, error)
NewFanIn creates a new FanIn input type.
func NewHTTPClient ¶ added in v0.7.0
NewHTTPClient creates a new HTTPClient output type.
func NewHTTPServer ¶
NewHTTPServer creates a new HTTPServer input type.
func NewKafkaBalanced ¶ added in v0.4.1
NewKafkaBalanced creates a new KafkaBalanced input type.
func NewLineReader ¶ added in v0.7.0
func NewLineReader( typeStr string, handleCtor func() (io.Reader, error), onClose func(), log log.Modular, stats metrics.Type, options ...func(r *LineReader), ) (Type, error)
NewLineReader creates a new reader input type.
Callers must provide a constructor function for the target io.Reader, which is called on start up and again each time a reader is exhausted. If the constructor is called but there is no more content to create a Reader for then the error `io.EOF` should be returned and the LineReader will close.
Callers must also provide an onClose function, which will be called if the LineReader has been instructed to shut down. This function should unblock any blocked Read calls.
func NewNATSStream ¶ added in v0.4.10
NewNATSStream creates a new NATSStream input type.
func NewRedisPubSub ¶ added in v0.6.0
NewRedisPubSub creates a new RedisPubSub input type.
func NewScaleProto ¶
NewScaleProto creates a new ScaleProto input type.
func WrapWithPipelines ¶ added in v0.2.9
func WrapWithPipelines(in Type, pipeConstructors ...pipeline.ConstructorFunc) (Type, error)
WrapWithPipelines wraps an input with a variadic number of pipelines.
type WithPipeline ¶ added in v0.2.9
type WithPipeline struct {
// contains filtered or unexported fields
}
WithPipeline is a type that wraps both an input type and a pipeline type by routing the input through the pipeline, and implements the input.Type interface in order to act like an ordinary input.
func WrapWithPipeline ¶ added in v0.2.9
func WrapWithPipeline(in Type, pipeConstructor pipeline.ConstructorFunc) (*WithPipeline, error)
WrapWithPipeline routes an input directly into a processing pipeline and returns a type that manages both and acts like an ordinary input.
func (*WithPipeline) CloseAsync ¶ added in v0.2.9
func (i *WithPipeline) CloseAsync()
CloseAsync triggers a closure of this object but does not block.
func (*WithPipeline) MessageChan ¶ added in v0.2.9
func (i *WithPipeline) MessageChan() <-chan types.Message
MessageChan returns the channel used for consuming messages from this input.
func (*WithPipeline) StartListening ¶ added in v0.2.9
func (i *WithPipeline) StartListening(resChan <-chan types.Response) error
StartListening starts the type listening to a response channel from a consumer.
func (*WithPipeline) WaitForClose ¶ added in v0.2.9
func (i *WithPipeline) WaitForClose(timeout time.Duration) error
WaitForClose is a blocking call to wait until the object has finished closing down and cleaning up resources.
type ZMQ4Config ¶
type ZMQ4Config struct{}
ZMQ4Config is an empty stub for when ZMQ4 is not compiled.