Skip to content

Latest commit

 

History

History
2790 lines (1696 loc) · 88.5 KB

CHANGELOG.md

File metadata and controls

2790 lines (1696 loc) · 88.5 KB

Changelog

All notable changes to this project will be documented in this file.

Unreleased

3.65.0 - 2022-03-07

Added

  • New sql_raw processor and output.

Fixed

  • Corrected a case where nested parallel processors that result in emptied batches (all messages filtered) would propagate an unack rather than an acknowledgement.

Changed

  • The sql processor and output are no longer marked as deprecated and will therefore not be removed in V4. This change was made in order to provide more time to migrate to the new sql_raw processor and output.

3.64.0 - 2022-02-23

Added

  • Field nack_reject_patterns added to the amqp_0_9 input.
  • New experimental mongodb input.
  • Field cast added to the xml processor and parse_xml bloblang method.
  • New experimental gcp_bigquery_select processor.
  • New assign bloblang method.
  • The protobuf processor now supports Any fields in protobuf definitions.
  • The azure_queue_storage input field queue_name now supports interpolation functions.

Fixed

  • Fixed an issue where manually clearing errors within a catch processor would result in subsequent processors in the block being skipped.
  • The cassandra output should now automatically match float columns.
  • Fixed an issue where the elasticsearch output would collapse batched messages of matching ID rather than send as individual items.
  • Running streams mode with --no-api no longer removes the /ready endpoint.

Changed

  • The throttle processor has now been marked as deprecated.

3.63.0 - 2022-02-08

Added

  • Field cors added to the http_server input and output, for supporting CORS requests when custom servers are used.
  • Field server_side_encryption added to the aws_s3 output.
  • Field use_histogram_timing and histogram_buckets added to the prometheus metrics exporter.
  • New duration string and back off field types added to plugin config builders.
  • Experimental field multipart added to the http_client output.
  • Codec regex added to inputs.
  • Field timeout added to the cassandra output.
  • New experimental gcp_bigquery_select input.
  • Field ack_wait added to the nats_jetstream input.

Changed

  • The old map-style resource config fields (resources.processors.<name>, etc) are now marked as deprecated. Use the newer list based fields (processor_resources, etc) instead.

Fixed

  • The generate input now supports zeroed duration strings (0s, etc) for unbounded document creation.
  • The aws_dynamodb_partiql processor no longer ignores the endpoint field.
  • Corrected duplicate detection for custom cache implementations.
  • Fixed panic caused by invalid bounds in the range function.
  • Resource config files imported now allow (and ignore) a tests field.
  • Fixed an issue where the aws_kinesis input would fail to back off during unyielding read attempts.
  • Fixed a linting error with zmq4 input/output urls fields that was incorrectly expecting a string.

3.62.0 - 2022-01-21

Added

  • Field sync added to the gcp_pubsub input.
  • New input, processor, and output config field types added to the plugin APIs.
  • Added new experimental parquet processor.
  • New Bloblang method format_json.
  • Field collection in mongodb processor and output now supports interpolation functions.
  • Field output_raw added to the jq processor.
  • The lambda distribution now supports a BENTHOS_CONFIG_PATH environment variable for specifying a custom config path.
  • Field metadata added to http and http_client components.
  • Field ordering_key added to the gcp_pubsub output.
  • A suite of new experimental geoip_ methods have been added.
  • Added flag --deprecated to the benthos lint subcommand for detecting deprecated fields.

Changed

  • The sql processor and output have been marked deprecated in favour of the newer sql_insert, sql_select alternatives.

Fixed

  • The input codec chunked is no longer capped by the packet size of the incoming streams.
  • The schema_registry_decode and schema_registry_encode processors now honour trailing slashes in the url field.
  • Processors configured within pipeline.processors now share processors across threads rather than clone them.
  • Go API: Errors returned from input/output plugin Close methods no longer cause shutdown to block.
  • The pulsar output should now follow authentication configuration.
  • Fixed an issue where the aws_sqs output might occasionally retry a failed message send with an invalid empty message body.

3.61.0 - 2021-12-28

Added

  • Field json_marshal_mode added to the MongoDB processor.
  • Fields extract_headers.include_prefixes and extract_headers.include_patterns added to the http_client input and output and to the http processor.
  • Fields sync_response.metadata_headers.include_prefixes and sync_response.metadata_headers.include_patterns added to the http_server input.
  • The http_client input and output and the http processor field copy_response_headers has been deprecated in favour of the extract_headers functionality.
  • Added new cli flag --no-api for the streams subcommand to disable the REST API.
  • New experimental kafka_franz input and output.
  • Added new Bloblang function ksuid.
  • All codec input fields now support custom csv delimiters.

Fixed

  • Streams mode paths now resolve glob patterns in all cases.
  • Prevented the nats input from error logging when acknowledgments can't be fulfilled due to the lack of message replies.
  • Fixed an issue where GCP inputs and outputs could terminate requests early due to a cancelled client context.
  • Prevented more parsing errors in Bloblang mappings with windows style line endings.

3.60.1 - 2021-12-03

Fixed

  • Fixed an issue where the mongodb output would incorrectly report upsert not allowed on valid operators.

3.60.0 - 2021-12-01

Added

  • The pulsar input and output now support oauth2 and token authentication mechanisms.
  • The pulsar input now enriches messages with more metadata.
  • Fields message_group_id, message_deduplication_id, and metadata added to the aws_sns output.
  • Field upsert added to the mongodb processor and output.

Fixed

  • The schema_registry_encode and schema_registry_decode processors now honour path prefixes included in the url field.
  • The mqtt input and output keepalive field is now interpreted as seconds, previously it was being erroneously interpreted as nanoseconds.
  • The header Content-Type in the field http_server.sync_response.headers is now detected in a case insensitive way when populating multipart message encoding types.
  • The nats_jetstream input and outputs should now honour auth.* config fields.

3.59.0 - 2021-11-22

Added

  • New Bloblang method parse_duration_iso8601 for parsing ISO-8601 duration strings into an integer.
  • The nats input now supports metadata from headers when supported.
  • Field headers added to the nats output.
  • Go API: Optional field definitions added for config specs.
  • New (experimental) sql_select input.
  • New (experimental) sql_select and sql_insert processors, which will supersede the existing sql processor.
  • New (experimental) sql_insert output, which will supersede the existing sql output.
  • Field retained_interpolated added to the mqtt output.
  • Bloblang now allows optional carriage returns before line feeds at line endings.
  • New CLI flag -w/-watcher added for automatically detecting and applying configuration file changes.
  • Field avro_raw_json added to the schema_registry_encode processor.
  • New (experimental) msgpack processor.
  • New parse_msgpack and format_msgpack Bloblang methods.

Fixed

  • Fixed an issue where the azure_table_storage output would attempt to send >100 size batches (and fail).
  • Fixed an issue in the subprocess input where saturated stdout streams could become corrupted.

3.58.0 - 2021-11-02

Added

  • amqp_0_9 components now support TLS EXTERNAL auth.
  • Field urls added to the amqp_0_9 input and output.
  • New experimental schema_registry_encode processor.
  • Field write_timeout added to the mqtt output, and field connect_timeout added to both the input and output.
  • The websocket input and output now support custom tls configuration.
  • New output broker type fallback added as a drop-in replacement for the now deprecated try broker.

Fixed

  • Removed a performance bottleneck when consuming a large quantity of small files with the file input.

3.57.0 - 2021-10-14

Added

  • Go API: New config field types StringMap, IntList, and IntMap.
  • The http_client input, output and processor now include the response body in request error logs for more context.
  • Field dynamic_client_id_suffix added to the mqtt input and output.

Fixed

  • Corrected an issue where the sftp input could consume duplicate documents before shutting down when ran in batch mode.

3.56.0 - 2021-09-22

Added

  • Fields cache_control, content_disposition, content_language and website_redirect_location added to the aws_s3 output.
  • Field cors.enabled and cors.allowed_origins added to the server wide http config.
  • For Kafka components the config now supports the rack_id field which may contain a rack identifier for the Kafka client.
  • Allow mapping imports in Bloblang environments to be disabled.
  • Go API: Isolated Bloblang environments are now honored by all components.
  • Go API: The stream builder now evaluates environment variable interpolations.
  • Field unsafe_dynamic_query added to the sql processor.
  • The kafka output now supports zstd compression.

Fixed

  • The test subcommand now expands resource glob patterns (benthos -r "./foo/*.yaml" test ./...).
  • The Bloblang equality operator now returns false when comparing non-null values with null rather than a mismatched types error.

3.55.0 - 2021-09-08

Added

  • New experimental gcp_bigquery output.
  • Go API: It's now possible to parse a config spec directly with ParseYAML.
  • Bloblang methods and functions now support named parameters.
  • Field args_mapping added to the cassandra output.
  • For NATS, NATS Streaming and Jetstream components the config now supports specifying either nkey_file or user_credentials_file to configure authentication.

3.54.0 - 2021-09-01

Added

  • The mqtt input and output now support sending a last will, configuring a keep alive timeout, and setting retained out output messages.
  • Go API: New stream builder AddBatchProducerFunc and AddBatchConsumerFunc methods.
  • Field gzip_compression added to the elasticsearch output.
  • The redis_streams input now supports creating the stream with the MKSTREAM command (enabled by default).
  • The kafka output now supports manual partition allocation using interpolation functions in the field partition.

Fixed

  • The bloblang method contains now correctly compares numerical values in arrays and objects.

3.53.0 - 2021-08-19

