Documentation ¶
Overview ¶
Package reader defines implementations of an interface for generic message reading from various third party sources.
Index ¶
- func OptLinesSetDelimiter(delimiter string) func(r *Lines)
- func OptLinesSetMaxBuffer(maxBuffer int) func(r *Lines)
- func OptLinesSetMultipart(multipart bool) func(r *Lines)
- type AMQP
- type AMQPBindingConfig
- type AMQPConfig
- type AMQPQueueDeclareConfig
- type AmazonS3
- type AmazonS3Config
- type AmazonSQS
- type AmazonSQSConfig
- type CutOff
- type Files
- type FilesConfig
- type GCPPubSub
- type GCPPubSubConfig
- type HDFS
- type HDFSConfig
- type Kafka
- type KafkaBalanced
- func (k *KafkaBalanced) Acknowledge(err error) error
- func (k *KafkaBalanced) Cleanup(sesh sarama.ConsumerGroupSession) error
- func (k *KafkaBalanced) CloseAsync()
- func (k *KafkaBalanced) Connect() error
- func (k *KafkaBalanced) ConsumeClaim(sess sarama.ConsumerGroupSession, claim sarama.ConsumerGroupClaim) error
- func (k *KafkaBalanced) Read() (types.Message, error)
- func (k *KafkaBalanced) Setup(sesh sarama.ConsumerGroupSession) error
- func (k *KafkaBalanced) WaitForClose(timeout time.Duration) error
- type KafkaBalancedConfig
- type KafkaBalancedGroupConfig
- type KafkaConfig
- type Kinesis
- type KinesisBalanced
- func (k *KinesisBalanced) Acknowledge(err error) error
- func (k *KinesisBalanced) CloseAsync()
- func (k *KinesisBalanced) Connect() error
- func (k *KinesisBalanced) Init(shardID string) error
- func (k *KinesisBalanced) ProcessRecords(records []*gokini.Records, _ *gokini.KinesisConsumer)
- func (k *KinesisBalanced) Read() (types.Message, error)
- func (k *KinesisBalanced) Shutdown()
- func (k *KinesisBalanced) WaitForClose(time.Duration) error
- type KinesisBalancedConfig
- type KinesisConfig
- type Lines
- type MQTT
- type MQTTConfig
- type NATS
- type NATSConfig
- type NATSStream
- type NATSStreamConfig
- type NSQ
- type NSQConfig
- type Preserver
- type RedisList
- type RedisListConfig
- type RedisPubSub
- type RedisPubSubConfig
- type RedisStreams
- type RedisStreamsConfig
- type S3DownloadManagerConfig
- type SASLConfig
- type ScaleProto
- type ScaleProtoConfig
- type Type
- func NewAMQP(conf AMQPConfig, log log.Modular, stats metrics.Type) (Type, error)
- func NewFiles(conf FilesConfig) (Type, error)
- func NewNATS(conf NATSConfig, log log.Modular, stats metrics.Type) (Type, error)
- func NewNATSStream(conf NATSStreamConfig, log log.Modular, stats metrics.Type) (Type, error)
- func NewNSQ(conf NSQConfig, log log.Modular, stats metrics.Type) (Type, error)
- func NewScaleProto(conf ScaleProtoConfig, log log.Modular, stats metrics.Type) (Type, error)
- type Websocket
- type WebsocketConfig
- type ZMQ4Config
Constants ¶
This section is empty.
Variables ¶
This section is empty.
Functions ¶
func OptLinesSetDelimiter ¶
OptLinesSetDelimiter is a option func that sets the delimiter (default '\n') used to divide lines (message parts) in the stream of data.
func OptLinesSetMaxBuffer ¶
OptLinesSetMaxBuffer is a option func that sets the maximum size of the line parsing buffers.
func OptLinesSetMultipart ¶
OptLinesSetMultipart is a option func that sets the boolean flag indicating whether lines should be parsed as multipart or not.
Types ¶
type AMQP ¶
type AMQP struct {
// contains filtered or unexported fields
}
AMQP is an input type that reads messages via the AMQP 0.91 protocol.
func (*AMQP) Acknowledge ¶
Acknowledge instructs whether unacknowledged messages have been successfully propagated.
func (*AMQP) CloseAsync ¶
func (a *AMQP) CloseAsync()
CloseAsync shuts down the AMQP input and stops processing requests.
type AMQPBindingConfig ¶
type AMQPBindingConfig struct { Exchange string `json:"exchange" yaml:"exchange"` RoutingKey string `json:"key" yaml:"key"` }
AMQPBindingConfig contains fields describing a queue binding to be declared.
type AMQPConfig ¶
type AMQPConfig struct { URL string `json:"url" yaml:"url"` Queue string `json:"queue" yaml:"queue"` QueueDeclare AMQPQueueDeclareConfig `json:"queue_declare" yaml:"queue_declare"` BindingsDeclare []AMQPBindingConfig `json:"bindings_declare" yaml:"bindings_declare"` ConsumerTag string `json:"consumer_tag" yaml:"consumer_tag"` PrefetchCount int `json:"prefetch_count" yaml:"prefetch_count"` PrefetchSize int `json:"prefetch_size" yaml:"prefetch_size"` MaxBatchCount int `json:"max_batch_count" yaml:"max_batch_count"` TLS btls.Config `json:"tls" yaml:"tls"` }
AMQPConfig contains configuration for the AMQP input type.
func NewAMQPConfig ¶
func NewAMQPConfig() AMQPConfig
NewAMQPConfig creates a new AMQPConfig with default values.
type AMQPQueueDeclareConfig ¶
type AMQPQueueDeclareConfig struct { Enabled bool `json:"enabled" yaml:"enabled"` Durable bool `json:"durable" yaml:"durable"` }
AMQPQueueDeclareConfig contains fields indicating whether the target AMQP queue needs to be declared and bound to an exchange, as well as any fields specifying how to accomplish that.
type AmazonS3 ¶
type AmazonS3 struct {
// contains filtered or unexported fields
}
AmazonS3 is a benthos reader.Type implementation that reads messages from an Amazon S3 bucket.
func NewAmazonS3 ¶
NewAmazonS3 creates a new Amazon S3 bucket reader.Type.
func (*AmazonS3) Acknowledge ¶
Acknowledge confirms whether or not our unacknowledged messages have been successfully propagated or not.
func (*AmazonS3) CloseAsync ¶
func (a *AmazonS3) CloseAsync()
CloseAsync begins cleaning up resources used by this reader asynchronously.
func (*AmazonS3) Connect ¶
Connect attempts to establish a connection to the target S3 bucket and any relevant queues used to traverse the objects (SQS, etc).
type AmazonS3Config ¶
type AmazonS3Config struct { sess.Config `json:",inline" yaml:",inline"` Bucket string `json:"bucket" yaml:"bucket"` Prefix string `json:"prefix" yaml:"prefix"` Retries int `json:"retries" yaml:"retries"` ForcePathStyleURLs bool `json:"force_path_style_urls" yaml:"force_path_style_urls"` DownloadManager S3DownloadManagerConfig `json:"download_manager" yaml:"download_manager"` DeleteObjects bool `json:"delete_objects" yaml:"delete_objects"` SQSURL string `json:"sqs_url" yaml:"sqs_url"` SQSBodyPath string `json:"sqs_body_path" yaml:"sqs_body_path"` SQSBucketPath string `json:"sqs_bucket_path" yaml:"sqs_bucket_path"` SQSEnvelopePath string `json:"sqs_envelope_path" yaml:"sqs_envelope_path"` SQSMaxMessages int64 `json:"sqs_max_messages" yaml:"sqs_max_messages"` MaxBatchCount int `json:"max_batch_count" yaml:"max_batch_count"` Timeout string `json:"timeout" yaml:"timeout"` }
AmazonS3Config contains configuration values for the AmazonS3 input type.
func NewAmazonS3Config ¶
func NewAmazonS3Config() AmazonS3Config
NewAmazonS3Config creates a new AmazonS3Config with default values.
type AmazonSQS ¶
type AmazonSQS struct {
// contains filtered or unexported fields
}
AmazonSQS is a benthos reader.Type implementation that reads messages from an Amazon SQS queue.
func NewAmazonSQS ¶
NewAmazonSQS creates a new Amazon SQS reader.Type.
func (*AmazonSQS) Acknowledge ¶
Acknowledge confirms whether or not our unacknowledged messages have been successfully propagated or not.
func (*AmazonSQS) CloseAsync ¶
func (a *AmazonSQS) CloseAsync()
CloseAsync begins cleaning up resources used by this reader asynchronously.
type AmazonSQSConfig ¶
type AmazonSQSConfig struct { sess.Config `json:",inline" yaml:",inline"` URL string `json:"url" yaml:"url"` Timeout string `json:"timeout" yaml:"timeout"` MaxNumberOfMessages int64 `json:"max_number_of_messages" yaml:"max_number_of_messages"` DeleteMessage bool `json:"delete_message" yaml:"delete_message"` }
AmazonSQSConfig contains configuration values for the input type.
func NewAmazonSQSConfig ¶
func NewAmazonSQSConfig() AmazonSQSConfig
NewAmazonSQSConfig creates a new Config with default values.
type CutOff ¶
type CutOff struct {
// contains filtered or unexported fields
}
CutOff is a wrapper for reader.Type implementations that exits from WaitForClose immediately. This is only useful when the underlying readable resource cannot be closed reliably and can block forever.
func (*CutOff) Acknowledge ¶
Acknowledge instructs whether messages read since the last Acknowledge call were successfully propagated. If the error is nil this will be forwarded to the underlying wrapped reader. If a non-nil error is returned the buffer of messages will be resent.
func (*CutOff) CloseAsync ¶
func (c *CutOff) CloseAsync()
CloseAsync triggers the asynchronous closing of the reader.
func (*CutOff) Connect ¶
Connect attempts to establish a connection to the source, if unsuccessful returns an error. If the attempt is successful (or not necessary) returns nil.
type Files ¶
type Files struct {
// contains filtered or unexported fields
}
Files is an input type that reads file contents at a path as messages.
func (*Files) Acknowledge ¶
Acknowledge instructs whether unacknowledged messages have been successfully propagated.
func (*Files) CloseAsync ¶
func (f *Files) CloseAsync()
CloseAsync shuts down the Files input and stops processing requests.
type FilesConfig ¶
type FilesConfig struct {
Path string `json:"path" yaml:"path"`
}
FilesConfig contains configuration for the Files input type.
func NewFilesConfig ¶
func NewFilesConfig() FilesConfig
NewFilesConfig creates a new FilesConfig with default values.
type GCPPubSub ¶
type GCPPubSub struct {
// contains filtered or unexported fields
}
GCPPubSub is a benthos reader.Type implementation that reads messages from a GCP Cloud Pub/Sub subscription.
func NewGCPPubSub ¶
NewGCPPubSub creates a new GCP pubsub reader.Type.
func (*GCPPubSub) Acknowledge ¶
Acknowledge confirms whether or not our unacknowledged messages have been successfully propagated or not.
func (*GCPPubSub) CloseAsync ¶
func (c *GCPPubSub) CloseAsync()
CloseAsync begins cleaning up resources used by this reader asynchronously.
type GCPPubSubConfig ¶
type GCPPubSubConfig struct { ProjectID string `json:"project" yaml:"project"` SubscriptionID string `json:"subscription" yaml:"subscription"` MaxOutstandingMessages int `json:"max_outstanding_messages" yaml:"max_outstanding_messages"` MaxOutstandingBytes int `json:"max_outstanding_bytes" yaml:"max_outstanding_bytes"` MaxBatchCount int `json:"max_batch_count" yaml:"max_batch_count"` }
GCPPubSubConfig contains configuration values for the input type.
func NewGCPPubSubConfig ¶
func NewGCPPubSubConfig() GCPPubSubConfig
NewGCPPubSubConfig creates a new Config with default values.
type HDFS ¶
type HDFS struct {
// contains filtered or unexported fields
}
HDFS is a benthos reader.Type implementation that reads messages from a HDFS directory.
func (*HDFS) Acknowledge ¶
Acknowledge instructs whether unacknowledged messages have been successfully propagated.
func (*HDFS) CloseAsync ¶
func (h *HDFS) CloseAsync()
CloseAsync shuts down the HDFS input and stops processing requests.
type HDFSConfig ¶
type HDFSConfig struct { Hosts []string `json:"hosts" yaml:"hosts"` User string `json:"user" yaml:"user"` Directory string `json:"directory" yaml:"directory"` }
HDFSConfig contains configuration fields for the HDFS input type.
func NewHDFSConfig ¶
func NewHDFSConfig() HDFSConfig
NewHDFSConfig creates a new Config 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) Acknowledge ¶
Acknowledge instructs whether the current offset should be committed.
func (*Kafka) CloseAsync ¶
func (k *Kafka) CloseAsync()
CloseAsync shuts down the Kafka input and stops processing requests.
type KafkaBalanced ¶
type KafkaBalanced struct {
// contains filtered or unexported fields
}
KafkaBalanced is an input type that reads from a Kafka cluster by balancing partitions across other consumers of the same consumer group.
func NewKafkaBalanced ¶
func NewKafkaBalanced( conf KafkaBalancedConfig, log log.Modular, stats metrics.Type, ) (*KafkaBalanced, error)
NewKafkaBalanced creates a new KafkaBalanced input type.
func (*KafkaBalanced) Acknowledge ¶
func (k *KafkaBalanced) Acknowledge(err error) error
Acknowledge instructs whether the current offset should be committed.
func (*KafkaBalanced) Cleanup ¶
func (k *KafkaBalanced) Cleanup(sesh sarama.ConsumerGroupSession) error
Cleanup is run at the end of a session, once all ConsumeClaim goroutines have exited but before the offsets are committed for the very last time.
func (*KafkaBalanced) CloseAsync ¶
func (k *KafkaBalanced) CloseAsync()
CloseAsync shuts down the KafkaBalanced input and stops processing requests.
func (*KafkaBalanced) Connect ¶
func (k *KafkaBalanced) Connect() error
Connect establishes a KafkaBalanced connection.
func (*KafkaBalanced) ConsumeClaim ¶
func (k *KafkaBalanced) ConsumeClaim(sess sarama.ConsumerGroupSession, claim sarama.ConsumerGroupClaim) error
ConsumeClaim must start a consumer loop of ConsumerGroupClaim's Messages(). Once the Messages() channel is closed, the Handler must finish its processing loop and exit.
func (*KafkaBalanced) Read ¶
func (k *KafkaBalanced) Read() (types.Message, error)
Read attempts to read a message from a KafkaBalanced topic.
func (*KafkaBalanced) Setup ¶
func (k *KafkaBalanced) Setup(sesh sarama.ConsumerGroupSession) error
Setup is run at the beginning of a new session, before ConsumeClaim.
func (*KafkaBalanced) WaitForClose ¶
func (k *KafkaBalanced) WaitForClose(timeout time.Duration) error
WaitForClose blocks until the KafkaBalanced input has closed down.
type KafkaBalancedConfig ¶
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"` Group KafkaBalancedGroupConfig `json:"group" yaml:"group"` CommitPeriod string `json:"commit_period" yaml:"commit_period"` MaxProcessingPeriod string `json:"max_processing_period" yaml:"max_processing_period"` FetchBufferCap int `json:"fetch_buffer_cap" yaml:"fetch_buffer_cap"` Topics []string `json:"topics" yaml:"topics"` StartFromOldest bool `json:"start_from_oldest" yaml:"start_from_oldest"` TargetVersion string `json:"target_version" yaml:"target_version"` MaxBatchCount int `json:"max_batch_count" yaml:"max_batch_count"` TLS btls.Config `json:"tls" yaml:"tls"` SASL SASLConfig `json:"sasl" yaml:"sasl"` }
KafkaBalancedConfig contains configuration for the KafkaBalanced input type.
func NewKafkaBalancedConfig ¶
func NewKafkaBalancedConfig() KafkaBalancedConfig
NewKafkaBalancedConfig creates a new KafkaBalancedConfig with default values.
type KafkaBalancedGroupConfig ¶
type KafkaBalancedGroupConfig struct { SessionTimeout string `json:"session_timeout" yaml:"session_timeout"` HeartbeatInterval string `json:"heartbeat_interval" yaml:"heartbeat_interval"` RebalanceTimeout string `json:"rebalance_timeout" yaml:"rebalance_timeout"` }
KafkaBalancedGroupConfig contains config fields for Kafka consumer groups.
func NewKafkaBalancedGroupConfig ¶
func NewKafkaBalancedGroupConfig() KafkaBalancedGroupConfig
NewKafkaBalancedGroupConfig returns a KafkaBalancedGroupConfig 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"` CommitPeriod string `json:"commit_period" yaml:"commit_period"` MaxProcessingPeriod string `json:"max_processing_period" yaml:"max_processing_period"` FetchBufferCap int `json:"fetch_buffer_cap" yaml:"fetch_buffer_cap"` Topic string `json:"topic" yaml:"topic"` Partition int32 `json:"partition" yaml:"partition"` StartFromOldest bool `json:"start_from_oldest" yaml:"start_from_oldest"` TargetVersion string `json:"target_version" yaml:"target_version"` MaxBatchCount int `json:"max_batch_count" yaml:"max_batch_count"` TLS btls.Config `json:"tls" yaml:"tls"` SASL SASLConfig `json:"sasl" yaml:"sasl"` }
KafkaConfig contains configuration fields for the Kafka input type.
func NewKafkaConfig ¶
func NewKafkaConfig() KafkaConfig
NewKafkaConfig creates a new KafkaConfig with default values.
type Kinesis ¶
type Kinesis struct {
// contains filtered or unexported fields
}
Kinesis is a benthos reader.Type implementation that reads messages from an Amazon Kinesis stream.
func NewKinesis ¶
NewKinesis creates a new Amazon Kinesis stream reader.Type.
func (*Kinesis) Acknowledge ¶
Acknowledge confirms whether or not our unacknowledged messages have been successfully propagated or not.
func (*Kinesis) CloseAsync ¶
func (k *Kinesis) CloseAsync()
CloseAsync begins cleaning up resources used by this reader asynchronously.
type KinesisBalanced ¶
type KinesisBalanced struct {
// contains filtered or unexported fields
}
KinesisBalanced is a benthos reader.Type implementation that reads messages from an Amazon Kinesis stream.
func NewKinesisBalanced ¶
func NewKinesisBalanced( conf KinesisBalancedConfig, log log.Modular, stats metrics.Type, ) (*KinesisBalanced, error)
NewKinesisBalanced creates a new Amazon Kinesis stream reader.Type.
func (*KinesisBalanced) Acknowledge ¶
func (k *KinesisBalanced) Acknowledge(err error) error
Acknowledge confirms whether or not our unacknowledged messages have been successfully propagated or not.
func (*KinesisBalanced) CloseAsync ¶
func (k *KinesisBalanced) CloseAsync()
CloseAsync begins cleaning up resources used by this reader asynchronously.
func (*KinesisBalanced) Connect ¶
func (k *KinesisBalanced) Connect() error
Connect attempts to establish a connection to the target Kinesis stream.
func (*KinesisBalanced) Init ¶
func (k *KinesisBalanced) Init(shardID string) error
Init is required by the KinesisConsumer interface
func (*KinesisBalanced) ProcessRecords ¶
func (k *KinesisBalanced) ProcessRecords(records []*gokini.Records, _ *gokini.KinesisConsumer)
ProcessRecords implements the KinesisConsumer interface
func (*KinesisBalanced) Read ¶
func (k *KinesisBalanced) Read() (types.Message, error)
Read attempts to read a new message from the target Kinesis stream.
func (*KinesisBalanced) Shutdown ¶
func (k *KinesisBalanced) Shutdown()
Shutdown implements the KinesisConsumer interface
func (*KinesisBalanced) WaitForClose ¶
func (k *KinesisBalanced) WaitForClose(time.Duration) error
WaitForClose will block until either the reader is closed or a specified timeout occurs.
type KinesisBalancedConfig ¶
type KinesisBalancedConfig struct { sess.Config `json:",inline" yaml:",inline"` Stream string `json:"stream" yaml:"stream"` DynamoDBTable string `json:"dynamodb_table" yaml:"dynamodb_table"` DynamoDBBillingMode string `json:"dynamodb_billing_mode" yaml:"dynamodb_billing_mode"` DynamoDBReadCapacity int64 `json:"dynamodb_read_provision" yaml:"dynamodb_read_provision"` DynamoDBWriteCapacity int64 `json:"dynamodb_write_provision" yaml:"dynamodb_write_provision"` MaxBatchCount int `json:"max_batch_count" yaml:"max_batch_count"` StartFromOldest bool `json:"start_from_oldest" yaml:"start_from_oldest"` }
KinesisBalancedConfig is configuration values for the input type.
func NewKinesisBalancedConfig ¶
func NewKinesisBalancedConfig() KinesisBalancedConfig
NewKinesisBalancedConfig creates a new Config with default values.
type KinesisConfig ¶
type KinesisConfig struct { sess.Config `json:",inline" yaml:",inline"` Limit int64 `json:"limit" yaml:"limit"` Stream string `json:"stream" yaml:"stream"` Shard string `json:"shard" yaml:"shard"` DynamoDBTable string `json:"dynamodb_table" yaml:"dynamodb_table"` ClientID string `json:"client_id" yaml:"client_id"` CommitPeriod string `json:"commit_period" yaml:"commit_period"` StartFromOldest bool `json:"start_from_oldest" yaml:"start_from_oldest"` Timeout string `json:"timeout" yaml:"timeout"` }
KinesisConfig is configuration values for the input type.
func NewKinesisConfig ¶
func NewKinesisConfig() KinesisConfig
NewKinesisConfig creates a new Config with default values.
type Lines ¶
type Lines struct {
// contains filtered or unexported fields
}
Lines is a reader implementation that continuously reads line delimited messages from an io.Reader type.
func NewLines ¶
func NewLines( handleCtor func() (io.Reader, error), onClose func(), options ...func(r *Lines), ) (*Lines, error)
NewLines 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 Lines will close.
Callers must also provide an onClose function, which will be called if the Lines has been instructed to shut down. This function should unblock any blocked Read calls.
func (*Lines) Acknowledge ¶
Acknowledge confirms whether or not our unacknowledged messages have been successfully propagated or not.
func (*Lines) CloseAsync ¶
func (r *Lines) CloseAsync()
CloseAsync shuts down the reader input and stops processing requests.
type MQTT ¶
type MQTT struct {
// contains filtered or unexported fields
}
MQTT is an input type that reads MQTT Pub/Sub messages.
func (*MQTT) Acknowledge ¶
Acknowledge instructs whether messages have been successfully propagated.
func (*MQTT) CloseAsync ¶
func (m *MQTT) CloseAsync()
CloseAsync shuts down the MQTT input and stops processing requests.
type MQTTConfig ¶
type MQTTConfig struct { URLs []string `json:"urls" yaml:"urls"` QoS uint8 `json:"qos" yaml:"qos"` Topics []string `json:"topics" yaml:"topics"` ClientID string `json:"client_id" yaml:"client_id"` CleanSession bool `json:"clean_session" yaml:"clean_session"` }
MQTTConfig contains configuration fields for the MQTT input type.
func NewMQTTConfig ¶
func NewMQTTConfig() MQTTConfig
NewMQTTConfig creates a new MQTTConfig with default values.
type NATS ¶
type NATS struct {
// contains filtered or unexported fields
}
NATS is an input type that receives NATS messages.
func (*NATS) Acknowledge ¶
Acknowledge is a noop since NATS messages do not support acknowledgments.
func (*NATS) CloseAsync ¶
func (n *NATS) CloseAsync()
CloseAsync shuts down the NATS input and stops processing requests.
type NATSConfig ¶
type NATSConfig struct { URLs []string `json:"urls" yaml:"urls"` Subject string `json:"subject" yaml:"subject"` QueueID string `json:"queue" yaml:"queue"` PrefetchCount int `json:"prefetch_count" yaml:"prefetch_count"` }
NATSConfig contains configuration fields for the NATS input type.
func NewNATSConfig ¶
func NewNATSConfig() NATSConfig
NewNATSConfig creates a new NATSConfig with default values.
type NATSStream ¶
type NATSStream struct {
// contains filtered or unexported fields
}
NATSStream is an input type that receives NATSStream messages.
func (*NATSStream) Acknowledge ¶
func (n *NATSStream) Acknowledge(err error) error
Acknowledge instructs whether unacknowledged messages have been successfully propagated.
func (*NATSStream) CloseAsync ¶
func (n *NATSStream) CloseAsync()
CloseAsync shuts down the NATSStream input and stops processing requests.
func (*NATSStream) Connect ¶
func (n *NATSStream) Connect() error
Connect attempts to establish a connection to a NATS streaming server.
func (*NATSStream) Read ¶
func (n *NATSStream) Read() (types.Message, error)
Read attempts to read a new message from the NATS streaming server.
func (*NATSStream) WaitForClose ¶
func (n *NATSStream) WaitForClose(timeout time.Duration) error
WaitForClose blocks until the NATSStream input has closed down.
type NATSStreamConfig ¶
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"` UnsubOnClose bool `json:"unsubscribe_on_close" yaml:"unsubscribe_on_close"` StartFromOldest bool `json:"start_from_oldest" yaml:"start_from_oldest"` Subject string `json:"subject" yaml:"subject"` MaxInflight int `json:"max_inflight" yaml:"max_inflight"` }
NATSStreamConfig contains configuration fields for the NATSStream input type.
func NewNATSStreamConfig ¶
func NewNATSStreamConfig() NATSStreamConfig
NewNATSStreamConfig creates a new NATSStreamConfig with default values.
type NSQ ¶
type NSQ struct {
// contains filtered or unexported fields
}
NSQ is an input type that receives NSQ messages.
func (*NSQ) Acknowledge ¶
Acknowledge instructs whether unacknowledged messages have been successfully propagated.
func (*NSQ) CloseAsync ¶
func (n *NSQ) CloseAsync()
CloseAsync shuts down the NSQ input and stops processing requests.
func (*NSQ) HandleMessage ¶
HandleMessage handles an NSQ message.
type NSQConfig ¶
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 contains configuration fields for the NSQ input type.
func NewNSQConfig ¶
func NewNSQConfig() NSQConfig
NewNSQConfig creates a new NSQConfig with default values.
type Preserver ¶
type Preserver struct {
// contains filtered or unexported fields
}
Preserver is a wrapper for reader.Type implementations that keeps a buffer of sent messages until they are acknowledged. If an error occurs during message propagation the contents of the buffer will be resent instead of reading new messages until it is depleted. Preserver implements reader.Type.
func NewPreserver ¶
NewPreserver returns a new Preserver wrapper around a reader.Type.
func (*Preserver) Acknowledge ¶
Acknowledge instructs whether messages read since the last Acknowledge call were successfully propagated. If the error is nil this will be forwarded to the underlying wrapped reader. If a non-nil error is returned the buffer of messages will be resent.
func (*Preserver) CloseAsync ¶
func (p *Preserver) CloseAsync()
CloseAsync triggers the asynchronous closing of the reader.
func (*Preserver) Connect ¶
Connect attempts to establish a connection to the source, if unsuccessful returns an error. If the attempt is successful (or not necessary) returns nil.
type RedisList ¶
type RedisList struct {
// contains filtered or unexported fields
}
RedisList is an input type that reads Redis List messages.
func NewRedisList ¶
NewRedisList creates a new RedisList input type.
func (*RedisList) Acknowledge ¶
Acknowledge is a noop since Redis Lists do not support acknowledgements.
func (*RedisList) CloseAsync ¶
func (r *RedisList) CloseAsync()
CloseAsync shuts down the RedisList input and stops processing requests.
type RedisListConfig ¶
type RedisListConfig struct { URL string `json:"url" yaml:"url"` Key string `json:"key" yaml:"key"` Timeout string `json:"timeout" yaml:"timeout"` }
RedisListConfig contains configuration fields for the RedisList input type.
func NewRedisListConfig ¶
func NewRedisListConfig() RedisListConfig
NewRedisListConfig creates a new RedisListConfig with default values.
type RedisPubSub ¶
type RedisPubSub struct {
// contains filtered or unexported fields
}
RedisPubSub is an input type that reads Redis Pub/Sub messages.
func NewRedisPubSub ¶
func NewRedisPubSub( conf RedisPubSubConfig, log log.Modular, stats metrics.Type, ) (*RedisPubSub, error)
NewRedisPubSub creates a new RedisPubSub input type.
func (*RedisPubSub) Acknowledge ¶
func (r *RedisPubSub) Acknowledge(err error) error
Acknowledge is a noop since Redis pub/sub channels do not support acknowledgements.
func (*RedisPubSub) CloseAsync ¶
func (r *RedisPubSub) CloseAsync()
CloseAsync shuts down the RedisPubSub input and stops processing requests.
func (*RedisPubSub) Connect ¶
func (r *RedisPubSub) Connect() error
Connect establishes a connection to an RedisPubSub server.
func (*RedisPubSub) Read ¶
func (r *RedisPubSub) Read() (types.Message, error)
Read attempts to pop a message from a redis pubsub channel.
func (*RedisPubSub) WaitForClose ¶
func (r *RedisPubSub) WaitForClose(timeout time.Duration) error
WaitForClose blocks until the RedisPubSub input has closed down.
type RedisPubSubConfig ¶
type RedisPubSubConfig struct { URL string `json:"url" yaml:"url"` Channels []string `json:"channels" yaml:"channels"` UsePatterns bool `json:"use_patterns" yaml:"use_patterns"` }
RedisPubSubConfig contains configuration fields for the RedisPubSub input type.
func NewRedisPubSubConfig ¶
func NewRedisPubSubConfig() RedisPubSubConfig
NewRedisPubSubConfig creates a new RedisPubSubConfig with default values.
type RedisStreams ¶
type RedisStreams struct {
// contains filtered or unexported fields
}
RedisStreams is an input type that reads Redis Streams messages.
func NewRedisStreams ¶
func NewRedisStreams( conf RedisStreamsConfig, log log.Modular, stats metrics.Type, ) (*RedisStreams, error)
NewRedisStreams creates a new RedisStreams input type.
func (*RedisStreams) Acknowledge ¶
func (r *RedisStreams) Acknowledge(err error) error
Acknowledge is a noop since Redis Lists do not support acknowledgements.
func (*RedisStreams) CloseAsync ¶
func (r *RedisStreams) CloseAsync()
CloseAsync shuts down the RedisStreams input and stops processing requests.
func (*RedisStreams) Connect ¶
func (r *RedisStreams) Connect() error
Connect establishes a connection to a Redis server.
func (*RedisStreams) Read ¶
func (r *RedisStreams) Read() (types.Message, error)
Read attempts to pop a message from a Redis list.
func (*RedisStreams) WaitForClose ¶
func (r *RedisStreams) WaitForClose(timeout time.Duration) error
WaitForClose blocks until the RedisStreams input has closed down.
type RedisStreamsConfig ¶
type RedisStreamsConfig struct { URL string `json:"url" yaml:"url"` BodyKey string `json:"body_key" yaml:"body_key"` Streams []string `json:"streams" yaml:"streams"` ConsumerGroup string `json:"consumer_group" yaml:"consumer_group"` ClientID string `json:"client_id" yaml:"client_id"` Limit int64 `json:"limit" yaml:"limit"` StartFromOldest bool `json:"start_from_oldest" yaml:"start_from_oldest"` CommitPeriod string `json:"commit_period" yaml:"commit_period"` Timeout string `json:"timeout" yaml:"timeout"` }
RedisStreamsConfig contains configuration fields for the RedisStreams input type.
func NewRedisStreamsConfig ¶
func NewRedisStreamsConfig() RedisStreamsConfig
NewRedisStreamsConfig creates a new RedisStreamsConfig with default values.
type S3DownloadManagerConfig ¶
type S3DownloadManagerConfig struct {
Enabled bool `json:"enabled" yaml:"enabled"`
}
S3DownloadManagerConfig is a config struct containing fields for an S3 download manager.
type SASLConfig ¶
type SASLConfig struct { Enabled bool `json:"enabled" yaml:"enabled"` User string `json:"user" yaml:"user"` Password string `json:"password" yaml:"password"` }
SASLConfig contains configuration for SASL based authentication.
type ScaleProto ¶
type ScaleProto struct {
// contains filtered or unexported fields
}
ScaleProto is an input type that contains Scalability Protocols messages.
func (*ScaleProto) Acknowledge ¶
func (s *ScaleProto) Acknowledge(err error) error
Acknowledge instructs whether the pending messages were propagated successfully.
func (*ScaleProto) CloseAsync ¶
func (s *ScaleProto) CloseAsync()
CloseAsync shuts down the ScaleProto input and stops processing requests.
func (*ScaleProto) Connect ¶
func (s *ScaleProto) Connect() error
Connect establishes a nanomsg socket.
func (*ScaleProto) Read ¶
func (s *ScaleProto) Read() (types.Message, error)
Read attempts to read a new message from the nanomsg socket.
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"` SubFilters []string `json:"sub_filters" yaml:"sub_filters"` PollTimeout string `json:"poll_timeout" yaml:"poll_timeout"` RepTimeout string `json:"reply_timeout" yaml:"reply_timeout"` }
ScaleProtoConfig contains configuration fields for the ScaleProto input type.
func NewScaleProtoConfig ¶
func NewScaleProtoConfig() ScaleProtoConfig
NewScaleProtoConfig creates a new ScaleProtoConfig with default values.
type Type ¶
type Type interface { // Connect attempts to establish a connection to the source, if unsuccessful // returns an error. If the attempt is successful (or not necessary) returns // nil. Connect() error // Acknowledge, if applicable to the source, should send acknowledgments for // (or commit) all unacknowledged (or uncommitted) messages that have thus // far been consumed. If the error is non-nil this means the message was // unsuccessfully propagated down the pipeline, in which case it is up to // the implementation to decide whether to simply retry uncommitted messages // that are buffered locally, or to send the error upstream. Acknowledge(err error) error // Read attempts to read a new message from the source. Read() (types.Message, error) types.Closable }
Type is a type that reads Benthos messages from an external source. If the source supports acknowledgements then it is the responsibility of Type implementations to ensure acknowledgements are not sent for consumed messages until a subsequent Acknowledge call contains a nil error.
func NewFiles ¶
func NewFiles(conf FilesConfig) (Type, error)
NewFiles creates a new Files input type.
func NewNATSStream ¶
NewNATSStream creates a new NATSStream input type.
func NewScaleProto ¶
NewScaleProto creates a new ScaleProto input type.
type Websocket ¶
type Websocket struct {
// contains filtered or unexported fields
}
Websocket is an input type that reads Websocket messages.
func NewWebsocket ¶
NewWebsocket creates a new Websocket input type.
func (*Websocket) Acknowledge ¶
Acknowledge instructs whether the pending messages were propagated successfully.
func (*Websocket) CloseAsync ¶
func (w *Websocket) CloseAsync()
CloseAsync shuts down the Websocket input and stops reading messages.
type WebsocketConfig ¶
type WebsocketConfig struct { URL string `json:"url" yaml:"url"` OpenMsg string `json:"open_message" yaml:"open_message"` auth.Config `json:",inline" yaml:",inline"` }
WebsocketConfig contains configuration fields for the Websocket input type.
func NewWebsocketConfig ¶
func NewWebsocketConfig() WebsocketConfig
NewWebsocketConfig creates a new WebsocketConfig with default values.
type ZMQ4Config ¶
type ZMQ4Config struct{}
ZMQ4Config is an empty stub for when ZMQ4 is not compiled.
Source Files ¶
- amazon_s3.go
- amazon_sqs.go
- amqp.go
- cut_off.go
- files.go
- gcp_pubsub.go
- hdfs.go
- interface.go
- kafka.go
- kafka_balanced.go
- kinesis.go
- kinesis_balanced.go
- lines.go
- mqtt.go
- nats.go
- nats_stream.go
- nsq.go
- package.go
- preserver.go
- redis_list.go
- redis_pubsub.go
- redis_streams.go
- scale_proto.go
- websocket.go
- zmq4_stub.go