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 an input consumer supports acknowledgements then the implementation of the input will wait for each message to reach a permanent destination before acknowledging it.
Index ¶
- Constants
- Variables
- func Descriptions() string
- func DocumentPlugin(typeString, description string, configSanitiser PluginConfigSanitiser)
- func PluginCount() int
- func PluginDescriptions() string
- func RegisterPlugin(typeString string, configConstructor PluginConfigConstructor, ...)
- func SanitiseConfig(conf Config) (interface{}, error)
- type AsyncReader
- type BrokerConfig
- type Config
- type DynamicConfig
- type FileConfig
- type HTTPClient
- type HTTPClientConfig
- type HTTPServer
- type HTTPServerConfig
- type Inproc
- type InprocConfig
- type PluginConfigConstructor
- type PluginConfigSanitiser
- type PluginConstructor
- type ReadUntil
- type ReadUntilConfig
- type Reader
- type STDINConfig
- type StreamConfig
- type TCPConfig
- type TCPServer
- type TCPServerConfig
- type Type
- func New(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type, ...) (Type, error)
- func NewAMQP(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewAmazonS3(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewAmazonSQS(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewAsyncReader(typeStr string, allowSkipAcks bool, r reader.Async, log log.Modular, ...) (Type, error)
- func NewBroker(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type, ...) (Type, error)
- func NewDynamic(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type, ...) (Type, error)
- func NewFile(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewFiles(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewGCPPubSub(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewHDFS(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewHTTPClient(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewHTTPServer(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewInproc(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewKafka(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewKafkaBalanced(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewKafkaCG(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewKinesis(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewKinesisBalanced(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewMQTT(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewNATS(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewNATSStream(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewNSQ(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewNanomsg(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewReadUntil(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewReader(typeStr string, r reader.Type, log log.Modular, stats metrics.Type) (Type, error)
- func NewRedisList(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewRedisPubSub(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewRedisStreams(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewSTDIN(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewTCP(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewTCPServer(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewUDPServer(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func NewWebsocket(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
- func WrapWithPipelines(in Type, pipeConstructors ...types.PipelineConstructorFunc) (Type, error)
- type TypeSpec
- type UDPServer
- type UDPServerConfig
- type WithPipeline
Constants ¶
const ( TypeAMQP = "amqp" TypeBroker = "broker" TypeDynamic = "dynamic" TypeFile = "file" TypeFiles = "files" TypeGCPPubSub = "gcp_pubsub" TypeHDFS = "hdfs" TypeHTTPClient = "http_client" TypeHTTPServer = "http_server" TypeInproc = "inproc" TypeKafka = "kafka" TypeKafkaBalanced = "kafka_balanced" TypeKafkaCG = "kafka_cg" TypeKinesis = "kinesis" TypeKinesisBalanced = "kinesis_balanced" TypeMQTT = "mqtt" TypeNanomsg = "nanomsg" TypeNATS = "nats" TypeNATSStream = "nats_stream" TypeNSQ = "nsq" TypeReadUntil = "read_until" TypeRedisList = "redis_list" TypeRedisPubSub = "redis_pubsub" TypeRedisStreams = "redis_streams" TypeS3 = "s3" TypeSQS = "sqs" TypeSTDIN = "stdin" TypeTCP = "tcp" TypeTCPServer = "tcp_server" TypeUDPServer = "udp_server" TypeWebsocket = "websocket" TypeZMQ4 = "zmq4" )
String constants representing each input type.
Variables ¶
var Constructors = map[string]TypeSpec{}
Constructors is a map of all input types with their specs.
var ( // ErrBrokerNoInputs is returned when creating a broker with zero inputs. ErrBrokerNoInputs = errors.New("attempting to create broker input type with no inputs") )
Functions ¶
func Descriptions ¶
func Descriptions() string
Descriptions returns a formatted string of descriptions for each type.
func DocumentPlugin ¶
func DocumentPlugin( typeString, description string, configSanitiser PluginConfigSanitiser, )
DocumentPlugin adds a description and an optional configuration sanitiser function to the definition of a registered plugin. This improves the documentation generated by PluginDescriptions.
func PluginCount ¶
func PluginCount() int
PluginCount returns the number of registered plugins. This does NOT count the standard set of components.
func PluginDescriptions ¶
func PluginDescriptions() string
PluginDescriptions generates and returns a markdown formatted document listing each registered plugin and an example configuration for it.
func RegisterPlugin ¶
func RegisterPlugin( typeString string, configConstructor PluginConfigConstructor, constructor PluginConstructor, )
RegisterPlugin registers a plugin by a unique name so that it can be constructed similar to regular inputs. If configuration is not needed for this plugin then configConstructor can be nil. A constructor for the plugin itself must be provided.
func SanitiseConfig ¶
SanitiseConfig returns a sanitised version of the Config, meaning sections that aren't relevant to behaviour are removed.
Types ¶
type AsyncReader ¶ added in v3.1.0
type AsyncReader struct {
// contains filtered or unexported fields
}
AsyncReader is an input implementation that reads messages from a reader.Async component.
func (*AsyncReader) CloseAsync ¶ added in v3.1.0
func (r *AsyncReader) CloseAsync()
CloseAsync shuts down the AsyncReader input and stops processing requests.
func (*AsyncReader) Connected ¶ added in v3.1.0
func (r *AsyncReader) Connected() bool
Connected returns a boolean indicating whether this input is currently connected to its target.
func (*AsyncReader) TransactionChan ¶ added in v3.1.0
func (r *AsyncReader) TransactionChan() <-chan types.Transaction
TransactionChan returns a transactions channel for consuming messages from this input type.
func (*AsyncReader) WaitForClose ¶ added in v3.1.0
func (r *AsyncReader) WaitForClose(timeout time.Duration) error
WaitForClose blocks until the AsyncReader input has closed down.
type BrokerConfig ¶
type BrokerConfig struct { Copies int `json:"copies" yaml:"copies"` Inputs brokerInputList `json:"inputs" yaml:"inputs"` }
BrokerConfig contains configuration fields for the Broker input type.
func NewBrokerConfig ¶
func NewBrokerConfig() BrokerConfig
NewBrokerConfig creates a new BrokerConfig with default values.
type Config ¶
type Config struct { Type string `json:"type" yaml:"type"` AMQP reader.AMQPConfig `json:"amqp" yaml:"amqp"` Broker BrokerConfig `json:"broker" yaml:"broker"` Dynamic DynamicConfig `json:"dynamic" yaml:"dynamic"` File FileConfig `json:"file" yaml:"file"` Files reader.FilesConfig `json:"files" yaml:"files"` GCPPubSub reader.GCPPubSubConfig `json:"gcp_pubsub" yaml:"gcp_pubsub"` HDFS reader.HDFSConfig `json:"hdfs" yaml:"hdfs"` HTTPClient HTTPClientConfig `json:"http_client" yaml:"http_client"` HTTPServer HTTPServerConfig `json:"http_server" yaml:"http_server"` Inproc InprocConfig `json:"inproc" yaml:"inproc"` Kafka reader.KafkaConfig `json:"kafka" yaml:"kafka"` KafkaBalanced reader.KafkaBalancedConfig `json:"kafka_balanced" yaml:"kafka_balanced"` KafkaCG reader.KafkaCGConfig `json:"kafka_cg" yaml:"kafka_cg"` Kinesis reader.KinesisConfig `json:"kinesis" yaml:"kinesis"` KinesisBalanced reader.KinesisBalancedConfig `json:"kinesis_balanced" yaml:"kinesis_balanced"` MQTT reader.MQTTConfig `json:"mqtt" yaml:"mqtt"` Nanomsg reader.ScaleProtoConfig `json:"nanomsg" yaml:"nanomsg"` NATS reader.NATSConfig `json:"nats" yaml:"nats"` NATSStream reader.NATSStreamConfig `json:"nats_stream" yaml:"nats_stream"` NSQ reader.NSQConfig `json:"nsq" yaml:"nsq"` Plugin interface{} `json:"plugin,omitempty" yaml:"plugin,omitempty"` ReadUntil ReadUntilConfig `json:"read_until" yaml:"read_until"` RedisList reader.RedisListConfig `json:"redis_list" yaml:"redis_list"` RedisPubSub reader.RedisPubSubConfig `json:"redis_pubsub" yaml:"redis_pubsub"` RedisStreams reader.RedisStreamsConfig `json:"redis_streams" yaml:"redis_streams"` S3 reader.AmazonS3Config `json:"s3" yaml:"s3"` SQS reader.AmazonSQSConfig `json:"sqs" yaml:"sqs"` STDIN STDINConfig `json:"stdin" yaml:"stdin"` TCP TCPConfig `json:"tcp" yaml:"tcp"` TCPServer TCPServerConfig `json:"tcp_server" yaml:"tcp_server"` UDPServer UDPServerConfig `json:"udp_server" yaml:"udp_server"` Websocket reader.WebsocketConfig `json:"websocket" yaml:"websocket"` ZMQ4 *reader.ZMQ4Config `json:"zmq4,omitempty" yaml:"zmq4,omitempty"` Processors []processor.Config `json:"processors" yaml:"processors"` }
Config is the all encompassing configuration struct for all input types.
type DynamicConfig ¶
type DynamicConfig struct { Inputs map[string]Config `json:"inputs" yaml:"inputs"` Prefix string `json:"prefix" yaml:"prefix"` Timeout string `json:"timeout" yaml:"timeout"` }
DynamicConfig contains configuration for the Dynamic input type.
func NewDynamicConfig ¶
func NewDynamicConfig() DynamicConfig
NewDynamicConfig creates a new DynamicConfig 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"` Delim string `json:"delimiter" yaml:"delimiter"` }
FileConfig contains configuration values for the File input type.
func NewFileConfig ¶
func NewFileConfig() FileConfig
NewFileConfig creates a new FileConfig with default values.
type HTTPClient ¶
type HTTPClient struct {
// contains filtered or unexported fields
}
HTTPClient is an input type that continuously makes HTTP requests and reads the response bodies as message payloads.
func (*HTTPClient) CloseAsync ¶
func (h *HTTPClient) CloseAsync()
CloseAsync shuts down the HTTPClient input.
func (*HTTPClient) Connected ¶
func (h *HTTPClient) Connected() bool
Connected returns a boolean indicating whether this input is currently connected to its target.
func (*HTTPClient) TransactionChan ¶
func (h *HTTPClient) TransactionChan() <-chan types.Transaction
TransactionChan returns a transactions channel for consuming messages from this input type.
func (*HTTPClient) WaitForClose ¶
func (h *HTTPClient) WaitForClose(timeout time.Duration) error
WaitForClose blocks until the HTTPClient input has closed down.
type HTTPClientConfig ¶
type HTTPClientConfig struct { client.Config `json:",inline" yaml:",inline"` Payload string `json:"payload" yaml:"payload"` Stream StreamConfig `json:"stream" yaml:"stream"` }
HTTPClientConfig contains configuration for the HTTPClient output type.
func NewHTTPClientConfig ¶
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 registers a range of HTTP endpoints where requests can send messages through Benthos. The endpoints are registered on the general Benthos HTTP server by default. It is also possible to specify a custom address to bind a new server to which the endpoints will be registered on instead.
func (*HTTPServer) CloseAsync ¶
func (h *HTTPServer) CloseAsync()
CloseAsync shuts down the HTTPServer input and stops processing requests.
func (*HTTPServer) Connected ¶
func (h *HTTPServer) Connected() bool
Connected returns a boolean indicating whether this input is currently connected to its target.
func (*HTTPServer) TransactionChan ¶
func (h *HTTPServer) TransactionChan() <-chan types.Transaction
TransactionChan returns a transactions channel for consuming messages from this input.
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"` WSPath string `json:"ws_path" yaml:"ws_path"` WSWelcomeMessage string `json:"ws_welcome_message" yaml:"ws_welcome_message"` WSRateLimitMessage string `json:"ws_rate_limit_message" yaml:"ws_rate_limit_message"` Timeout string `json:"timeout" yaml:"timeout"` RateLimit string `json:"rate_limit" yaml:"rate_limit"` CertFile string `json:"cert_file" yaml:"cert_file"` KeyFile string `json:"key_file" yaml:"key_file"` }
HTTPServerConfig contains configuration for the HTTPServer input type.
func NewHTTPServerConfig ¶
func NewHTTPServerConfig() HTTPServerConfig
NewHTTPServerConfig creates a new HTTPServerConfig with default values.
type Inproc ¶
type Inproc struct {
// contains filtered or unexported fields
}
Inproc is an input type that reads from a named pipe, which could be the output of a separate Benthos stream of the same process.
func (*Inproc) CloseAsync ¶
func (i *Inproc) CloseAsync()
CloseAsync shuts down the Inproc input and stops processing requests.
func (*Inproc) Connected ¶
Connected returns a boolean indicating whether this input is currently connected to its target.
func (*Inproc) TransactionChan ¶
func (i *Inproc) TransactionChan() <-chan types.Transaction
TransactionChan returns a transactions channel for consuming messages from this input type.
type InprocConfig ¶
type InprocConfig string
InprocConfig is a configuration type for the inproc input.
func NewInprocConfig ¶
func NewInprocConfig() InprocConfig
NewInprocConfig creates a new inproc input config.
type PluginConfigConstructor ¶
type PluginConfigConstructor func() interface{}
PluginConfigConstructor is a func that returns a pointer to a new and fully populated configuration struct for a plugin type.
type PluginConfigSanitiser ¶
type PluginConfigSanitiser func(conf interface{}) interface{}
PluginConfigSanitiser is a function that takes a configuration object for a plugin and returns a sanitised (minimal) version of it for printing in examples and plugin documentation.
This function is useful for when a plugins configuration struct is very large and complex, but can sometimes be expressed in a more concise way without losing the original intent.
type PluginConstructor ¶
type PluginConstructor func( config interface{}, manager types.Manager, logger log.Modular, metrics metrics.Type, ) (types.Input, error)
PluginConstructor is a func that constructs a Benthos input plugin. These are plugins that are specific to certain use cases, experimental, private or otherwise unfit for widespread general use. Any number of plugins can be specified when using Benthos as a framework.
The configuration object will be the result of the PluginConfigConstructor after overlaying the user configuration.
type ReadUntil ¶
type ReadUntil struct {
// contains filtered or unexported fields
}
ReadUntil is an input type that continuously reads another input type until a condition returns true on a message consumed.
func (*ReadUntil) CloseAsync ¶
func (r *ReadUntil) CloseAsync()
CloseAsync shuts down the ReadUntil input and stops processing requests.
func (*ReadUntil) Connected ¶
Connected returns a boolean indicating whether this input is currently connected to its target.
func (*ReadUntil) TransactionChan ¶
func (r *ReadUntil) TransactionChan() <-chan types.Transaction
TransactionChan returns a transactions channel for consuming messages from this input type.
type ReadUntilConfig ¶
type ReadUntilConfig struct { Input *Config `json:"input" yaml:"input"` Restart bool `json:"restart_input" yaml:"restart_input"` Condition condition.Config `json:"condition" yaml:"condition"` }
ReadUntilConfig contains configuration values for the ReadUntil input type.
func NewReadUntilConfig ¶
func NewReadUntilConfig() ReadUntilConfig
NewReadUntilConfig creates a new ReadUntilConfig with default values.
func (ReadUntilConfig) MarshalJSON ¶
func (r ReadUntilConfig) MarshalJSON() ([]byte, error)
MarshalJSON prints an empty object instead of nil.
func (ReadUntilConfig) MarshalYAML ¶
func (r ReadUntilConfig) MarshalYAML() (interface{}, error)
MarshalYAML prints an empty object instead of nil.
type Reader ¶
type Reader struct {
// contains filtered or unexported fields
}
Reader is an input implementation that reads messages from a reader.Type.
func (*Reader) CloseAsync ¶
func (r *Reader) CloseAsync()
CloseAsync shuts down the Reader input and stops processing requests.
func (*Reader) Connected ¶
Connected returns a boolean indicating whether this input is currently connected to its target.
func (*Reader) TransactionChan ¶
func (r *Reader) TransactionChan() <-chan types.Transaction
TransactionChan returns a transactions channel for consuming messages from this input type.
type STDINConfig ¶
type STDINConfig struct { Multipart bool `json:"multipart" yaml:"multipart"` MaxBuffer int `json:"max_buffer" yaml:"max_buffer"` Delim string `json:"delimiter" yaml:"delimiter"` }
STDINConfig contains config fields for the STDIN input type.
func NewSTDINConfig ¶
func NewSTDINConfig() STDINConfig
NewSTDINConfig creates a STDINConfig populated with default values.
type StreamConfig ¶
type StreamConfig struct { Enabled bool `json:"enabled" yaml:"enabled"` Reconnect bool `json:"reconnect" yaml:"reconnect"` Multipart bool `json:"multipart" yaml:"multipart"` MaxBuffer int `json:"max_buffer" yaml:"max_buffer"` Delim string `json:"delimiter" yaml:"delimiter"` }
StreamConfig contains fields for specifying consumption behaviour when the body of a request is a constant stream of bytes.
type TCPConfig ¶
type TCPConfig struct { Address string `json:"address" yaml:"address"` Multipart bool `json:"multipart" yaml:"multipart"` MaxBuffer int `json:"max_buffer" yaml:"max_buffer"` Delim string `json:"delimiter" yaml:"delimiter"` }
TCPConfig contains configuration values for the TCP input type.
func NewTCPConfig ¶
func NewTCPConfig() TCPConfig
NewTCPConfig creates a new TCPConfig with default values.
type TCPServer ¶
type TCPServer struct {
// contains filtered or unexported fields
}
TCPServer is an input type that binds to an address and consumes streams of messages over TCP.
func (*TCPServer) CloseAsync ¶
func (t *TCPServer) CloseAsync()
CloseAsync shuts down the TCPServer input and stops processing requests.
func (*TCPServer) Connected ¶
Connected returns a boolean indicating whether this input is currently connected to its target.
func (*TCPServer) TransactionChan ¶
func (t *TCPServer) TransactionChan() <-chan types.Transaction
TransactionChan returns a transactions channel for consuming messages from this input.
type TCPServerConfig ¶
type TCPServerConfig struct { Address string `json:"address" yaml:"address"` Multipart bool `json:"multipart" yaml:"multipart"` MaxBuffer int `json:"max_buffer" yaml:"max_buffer"` Delim string `json:"delimiter" yaml:"delimiter"` }
TCPServerConfig contains configuration for the TCPServer input type.
func NewTCPServerConfig ¶
func NewTCPServerConfig() TCPServerConfig
NewTCPServerConfig creates a new TCPServerConfig with default values.
type Type ¶
type Type interface { types.Closable types.Producer // Connected returns a boolean indicating whether this input is currently // connected to its target. Connected() bool }
Type is the standard interface of an input type.
func New ¶
func New( conf Config, mgr types.Manager, log log.Modular, stats metrics.Type, pipelines ...types.PipelineConstructorFunc, ) (Type, error)
New creates an input type based on an input configuration.
func NewAmazonS3 ¶
NewAmazonS3 creates a new AWS S3 input type.
func NewAmazonSQS ¶
func NewAmazonSQS(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
NewAmazonSQS creates a new AWS SQS input type.
func NewAsyncReader ¶ added in v3.1.0
func NewAsyncReader( typeStr string, allowSkipAcks bool, r reader.Async, log log.Modular, stats metrics.Type, ) (Type, error)
NewAsyncReader creates a new AsyncReader input type.
func NewBroker ¶
func NewBroker( conf Config, mgr types.Manager, log log.Modular, stats metrics.Type, pipelines ...types.PipelineConstructorFunc, ) (Type, error)
NewBroker creates a new Broker input type.
func NewDynamic ¶
func NewDynamic( conf Config, mgr types.Manager, log log.Modular, stats metrics.Type, pipelines ...types.PipelineConstructorFunc, ) (Type, error)
NewDynamic creates a new Dynamic input type.
func NewGCPPubSub ¶
func NewGCPPubSub(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
NewGCPPubSub creates a new GCP Cloud Pub/Sub input type.
func NewHTTPClient ¶
func NewHTTPClient(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
NewHTTPClient creates a new HTTPClient input type.
func NewHTTPServer ¶
func NewHTTPServer(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
NewHTTPServer creates a new HTTPServer input type.
func NewInproc ¶
func NewInproc( conf Config, mgr types.Manager, log log.Modular, stats metrics.Type, ) (Type, error)
NewInproc creates a new Inproc input type.
func NewKafkaBalanced ¶
func NewKafkaBalanced(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
NewKafkaBalanced creates a new KafkaBalanced input type.
func NewKafkaCG ¶ added in v3.1.0
NewKafkaCG creates a new KafkaCG input type.
func NewKinesis ¶
NewKinesis creates a new AWS Kinesis input type.
func NewKinesisBalanced ¶
func NewKinesisBalanced(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
NewKinesisBalanced creates a new AWS KinesisBalanced input type.
func NewNATSStream ¶
func NewNATSStream(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
NewNATSStream creates a new NATSStream input type.
func NewNanomsg ¶
NewNanomsg creates a new Nanomsg input type.
func NewReadUntil ¶
func NewReadUntil( conf Config, mgr types.Manager, log log.Modular, stats metrics.Type, ) (Type, error)
NewReadUntil creates a new ReadUntil input type.
func NewRedisList ¶
func NewRedisList(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
NewRedisList creates a new Redis List input type.
func NewRedisPubSub ¶
func NewRedisPubSub(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
NewRedisPubSub creates a new RedisPubSub input type.
func NewRedisStreams ¶
func NewRedisStreams(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
NewRedisStreams creates a new Redis List input type.
func NewTCPServer ¶
func NewTCPServer(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
NewTCPServer creates a new TCPServer input type.
func NewUDPServer ¶
func NewUDPServer(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
NewUDPServer creates a new UDPServer input type.
func NewWebsocket ¶
func NewWebsocket(conf Config, mgr types.Manager, log log.Modular, stats metrics.Type) (Type, error)
NewWebsocket creates a new Websocket input type.
func WrapWithPipelines ¶
func WrapWithPipelines(in Type, pipeConstructors ...types.PipelineConstructorFunc) (Type, error)
WrapWithPipelines wraps an input with a variadic number of pipelines.
type TypeSpec ¶
type TypeSpec struct {
// contains filtered or unexported fields
}
TypeSpec is a struct containing constructors, markdown descriptions and an optional sanitisation function for each input type.
type UDPServer ¶
type UDPServer struct {
// contains filtered or unexported fields
}
UDPServer is an input type that binds to an address and consumes streams of messages over UDP.
func (*UDPServer) CloseAsync ¶
func (t *UDPServer) CloseAsync()
CloseAsync shuts down the UDPServer input and stops processing requests.
func (*UDPServer) Connected ¶
Connected returns a boolean indicating whether this input is currently connected to its target.
func (*UDPServer) TransactionChan ¶
func (t *UDPServer) TransactionChan() <-chan types.Transaction
TransactionChan returns a transactions channel for consuming messages from this input.
type UDPServerConfig ¶
type UDPServerConfig struct { Address string `json:"address" yaml:"address"` MaxBuffer int `json:"max_buffer" yaml:"max_buffer"` Delim string `json:"delimiter" yaml:"delimiter"` }
UDPServerConfig contains configuration for the UDPServer input type.
func NewUDPServerConfig ¶
func NewUDPServerConfig() UDPServerConfig
NewUDPServerConfig creates a new UDPServerConfig with default values.
type WithPipeline ¶
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 ¶
func WrapWithPipeline(procs *int, in Type, pipeConstructor types.PipelineConstructorFunc) (*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 ¶
func (i *WithPipeline) CloseAsync()
CloseAsync triggers a closure of this object but does not block.
func (*WithPipeline) Connected ¶
func (i *WithPipeline) Connected() bool
Connected returns a boolean indicating whether this input is currently connected to its target.
func (*WithPipeline) TransactionChan ¶
func (i *WithPipeline) TransactionChan() <-chan types.Transaction
TransactionChan returns the channel used for consuming transactions from this input.
func (*WithPipeline) WaitForClose ¶
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.
Source Files ¶
- amqp.go
- async_reader.go
- broker.go
- constructor.go
- dynamic.go
- file.go
- files.go
- gcp_pubsub.go
- hdfs.go
- http_client.go
- http_server.go
- inproc.go
- interface.go
- kafka.go
- kafka_balanced.go
- kafka_cg.go
- kinesis.go
- kinesis_balanced.go
- mqtt.go
- nanomsg.go
- nats.go
- nats_stream.go
- nsq.go
- package.go
- plugin.go
- read_until.go
- reader.go
- redis_list.go
- redis_pubsub.go
- redis_streams.go
- s3.go
- sqs.go
- stdin.go
- tcp.go
- tcp_server.go
- udp_server.go
- websocket.go
- wrap_with_pipeline.go