Added

  • Go API: Added ability to create and register BatchBuffer plugins.
  • New system_window buffer for processing message windows (sliding or tumbling) following the system clock.
  • Field root_cas added to all TLS configuration blocks.
  • The sftp input and output now support key based authentication.
  • New Bloblang function nanoid.
  • The gcp_cloud_storage output now supports custom collision behaviour with the field collision_mode.
  • Field priority added to the amqp_0_9 output.
  • Operator keys added to the redis processor.
  • The http_client input when configured in stream mode now allows message body interpolation functions within the URL and header parameters.

Fixed

  • Fixed a panic that would occur when executing a pipeline where processor or input resources reference rate limits.

3.52.0 - 2021-08-02

Added

  • The elasticsearch output now supports delete, update and index operations.
  • Go API: Added ability to create and register BatchInput plugins.

Fixed

  • Prevented the http_server input from blocking graceful pipeline termination indefinitely.
  • Removed annoying nil error log from HTTP client components when parsing responses.

3.51.0 - 2021-07-26

Added

  • The redis_streams, redis_pubsub and redis_list outputs now all support batching for higher throughput.
  • The amqp_1 input and output now support passing and receiving metadata as annotations.
  • Config unit test definitions can now use files for both the input and expected output.
  • Field track_properties added to the azure_queue_storage input for enriching messages with properties such as the message backlog.
  • Go API: The new plugin APIs, available at ./public/service, are considered stable.
  • The streams mode API now uses the setting http.read_timeout for timing out stream CRUD endpoints.

Fixed

  • The Bloblang function random_int now only resolves dynamic arguments once during the lifetime of the mapping. Documentation has been updated in order to clarify the behaviour with dynamic arguments.
  • Fixed an issue where plugins registered would return failed to obtain docs for X type Y linting errors.
  • HTTP client components are now more permissive regarding invalid Content-Type headers.

3.50.0 - 2021-07-19

Added

  • New CLI flag --set (-s) for overriding arbitrary fields in a config. E.g. -s input.type=http_server would override the config setting the input type to http_server.
  • Unit test definitions now support mocking components.

3.49.0 - 2021-07-12

Added

  • The nats input now supports acks.
  • The memory and file cache types now expose metrics akin to other caches.

Fixed

  • The switch output when retry_until_success is set to false will now provide granular nacks to pre-batched messages.
  • The URL printed in error messages when HTTP client components fail should now show interpolated values as they were interpreted.
  • Go Plugins API V2: Batched processors should now show in tracing, and no longer complain about spans being closed more than once.

3.48.0 - 2021-06-25

Added

  • Algorithm lz4 added to the compress and decompress processors.
  • New experimental aws_dynamodb_partiql processor.
  • Go Plugins API: new run opt OptUseContext for an extra shutdown mechanism.

Fixed

  • Fixed an issue here the http_client would prematurely drop connections when configured with stream.enabled set to true.
  • Prevented closed output brokers from leaving child outputs running when they've failed to establish a connection.
  • Fixed metrics prefixes in streams mode for nested components.

3.47.0 - 2021-06-16

Added

  • CLI flag max-token-length added to the blobl subcommand.
  • Go Plugins API: Plugin components can now be configured seamlessly like native components, meaning the namespace plugin is no longer required and configuration fields can be placed within the namespace of the plugin itself. Note that the old style (within plugin) is still supported.
  • The http_client input fields url and headers now support interpolation functions that access metadata and contents of the last received message.
  • Rate limit resources now emit checked, limited and error metrics.
  • A new experimental plugins API is available for early adopters, and can be found at ./public/x/service.
  • A new experimental template system is available for early adopters, examples can be found in ./template.
  • New beta Bloblang method bloblang for executing dynamic mappings.
  • All http components now support a beta jwt authentication mechanism.
  • New experimental schema_registry_decode processor.
  • New Bloblang method parse_duration for parsing duration strings into an integer.
  • New experimental twitter_search input.
  • New field args_mapping added to the sql processor and output for mapping explicitly typed arguments.
  • Added format csv to the unarchive processor.
  • The redis processor now supports incrby operations.
  • New experimental discord input and output.
  • The http_server input now adds a metadata field http_server_verb.
  • New Bloblang methods parse_yaml and format_yaml.
  • CLI flag env-file added to Benthos for parsing dotenv files.
  • New mssql SQL driver for the sql processor and output.
  • New POST endpoint /resources/{type}/{id} added to Benthos streams mode for dynamically mutating resource configs.

Changed

  • Go Plugins API: The Bloblang ArgSpec now returns a public error type ArgError.
  • Components that support glob paths (file, csv, etc) now also support super globs (double asterisk).
  • The aws_kinesis input is now stable.
  • The gcp_cloud_storage input and output are now beta.
  • The kinesis input is now deprecated.
  • Go Plugins API: the minimum version of Go required is now 1.16.

Fixed

  • Fixed a rare panic caused when executing a workflow resource processor that references branch resources across parallel threads.
  • The mqtt input with multiple topics now works with brokers that would previously error on multiple subscriptions.
  • Fixed initialisation of components configured as resources that reference other resources, where under certain circumstances the components would fail to obtain a true reference to the target resource. This fix makes it so that resources are accessed only when used, which will also make it possible to introduce dynamic resources in future.
  • The streams mode endpoint /streams/{id}/stats should now work again provided the default manager is used.

3.46.1 - 2021-05-19

Fixed

  • The branch processor now writes error logs when the request or result map fails.
  • The branch processor (and workflow by proxy) now allow errors to be mapped into the branch using error() in the request_map.
  • Added a linting rule that warns against having a reject output under a switch broker without retry_until_success disabled.
  • Prevented a panic or variable corruption that could occur when a Bloblang mapping is executed by parallel threads.

3.46.0 - 2021-05-06

Added

  • The create subcommand now supports a --small/-s flag that reduces the output down to only core components and common fields.
  • Go Plugins API: Added method Overlay to the public Bloblang package.
  • The http_server input now adds path parameters (/{foo}/{bar}) to the metadata of ingested messages.
  • The stdout output now has a codec field.
  • New Bloblang methods format_timestamp_strftime and parse_timestamp_strptime.
  • New experimental nats_jetstream input and output.

Fixed

  • Go Plugins API: Bloblang method and function plugins now automatically resolve dynamic arguments.

3.45.1 - 2021-04-27

Fixed

  • Fixed a regression where the http_client input with an empty payload would crash with a url containing interpolation functions.
  • Broker output types (broker, try, switch) now automatically match the highest max_in_flight of their children. The field max_in_flight can still be manually set in order to enforce a minimum value for when inference isn't possible, such as with dynamic output resources.

3.45.0 - 2021-04-23

Added

  • Experimental azure_renew_lock field added to the amqp_1 input.
  • New beta root_meta function.
  • Field dequeue_visibility_timeout added to the azure_queue_storage input.
  • Field max_in_flight added to the azure_queue_storage output.
  • New beta Bloblang methods format_timestamp_unix and format_timestamp_unix_nano.
  • New Bloblang methods reverse and index_of.
  • Experimental extract_tracing_map field added to the kafka input.
  • Experimental inject_tracing_map field added to the kafka output.
  • Field oauth2.scopes added to HTTP components.
  • The mqtt input and output now support TLS.
  • Field enable_renegotiation added to tls configurations.
  • Bloblang if expressions now support an arbitrary number of else if blocks.

Fixed

  • The checkpoint_limit field for the kafka input now works according to explicit messages in flight rather than the actual offset. This means it now works as expected with compacted topics.
  • The aws_kinesis input should now automatically recover when the shard iterator has expired.
  • Corrected an issue where messages prefixed with valid JSON documents or values were being decoded in truncated form when the remainder was invalid.

Changed

  • The following beta components have been promoted to stable:
    • ristretto cache
    • csv and generate inputs
    • reject output
    • branch, jq and workflow processors

3.44.1 - 2021-04-15

Fixed

  • Fixed an issue where the kafka input with partition balancing wasn't committing offsets.

3.44.0 - 2021-04-09

Added

  • The http_server input now provides a metadata field http_server_request_path.
  • New methods sort_by and key_values added to Bloblang.

Fixed

  • Glob patterns for various components no longer resolve to bad paths in the absence of matches.
  • Fixed an issue where acknowledgements from the azure_queue_storage input would timeout prematurely, resulting in duplicated message delivery.
  • Unit test definitions no longer have implicit test cases when omitted.

3.43.1 - 2021-04-05

Fixed

  • Vastly improved Bloblang mapping errors.
  • The azure_blob_storage input will now gracefully terminate if the client credentials become invalid.
  • Prevented the experimental gcp_cloud_storage input from closing early during large file consumption.

3.43.0 - 2021-03-31

New

  • New (experimental) Apache Pulsar input and output.
  • Field codec added to the socket output.
  • New Bloblang method map_each_key.
  • General config linting improvements.
  • Bloblang mappings and interpolated fields within configs are now compile checked during linting.
  • New output level metadata.exclude_prefixes config field for restricting metadata values sent to the following outputs: kafka, aws_s3, amqp_0_9, redis_streams, aws_sqs, gcp_pubsub.
  • All NATS components now have tls support.
  • Bloblang now supports context capture in query lambdas.
  • New subcommand benthos blobl server that hosts a Bloblang editor web application.
  • New (experimental) mongodb output, cache and processor.
  • New (experimental) gcp_cloud_storage input and output.
  • Field batch_as_multipart added to the http_client output.
  • Inputs, outputs, processors, caches and rate limits now have a component level config field label, which sets the metrics and logging prefix.
  • Resources can now be declared in the new <component>_resources fields at the root of config files, the old resources.<component>s.<label> style is still valid for backwards compatibility reasons.
  • Bloblang mappings now support importing the entirety of a map from a path using from "<path>" syntax.

