Documentation ¶
Overview ¶
Package pure contains all component implementations that are pure, in that they do not interact with external systems. This includes all base component types such as brokers and is likely necessary as a base for all builds.
Index ¶
- Variables
- func AddKnownCompressionAlgorithm(name string, a KnownCompressionAlgorithm) struct{}
- func CacheOutputSpec() *service.ConfigSpec
- func CompressionAlgsList() (v []string)
- func DecompressionAlgsList() (v []string)
- func RetryOutputIndefinitely(mgr bundle.NewManagement, wrapped output.Streamed) (output.Streamed, error)
- func SwitchReorderFromGroup(group *message.SortGroup, parts []*message.Part)
- type Branch
- type CacheWriter
- type CombinedReadCloser
- type CombinedWriteCloser
- type CompressFunc
- type CompressWriter
- type DecompressFunc
- type DecompressReader
- type KnownCompressionAlgorithm
- type SyncResponseWriter
- type Workflow
Constants ¶
This section is empty.
Variables ¶
var ( // ErrSwitchNoConditionMet is returned when a message does not match any // output conditions. ErrSwitchNoConditionMet = errors.New("no switch output conditions were met by message") // ErrSwitchNoCasesMatched is returned when a message does not match any // output cases. ErrSwitchNoCasesMatched = errors.New("no switch cases were matched by message") // ErrSwitchNoOutputs is returned when creating a switchOutput type with less than // 2 outputs. ErrSwitchNoOutputs = errors.New("attempting to create switch with fewer than 2 cases") )
var ErrBrokerNoInputs = errors.New("attempting to create broker input type with no inputs")
ErrBrokerNoInputs is returned when creating a broker with zero inputs.
var ErrBrokerNoOutputs = errors.New("attempting to create broker output type with no outputs")
ErrBrokerNoOutputs is returned when creating a Broker type with zero outputs.
Functions ¶
func AddKnownCompressionAlgorithm ¶
func AddKnownCompressionAlgorithm(name string, a KnownCompressionAlgorithm) struct{}
AddKnownCompressionAlgorithm registers a compression algorithm.
func CacheOutputSpec ¶
func CacheOutputSpec() *service.ConfigSpec
CacheOutputSpec returns the config spec of the cache output plugin.
func CompressionAlgsList ¶
func CompressionAlgsList() (v []string)
CompressionAlgsList returns the list of registered compression algorithms.
func DecompressionAlgsList ¶
func DecompressionAlgsList() (v []string)
DecompressionAlgsList returns the list of registered decompression algorithms.
func RetryOutputIndefinitely ¶
func RetryOutputIndefinitely(mgr bundle.NewManagement, wrapped output.Streamed) (output.Streamed, error)
RetryOutputIndefinitely returns a wrapped variant of the provided output where send errors downstream are automatically caught and retried rather than propagated upstream as nacks.
Types ¶
type Branch ¶
type Branch struct {
// contains filtered or unexported fields
}
Branch contains conditions and maps for transforming a batch of messages into a subset of request messages, and mapping results from those requests back into the original message batch.
type CacheWriter ¶
type CacheWriter struct {
// contains filtered or unexported fields
}
CacheWriter is a writer implementation for the cache output plugin.
func NewCacheWriter ¶
func NewCacheWriter(conf *service.ParsedConfig, mgr bundle.NewManagement) (*CacheWriter, error)
NewCacheWriter creates a writer for the cache output plugin.
func (*CacheWriter) Connect ¶
func (c *CacheWriter) Connect(ctx context.Context) error
Connect does nothing.
func (*CacheWriter) WriteBatch ¶
WriteBatch attempts to store a message within a cache.
type CombinedReadCloser ¶
CombinedReadCloser combines a Primary destination and a Source. The Primary is read from and closed second. The Source is closed first.
func (*CombinedReadCloser) Close ¶
func (c *CombinedReadCloser) Close() error
Close closes the Source and then the Primary.
type CombinedWriteCloser ¶
CombinedWriteCloser combines a Primary source and a Sink. The Primary is written to and closed first. The Sink is closed second.
func (*CombinedWriteCloser) Close ¶
func (c *CombinedWriteCloser) Close() error
Close closes the Primary and then the Sink.
type CompressFunc ¶
CompressFunc is a func which compresses a byte slice.
type CompressWriter ¶
CompressWriter is a compressor func which wraps an io.Writer.
type DecompressFunc ¶
DecompressFunc is a func which decompresses a byte slice.
type DecompressReader ¶
DecompressReader is a decompressor func which wraps an io.Reader.
type KnownCompressionAlgorithm ¶
type KnownCompressionAlgorithm struct { CompressFunc CompressFunc CompressWriter CompressWriter DecompressFunc DecompressFunc DecompressReader DecompressReader }
KnownCompressionAlgorithm is a unified interface for various compression algorithms.
type SyncResponseWriter ¶
type SyncResponseWriter struct{}
SyncResponseWriter is a writer implementation that adds messages to a ResultStore located in the context of the first message part of each batch. This is essentially a mechanism that returns the result of a pipeline directly back to the origin of the message.
func (SyncResponseWriter) Close ¶
func (s SyncResponseWriter) Close(context.Context) error
Close is a noop.
func (SyncResponseWriter) Connect ¶
func (s SyncResponseWriter) Connect(ctx context.Context) error
Connect is a noop.
func (SyncResponseWriter) WriteBatch ¶
WriteBatch writes a message batch to a ResultStore located in the first message of the batch.
type Workflow ¶
type Workflow struct {
// contains filtered or unexported fields
}
Workflow is a processor that applies a list of child processors to a new payload mapped from the original, and after processing attempts to overlay the results back onto the original payloads according to more mappings.
func NewWorkflow ¶
func NewWorkflow(conf *service.ParsedConfig, mgr bundle.NewManagement) (*Workflow, error)
NewWorkflow instantiates a new workflow processor.
Source Files ¶
- algorithms.go
- bloblang_encoding.go
- bloblang_general.go
- bloblang_numbers.go
- bloblang_objects.go
- bloblang_string.go
- bloblang_time.go
- buffer_memory.go
- buffer_none.go
- buffer_system_window.go
- cache_lru.go
- cache_memory.go
- cache_multilevel.go
- cache_noop.go
- cache_ttlru.go
- input_batched.go
- input_broker.go
- input_broker_fan_in.go
- input_generate.go
- input_inproc.go
- input_read_until.go
- input_resource.go
- input_sequence.go
- metrics_logger.go
- metrics_none.go
- output_broker.go
- output_broker_fan_out.go
- output_broker_fan_out_sequential.go
- output_broker_greedy.go
- output_broker_round_robin.go
- output_cache.go
- output_drop.go
- output_drop_on.go
- output_fallback.go
- output_inproc.go
- output_reject.go
- output_reject_errored.go
- output_resource.go
- output_retry.go
- output_switch.go
- output_sync_response.go
- package.go
- processor_archive.go
- processor_benchmark.go
- processor_bloblang.go
- processor_bounds_check.go
- processor_branch.go
- processor_cache.go
- processor_cached.go
- processor_catch.go
- processor_compress.go
- processor_decompress.go
- processor_dedupe.go
- processor_for_each.go
- processor_grok.go
- processor_group_by.go
- processor_group_by_value.go
- processor_insert_part.go
- processor_jmespath.go
- processor_jq.go
- processor_jsonschema.go
- processor_log.go
- processor_mapping.go
- processor_metric.go
- processor_mutation.go
- processor_noop.go
- processor_parallel.go
- processor_parse_log.go
- processor_processors.go
- processor_rate_limit.go
- processor_resource.go
- processor_retry.go
- processor_select_parts.go
- processor_sleep.go
- processor_split.go
- processor_switch.go
- processor_sync_response.go
- processor_try.go
- processor_unarchive.go
- processor_while.go
- processor_workflow.go
- processor_workflow_branch_map.go
- rate_limit_local.go
- scanner_chunker.go
- scanner_csv.go
- scanner_decompress.go
- scanner_json.go
- scanner_lines.go
- scanner_re_match.go
- scanner_skip_bom.go
- scanner_switch.go
- scanner_tar.go
- scanner_to_the_end.go
- tracer_none.go