Fixed

  • Corrected ack behaviour for the beta azure_queue_storage input.
  • Bloblang compressed arithmetic expressions with field names (foo+bar) now correctly parse.
  • Fixed throughput issues with the aws_sqs input.
  • Prevented using the root keyword within Bloblang queries, returning an error message explaining alternative options. Eventually root references within queries will be fully supported and so returning clear errors messages is a temporary fix.
  • Increased the offset commit API version used by the kafka input to v0.8.2 when consuming explicit partitions.

Changed

  • Go API: Component implementations now require explicit import from ./public/components/all in order to be invokable. This should be done automatically at all plugin and custom build entry points. If, however, you notice that your builds have begun complaining that known components do not exist then you will need to explicitly import the package with _ "github.com/Jeffail/benthos/v3/public/components/all", if this is the case then please report it as an issue so that it can be dealt with.

3.42.1 - 2021-03-26

Fixed

  • Fixed a potential pipeline stall that would occur when non-batched outputs receive message batches.

3.42.0 - 2021-02-22

New

  • New azure_queue_storage input.
  • All inputs with a codec field now support multipart.
  • New codec field added to the http_client, socket, socket_server and stdin inputs.
  • The kafka input now allows an empty consumer group for operating without stored offsets.
  • The kafka input now supports partition ranges.

Fixed

  • The bloblang encode method algorithm ascii85 no longer returns an error when the input is misaligned.

3.41.1 - 2021-02-15

Fixed

  • The catch method now properly executes dynamic argument functions.

3.41.0 - 2021-02-15

New

  • New http fields cert_file and key_file, which when specified enforce HTTPS for the general Benthos server.
  • Bloblang method catch now supports deleted() as an argument.

Fixed

  • Fixed an issue with custom labels becoming stagnant with the influxdb metrics type.
  • Fixed a potential unhandled error when writing to the azure_queue_storage output.

3.40.0 - 2021-02-08

New

  • Experimental sharded_join fields added to the sequence input.
  • Added a new API for writing Bloblang plugins in Go at ./public/bloblang.
  • Field fields_mapping added to the log processor.

Fixed

  • Prevented pre-existing errors from failing/aborting branch execution in the branch and workflow processors.
  • Fixed subprocess processor message corruption with codecs length_prefixed_uint32_be and netstring.

Changed

  • The bloblang input has been renamed to generate. This change is backwards compatible and bloblang will still be recognized until the next major version release.
  • Bloblang more often preserves integer precision in arithmetic operations.

3.39.0 - 2021-02-01

New

  • Field key in output redis_list now supports interpolation functions.
  • Field tags added to output aws_s3.
  • New experimental sftp input and output.
  • New input codec chunker.
  • New field import_paths added to the protobuf processor, replaces the now deprecated import_path field.
  • Added format concatenate to the archive processor.

Changed

  • The aws_lambda processor now adds a metadata field lambda_function_error to messages when the function invocation suffers a runtime error.

Fixed

  • Fixed an issue with the azure_blob_storage output where blob_type set to APPEND could result in send failures.
  • Fixed a potential panic when shutting down a socket_server input with messages in flight.
  • The switch processor now correctly flags errors on messages that cause a check to throw an error.

3.38.0 - 2021-01-18

New

  • New bloblang method bytes.
  • The bloblang method index now works on byte arrays.
  • Field branch_resources added to the workflow processor.
  • Field storage_sas_token added to the azure_blob_storage input and output.
  • The bloblang method hash and the hash processor now support md5.
  • Field collector_url added to the jaeger tracer.
  • The bloblang method strip_html now allows you to specify a list of allowed elements.
  • New bloblang method parse_xml.
  • New bloblang method replace_many.
  • New bloblang methods filepath_split and filepath_join.

Changed

  • The cassandra outputs backoff.max_elapsed_time field was unused and has been hidden from docs.

3.37.0 - 2021-01-06

New

  • Field content_type and content_encoding added to the amqp_0_9 output.
  • Batching fields added to the hdfs output.
  • Field codec_send and codec_recv added to the subprocess processor.
  • Methods min, max, abs, log, log10 and ceil added to Bloblang.
  • Added field pattern_paths to the grok processor.
  • The grok processor now supports dots within field names for nested values.
  • New drop_on output.

Fixed

  • The xml processor now supports non UTF-8 encoding schemes.

Changed

  • The drop_on_error output has been deprecated in favour of the new drop_on output.

3.36.0 - 2020-12-24

New

  • New influxdb metrics target.
  • New azure_blob_storage input.
  • New azure_queue_storage output.
  • The bloblang input field interval now supports cron expressions.
  • New beta aws_kinesis and aws_sqs inputs.
  • The bool bloblang method now supports a wider range of string values.
  • New reject output type for conditionally rejecting messages.
  • All Redis components now support clustering and fail-over patterns.
  • The compress and decompress processors now support snappy.

Fixed

  • Fixed a panic on startup when using if statements within a workflow branch request or response map.
  • The meta bloblang function error messages now include the name of the required value.
  • Config unit tests now report processor errors when checks fail.
  • Environment variable interpolations now allow dots within the variable name.

Changed

  • The experimental aws_s3 input is now marked as beta.
  • The beta kinesis_balanced input is now deprecated.
  • All Azure components have been renamed to include the prefix azure_, e.g. blob_storage is now azure_blob_storage. The old names can still be used for backwards compatibility.
  • All AWS components have been renamed to include the prefix aws_, e.g. s3 is now aws_s3. The old names can still be used for backwards compatibility.

3.35.0 - 2020-12-07

New

  • New field retry_as_batch added to the kafka output to assist in ensuring message ordering through retries.
  • Field delay_period added to the experimental aws_s3 input.
  • Added service options for adding API middlewares and specify TLS options for plugin builds.
  • Method not_empty added to Bloblang.
  • New bloblang predicate type added to unit tests.
  • Unit test case field target_processors now allows you to optionally specify a target file.
  • Basic auth support added to the prometheus metrics pusher.

Changed

  • Unit tests that define environment variables that are run serially (parallel: false) will retain those environment variables during execution, as opposed to only at config parse time.
  • Lambda distributions now look for config files relative to the binary location, allowing you to deploy configs from the same zip as the binary.

Fixed

  • Add Content-Type headers in streams API responses.
  • Field delete_objects is now respected by the experimental aws_s3 input.
  • Fixed a case where resource processors couldn't access rate limit resources.
  • Input files that are valid according to the codec but empty now trigger acknowledgements.
  • Mapping deleted() within Bloblang object and array literals now correctly omits the values.

3.34.0 - 2020-11-20

New

  • New field format added to logger supporting json and logfmt.
  • The file input now provides the metadata field path on payloads.

Fixed

  • The output.sent metric now properly represents the number of individual messages sent even after archiving batches.
  • Fixed a case where metric processors in streams mode pipelines and dynamic components would hang.
  • Sync responses of >1 payloads should now get a correct rfc1341 multipart header.
  • The cassandra output now correctly marshals float and double values.
  • The nanomsg input with a SUB socket no longer attempts to set invalid timeout.

3.33.0 - 2020-11-16

Added

  • Added field codec to the file output.
  • The file output now supports dynamic file paths.
  • Added field ttl to the cache processor and output.
  • New sql output, which is similar to the sql processor and currently supports Clickhouse, PostgreSQL and MySQL.
  • The kafka input now supports multiple topics, topic partition balancing, and checkpointing.
  • New cassandra output.
  • Field allowed_verbs added to the http_server input and output.
  • New bloblang function now, and method parse_timestamp.
  • New bloblang methods floor and round.
  • The bloblang method format_timestamp now supports strings in ISO 8601 format as well as unix epochs with decimal precision up to nanoseconds.

Changed

  • The files output has been deprecated as its behaviour is now covered by file.
  • The kafka_balanced input has now been deprecated as its functionality has been added to the kafka input.
  • The cloudwatch metrics aggregator is now considered stable.
  • The sequence input is now considered stable.
  • The switch processor no longer permits cases with no processors.

Fixed

  • Fixed the tar and tar-gzip input codecs in experimental inputs.
  • Fixed a crash that could occur when referencing contextual fields within interpolation functions.
  • The noop processor can now be inferred with an empty object (noop: {}).
  • Fixed potential message corruption with the file input when using the lines codec.

3.32.0 - 2020-10-29

Added

  • The csv input now supports glob patterns in file paths.
  • The file input now supports multiple paths, glob patterns, and a range of codecs.
  • New experimental aws_s3 input.
  • All redis components now support TLS.
  • The -r cli flag now supports glob patterns.

Fixed

  • Bloblang literals, including method and function arguments, can now be mutated without brackets regardless of where they appear.
  • Bloblang maps now work when running bloblang with the blobl subcommand.

Changed

  • The ristretto cache no longer forces retries on get commands, and the retry fields have been changed in order to reflect this behaviour.

  • The files input has been deprecated as its behaviour is now covered by file.

  • Numbers within JSON documents are now parsed in a way that preserves precision even in cases where the number does not fit a 64-bit signed integer or float. When arithmetic is applied to those numbers (either in Bloblang or by other means) the number is converted (and precision lost) at that point based on the operation itself.

    This change means that string coercion on large numbers (e.g. root.foo = this.large_int.string()) should now preserve the original form. However, if you are using plugins that interact with JSON message payloads you must ensure that your plugins are able to process the json.Number type.

    This change should otherwise not alter the behaviour of your configs, but if you notice odd side effects you can disable this feature by setting the environment variable BENTHOS_USE_NUMBER to false (BENTHOS_USE_NUMBER=false benthos -c ./config.yaml). Please raise an issue if this is the case so that it can be looked into.

3.31.0 - 2020-10-15

Added

  • New input subprocess.
  • New output subprocess.
  • Field auto_ack added to the amqp_0_9 input.
  • Metric labels can be renamed for prometheus and cloudwatch metrics components using path_mapping by assigning meta fields.

Fixed

  • Metrics labels registered using the rename metrics component are now sorted before registering, fixing incorrect values that could potentially be seen when renaming multiple metrics to the same name.

3.30.0 - 2020-10-06

Added

  • OAuth 2.0 using the client credentials token flow is now supported by the http_client input and output, and the http processor.
  • Method format_timestamp added to Bloblang.
  • Methods re_find_object and re_find_all_object added to Bloblang.
  • Field connection_string added to the Azure blob_storage and table_storage outputs.
  • Field public_access_level added to the Azure blob_storage output.
  • Bloblang now supports trailing commas in object and array literals and function and method parameters.

Fixed

  • The amqp_1 input and output now re-establish connections to brokers on any unknown error.
  • Batching components now more efficiently attempt a final flush of data during graceful shutdown.
  • The dynamic output is now more flexible with removing outputs, and should no longer block the API as aggressively.

3.29.0 - 2020-09-21

Added

  • New cli flag log.level for overriding the configured logging level.
  • New integration test suite (much more dapper and also a bit more swanky than the last).

Changed

  • The default value for batching.count fields is now zero, which means adding a non-count based batching mechanism without also explicitly overriding count no longer incorrectly caps batches at one message. This change is backwards compatible in that working batching configs will not change in behaviour. However, a broken batching config will now behave as expected.

Fixed

  • Improved Bloblang parser error messages for function and method parameters.

3.28.0 - 2020-09-14

Added

  • New methods any, all and json_schema added to Bloblang.
  • New function file added to Bloblang.
  • The switch output can now route batched messages individually (when using the new cases field).
  • The switch processor now routes batched messages individually (when using the new cases field).
  • The workflow processor can now reference resource configured branch processors.
  • The metric processor now has a field name that replaces the now deprecated field path. When used the processor now applies to all messages of a batch and the name of the metric is now absolute, without being prefixed by a path generated based on its position within the config.
  • New field check added to group_by processor children, which now replaces the old condition field.
  • New field check added to while processor, which now replaces the old condition field.
  • New field check added to read_until input, which now replaces the old condition field.

Changed

  • The bloblang input with an interval configured now emits the first message straight away.

3.27.0 - 2020-09-07

Added

  • New function range added to Bloblang.
  • New beta jq processor.
  • New driver clickhouse added to the sql processor.

Changed

  • New field data_source_name replaces dsn for the sql processor, and when using this field each message of a batch is processed individually. When using the field dsn the behaviour remains unchanged for backwards compatibility.

Fixed

  • Eliminated situations where an amqp_0_9 or amqp_1 component would abandon a connection reset due to partial errors.
  • The Bloblang parser now allows naked negation of queries.
  • The cache processor interpolations for key and value now cross-batch reference messages before processing.

3.26.0 - 2020-08-30

Added

  • New Bloblang methods not_null and filter.
  • New Bloblang function env.
  • New field path_mapping added to all metrics types.
  • Field max_in_flight added to the dynamic output.
  • The workflow processor has been updated to use branch processors with the new field branches, these changes are backwards compatible with the now deprecated stages field.

Changed

  • The rename, whitelist and blacklist metrics types are now deprecated, and the path_mapping field should be used instead.
  • The conditional, process_map and process_dag processors are now deprecated and are superseded by the switch, branch and workflow processors respectively.

Fixed

  • Fixed http processor error log messages that would print incorrect URLs.
  • The http_server input now emits latency metrics.
  • Fixed a panic that could occur during the shutdown of an http_server input serving a backlog of requests.
  • Explicit component types (type: foo) are now checked by the config linter.
  • The amqp_1 input and output should now reconnect automatically after an unexpected link detach.

3.25.0 - 2020-08-16

Added

  • Improved parser error messages with the blobl subcommand.
  • Added flag file to the blobl subcommand.
  • New Bloblang method parse_timestamp_unix.
  • New beta protobuf processor.
  • New beta branch processor.
  • Batching fields added to s3 output.

Changed

  • The http processor field max_parallel has been deprecated in favour of rate limits, and the fields within request have been moved to the root of the http namespace. This change is backwards compatible and http.request fields will still be recognized until the next major version release.
  • The process_field processor is now deprecated, and branch should be used instead.

Fixed

  • Wholesale metadata mappings (meta = {"foo":"bar"}) in Bloblang now correctly clear pre-existing fields.

3.24.1 - 2020-08-03

Fixed

  • Prevented an issue where batched outputs would terminate at start up. Fixes a regression introduced in v3.24.0.

3.24.0 - 2020-08-02

Added

  • Endpoint /ready added to streams mode API.
  • Azure table_storage output now supports batched sends.
  • All HTTP components are now able to configure a proxy URL.
  • New ristretto cache.
  • Field shards added to memory cache.

Fixed

  • Batch error handling and retry logic has been improved for the kafka and dynamodb outputs.
  • Bloblang now allows non-matching not-equals comparisons, allowing foo != null expressions.

Changed

  • Condition check_interpolation has been deprecated.

3.23.0 - 2020-07-26

Added

  • Path segments in Bloblang mapping targets can now be quote-escaped.
  • New beta sequence input, for sequentially chaining inputs.
  • New beta csv input for consuming CSV files.
  • New beta Azure table_storage output.
  • New parse_csv Bloblang method.
  • New throw Bloblang function.
  • The slice Bloblang method now supports negative low and high arguments.

Fixed

  • Manual mqtt connection handling for both the input and output. This should fix some cases where connections were dropped and never recovered.
  • Fixed Bloblang error where calls to a .get method would return null after the first query.
  • The for_each processor no longer interlaces child processors during split processing.

3.22.0 - 2020-07-19

Added

  • Added TLS fields to elasticsearch output.
  • New Bloblang methods encrypt_aes and decrypt_aes added.
  • New field static_headers added to the kafka output.
  • New field enabled added to the http config section.
  • Experimental CLI flag -resources added for specifying files containing extra resources.

Fixed

  • The amqp_0_9 now resolves type and key fields per message of a batch.

3.21.0 - 2020-07-12

Added

  • New beta bloblang input for generating documents.
  • New beta Azure blob_storage output.
  • Field sync_response.status added to http_server input.
  • New Bloblang errored function.

Fixed

  • The json_schema processor no longer lower cases fields within error messages.
  • The dynamodb cache no longer creates warning logs for get misses.

3.20.0 - 2020-07-05

Added

  • SASL config fields added to amqp_1 input and output.
  • The lint subcommand now supports triple dot wildcard paths: ./foo/....
  • The test subcommand now supports tests defined within the target config file being tested.

Fixed

  • Bloblang boolean operands now short circuit.

3.19.0 - 2020-06-28

Added

  • Fields strict_mode and max_in_flight added to the switch output.
  • New beta amqp_1 input and output added.

3.18.0 - 2020-06-14

Added

  • Field drop_empty_bodies added to the http_client input.

Fixed

  • Fixed deleting and skipping maps with the blobl subcommand.

3.17.0 - 2020-06-07

Added

  • New field type added to the amqp_0_9 output.
  • New bloblang methods explode and without.

Fixed

  • Message functions such as json and content now work correctly when executing bloblang with the blobl sub command.

3.16.0 - 2020-05-31

Added

  • New bloblang methods type, join, unique, escape_html, unescape_html, re_find_all and re_find_all_submatch.
  • Bloblang sort method now allows custom sorting functions.
  • Bloblang now supports if expressions.
  • Bloblang now allows joining strings with the + operator.
  • Bloblang now supports multiline strings with triple quotes.

Changed

  • The xml processor is now less strict with XML parsing, allowing unrecognised escape sequences to be passed through unchanged.

Fixed

  • The bloblang method map_each now respects Nothing mapping by copying the underlying value unchanged.
  • It's now possible to reference resource inputs and outputs in streams mode.
  • Fixed a problem with compiling old interpolation functions with arguments containing colons (i.e. ${!timestamp_utc:2006-01-02T15:04:05.000Z})

3.15.0 - 2020-05-24

Added

  • Flag log added to test sub command to allow logging during tests.
  • New subcommand blobl added for convenient mapping over the command line.
  • Lots of new bloblang methods.

Fixed

  • The redis_streams input no longer incorrectly copies message data into a metadata field.

Changed

  • Bloblang is no longer considered beta. Therefore, no breaking changes will be introduced outside of a major version release.

3.14.0 - 2020-05-17

Added

  • New ascii85 and z85 options have been added to the encode and decode processors.

Bloblang BETA Changes

  • The meta function no longer reflects changes made within the map itself.
  • Extracting data from other messages of a batch using from no longer reflects changes made within a map.
  • Meta assignments are no longer allowed within named maps.
  • Assigning deleted() to root now filters out a message entirely.
  • Lots of new methods and goodies.

3.13.0 - 2020-05-10

Added

  • New HMAC algorithms added to hash processor.
  • New beta bloblang processor.
  • New beta bloblang condition.

Fixed

  • Prevented a crash that might occur with high-concurrent access of http_server metrics with labels.
  • The http_client output now respects the copy_response_headers field.

3.12.0 - 2020-04-19

Added

  • Vastly improved function interpolations, including better batch handling and arithmetic operators.
  • The gcp_pubsub output now supports function interpolation on the field topic.
  • New contains_any and contains_any_cs operators added to the text condition.
  • Support for input and output resource types.
  • The broker and switch output types now allow async messages and batching within child outputs.
  • Field schema_path added to the avro processor.
  • The redis cache, redis_list inputs and outputs now support selecting a database with the URL path.
  • New field max_in_flight added to the broker output.

Changed

  • Benthos now runs in strict mode, but this can be disabled with --chilled.
  • The Benthos CLI has been revamped, the old flags are still supported but are deprecated.
  • The http_server input now accepts requests without a content-type header.

Fixed

  • Outputs that resolve function interpolations now correctly resolve the batch_size function.
  • The kinesis_balanced input now correctly establishes connections.
  • Fixed an auth transport issue with the gcp_pubsub input and output.

3.11.0 - 2020-03-08

Added

  • Format syslog_rfc3164 added to the parse_log processor.
  • New multilevel cache.
  • New json_append, json_type and json_length functions added to the awk processor.
  • New flatten operator added to the json processor.

Changed

  • Processors that fail now set the opentracing tag error to true.

Fixed

  • Kafka connectors now correctly set username and password for all SASL strategies.

3.10.0 - 2020-02-05

Added

  • Field delete_files added to files input.
  • TLS fields added to nsq input and output.
  • Field processors added to batching fields to easily accommodate aggregations and archiving of batched messages.
  • New parse_log processor.
  • New json condition.
  • Operators flatten_array, fold_number_array and fold_string_array added to json processor.

Changed

  • The redis_streams input no longer flushes >1 fetched messages as a batch.

Fixed

  • Re-enabled Kafka connections using SASL without TLS.

3.9.0 - 2020-01-27

Added

  • New socket, socket_server inputs.
  • New socket output.
  • Kafka connectors now support SASL using OAUTHBEARER, SCRAM-SHA-256, SCRAM-SHA-512 mechanisms.
  • Experimental support for AWS CloudWatch metrics.

Changed

  • The tcp, tcp_server and udp_server inputs have been deprecated and moved into the socket and socket_server inputs respectively.
  • The udp and tcp outputs have been deprecated and moved into the socket output.

Fixed

  • The subprocess processor now correctly flags errors that occur.

3.8.0 - 2020-01-17

Added

  • New field max_in_flight added to the following outputs:
    • amqp_0_9
    • cache
    • dynamodb
    • elasticsearch
    • gcp_pubsub
    • hdfs
    • http_client
    • kafka
    • kinesis
    • kinesis_firehose
    • mqtt
    • nanomsg
    • nats
    • nats_stream
    • nsq
    • redis_hash
    • redis_list
    • redis_pubsub
    • redis_streams
    • s3
    • sns
    • sqs
  • Batching fields added to the following outputs:
    • dynamodb
    • elasticsearch
    • http_client
    • kafka
    • kinesis
    • kinesis_firehose
    • sqs
  • More TRACE level logs added throughout the pipeline.
  • Operator delete added to cache processor.
  • Operator explode added to json processor.
  • Field storage_class added to s3 output.
  • Format json_map added to unarchive processor.

Fixed

  • Function interpolated strings within the json processor value field are now correctly unicode escaped.
  • Retry intervals for kafka output have been tuned to prevent circuit breaker throttling.

3.7.0 - 2019-12-21

Added

  • New try output, which is a drop-in replacement for a broker with the try pattern.
  • Field successful_on added to the http processor.
  • The statsd metrics type now supports Datadog or InfluxDB tagging.
  • Field sync_response.headers added to http_server input.
  • New sync_response processor.
  • Field partitioner added to the kafka output.

Changed

  • The http processor now gracefully handles empty responses.

Fixed

  • The kafka input should now correctly recover from coordinator failures during an offset commit.
  • Attributes permitted by the sqs output should now have parity with real limitations.

3.6.1 - 2019-12-05

Fixed

  • Batching using an input broker now works with only one child input configured.
  • The zmq4 input now correctly supports broker based batching.

3.6.0 - 2019-12-03

Added

  • New workflow processor.
  • New resource processor.
  • Processors can now be registered within the resources section of a config.

Changed

  • The mqtt output field topic field now supports interpolation functions.

Fixed

  • The kafka output no longer attempts to send headers on old versions of the protocol.

3.5.0 - 2019-11-26

Added

  • New regexp_expand operator added to the text processor.
  • New json_schema processor.

3.4.0 - 2019-11-12

Added

  • New amqp_0_9 output which replaces the now deprecated amqp output.
  • The broker output now supports batching.

Fixed

  • The memory buffer now allows parallel processing of batched payloads.
  • Version and date information should now be correctly displayed in archive distributions.

3.3.1 - 2019-10-21

Fixed

  • The s3 input now correctly unescapes bucket keys when streaming from SQS.

3.3.0 - 2019-10-20

Added

  • Field sqs_endpoint added to the s3 input.
  • Field kms_key_id added to the s3 output.
  • Operator delete added to metadata processor.
  • New experimental metrics aggregator stdout.
  • Field ack_wait added to nats_stream input.
  • New batching field added to broker input for batching merged streams.
  • Field healthcheck added to elasticsearch output.
  • New json_schema condition.

Changed

  • Experimental kafka_cg input has been removed.
  • The kafka_balanced inputs underlying implementation has been replaced with the kafka_cg one.
  • All inputs have been updated to automatically utilise >1 processing threads, with the exception of kafka and kinesis.

3.2.0 - 2019-09-27

Added

  • New is operator added to text condition.
  • New config unit test condition content_matches.
  • Field init_values added to the memory cache.
  • New split operator added to json processor.
  • Fields user and password added to mqtt input and output.
  • New experimental amqp_0_9 input.

Changed

  • Linting is now disabled for the environment var config shipped with docker images, this should prevent the log spam on start up.
  • Go API: Experimental reader.Async component methods renamed.

3.1.1 - 2019-09-23

Fixed

  • Prevented kafka_cg input lock up after batch policy period trigger with no backlog.

3.1.0 - 2019-09-23

Added

  • New redis processor.
  • New kinesis_firehose output.
  • New experimental kafka_cg input.
  • Go API: The metrics.Local aggregator now supports labels.

Fixed

  • The json processor no longer removes content moved from a path to the same path.

3.0.0 - 2019-09-17

This is a major version release, for more information and guidance on how to migrate please refer to https://benthos.dev/docs/guides/migration/v3.

Added

  • The json processor now allows you to move from either a root source or to a root destination.
  • Added interpolation to the metadata processor key field.
  • Granular retry fields added to kafka output.

Changed

  • Go modules are now fully supported, imports must now include the major version (e.g. github.com/Jeffail/benthos/v3).
  • Removed deprecated mmap_file buffer.
  • Removed deprecated (and undocumented) metrics paths.
  • Moved field prefix from root of metrics into relevant child components.
  • Names of process_dag stages must now match the regexp [a-zA-Z0-9_-]+.
  • Go API: buffer constructors now take a types.Manager argument in parity with other components.
  • JSON dot paths within the following components have been updated to allow array-based operations:
    • awk processor
    • json processor
    • process_field processor
    • process_map processor
    • check_field condition
    • json_field function interpolation
    • s3 input
    • dynamodb output

Fixed

  • The sqs output no longer attempts to send invalid attributes with payloads from metadata.
  • During graceful shutdown Benthos now scales the attempt to propagate acks for sent messages with the overall system shutdown period.

2.15.1 - 2019-09-10

Fixed

  • The s3 and sqs inputs should now correctly log handles and codes from failed SQS message deletes and visibility timeout changes.

2.15.0 - 2019-09-03

Added

  • New message_group_id and message_deduplication_id fields added to sqs output for supporting FIFO queues.

2.14.0 - 2019-08-29

Added

  • Metadata field gcp_pubsub_publish_time_unix added to gcp_pubsub input.
  • New tcp and tcp_server inputs.
  • New udp_server input.
  • New tcp and udp outputs.
  • Metric paths output.batch.bytes and output.batch.latency added.
  • New rate_limit processor.

Fixed

  • The json processor now correctly stores parsed value JSON when using set on the root path.

2.13.0 - 2019-08-27

Added

  • The sqs input now adds some message attributes as metadata.
  • Added field delete_message to sqs input.
  • The sqs output now sends metadata as message attributes.
  • New batch_policy field added to memory buffer.
  • New xml processor.

Fixed

  • The prometheus metrics exporter adds quantiles back to timing metrics.

2.12.2 - 2019-08-19

Fixed

  • Capped slices from lines reader are now enforced.
  • The json processor now correctly honours a null value.

2.12.1 - 2019-08-16

Changed

  • Disabled kinesis_balanced input for WASM builds.

2.12.0 - 2019-08-16

Added

  • Field codec added to process_field processor.
  • Removed experimental status from sync responses components, which are now considered stable.
  • Field pattern_definitions added to grok processor.

Changed

  • Simplified serverless lambda main function body for improving plugin documentation.

Fixed

  • Fixed a bug where the prepend and append operators of the text processor could result in invalid messages when consuming line-based inputs.

2.11.2 - 2019-08-06

Added

  • Field clean_session added to mqtt input.
  • The http_server input now adds request query parameters to messages as metadata.

2.11.1 - 2019-08-05

Fixed

  • Prevent concurrent access race condition on nested parallel process_map processors.

2.11.0 - 2019-08-03

Added

  • New beta input kinesis_balanced.
  • Field profile added to AWS components credentials config.

2.10.0 - 2019-07-29

Added

  • Improved error messages attached to payloads that fail process_dag. post mappings.
  • New redis_hash output.
  • New sns output.

2.9.3 - 2019-07-18

Added

  • Allow extracting metric rename submatches into labels.
  • Field use_patterns added to redis_pubsub input for subscribing to channels using glob-style patterns.

2.9.2 - 2019-07-17

Changed

  • Go API: It's now possible to specify a custom config unit test file path suffix.

2.9.1 - 2019-07-15

Added

  • New rate limit and websocket message fields added to http_server input.
  • The http processor now optionally copies headers from response into resulting message metadata.
  • The http processor now sets a http_status_code metadata value into resulting messages (provided one is received.)

Changed

  • Go API: Removed experimental Block functions from the cache and rate limit packages.

2.9.0 - 2019-07-12

Added

  • New (experimental) command flags --test and --gen-test added.
  • All http client components output now set a metric request_timeout.

2.8.6 - 2019-07-10

Added

  • All errors caught by processors should now be accessible via the ${!error} interpolation function, rather than just flagged as true.

Fixed

  • The process_field processor now propagates metadata to the original payload with the result_type set to discard. This allows proper error propagation.

2.8.5 - 2019-07-03

Added

  • Field max_buffer added to subprocess processor.

Fixed

  • The subprocess processor now correctly logs and recovers subprocess pipeline related errors (such as exceeding buffer limits.)

2.8.4 - 2019-07-02

Added

  • New json_delete function added to the awk processor.

Fixed

  • SQS output now correctly waits between retry attempts and escapes error loops during shutdown.

2.8.3 - 2019-06-28

Added

  • Go API: Add RunWithOpts opt OptOverrideConfigDefaults.

Fixed

  • The filter and filter_parts config sections now correctly marshall when printing with --all.

2.8.2 - 2019-06-28

Added

  • Go API: A new service method RunWithOpts has been added in order to accomodate service customisations with opt funcs.

2.8.1 - 2019-06-28

  • New interpolation function error.

2.8.0 - 2019-06-24

Added

  • New number condition.
  • New number processor.
  • New avro processor.
  • Operator enum added to text condition.
  • Field result_type added to process_field processor for marshalling results into non-string types.
  • Go API: Plugin APIs now allow nil config constructors.
  • Registering plugins automatically adds plugin documentation flags to the main Benthos service.

2.7.0 - 2019-06-20

Added

  • Output http_client is now able to propagate responses from each request back to inputs supporting sync responses.
  • Added support for Gzip compression to http_server output sync responses.
  • New check_interpolation condition.

2.6.0 - 2019-06-18

Added

  • New sync_response output type, with experimental support added to the http_server input.
  • SASL authentication fields added to all Kafka components.

2.5.0 - 2019-06-14

Added

  • The s3 input now sets s3_content_encoding metadata (when not using the download manager.)
  • New trace logging for the rename, blacklist and whitelist metric components to assist with debugging.

2.4.0 - 2019-06-06

Added

  • Ability to combine sync and async responses in serverless distributions.

Changed

  • The insert_part, merge_json and unarchive processors now propagate message contexts.

2.3.2 - 2019-06-05

Fixed

  • JSON processors no longer escape &, <, and > characters by default.

2.3.1 - 2019-06-04

Fixed

  • The http processor now preserves message metadata and contexts.
  • Any http components that create requests with messages containing empty bodies now correctly function in WASM.

2.3.0 - 2019-06-04

Added

  • New fetch_buffer_cap field for kafka and kafka_balanced inputs.
  • Input gcp_pubsub now has the field max_batch_count.

Changed

  • Reduced allocations under most JSON related processors.
  • Streams mode API now logs linting errors.

2.2.4 - 2019-06-02

Added

  • New interpolation function batch_size.

2.2.3 - 2019-05-31

Fixed

  • Output elasticsearch no longer reports index not found errors on connect.

2.2.2 - 2019-05-30

Fixed

  • Input reader no longer overrides message contexts for opentracing spans.

2.2.1 - 2019-05-29

Fixed

  • Improved construction error messages for broker and switch input and outputs.

Changed

  • Plugins that don't use a configuration structure can now return nil in their sanitise functions in order to have the plugin section omitted.

2.2.0 - 2019-05-22

Added

  • The kafka and kafka_balanced inputs now set a kafka_lag metadata field to incoming messages.
  • The awk processor now has a variety of typed json_set functions json_set_int, json_set_float and json_set_bool.
  • Go API: Add experimental function for blocking cache and ratelimit constructors.

Fixed

  • The json processor now defaults to an executable operator (clean).

2.1.3 - 2019-05-20

Added

  • Add experimental function for blocking processor constructors.

2.1.2 - 2019-05-20

Added

  • Core service logic has been moved into new package service, making it easier to maintain plugin builds that match upstream Benthos.

2.1.1 - 2019-05-17

Added

  • Experimental support for WASM builds.

2.1.0 - 2019-05-16

Added

  • Config linting now reports line numbers.
  • Config interpolations now support escaping.

2.0.0 - 2019-05-14

Added

  • API for creating cache implementations.
  • API for creating rate_limit implementations.

Changed

This is a major version released due to a series of minor breaking changes, you can read the full migration guide here.

Configuration

  • Benthos now attempts to infer the type of config sections whenever the field is omitted, for more information please read this overview: Concise Configuration.
  • Field unsubscribe_on_close of the nats_stream input is now false by default.

Service

  • The following commandline flags have been removed: swap-envs, plugins-dir, list-input-plugins, list-output-plugins, list-processor-plugins, list-condition-plugins.

Go API

  • Package github.com/Jeffail/benthos/lib/processor/condition changed to github.com/Jeffail/benthos/lib/condition.
  • Interface types.Cache now has types.Closable embedded.
  • Interface types.RateLimit now has types.Closable embedded.
  • Add method GetPlugin to interface types.Manager.
  • Add method WithFields to interface log.Modular.

1.20.4 - 2019-05-13

Fixed

  • Ensure process_batch processor gets normalised correctly.

1.20.3 - 2019-05-11

Added

  • New for_each processor with the same behaviour as process_batch, process_batch is now considered an alias for for_each.

1.20.2 - 2019-05-10

Changed

  • The sql processor now executes across the batch, documentation updated to clarify.

1.20.1 - 2019-05-10

Fixed

  • Corrected result_codec field in sql processor config.

1.20.0 - 2019-05-10

Added

  • New sql processor.

Fixed

  • Using json_map_columns with the dynamodb output should now correctly store null and array values within the target JSON structure.

1.19.2 - 2019-05-09

Added

  • New encode and decode scheme hex.

Fixed

  • Fixed potential panic when attempting an invalid HTTP client configuration.

1.19.1 - 2019-05-08

Fixed

  • Benthos in streams mode no longer tries to load directory /benthos/streams by default.

1.19.0 - 2019-05-07

Added

  • Field json_map_columns added to dynamodb output.

1.18.0 - 2019-05-06

Added

  • JSON references are now supported in configuration files.

1.17.0 - 2019-05-04

Added

  • The hash processor now supports sha1.
  • Field force_path_style_urls added to s3 components.
  • Field content_type of the s3 output is now interpolated.
  • Field content_encoding added to s3 output.

Fixed

  • The benthos-lambda distribution now correctly returns all message parts in synchronous execution.

Changed

  • Docker builds now use a locally cached vendor for dependencies.
  • All s3 components no longer default to enforcing path style URLs.

1.16.0 - 2019-04-30

Added

  • New output drop_on_error.
  • Field retry_until_success added to switch output.

Fixed

  • Improved error and output logging for subprocess processor when the process exits unexpectedly.

1.15.0 - 2019-04-26

Changed

  • The main docker image is now based on busybox.
  • Lint rule added for batch processors outside of the input section.

1.14.3 - 2019-04-25

Fixed

  • Removed potential benthos-lambda panic on shut down.

1.14.2 - 2019-04-25

Fixed

  • The redis cache no longer incorrectly returns a "key not found" error instead of connection errors.

1.14.1 - 2019-04-24

Changed

  • Changed docker tag format from vX.Y.Z to X.Y.Z.

1.14.0 - 2019-04-24

Added

  • Output broker pattern fan_out_sequential.
  • Output type drop for dropping all messages.
  • New interpolation function timestamp_utc.

1.13.0 - 2019-04-22

Added

  • New benthos-lambda distribution for running Benthos as a lambda function.

1.12.0 - 2019-04-21

Added

  • New s3 cache implementation.
  • New file cache implementation.
  • Operators quote and unquote added to the text processor.
  • Configs sent via the streams mode HTTP API are now interpolated with environment variable substitutes.

Changed

  • All AWS s3 components now enforce path style syntax for bucket URLs. This improves compatibility with third party endpoints.

1.11.0 - 2019-04-12

Added

  • New parallel processor.

Fixed

  • The dynamodb cache get call now correctly reports key not found versus general request error.

1.10.10 - 2019-04-10

Added

  • New sqs_bucket_path field added to s3 input.

Fixed

  • The sqs input now rejects messages that fail by resetting the visibility timeout.
  • The sqs input no longer fails to delete consumed messages when the batch contains duplicate message IDs.

1.10.9 - 2019-04-05

Fixed

  • The metric processor no longer mixes label keys when processing across parallel pipelines.

1.10.8 - 2019-04-03

Added

  • Comma separated kafka and kafka_balanced address and topic values are now trimmed for whitespace.

1.10.6 - 2019-04-02

Added

  • Field max_processing_period added to kafka and kafka_balanced inputs.

Fixed

  • Compaction intervals are now respected by the memory cache type.

1.10.5 - 2019-03-29

Fixed

  • Improved kafka_balanced consumer group connection behaviour.

1.10.4 - 2019-03-29

Added

  • More kafka_balanced input config fields for consumer group timeouts.

1.10.3 - 2019-03-28

Added

  • New config interpolation function uuid_v4.

1.10.2 - 2019-03-21

Fixed

  • The while processor now correctly checks conditions against the first batch of the result of last processor loop.

1.10.1 - 2019-03-19

Added

  • Field max_loops added to while processor.

1.10.0 - 2019-03-18

Added

  • New while processor.

1.9.0 - 2019-03-17

Added

  • New cache processor.
  • New all condition.
  • New any condition.

1.8.0 - 2019-03-14

Added

  • Function interpolation for field subject added to nats output.

Changed

  • Switched underlying kafka_balanced implementation to sarama consumer.

1.7.10 - 2019-03-11

Fixed

  • Always allow acknowledgement flush during graceful termination.

1.7.9 - 2019-03-08

Fixed

  • Removed unnecessary subscription check from gcp_pubsub input.

1.7.7 - 2019-03-08

Added

  • New field fields added to log processor for structured log output.

1.7.3 - 2019-03-05

Added

  • Function interpolation for field channel added to redis_pubsub output.

1.7.2 - 2019-03-01

Added

  • Field byte_size added to split processor.

1.7.1 - 2019-02-27

Fixed

  • Field dependencies of children of the process_dag processor now correctly parsed from config files.

1.7.0 - 2019-02-26

Added

  • Field push_job_name added to prometheus metrics type.
  • New rename metrics target.

Fixed

  • Removed potential race condition in process_dag with raw bytes conditions.

1.6.1 - 2019-02-21

Added

  • Field max_batch_count added to s3 input.
  • Field max_number_of_messages added to sqs input.

1.6.0 - 2019-02-20

Added

  • New blacklist metrics target.
  • New whitelist metrics target.
  • Initial support for opentracing, including a new tracer root component.
  • Improved generated metrics documentation and config examples.
  • The nats_stream input now has a field unsubscribe_on_close that when disabled allows durable subscription offsets to persist even when all connections are closed.
  • Metadata field nats_stream_sequence added to nats_stream input.

1.5.1 - 2019-02-11

Fixed

  • The subprocess processor no longer sends unexpected empty lines when messages end with a line break.

1.5.0 - 2019-02-07

Added

  • New switch processor.

Fixed

  • Printing configs now sanitises resource sections.

1.4.1 - 2019-02-04

Fixed

  • The headers field in http configs now detects and applies host keys.

1.4.0 - 2019-02-04

Added

  • New json_documents format added to the unarchive processor.
  • Field push_interval added to the prometheus metrics type.

1.3.2 - 2019-01-31

Fixed

  • Brokers now correctly parse configs containing plugin types as children.

1.3.1 - 2019-01-30

Fixed

  • Output broker types now correctly allocates nested processors for fan_out and try patterns.
  • JSON formatted loggers now correctly escape error messages with line breaks.

1.3.0 - 2019-01-29

Added

  • Improved error logging for s3 input download failures.
  • More metadata fields copied to messages from the s3 input.
  • Field push_url added to the prometheus metrics target.

1.2.1 - 2019-01-28

Added

  • Resources (including plugins) that implement Closable are now shutdown cleanly.

1.2.0 - 2019-01-28

Added

  • New json_array format added to the archive and unarchive processors.
  • Preliminary support added to the resource manager API to allow arbitrary shared resource plugins.

1.1.4 - 2019-01-23

Fixed

  • The s3 input now caps and iterates batched SQS deletes.

1.1.3 - 2019-01-22

Fixed

  • The archive processor now interpolates the path per message of the batch.

1.1.2 - 2019-01-21

Fixed

  • Fixed environment variable interpolation when combined with embedded function interpolations.
  • Fixed break down metric indexes for input and output brokers.

1.1.0 - 2019-01-17

Added

  • Input s3 can now toggle the use of a download manager, switching off now downloads metadata from the target file.
  • Output s3 now writes metadata to the uploaded file.
  • Operator unescape_url_query added to text processor.

Fixed

  • The nats_steam input and output now actively attempt to recover stale connections.
  • The awk processor prints errors and flags failure when the program exits with a non-zero status.

1.0.2 - 2019-01-07

Fixed

  • The subprocess processor now attempts to read all flushed stderr output from a process when it fails.

1.0.1 - 2019-01-05

Added

  • Function print_log added to awk processor.

Fixed

  • The awk processor function json_get no longer returns string values with quotes.

1.0.0 - 2019-01-01

Changed

  • Processor awk codecs changed.

0.42.4 - 2018-12-31

Changed

  • Output type sqs now supports batched message sends.

0.42.3 - 2018-12-28

Added

  • Functions json_get and json_set added to awk processor.

0.42.1 - 2018-12-20

Added

  • Functions timestamp_format, timestamp_format_nano, metadata_get and metadata_set added to awk processor.

0.42.0 - 2018-12-19

Added

  • New sleep processor.
  • New awk processor.

Changed

  • Converted all integer based time period fields to string based, e.g. timeout_ms: 5000 would now be timeout: 5s. This will may potentially be disruptive but the --strict flag should catch all deprecated fields in an existing config.

0.41.0 - 2018-12-12

Changed

  • Renamed max_batch_size to max_batch_count for consistency.

0.40.2 - 2018-12-12

Added

  • New max_batch_size field added to kafka, kafka_balanced and amqp inputs. This provides a mechanism for creating message batches optimistically.

0.40.0 - 2018-12-10

Added

  • New subprocess processor.

Changed

  • API: The types.Processor interface has been changed in order to add lifetime cleanup methods (added CloseAsync and WaitForClose). For the overwhelming majority of processors these functions will be no-ops.
  • More consistent condition metrics.

0.39.2 - 2018-12-07

Added

  • New try and catch processors for improved processor error handling.

0.39.1 - 2018-12-07

Added

  • All processors now attach error flags.
  • S3 input is now more flexible with SNS triggered SQS events.

Changed

  • Processor metrics have been made more consistent.

0.39.0 - 2018-12-05

Added

  • New endpoint /ready that returns 200 when both the input and output components are connected, otherwise 503. This is intended to be used as a readiness probe.

Changed

  • Large simplifications to all metrics paths.
  • Fully removed the previously deprecated combine processor.
  • Input and output plugins updated to support new connection health checks.

0.38.10 - 2018-12-04

Added

  • Field role_external_id added to all S3 credential configs.
  • New processor_failed condition and improved processor error handling which can be read about here

0.38.8 - 2018-11-29

Added

  • New content_type field for the s3 output.

0.38.6 - 2018-11-28

Added

  • New group_by_value processor.

0.38.5 - 2018-11-27

Added

  • Lint errors are logged (level INFO) during normal Benthos operation.
  • New --strict command flag which causes Benthos to abort when linting errors are found in a config file.

0.38.4 - 2018-11-26

Added

  • New --lint command flag for linting config files.

0.38.1 - 2018-11-23

Changed

  • The s3 output now attempts to batch uploads.
  • The s3 input now exposes errors in deleting SQS messages during acks.

0.38.0 - 2018-11-22

Changed

  • Resource based conditions no longer benefit from cached results. In practice this optimisation was easy to lose in config and difficult to maintain.

0.37.4 - 2018-11-22

Added

  • Metadata is now sent to kafka outputs.
  • New max_inflight field added to the nats_stream input.

Fixed

  • Fixed relative path trimming for streams from file directories.

0.37.2 - 2018-11-15

Fixed

  • The dynamodb cache and output types now set TTL columns as unix timestamps.

0.37.1 - 2018-11-13

Added

  • New escape_url_query operator for the text processor.

0.37.0 - 2018-11-09

Changed

  • Removed submatch indexes in the text processor find_regexp operator and added documentation for expanding submatches in the replace_regexp operator.

0.36.4 - 2018-11-09

Added

  • Allow submatch indexes in the find_regexp operator for the text processor.

0.36.3 - 2018-11-08

Added

  • New find_regexp operator for the text processor.

0.36.1 - 2018-11-07

Added

  • New aws fields to the elasticsearch output to allow AWS authentication.

0.36.0 - 2018-11-06

Added

  • Add max-outstanding fields to gcp_pubsub input.
  • Add new dynamodb output.

Changed

  • The s3 output now calculates path field function interpolations per message of a batch.

0.35.1 - 2018-10-31

Added

  • New set operator for the text processor.

0.35.0 - 2018-10-30

Added

  • New cache output type.

0.34.13 - 2018-10-29

Added

  • New group_by processor.
  • Add bulk send support to elasticsearch output.

0.34.8 - 2018-10-10

Added

  • New content interpolation function.

0.34.7 - 2018-10-04

Added

  • New redis cache type.

0.34.5 - 2018-10-02

Changed

  • The process_map processor now allows map target path overrides when a target is the parent of another target.

0.34.4 - 2018-10-02

Added

  • Field pipeline and sniff added to the elasticsearch output.
  • Operators to_lower and to_upper added to the text processor.

0.34.3 - 2018-09-29

Added

  • Field endpoint added to all AWS types.

0.34.2 - 2018-09-27

Changed

  • Allow log config field static_fields to be fully overridden.

0.34.0 - 2018-09-27

Added

  • New process_dag processor.
  • New static_fields map added to log config for setting static log fields.

Changed

  • JSON log field containing component path moved from @service to component.

0.33.0 - 2018-09-22

Added

  • New gcp_pubsub input and outputs.
  • New log processor.
  • New lambda processor.

0.32.0 - 2018-09-18

Added

  • New process_batch processor.
  • Added count field to batch processor.
  • Metrics for kinesis output throttles.

Changed

  • The combine processor is now considered DEPRECATED, please use the batch processor instead.
  • The batch processor field byte_size is now set at 0 (and therefore ignored) by default. A log warning has been added in case anyone was relying on the default.

0.31.4 - 2018-09-16

Added

  • New rate_limit resource with a local type.
  • Field rate_limit added to http based processors, inputs and outputs.

0.31.2 - 2018-09-14

Added

  • New prefetch_count field added to nats input.

0.31.0 - 2018-09-11

Added

  • New bounds_check condition type.
  • New check_field condition type.
  • New queue field added to nats input.
  • Function interpolation for the topic field of the nsq output.

Changed

  • The nats input now defaults to joining a queue.

0.30.1 - 2018-09-06

Changed

  • The redundant nsq output field max_in_flight has been removed.
  • The files output now interpolates paths per message part of a batch.

0.30.0 - 2018-09-06

Added

  • New hdfs input and output.
  • New switch output.
  • New enum and has_prefix operators for the metadata condition.
  • Ability to set tls client certificate fields directly.

0.29.0 - 2018-09-02

Added

  • New retry output.
  • Added regex_partial and regex_exact operators to the metadata condition.

Changed

  • The kinesis output field retries has been renamed max_retries in order to expose the difference in its zero value behaviour (endless retries) versus other retry fields (zero retries).

0.28.0 - 2018-09-01

Added

  • New endpoint field added to kinesis input.
  • New dynamodb cache type.

0.27.0 - 2018-08-30

Added

  • Function interpolation for the topic field of the kafka output.
  • New target_version field for the kafka_balanced input.
  • TLS config fields for client certificates.

Changed

  • TLS config field cas_file has been renamed root_cas_file.

0.26.3 - 2018-08-29

Added

  • New zip option for the archive and unarchive processors.

Changed

  • The kinesis output type now supports batched sends and per message interpolation.

0.26.2 - 2018-08-27

Added

  • New metric processor.

0.26.1 - 2018-08-26

Added

  • New redis_streams input and output.

0.26.0 - 2018-08-25

Added

  • New kinesis input and output.

0.25.0 - 2018-08-22

Added

  • The index field of the elasticsearch output can now be dynamically set using function interpolation.
  • New hash processor.

Changed

  • API: The metrics.Type interface has been changed in order to add labels.

0.24.0 - 2018-08-17

Changed

  • Significant restructuring of amqp inputs and outputs. These changes should be backwards compatible for existing pipelines, but changes the way in which queues, exchanges and bindings are declared using these types.

0.23.17 - 2018-08-17

Added

  • New durable fields for amqp input and output types.

0.23.15 - 2018-08-16

Changed

  • Improved statsd client with better cached aggregation.

0.23.14 - 2018-08-16

Added

  • New tls fields for amqp input and output types.

0.23.12 - 2018-08-14

Added

  • New type field for elasticsearch output.

0.23.9 - 2018-08-10

Added

  • New throttle processor.

0.23.6 - 2018-08-09

Added

  • New less_than and greater_than operators for metadata condition.

0.23.4 - 2018-08-09

Added

  • New metadata condition type.
  • More metadata fields for kafka input.
  • Field commit_period_ms for kafka and kafka_balanced inputs for specifying a commit period.

0.23.1 - 2018-08-06

Added

  • New retries field to s3 input, to cap the number of download attempts made on the same bucket item.
  • Added metadata based mechanism to detect final message from a read_until input.
  • Added field to split processor for specifying target batch sizes.

0.23.0 - 2018-08-06

Added

  • Metadata fields are now per message part within a batch.
  • New metadata_json_object function interpolation to return a JSON object of metadata key/value pairs.

Changed

  • The metadata function interpolation now allows part indexing and no longer returns a JSON object when no key is specified, this behaviour can now be done using the metadata_json_object function.

0.22.0 - 2018-08-03

Added

  • Fields for the http processor to enable parallel requests from message batches.

Changed

  • Broker level output processors are now applied before the individual output processors.
  • The dynamic input and output HTTP paths for CRUD operations are now /inputs/{input_id} and /outputs/{output_id} respectively.
  • Removed deprecated amazon_s3, amazon_sqs and scalability_protocols input and output types.
  • Removed deprecated json_fields field from the dedupe processor.

0.21.0 - 2018-07-31

Added

  • Add conditions to process_map processor.

Changed

  • TLS config fields have been cleaned up for multiple types. This affects the kafka, kafka_balanced and http_client input and output types, as well as the http processor type.

0.20.8 - 2018-07-30

Added

  • New delete_all and delete_prefix operators for metadata processor.
  • More metadata fields extracted from the AMQP input.
  • HTTP clients now support function interpolation on the URL and header values, this includes the http_client input and output as well as the http processor.

0.20.7 - 2018-07-27

Added

  • New key field added to the dedupe processor, allowing you to deduplicate using function interpolation. This deprecates the json_paths array field.

0.20.6 - 2018-07-27

Added

  • New s3 and sqs input and output types, these replace the now deprecated amazon_s3 and amazon_sqs types respectively, which will eventually be removed.
  • New nanomsg input and output types, these replace the now deprecated scalability_protocols types, which will eventually be removed.

0.20.5 - 2018-07-27

Added

  • Metadata fields are now collected from MQTT input.
  • AMQP output writes all metadata as headers.
  • AMQP output field key now supports function interpolation.

0.20.1 - 2018-07-26

Added

  • New metadata processor and configuration interpolation function.

0.20.0 - 2018-07-26

Added

  • New config interpolator function json_field for extracting parts of a JSON message into a config value.

Changed

  • Log level config field no longer stutters, logger.log_level is now logger.level.

0.19.1 - 2018-07-25

Added

  • Ability to create batches via conditions on message payloads in the batch processor.
  • New --examples flag for generating specific examples from Benthos.

0.19.0 - 2018-07-23

Added

  • New text processor.

Changed

  • Processor process_map replaced field strict_premapping with premap_optional.

0.18.0 - 2018-07-20

Added

  • New process_field processor.
  • New process_map processor.

Changed

  • Removed mapping fields from the http processor, this behaviour has been put into the new process_map processor instead.

0.17.0 - 2018-07-17

Changed

  • Renamed content condition type to text in order to clarify its purpose.

0.16.4 - 2018-07-17

Added

  • Latency metrics for caches.
  • TLS options for kafka and kafka_partitions inputs and outputs.

Changed

  • Metrics for items configured within the resources section are now namespaced under their identifier.

0.16.3 - 2018-07-16

Added

  • New copy and move operators for the json processor.

0.16.2 - 2018-07-12

Added

  • Metrics for recording http request latencies.

0.16.0 - 2018-07-09

Changed

  • Improved and rearranged fields for http_client input and output.

0.15.5 - 2018-07-08

Added

  • More compression and decompression targets.
  • New lines option for archive/unarchive processors.
  • New encode and decode processors.
  • New period_ms field for the batch processor.
  • New clean operator for the json processor.

0.15.4 - 2018-07-04

Added

  • New http processor, where payloads can be sent to arbitrary HTTP endpoints and the result constructed into a new payload.
  • New inproc inputs and outputs for linking streams together.

0.15.3 - 2018-07-03

Added

  • New streams endpoint /streams/{id}/stats for obtaining JSON metrics for a stream.

Changed

  • Allow comma separated topics for kafka_balanced.

0.15.0 - 2018-06-28

Added

  • Support for PATCH verb on the streams mode /streams/{id} endpoint.

Changed

  • Sweeping changes were made to the environment variable configuration file. This file is now auto generated along with its supporting document. This change will impact the docker image.

0.14.7 - 2018-06-24

Added

  • New filter_parts processor for filtering individual parts of a message batch.
  • New field open_message for websocket input.

Changed

  • No longer setting default input processor.

0.14.6 - 2018-06-21

Added

  • New root_path field for service wide http config.

0.14.5 - 2018-06-21

Added

  • New regexp_exact and regexp_partial content condition operators.

0.14.4 - 2018-06-19

Changed

  • The statsd metrics target will now periodically report connection errors.

0.14.2 - 2018-06-18

Changed

  • The json processor will now append array values in expanded form.

0.14.0 - 2018-06-15

Added

  • More granular config options in the http_client output for controlling retry logic.
  • New try pattern for the output broker type, which can be used in order to configure fallback outputs.
  • New json processor, this replaces delete_json, select_json, set_json.

Changed

  • The streams API endpoints have been changed to become more "RESTy".
  • Removed the delete_json, select_json and set_json processors, please use the json processor instead.

0.13.5 - 2018-06-10

Added

  • New grok processor for creating structured objects from unstructured data.

0.13.4 - 2018-06-08

Added

  • New files input type for reading multiple files as discrete messages.

Changed

  • Increase default max_buffer for stdin, file and http_client inputs.
  • Command flags --print-yaml and --print-json changed to provide sanitised outputs unless accompanied by new --all flag.

Removed

  • Badger based buffer option has been removed.

0.13.3 - 2018-06-06

Added

  • New metrics wrapper for more basic interface implementations.
  • New delete_json processor.
  • New field else_processors for conditional processor.

0.13.2 - 2018-06-03

Added

  • New websocket endpoint for http_server input.
  • New websocket endpoint for http_server output.
  • New websocket input type.
  • New websocket output type.

0.13.1 - 2018-06-02

Added

  • Goreleaser config for generating release packages.

Changed

  • Back to using Scratch as base for Docker image, instead taking ca-certificates from the build image.

0.13.0 - 2018-06-02

Added

  • New batch processor for combining payloads up to a number of bytes.
  • New conditional processor, allows you to configure a chain of processors to only be run if the payload passes a condition.
  • New --stream mode features:
    • POST verb for /streams path now supported.
    • New --streams-dir flag for parsing a directory of stream configs.

Changed

  • The condition processor has been renamed filter.
  • The custom_delimiter fields in any line reader types file, stdin, stdout, etc have been renamed delimiter, where the behaviour is the same.
  • Now using Alpine as base for Docker image, includes ca-certificates.