1. Packages
  2. AWS Classic
  3. API Docs
  4. kinesis
  5. FirehoseDeliveryStream

Try AWS Native preview for resources not in the classic version.

AWS Classic v6.31.0 published on Monday, Apr 15, 2024 by Pulumi

aws.kinesis.FirehoseDeliveryStream

Explore with Pulumi AI

aws logo

Try AWS Native preview for resources not in the classic version.

AWS Classic v6.31.0 published on Monday, Apr 15, 2024 by Pulumi

    Provides a Kinesis Firehose Delivery Stream resource. Amazon Kinesis Firehose is a fully managed, elastic service to easily deliver real-time data streams to destinations such as Amazon S3 and Amazon Redshift.

    For more details, see the Amazon Kinesis Firehose Documentation.

    Example Usage

    Extended S3 Destination

    import * as pulumi from "@pulumi/pulumi";
    import * as aws from "@pulumi/aws";
    
    const bucket = new aws.s3.BucketV2("bucket", {bucket: "tf-test-bucket"});
    const firehoseAssumeRole = aws.iam.getPolicyDocument({
        statements: [{
            effect: "Allow",
            principals: [{
                type: "Service",
                identifiers: ["firehose.amazonaws.com"],
            }],
            actions: ["sts:AssumeRole"],
        }],
    });
    const firehoseRole = new aws.iam.Role("firehose_role", {
        name: "firehose_test_role",
        assumeRolePolicy: firehoseAssumeRole.then(firehoseAssumeRole => firehoseAssumeRole.json),
    });
    const lambdaAssumeRole = aws.iam.getPolicyDocument({
        statements: [{
            effect: "Allow",
            principals: [{
                type: "Service",
                identifiers: ["lambda.amazonaws.com"],
            }],
            actions: ["sts:AssumeRole"],
        }],
    });
    const lambdaIam = new aws.iam.Role("lambda_iam", {
        name: "lambda_iam",
        assumeRolePolicy: lambdaAssumeRole.then(lambdaAssumeRole => lambdaAssumeRole.json),
    });
    const lambdaProcessor = new aws.lambda.Function("lambda_processor", {
        code: new pulumi.asset.FileArchive("lambda.zip"),
        name: "firehose_lambda_processor",
        role: lambdaIam.arn,
        handler: "exports.handler",
        runtime: aws.lambda.Runtime.NodeJS16dX,
    });
    const extendedS3Stream = new aws.kinesis.FirehoseDeliveryStream("extended_s3_stream", {
        name: "kinesis-firehose-extended-s3-test-stream",
        destination: "extended_s3",
        extendedS3Configuration: {
            roleArn: firehoseRole.arn,
            bucketArn: bucket.arn,
            processingConfiguration: {
                enabled: true,
                processors: [{
                    type: "Lambda",
                    parameters: [{
                        parameterName: "LambdaArn",
                        parameterValue: pulumi.interpolate`${lambdaProcessor.arn}:$LATEST`,
                    }],
                }],
            },
        },
    });
    const bucketAcl = new aws.s3.BucketAclV2("bucket_acl", {
        bucket: bucket.id,
        acl: "private",
    });
    
    import pulumi
    import pulumi_aws as aws
    
    bucket = aws.s3.BucketV2("bucket", bucket="tf-test-bucket")
    firehose_assume_role = aws.iam.get_policy_document(statements=[aws.iam.GetPolicyDocumentStatementArgs(
        effect="Allow",
        principals=[aws.iam.GetPolicyDocumentStatementPrincipalArgs(
            type="Service",
            identifiers=["firehose.amazonaws.com"],
        )],
        actions=["sts:AssumeRole"],
    )])
    firehose_role = aws.iam.Role("firehose_role",
        name="firehose_test_role",
        assume_role_policy=firehose_assume_role.json)
    lambda_assume_role = aws.iam.get_policy_document(statements=[aws.iam.GetPolicyDocumentStatementArgs(
        effect="Allow",
        principals=[aws.iam.GetPolicyDocumentStatementPrincipalArgs(
            type="Service",
            identifiers=["lambda.amazonaws.com"],
        )],
        actions=["sts:AssumeRole"],
    )])
    lambda_iam = aws.iam.Role("lambda_iam",
        name="lambda_iam",
        assume_role_policy=lambda_assume_role.json)
    lambda_processor = aws.lambda_.Function("lambda_processor",
        code=pulumi.FileArchive("lambda.zip"),
        name="firehose_lambda_processor",
        role=lambda_iam.arn,
        handler="exports.handler",
        runtime=aws.lambda_.Runtime.NODE_JS16D_X)
    extended_s3_stream = aws.kinesis.FirehoseDeliveryStream("extended_s3_stream",
        name="kinesis-firehose-extended-s3-test-stream",
        destination="extended_s3",
        extended_s3_configuration=aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationArgs(
            role_arn=firehose_role.arn,
            bucket_arn=bucket.arn,
            processing_configuration=aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationArgs(
                enabled=True,
                processors=[aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArgs(
                    type="Lambda",
                    parameters=[aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs(
                        parameter_name="LambdaArn",
                        parameter_value=lambda_processor.arn.apply(lambda arn: f"{arn}:$LATEST"),
                    )],
                )],
            ),
        ))
    bucket_acl = aws.s3.BucketAclV2("bucket_acl",
        bucket=bucket.id,
        acl="private")
    
    package main
    
    import (
    	"fmt"
    
    	"github.com/pulumi/pulumi-aws/sdk/v6/go/aws/iam"
    	"github.com/pulumi/pulumi-aws/sdk/v6/go/aws/kinesis"
    	"github.com/pulumi/pulumi-aws/sdk/v6/go/aws/lambda"
    	"github.com/pulumi/pulumi-aws/sdk/v6/go/aws/s3"
    	"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
    )
    
    func main() {
    	pulumi.Run(func(ctx *pulumi.Context) error {
    		bucket, err := s3.NewBucketV2(ctx, "bucket", &s3.BucketV2Args{
    			Bucket: pulumi.String("tf-test-bucket"),
    		})
    		if err != nil {
    			return err
    		}
    		firehoseAssumeRole, err := iam.GetPolicyDocument(ctx, &iam.GetPolicyDocumentArgs{
    			Statements: []iam.GetPolicyDocumentStatement{
    				{
    					Effect: pulumi.StringRef("Allow"),
    					Principals: []iam.GetPolicyDocumentStatementPrincipal{
    						{
    							Type: "Service",
    							Identifiers: []string{
    								"firehose.amazonaws.com",
    							},
    						},
    					},
    					Actions: []string{
    						"sts:AssumeRole",
    					},
    				},
    			},
    		}, nil)
    		if err != nil {
    			return err
    		}
    		firehoseRole, err := iam.NewRole(ctx, "firehose_role", &iam.RoleArgs{
    			Name:             pulumi.String("firehose_test_role"),
    			AssumeRolePolicy: pulumi.String(firehoseAssumeRole.Json),
    		})
    		if err != nil {
    			return err
    		}
    		lambdaAssumeRole, err := iam.GetPolicyDocument(ctx, &iam.GetPolicyDocumentArgs{
    			Statements: []iam.GetPolicyDocumentStatement{
    				{
    					Effect: pulumi.StringRef("Allow"),
    					Principals: []iam.GetPolicyDocumentStatementPrincipal{
    						{
    							Type: "Service",
    							Identifiers: []string{
    								"lambda.amazonaws.com",
    							},
    						},
    					},
    					Actions: []string{
    						"sts:AssumeRole",
    					},
    				},
    			},
    		}, nil)
    		if err != nil {
    			return err
    		}
    		lambdaIam, err := iam.NewRole(ctx, "lambda_iam", &iam.RoleArgs{
    			Name:             pulumi.String("lambda_iam"),
    			AssumeRolePolicy: pulumi.String(lambdaAssumeRole.Json),
    		})
    		if err != nil {
    			return err
    		}
    		lambdaProcessor, err := lambda.NewFunction(ctx, "lambda_processor", &lambda.FunctionArgs{
    			Code:    pulumi.NewFileArchive("lambda.zip"),
    			Name:    pulumi.String("firehose_lambda_processor"),
    			Role:    lambdaIam.Arn,
    			Handler: pulumi.String("exports.handler"),
    			Runtime: pulumi.String(lambda.RuntimeNodeJS16dX),
    		})
    		if err != nil {
    			return err
    		}
    		_, err = kinesis.NewFirehoseDeliveryStream(ctx, "extended_s3_stream", &kinesis.FirehoseDeliveryStreamArgs{
    			Name:        pulumi.String("kinesis-firehose-extended-s3-test-stream"),
    			Destination: pulumi.String("extended_s3"),
    			ExtendedS3Configuration: &kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationArgs{
    				RoleArn:   firehoseRole.Arn,
    				BucketArn: bucket.Arn,
    				ProcessingConfiguration: &kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationArgs{
    					Enabled: pulumi.Bool(true),
    					Processors: kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArray{
    						&kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArgs{
    							Type: pulumi.String("Lambda"),
    							Parameters: kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArray{
    								&kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs{
    									ParameterName: pulumi.String("LambdaArn"),
    									ParameterValue: lambdaProcessor.Arn.ApplyT(func(arn string) (string, error) {
    										return fmt.Sprintf("%v:$LATEST", arn), nil
    									}).(pulumi.StringOutput),
    								},
    							},
    						},
    					},
    				},
    			},
    		})
    		if err != nil {
    			return err
    		}
    		_, err = s3.NewBucketAclV2(ctx, "bucket_acl", &s3.BucketAclV2Args{
    			Bucket: bucket.ID(),
    			Acl:    pulumi.String("private"),
    		})
    		if err != nil {
    			return err
    		}
    		return nil
    	})
    }
    
    using System.Collections.Generic;
    using System.Linq;
    using Pulumi;
    using Aws = Pulumi.Aws;
    
    return await Deployment.RunAsync(() => 
    {
        var bucket = new Aws.S3.BucketV2("bucket", new()
        {
            Bucket = "tf-test-bucket",
        });
    
        var firehoseAssumeRole = Aws.Iam.GetPolicyDocument.Invoke(new()
        {
            Statements = new[]
            {
                new Aws.Iam.Inputs.GetPolicyDocumentStatementInputArgs
                {
                    Effect = "Allow",
                    Principals = new[]
                    {
                        new Aws.Iam.Inputs.GetPolicyDocumentStatementPrincipalInputArgs
                        {
                            Type = "Service",
                            Identifiers = new[]
                            {
                                "firehose.amazonaws.com",
                            },
                        },
                    },
                    Actions = new[]
                    {
                        "sts:AssumeRole",
                    },
                },
            },
        });
    
        var firehoseRole = new Aws.Iam.Role("firehose_role", new()
        {
            Name = "firehose_test_role",
            AssumeRolePolicy = firehoseAssumeRole.Apply(getPolicyDocumentResult => getPolicyDocumentResult.Json),
        });
    
        var lambdaAssumeRole = Aws.Iam.GetPolicyDocument.Invoke(new()
        {
            Statements = new[]
            {
                new Aws.Iam.Inputs.GetPolicyDocumentStatementInputArgs
                {
                    Effect = "Allow",
                    Principals = new[]
                    {
                        new Aws.Iam.Inputs.GetPolicyDocumentStatementPrincipalInputArgs
                        {
                            Type = "Service",
                            Identifiers = new[]
                            {
                                "lambda.amazonaws.com",
                            },
                        },
                    },
                    Actions = new[]
                    {
                        "sts:AssumeRole",
                    },
                },
            },
        });
    
        var lambdaIam = new Aws.Iam.Role("lambda_iam", new()
        {
            Name = "lambda_iam",
            AssumeRolePolicy = lambdaAssumeRole.Apply(getPolicyDocumentResult => getPolicyDocumentResult.Json),
        });
    
        var lambdaProcessor = new Aws.Lambda.Function("lambda_processor", new()
        {
            Code = new FileArchive("lambda.zip"),
            Name = "firehose_lambda_processor",
            Role = lambdaIam.Arn,
            Handler = "exports.handler",
            Runtime = Aws.Lambda.Runtime.NodeJS16dX,
        });
    
        var extendedS3Stream = new Aws.Kinesis.FirehoseDeliveryStream("extended_s3_stream", new()
        {
            Name = "kinesis-firehose-extended-s3-test-stream",
            Destination = "extended_s3",
            ExtendedS3Configuration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationArgs
            {
                RoleArn = firehoseRole.Arn,
                BucketArn = bucket.Arn,
                ProcessingConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationArgs
                {
                    Enabled = true,
                    Processors = new[]
                    {
                        new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArgs
                        {
                            Type = "Lambda",
                            Parameters = new[]
                            {
                                new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs
                                {
                                    ParameterName = "LambdaArn",
                                    ParameterValue = lambdaProcessor.Arn.Apply(arn => $"{arn}:$LATEST"),
                                },
                            },
                        },
                    },
                },
            },
        });
    
        var bucketAcl = new Aws.S3.BucketAclV2("bucket_acl", new()
        {
            Bucket = bucket.Id,
            Acl = "private",
        });
    
    });
    
    package generated_program;
    
    import com.pulumi.Context;
    import com.pulumi.Pulumi;
    import com.pulumi.core.Output;
    import com.pulumi.aws.s3.BucketV2;
    import com.pulumi.aws.s3.BucketV2Args;
    import com.pulumi.aws.iam.IamFunctions;
    import com.pulumi.aws.iam.inputs.GetPolicyDocumentArgs;
    import com.pulumi.aws.iam.Role;
    import com.pulumi.aws.iam.RoleArgs;
    import com.pulumi.aws.lambda.Function;
    import com.pulumi.aws.lambda.FunctionArgs;
    import com.pulumi.aws.kinesis.FirehoseDeliveryStream;
    import com.pulumi.aws.kinesis.FirehoseDeliveryStreamArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamExtendedS3ConfigurationArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationArgs;
    import com.pulumi.aws.s3.BucketAclV2;
    import com.pulumi.aws.s3.BucketAclV2Args;
    import com.pulumi.asset.FileArchive;
    import java.util.List;
    import java.util.ArrayList;
    import java.util.Map;
    import java.io.File;
    import java.nio.file.Files;
    import java.nio.file.Paths;
    
    public class App {
        public static void main(String[] args) {
            Pulumi.run(App::stack);
        }
    
        public static void stack(Context ctx) {
            var bucket = new BucketV2("bucket", BucketV2Args.builder()        
                .bucket("tf-test-bucket")
                .build());
    
            final var firehoseAssumeRole = IamFunctions.getPolicyDocument(GetPolicyDocumentArgs.builder()
                .statements(GetPolicyDocumentStatementArgs.builder()
                    .effect("Allow")
                    .principals(GetPolicyDocumentStatementPrincipalArgs.builder()
                        .type("Service")
                        .identifiers("firehose.amazonaws.com")
                        .build())
                    .actions("sts:AssumeRole")
                    .build())
                .build());
    
            var firehoseRole = new Role("firehoseRole", RoleArgs.builder()        
                .name("firehose_test_role")
                .assumeRolePolicy(firehoseAssumeRole.applyValue(getPolicyDocumentResult -> getPolicyDocumentResult.json()))
                .build());
    
            final var lambdaAssumeRole = IamFunctions.getPolicyDocument(GetPolicyDocumentArgs.builder()
                .statements(GetPolicyDocumentStatementArgs.builder()
                    .effect("Allow")
                    .principals(GetPolicyDocumentStatementPrincipalArgs.builder()
                        .type("Service")
                        .identifiers("lambda.amazonaws.com")
                        .build())
                    .actions("sts:AssumeRole")
                    .build())
                .build());
    
            var lambdaIam = new Role("lambdaIam", RoleArgs.builder()        
                .name("lambda_iam")
                .assumeRolePolicy(lambdaAssumeRole.applyValue(getPolicyDocumentResult -> getPolicyDocumentResult.json()))
                .build());
    
            var lambdaProcessor = new Function("lambdaProcessor", FunctionArgs.builder()        
                .code(new FileArchive("lambda.zip"))
                .name("firehose_lambda_processor")
                .role(lambdaIam.arn())
                .handler("exports.handler")
                .runtime("nodejs16.x")
                .build());
    
            var extendedS3Stream = new FirehoseDeliveryStream("extendedS3Stream", FirehoseDeliveryStreamArgs.builder()        
                .name("kinesis-firehose-extended-s3-test-stream")
                .destination("extended_s3")
                .extendedS3Configuration(FirehoseDeliveryStreamExtendedS3ConfigurationArgs.builder()
                    .roleArn(firehoseRole.arn())
                    .bucketArn(bucket.arn())
                    .processingConfiguration(FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationArgs.builder()
                        .enabled("true")
                        .processors(FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArgs.builder()
                            .type("Lambda")
                            .parameters(FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs.builder()
                                .parameterName("LambdaArn")
                                .parameterValue(lambdaProcessor.arn().applyValue(arn -> String.format("%s:$LATEST", arn)))
                                .build())
                            .build())
                        .build())
                    .build())
                .build());
    
            var bucketAcl = new BucketAclV2("bucketAcl", BucketAclV2Args.builder()        
                .bucket(bucket.id())
                .acl("private")
                .build());
    
        }
    }
    
    resources:
      extendedS3Stream:
        type: aws:kinesis:FirehoseDeliveryStream
        name: extended_s3_stream
        properties:
          name: kinesis-firehose-extended-s3-test-stream
          destination: extended_s3
          extendedS3Configuration:
            roleArn: ${firehoseRole.arn}
            bucketArn: ${bucket.arn}
            processingConfiguration:
              enabled: 'true'
              processors:
                - type: Lambda
                  parameters:
                    - parameterName: LambdaArn
                      parameterValue: ${lambdaProcessor.arn}:$LATEST
      bucket:
        type: aws:s3:BucketV2
        properties:
          bucket: tf-test-bucket
      bucketAcl:
        type: aws:s3:BucketAclV2
        name: bucket_acl
        properties:
          bucket: ${bucket.id}
          acl: private
      firehoseRole:
        type: aws:iam:Role
        name: firehose_role
        properties:
          name: firehose_test_role
          assumeRolePolicy: ${firehoseAssumeRole.json}
      lambdaIam:
        type: aws:iam:Role
        name: lambda_iam
        properties:
          name: lambda_iam
          assumeRolePolicy: ${lambdaAssumeRole.json}
      lambdaProcessor:
        type: aws:lambda:Function
        name: lambda_processor
        properties:
          code:
            fn::FileArchive: lambda.zip
          name: firehose_lambda_processor
          role: ${lambdaIam.arn}
          handler: exports.handler
          runtime: nodejs16.x
    variables:
      firehoseAssumeRole:
        fn::invoke:
          Function: aws:iam:getPolicyDocument
          Arguments:
            statements:
              - effect: Allow
                principals:
                  - type: Service
                    identifiers:
                      - firehose.amazonaws.com
                actions:
                  - sts:AssumeRole
      lambdaAssumeRole:
        fn::invoke:
          Function: aws:iam:getPolicyDocument
          Arguments:
            statements:
              - effect: Allow
                principals:
                  - type: Service
                    identifiers:
                      - lambda.amazonaws.com
                actions:
                  - sts:AssumeRole
    

    Extended S3 Destination with dynamic partitioning

    These examples use built-in Firehose functionality, rather than requiring a lambda.

    import * as pulumi from "@pulumi/pulumi";
    import * as aws from "@pulumi/aws";
    
    const extendedS3Stream = new aws.kinesis.FirehoseDeliveryStream("extended_s3_stream", {
        name: "kinesis-firehose-extended-s3-test-stream",
        destination: "extended_s3",
        extendedS3Configuration: {
            roleArn: firehoseRole.arn,
            bucketArn: bucket.arn,
            bufferingSize: 64,
            dynamicPartitioningConfiguration: {
                enabled: true,
            },
            prefix: "data/customer_id=!{partitionKeyFromQuery:customer_id}/year=!{timestamp:yyyy}/month=!{timestamp:MM}/day=!{timestamp:dd}/hour=!{timestamp:HH}/",
            errorOutputPrefix: "errors/year=!{timestamp:yyyy}/month=!{timestamp:MM}/day=!{timestamp:dd}/hour=!{timestamp:HH}/!{firehose:error-output-type}/",
            processingConfiguration: {
                enabled: true,
                processors: [
                    {
                        type: "RecordDeAggregation",
                        parameters: [{
                            parameterName: "SubRecordType",
                            parameterValue: "JSON",
                        }],
                    },
                    {
                        type: "AppendDelimiterToRecord",
                    },
                    {
                        type: "MetadataExtraction",
                        parameters: [
                            {
                                parameterName: "JsonParsingEngine",
                                parameterValue: "JQ-1.6",
                            },
                            {
                                parameterName: "MetadataExtractionQuery",
                                parameterValue: "{customer_id:.customer_id}",
                            },
                        ],
                    },
                ],
            },
        },
    });
    
    import pulumi
    import pulumi_aws as aws
    
    extended_s3_stream = aws.kinesis.FirehoseDeliveryStream("extended_s3_stream",
        name="kinesis-firehose-extended-s3-test-stream",
        destination="extended_s3",
        extended_s3_configuration=aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationArgs(
            role_arn=firehose_role["arn"],
            bucket_arn=bucket["arn"],
            buffering_size=64,
            dynamic_partitioning_configuration=aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationDynamicPartitioningConfigurationArgs(
                enabled=True,
            ),
            prefix="data/customer_id=!{partitionKeyFromQuery:customer_id}/year=!{timestamp:yyyy}/month=!{timestamp:MM}/day=!{timestamp:dd}/hour=!{timestamp:HH}/",
            error_output_prefix="errors/year=!{timestamp:yyyy}/month=!{timestamp:MM}/day=!{timestamp:dd}/hour=!{timestamp:HH}/!{firehose:error-output-type}/",
            processing_configuration=aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationArgs(
                enabled=True,
                processors=[
                    aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArgs(
                        type="RecordDeAggregation",
                        parameters=[aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs(
                            parameter_name="SubRecordType",
                            parameter_value="JSON",
                        )],
                    ),
                    aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArgs(
                        type="AppendDelimiterToRecord",
                    ),
                    aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArgs(
                        type="MetadataExtraction",
                        parameters=[
                            aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs(
                                parameter_name="JsonParsingEngine",
                                parameter_value="JQ-1.6",
                            ),
                            aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs(
                                parameter_name="MetadataExtractionQuery",
                                parameter_value="{customer_id:.customer_id}",
                            ),
                        ],
                    ),
                ],
            ),
        ))
    
    package main
    
    import (
    	"github.com/pulumi/pulumi-aws/sdk/v6/go/aws/kinesis"
    	"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
    )
    
    func main() {
    	pulumi.Run(func(ctx *pulumi.Context) error {
    		_, err := kinesis.NewFirehoseDeliveryStream(ctx, "extended_s3_stream", &kinesis.FirehoseDeliveryStreamArgs{
    			Name:        pulumi.String("kinesis-firehose-extended-s3-test-stream"),
    			Destination: pulumi.String("extended_s3"),
    			ExtendedS3Configuration: &kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationArgs{
    				RoleArn:       pulumi.Any(firehoseRole.Arn),
    				BucketArn:     pulumi.Any(bucket.Arn),
    				BufferingSize: pulumi.Int(64),
    				DynamicPartitioningConfiguration: &kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationDynamicPartitioningConfigurationArgs{
    					Enabled: pulumi.Bool(true),
    				},
    				Prefix:            pulumi.String("data/customer_id=!{partitionKeyFromQuery:customer_id}/year=!{timestamp:yyyy}/month=!{timestamp:MM}/day=!{timestamp:dd}/hour=!{timestamp:HH}/"),
    				ErrorOutputPrefix: pulumi.String("errors/year=!{timestamp:yyyy}/month=!{timestamp:MM}/day=!{timestamp:dd}/hour=!{timestamp:HH}/!{firehose:error-output-type}/"),
    				ProcessingConfiguration: &kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationArgs{
    					Enabled: pulumi.Bool(true),
    					Processors: kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArray{
    						&kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArgs{
    							Type: pulumi.String("RecordDeAggregation"),
    							Parameters: kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArray{
    								&kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs{
    									ParameterName:  pulumi.String("SubRecordType"),
    									ParameterValue: pulumi.String("JSON"),
    								},
    							},
    						},
    						&kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArgs{
    							Type: pulumi.String("AppendDelimiterToRecord"),
    						},
    						&kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArgs{
    							Type: pulumi.String("MetadataExtraction"),
    							Parameters: kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArray{
    								&kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs{
    									ParameterName:  pulumi.String("JsonParsingEngine"),
    									ParameterValue: pulumi.String("JQ-1.6"),
    								},
    								&kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs{
    									ParameterName:  pulumi.String("MetadataExtractionQuery"),
    									ParameterValue: pulumi.String("{customer_id:.customer_id}"),
    								},
    							},
    						},
    					},
    				},
    			},
    		})
    		if err != nil {
    			return err
    		}
    		return nil
    	})
    }
    
    using System.Collections.Generic;
    using System.Linq;
    using Pulumi;
    using Aws = Pulumi.Aws;
    
    return await Deployment.RunAsync(() => 
    {
        var extendedS3Stream = new Aws.Kinesis.FirehoseDeliveryStream("extended_s3_stream", new()
        {
            Name = "kinesis-firehose-extended-s3-test-stream",
            Destination = "extended_s3",
            ExtendedS3Configuration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationArgs
            {
                RoleArn = firehoseRole.Arn,
                BucketArn = bucket.Arn,
                BufferingSize = 64,
                DynamicPartitioningConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationDynamicPartitioningConfigurationArgs
                {
                    Enabled = true,
                },
                Prefix = "data/customer_id=!{partitionKeyFromQuery:customer_id}/year=!{timestamp:yyyy}/month=!{timestamp:MM}/day=!{timestamp:dd}/hour=!{timestamp:HH}/",
                ErrorOutputPrefix = "errors/year=!{timestamp:yyyy}/month=!{timestamp:MM}/day=!{timestamp:dd}/hour=!{timestamp:HH}/!{firehose:error-output-type}/",
                ProcessingConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationArgs
                {
                    Enabled = true,
                    Processors = new[]
                    {
                        new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArgs
                        {
                            Type = "RecordDeAggregation",
                            Parameters = new[]
                            {
                                new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs
                                {
                                    ParameterName = "SubRecordType",
                                    ParameterValue = "JSON",
                                },
                            },
                        },
                        new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArgs
                        {
                            Type = "AppendDelimiterToRecord",
                        },
                        new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArgs
                        {
                            Type = "MetadataExtraction",
                            Parameters = new[]
                            {
                                new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs
                                {
                                    ParameterName = "JsonParsingEngine",
                                    ParameterValue = "JQ-1.6",
                                },
                                new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs
                                {
                                    ParameterName = "MetadataExtractionQuery",
                                    ParameterValue = "{customer_id:.customer_id}",
                                },
                            },
                        },
                    },
                },
            },
        });
    
    });
    
    package generated_program;
    
    import com.pulumi.Context;
    import com.pulumi.Pulumi;
    import com.pulumi.core.Output;
    import com.pulumi.aws.kinesis.FirehoseDeliveryStream;
    import com.pulumi.aws.kinesis.FirehoseDeliveryStreamArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamExtendedS3ConfigurationArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamExtendedS3ConfigurationDynamicPartitioningConfigurationArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationArgs;
    import java.util.List;
    import java.util.ArrayList;
    import java.util.Map;
    import java.io.File;
    import java.nio.file.Files;
    import java.nio.file.Paths;
    
    public class App {
        public static void main(String[] args) {
            Pulumi.run(App::stack);
        }
    
        public static void stack(Context ctx) {
            var extendedS3Stream = new FirehoseDeliveryStream("extendedS3Stream", FirehoseDeliveryStreamArgs.builder()        
                .name("kinesis-firehose-extended-s3-test-stream")
                .destination("extended_s3")
                .extendedS3Configuration(FirehoseDeliveryStreamExtendedS3ConfigurationArgs.builder()
                    .roleArn(firehoseRole.arn())
                    .bucketArn(bucket.arn())
                    .bufferingSize(64)
                    .dynamicPartitioningConfiguration(FirehoseDeliveryStreamExtendedS3ConfigurationDynamicPartitioningConfigurationArgs.builder()
                        .enabled("true")
                        .build())
                    .prefix("data/customer_id=!{partitionKeyFromQuery:customer_id}/year=!{timestamp:yyyy}/month=!{timestamp:MM}/day=!{timestamp:dd}/hour=!{timestamp:HH}/")
                    .errorOutputPrefix("errors/year=!{timestamp:yyyy}/month=!{timestamp:MM}/day=!{timestamp:dd}/hour=!{timestamp:HH}/!{firehose:error-output-type}/")
                    .processingConfiguration(FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationArgs.builder()
                        .enabled("true")
                        .processors(                    
                            FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArgs.builder()
                                .type("RecordDeAggregation")
                                .parameters(FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs.builder()
                                    .parameterName("SubRecordType")
                                    .parameterValue("JSON")
                                    .build())
                                .build(),
                            FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArgs.builder()
                                .type("AppendDelimiterToRecord")
                                .build(),
                            FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArgs.builder()
                                .type("MetadataExtraction")
                                .parameters(                            
                                    FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs.builder()
                                        .parameterName("JsonParsingEngine")
                                        .parameterValue("JQ-1.6")
                                        .build(),
                                    FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs.builder()
                                        .parameterName("MetadataExtractionQuery")
                                        .parameterValue("{customer_id:.customer_id}")
                                        .build())
                                .build())
                        .build())
                    .build())
                .build());
    
        }
    }
    
    resources:
      extendedS3Stream:
        type: aws:kinesis:FirehoseDeliveryStream
        name: extended_s3_stream
        properties:
          name: kinesis-firehose-extended-s3-test-stream
          destination: extended_s3
          extendedS3Configuration:
            roleArn: ${firehoseRole.arn}
            bucketArn: ${bucket.arn}
            bufferingSize: 64
            dynamicPartitioningConfiguration:
              enabled: 'true'
            prefix: data/customer_id=!{partitionKeyFromQuery:customer_id}/year=!{timestamp:yyyy}/month=!{timestamp:MM}/day=!{timestamp:dd}/hour=!{timestamp:HH}/
            errorOutputPrefix: errors/year=!{timestamp:yyyy}/month=!{timestamp:MM}/day=!{timestamp:dd}/hour=!{timestamp:HH}/!{firehose:error-output-type}/
            processingConfiguration:
              enabled: 'true'
              processors:
                - type: RecordDeAggregation
                  parameters:
                    - parameterName: SubRecordType
                      parameterValue: JSON
                - type: AppendDelimiterToRecord
                - type: MetadataExtraction
                  parameters:
                    - parameterName: JsonParsingEngine
                      parameterValue: JQ-1.6
                    - parameterName: MetadataExtractionQuery
                      parameterValue: '{customer_id:.customer_id}'
    

    Multiple Dynamic Partitioning Keys (maximum of 50) can be added by comma separating the parameter_value.

    The following example adds the Dynamic Partitioning Keys: store_id and customer_id to the S3 prefix.

    import * as pulumi from "@pulumi/pulumi";
    import * as aws from "@pulumi/aws";
    
    const extendedS3Stream = new aws.kinesis.FirehoseDeliveryStream("extended_s3_stream", {
        name: "kinesis-firehose-extended-s3-test-stream",
        destination: "extended_s3",
        extendedS3Configuration: {
            roleArn: firehoseRole.arn,
            bucketArn: bucket.arn,
            bufferingSize: 64,
            dynamicPartitioningConfiguration: {
                enabled: true,
            },
            prefix: "data/store_id=!{partitionKeyFromQuery:store_id}/customer_id=!{partitionKeyFromQuery:customer_id}/year=!{timestamp:yyyy}/month=!{timestamp:MM}/day=!{timestamp:dd}/hour=!{timestamp:HH}/",
            errorOutputPrefix: "errors/year=!{timestamp:yyyy}/month=!{timestamp:MM}/day=!{timestamp:dd}/hour=!{timestamp:HH}/!{firehose:error-output-type}/",
            processingConfiguration: {
                enabled: true,
                processors: [{
                    type: "MetadataExtraction",
                    parameters: [
                        {
                            parameterName: "JsonParsingEngine",
                            parameterValue: "JQ-1.6",
                        },
                        {
                            parameterName: "MetadataExtractionQuery",
                            parameterValue: "{store_id:.store_id,customer_id:.customer_id}",
                        },
                    ],
                }],
            },
        },
    });
    
    import pulumi
    import pulumi_aws as aws
    
    extended_s3_stream = aws.kinesis.FirehoseDeliveryStream("extended_s3_stream",
        name="kinesis-firehose-extended-s3-test-stream",
        destination="extended_s3",
        extended_s3_configuration=aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationArgs(
            role_arn=firehose_role["arn"],
            bucket_arn=bucket["arn"],
            buffering_size=64,
            dynamic_partitioning_configuration=aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationDynamicPartitioningConfigurationArgs(
                enabled=True,
            ),
            prefix="data/store_id=!{partitionKeyFromQuery:store_id}/customer_id=!{partitionKeyFromQuery:customer_id}/year=!{timestamp:yyyy}/month=!{timestamp:MM}/day=!{timestamp:dd}/hour=!{timestamp:HH}/",
            error_output_prefix="errors/year=!{timestamp:yyyy}/month=!{timestamp:MM}/day=!{timestamp:dd}/hour=!{timestamp:HH}/!{firehose:error-output-type}/",
            processing_configuration=aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationArgs(
                enabled=True,
                processors=[aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArgs(
                    type="MetadataExtraction",
                    parameters=[
                        aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs(
                            parameter_name="JsonParsingEngine",
                            parameter_value="JQ-1.6",
                        ),
                        aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs(
                            parameter_name="MetadataExtractionQuery",
                            parameter_value="{store_id:.store_id,customer_id:.customer_id}",
                        ),
                    ],
                )],
            ),
        ))
    
    package main
    
    import (
    	"github.com/pulumi/pulumi-aws/sdk/v6/go/aws/kinesis"
    	"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
    )
    
    func main() {
    	pulumi.Run(func(ctx *pulumi.Context) error {
    		_, err := kinesis.NewFirehoseDeliveryStream(ctx, "extended_s3_stream", &kinesis.FirehoseDeliveryStreamArgs{
    			Name:        pulumi.String("kinesis-firehose-extended-s3-test-stream"),
    			Destination: pulumi.String("extended_s3"),
    			ExtendedS3Configuration: &kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationArgs{
    				RoleArn:       pulumi.Any(firehoseRole.Arn),
    				BucketArn:     pulumi.Any(bucket.Arn),
    				BufferingSize: pulumi.Int(64),
    				DynamicPartitioningConfiguration: &kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationDynamicPartitioningConfigurationArgs{
    					Enabled: pulumi.Bool(true),
    				},
    				Prefix:            pulumi.String("data/store_id=!{partitionKeyFromQuery:store_id}/customer_id=!{partitionKeyFromQuery:customer_id}/year=!{timestamp:yyyy}/month=!{timestamp:MM}/day=!{timestamp:dd}/hour=!{timestamp:HH}/"),
    				ErrorOutputPrefix: pulumi.String("errors/year=!{timestamp:yyyy}/month=!{timestamp:MM}/day=!{timestamp:dd}/hour=!{timestamp:HH}/!{firehose:error-output-type}/"),
    				ProcessingConfiguration: &kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationArgs{
    					Enabled: pulumi.Bool(true),
    					Processors: kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArray{
    						&kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArgs{
    							Type: pulumi.String("MetadataExtraction"),
    							Parameters: kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArray{
    								&kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs{
    									ParameterName:  pulumi.String("JsonParsingEngine"),
    									ParameterValue: pulumi.String("JQ-1.6"),
    								},
    								&kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs{
    									ParameterName:  pulumi.String("MetadataExtractionQuery"),
    									ParameterValue: pulumi.String("{store_id:.store_id,customer_id:.customer_id}"),
    								},
    							},
    						},
    					},
    				},
    			},
    		})
    		if err != nil {
    			return err
    		}
    		return nil
    	})
    }
    
    using System.Collections.Generic;
    using System.Linq;
    using Pulumi;
    using Aws = Pulumi.Aws;
    
    return await Deployment.RunAsync(() => 
    {
        var extendedS3Stream = new Aws.Kinesis.FirehoseDeliveryStream("extended_s3_stream", new()
        {
            Name = "kinesis-firehose-extended-s3-test-stream",
            Destination = "extended_s3",
            ExtendedS3Configuration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationArgs
            {
                RoleArn = firehoseRole.Arn,
                BucketArn = bucket.Arn,
                BufferingSize = 64,
                DynamicPartitioningConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationDynamicPartitioningConfigurationArgs
                {
                    Enabled = true,
                },
                Prefix = "data/store_id=!{partitionKeyFromQuery:store_id}/customer_id=!{partitionKeyFromQuery:customer_id}/year=!{timestamp:yyyy}/month=!{timestamp:MM}/day=!{timestamp:dd}/hour=!{timestamp:HH}/",
                ErrorOutputPrefix = "errors/year=!{timestamp:yyyy}/month=!{timestamp:MM}/day=!{timestamp:dd}/hour=!{timestamp:HH}/!{firehose:error-output-type}/",
                ProcessingConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationArgs
                {
                    Enabled = true,
                    Processors = new[]
                    {
                        new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArgs
                        {
                            Type = "MetadataExtraction",
                            Parameters = new[]
                            {
                                new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs
                                {
                                    ParameterName = "JsonParsingEngine",
                                    ParameterValue = "JQ-1.6",
                                },
                                new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs
                                {
                                    ParameterName = "MetadataExtractionQuery",
                                    ParameterValue = "{store_id:.store_id,customer_id:.customer_id}",
                                },
                            },
                        },
                    },
                },
            },
        });
    
    });
    
    package generated_program;
    
    import com.pulumi.Context;
    import com.pulumi.Pulumi;
    import com.pulumi.core.Output;
    import com.pulumi.aws.kinesis.FirehoseDeliveryStream;
    import com.pulumi.aws.kinesis.FirehoseDeliveryStreamArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamExtendedS3ConfigurationArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamExtendedS3ConfigurationDynamicPartitioningConfigurationArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationArgs;
    import java.util.List;
    import java.util.ArrayList;
    import java.util.Map;
    import java.io.File;
    import java.nio.file.Files;
    import java.nio.file.Paths;
    
    public class App {
        public static void main(String[] args) {
            Pulumi.run(App::stack);
        }
    
        public static void stack(Context ctx) {
            var extendedS3Stream = new FirehoseDeliveryStream("extendedS3Stream", FirehoseDeliveryStreamArgs.builder()        
                .name("kinesis-firehose-extended-s3-test-stream")
                .destination("extended_s3")
                .extendedS3Configuration(FirehoseDeliveryStreamExtendedS3ConfigurationArgs.builder()
                    .roleArn(firehoseRole.arn())
                    .bucketArn(bucket.arn())
                    .bufferingSize(64)
                    .dynamicPartitioningConfiguration(FirehoseDeliveryStreamExtendedS3ConfigurationDynamicPartitioningConfigurationArgs.builder()
                        .enabled("true")
                        .build())
                    .prefix("data/store_id=!{partitionKeyFromQuery:store_id}/customer_id=!{partitionKeyFromQuery:customer_id}/year=!{timestamp:yyyy}/month=!{timestamp:MM}/day=!{timestamp:dd}/hour=!{timestamp:HH}/")
                    .errorOutputPrefix("errors/year=!{timestamp:yyyy}/month=!{timestamp:MM}/day=!{timestamp:dd}/hour=!{timestamp:HH}/!{firehose:error-output-type}/")
                    .processingConfiguration(FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationArgs.builder()
                        .enabled("true")
                        .processors(FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArgs.builder()
                            .type("MetadataExtraction")
                            .parameters(                        
                                FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs.builder()
                                    .parameterName("JsonParsingEngine")
                                    .parameterValue("JQ-1.6")
                                    .build(),
                                FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs.builder()
                                    .parameterName("MetadataExtractionQuery")
                                    .parameterValue("{store_id:.store_id,customer_id:.customer_id}")
                                    .build())
                            .build())
                        .build())
                    .build())
                .build());
    
        }
    }
    
    resources:
      extendedS3Stream:
        type: aws:kinesis:FirehoseDeliveryStream
        name: extended_s3_stream
        properties:
          name: kinesis-firehose-extended-s3-test-stream
          destination: extended_s3
          extendedS3Configuration:
            roleArn: ${firehoseRole.arn}
            bucketArn: ${bucket.arn}
            bufferingSize: 64
            dynamicPartitioningConfiguration:
              enabled: 'true'
            prefix: data/store_id=!{partitionKeyFromQuery:store_id}/customer_id=!{partitionKeyFromQuery:customer_id}/year=!{timestamp:yyyy}/month=!{timestamp:MM}/day=!{timestamp:dd}/hour=!{timestamp:HH}/
            errorOutputPrefix: errors/year=!{timestamp:yyyy}/month=!{timestamp:MM}/day=!{timestamp:dd}/hour=!{timestamp:HH}/!{firehose:error-output-type}/
            processingConfiguration:
              enabled: 'true'
              processors:
                - type: MetadataExtraction
                  parameters:
                    - parameterName: JsonParsingEngine
                      parameterValue: JQ-1.6
                    - parameterName: MetadataExtractionQuery
                      parameterValue: '{store_id:.store_id,customer_id:.customer_id}'
    

    Redshift Destination

    import * as pulumi from "@pulumi/pulumi";
    import * as aws from "@pulumi/aws";
    
    const testCluster = new aws.redshift.Cluster("test_cluster", {
        clusterIdentifier: "tf-redshift-cluster",
        databaseName: "test",
        masterUsername: "testuser",
        masterPassword: "T3stPass",
        nodeType: "dc1.large",
        clusterType: "single-node",
    });
    const testStream = new aws.kinesis.FirehoseDeliveryStream("test_stream", {
        name: "kinesis-firehose-test-stream",
        destination: "redshift",
        redshiftConfiguration: {
            roleArn: firehoseRole.arn,
            clusterJdbcurl: pulumi.interpolate`jdbc:redshift://${testCluster.endpoint}/${testCluster.databaseName}`,
            username: "testuser",
            password: "T3stPass",
            dataTableName: "test-table",
            copyOptions: "delimiter '|'",
            dataTableColumns: "test-col",
            s3BackupMode: "Enabled",
            s3Configuration: {
                roleArn: firehoseRole.arn,
                bucketArn: bucket.arn,
                bufferingSize: 10,
                bufferingInterval: 400,
                compressionFormat: "GZIP",
            },
            s3BackupConfiguration: {
                roleArn: firehoseRole.arn,
                bucketArn: bucket.arn,
                bufferingSize: 15,
                bufferingInterval: 300,
                compressionFormat: "GZIP",
            },
        },
    });
    
    import pulumi
    import pulumi_aws as aws
    
    test_cluster = aws.redshift.Cluster("test_cluster",
        cluster_identifier="tf-redshift-cluster",
        database_name="test",
        master_username="testuser",
        master_password="T3stPass",
        node_type="dc1.large",
        cluster_type="single-node")
    test_stream = aws.kinesis.FirehoseDeliveryStream("test_stream",
        name="kinesis-firehose-test-stream",
        destination="redshift",
        redshift_configuration=aws.kinesis.FirehoseDeliveryStreamRedshiftConfigurationArgs(
            role_arn=firehose_role["arn"],
            cluster_jdbcurl=pulumi.Output.all(test_cluster.endpoint, test_cluster.database_name).apply(lambda endpoint, database_name: f"jdbc:redshift://{endpoint}/{database_name}"),
            username="testuser",
            password="T3stPass",
            data_table_name="test-table",
            copy_options="delimiter '|'",
            data_table_columns="test-col",
            s3_backup_mode="Enabled",
            s3_configuration=aws.kinesis.FirehoseDeliveryStreamRedshiftConfigurationS3ConfigurationArgs(
                role_arn=firehose_role["arn"],
                bucket_arn=bucket["arn"],
                buffering_size=10,
                buffering_interval=400,
                compression_format="GZIP",
            ),
            s3_backup_configuration=aws.kinesis.FirehoseDeliveryStreamRedshiftConfigurationS3BackupConfigurationArgs(
                role_arn=firehose_role["arn"],
                bucket_arn=bucket["arn"],
                buffering_size=15,
                buffering_interval=300,
                compression_format="GZIP",
            ),
        ))
    
    package main
    
    import (
    	"fmt"
    
    	"github.com/pulumi/pulumi-aws/sdk/v6/go/aws/kinesis"
    	"github.com/pulumi/pulumi-aws/sdk/v6/go/aws/redshift"
    	"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
    )
    
    func main() {
    	pulumi.Run(func(ctx *pulumi.Context) error {
    		testCluster, err := redshift.NewCluster(ctx, "test_cluster", &redshift.ClusterArgs{
    			ClusterIdentifier: pulumi.String("tf-redshift-cluster"),
    			DatabaseName:      pulumi.String("test"),
    			MasterUsername:    pulumi.String("testuser"),
    			MasterPassword:    pulumi.String("T3stPass"),
    			NodeType:          pulumi.String("dc1.large"),
    			ClusterType:       pulumi.String("single-node"),
    		})
    		if err != nil {
    			return err
    		}
    		_, err = kinesis.NewFirehoseDeliveryStream(ctx, "test_stream", &kinesis.FirehoseDeliveryStreamArgs{
    			Name:        pulumi.String("kinesis-firehose-test-stream"),
    			Destination: pulumi.String("redshift"),
    			RedshiftConfiguration: &kinesis.FirehoseDeliveryStreamRedshiftConfigurationArgs{
    				RoleArn: pulumi.Any(firehoseRole.Arn),
    				ClusterJdbcurl: pulumi.All(testCluster.Endpoint, testCluster.DatabaseName).ApplyT(func(_args []interface{}) (string, error) {
    					endpoint := _args[0].(string)
    					databaseName := _args[1].(string)
    					return fmt.Sprintf("jdbc:redshift://%v/%v", endpoint, databaseName), nil
    				}).(pulumi.StringOutput),
    				Username:         pulumi.String("testuser"),
    				Password:         pulumi.String("T3stPass"),
    				DataTableName:    pulumi.String("test-table"),
    				CopyOptions:      pulumi.String("delimiter '|'"),
    				DataTableColumns: pulumi.String("test-col"),
    				S3BackupMode:     pulumi.String("Enabled"),
    				S3Configuration: &kinesis.FirehoseDeliveryStreamRedshiftConfigurationS3ConfigurationArgs{
    					RoleArn:           pulumi.Any(firehoseRole.Arn),
    					BucketArn:         pulumi.Any(bucket.Arn),
    					BufferingSize:     pulumi.Int(10),
    					BufferingInterval: pulumi.Int(400),
    					CompressionFormat: pulumi.String("GZIP"),
    				},
    				S3BackupConfiguration: &kinesis.FirehoseDeliveryStreamRedshiftConfigurationS3BackupConfigurationArgs{
    					RoleArn:           pulumi.Any(firehoseRole.Arn),
    					BucketArn:         pulumi.Any(bucket.Arn),
    					BufferingSize:     pulumi.Int(15),
    					BufferingInterval: pulumi.Int(300),
    					CompressionFormat: pulumi.String("GZIP"),
    				},
    			},
    		})
    		if err != nil {
    			return err
    		}
    		return nil
    	})
    }
    
    using System.Collections.Generic;
    using System.Linq;
    using Pulumi;
    using Aws = Pulumi.Aws;
    
    return await Deployment.RunAsync(() => 
    {
        var testCluster = new Aws.RedShift.Cluster("test_cluster", new()
        {
            ClusterIdentifier = "tf-redshift-cluster",
            DatabaseName = "test",
            MasterUsername = "testuser",
            MasterPassword = "T3stPass",
            NodeType = "dc1.large",
            ClusterType = "single-node",
        });
    
        var testStream = new Aws.Kinesis.FirehoseDeliveryStream("test_stream", new()
        {
            Name = "kinesis-firehose-test-stream",
            Destination = "redshift",
            RedshiftConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamRedshiftConfigurationArgs
            {
                RoleArn = firehoseRole.Arn,
                ClusterJdbcurl = Output.Tuple(testCluster.Endpoint, testCluster.DatabaseName).Apply(values =>
                {
                    var endpoint = values.Item1;
                    var databaseName = values.Item2;
                    return $"jdbc:redshift://{endpoint}/{databaseName}";
                }),
                Username = "testuser",
                Password = "T3stPass",
                DataTableName = "test-table",
                CopyOptions = "delimiter '|'",
                DataTableColumns = "test-col",
                S3BackupMode = "Enabled",
                S3Configuration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamRedshiftConfigurationS3ConfigurationArgs
                {
                    RoleArn = firehoseRole.Arn,
                    BucketArn = bucket.Arn,
                    BufferingSize = 10,
                    BufferingInterval = 400,
                    CompressionFormat = "GZIP",
                },
                S3BackupConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamRedshiftConfigurationS3BackupConfigurationArgs
                {
                    RoleArn = firehoseRole.Arn,
                    BucketArn = bucket.Arn,
                    BufferingSize = 15,
                    BufferingInterval = 300,
                    CompressionFormat = "GZIP",
                },
            },
        });
    
    });
    
    package generated_program;
    
    import com.pulumi.Context;
    import com.pulumi.Pulumi;
    import com.pulumi.core.Output;
    import com.pulumi.aws.redshift.Cluster;
    import com.pulumi.aws.redshift.ClusterArgs;
    import com.pulumi.aws.kinesis.FirehoseDeliveryStream;
    import com.pulumi.aws.kinesis.FirehoseDeliveryStreamArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamRedshiftConfigurationArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamRedshiftConfigurationS3ConfigurationArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamRedshiftConfigurationS3BackupConfigurationArgs;
    import java.util.List;
    import java.util.ArrayList;
    import java.util.Map;
    import java.io.File;
    import java.nio.file.Files;
    import java.nio.file.Paths;
    
    public class App {
        public static void main(String[] args) {
            Pulumi.run(App::stack);
        }
    
        public static void stack(Context ctx) {
            var testCluster = new Cluster("testCluster", ClusterArgs.builder()        
                .clusterIdentifier("tf-redshift-cluster")
                .databaseName("test")
                .masterUsername("testuser")
                .masterPassword("T3stPass")
                .nodeType("dc1.large")
                .clusterType("single-node")
                .build());
    
            var testStream = new FirehoseDeliveryStream("testStream", FirehoseDeliveryStreamArgs.builder()        
                .name("kinesis-firehose-test-stream")
                .destination("redshift")
                .redshiftConfiguration(FirehoseDeliveryStreamRedshiftConfigurationArgs.builder()
                    .roleArn(firehoseRole.arn())
                    .clusterJdbcurl(Output.tuple(testCluster.endpoint(), testCluster.databaseName()).applyValue(values -> {
                        var endpoint = values.t1;
                        var databaseName = values.t2;
                        return String.format("jdbc:redshift://%s/%s", endpoint,databaseName);
                    }))
                    .username("testuser")
                    .password("T3stPass")
                    .dataTableName("test-table")
                    .copyOptions("delimiter '|'")
                    .dataTableColumns("test-col")
                    .s3BackupMode("Enabled")
                    .s3Configuration(FirehoseDeliveryStreamRedshiftConfigurationS3ConfigurationArgs.builder()
                        .roleArn(firehoseRole.arn())
                        .bucketArn(bucket.arn())
                        .bufferingSize(10)
                        .bufferingInterval(400)
                        .compressionFormat("GZIP")
                        .build())
                    .s3BackupConfiguration(FirehoseDeliveryStreamRedshiftConfigurationS3BackupConfigurationArgs.builder()
                        .roleArn(firehoseRole.arn())
                        .bucketArn(bucket.arn())
                        .bufferingSize(15)
                        .bufferingInterval(300)
                        .compressionFormat("GZIP")
                        .build())
                    .build())
                .build());
    
        }
    }
    
    resources:
      testCluster:
        type: aws:redshift:Cluster
        name: test_cluster
        properties:
          clusterIdentifier: tf-redshift-cluster
          databaseName: test
          masterUsername: testuser
          masterPassword: T3stPass
          nodeType: dc1.large
          clusterType: single-node
      testStream:
        type: aws:kinesis:FirehoseDeliveryStream
        name: test_stream
        properties:
          name: kinesis-firehose-test-stream
          destination: redshift
          redshiftConfiguration:
            roleArn: ${firehoseRole.arn}
            clusterJdbcurl: jdbc:redshift://${testCluster.endpoint}/${testCluster.databaseName}
            username: testuser
            password: T3stPass
            dataTableName: test-table
            copyOptions: delimiter '|'
            dataTableColumns: test-col
            s3BackupMode: Enabled
            s3Configuration:
              roleArn: ${firehoseRole.arn}
              bucketArn: ${bucket.arn}
              bufferingSize: 10
              bufferingInterval: 400
              compressionFormat: GZIP
            s3BackupConfiguration:
              roleArn: ${firehoseRole.arn}
              bucketArn: ${bucket.arn}
              bufferingSize: 15
              bufferingInterval: 300
              compressionFormat: GZIP
    

    Elasticsearch Destination

    import * as pulumi from "@pulumi/pulumi";
    import * as aws from "@pulumi/aws";
    
    const testCluster = new aws.elasticsearch.Domain("test_cluster", {domainName: "firehose-es-test"});
    const testStream = new aws.kinesis.FirehoseDeliveryStream("test_stream", {
        name: "kinesis-firehose-test-stream",
        destination: "elasticsearch",
        elasticsearchConfiguration: {
            domainArn: testCluster.arn,
            roleArn: firehoseRole.arn,
            indexName: "test",
            typeName: "test",
            s3Configuration: {
                roleArn: firehoseRole.arn,
                bucketArn: bucket.arn,
                bufferingSize: 10,
                bufferingInterval: 400,
                compressionFormat: "GZIP",
            },
            processingConfiguration: {
                enabled: true,
                processors: [{
                    type: "Lambda",
                    parameters: [{
                        parameterName: "LambdaArn",
                        parameterValue: `${lambdaProcessor.arn}:$LATEST`,
                    }],
                }],
            },
        },
    });
    
    import pulumi
    import pulumi_aws as aws
    
    test_cluster = aws.elasticsearch.Domain("test_cluster", domain_name="firehose-es-test")
    test_stream = aws.kinesis.FirehoseDeliveryStream("test_stream",
        name="kinesis-firehose-test-stream",
        destination="elasticsearch",
        elasticsearch_configuration=aws.kinesis.FirehoseDeliveryStreamElasticsearchConfigurationArgs(
            domain_arn=test_cluster.arn,
            role_arn=firehose_role["arn"],
            index_name="test",
            type_name="test",
            s3_configuration=aws.kinesis.FirehoseDeliveryStreamElasticsearchConfigurationS3ConfigurationArgs(
                role_arn=firehose_role["arn"],
                bucket_arn=bucket["arn"],
                buffering_size=10,
                buffering_interval=400,
                compression_format="GZIP",
            ),
            processing_configuration=aws.kinesis.FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationArgs(
                enabled=True,
                processors=[aws.kinesis.FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorArgs(
                    type="Lambda",
                    parameters=[aws.kinesis.FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorParameterArgs(
                        parameter_name="LambdaArn",
                        parameter_value=f"{lambda_processor['arn']}:$LATEST",
                    )],
                )],
            ),
        ))
    
    package main
    
    import (
    	"fmt"
    
    	"github.com/pulumi/pulumi-aws/sdk/v6/go/aws/elasticsearch"
    	"github.com/pulumi/pulumi-aws/sdk/v6/go/aws/kinesis"
    	"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
    )
    
    func main() {
    	pulumi.Run(func(ctx *pulumi.Context) error {
    		testCluster, err := elasticsearch.NewDomain(ctx, "test_cluster", &elasticsearch.DomainArgs{
    			DomainName: pulumi.String("firehose-es-test"),
    		})
    		if err != nil {
    			return err
    		}
    		_, err = kinesis.NewFirehoseDeliveryStream(ctx, "test_stream", &kinesis.FirehoseDeliveryStreamArgs{
    			Name:        pulumi.String("kinesis-firehose-test-stream"),
    			Destination: pulumi.String("elasticsearch"),
    			ElasticsearchConfiguration: &kinesis.FirehoseDeliveryStreamElasticsearchConfigurationArgs{
    				DomainArn: testCluster.Arn,
    				RoleArn:   pulumi.Any(firehoseRole.Arn),
    				IndexName: pulumi.String("test"),
    				TypeName:  pulumi.String("test"),
    				S3Configuration: &kinesis.FirehoseDeliveryStreamElasticsearchConfigurationS3ConfigurationArgs{
    					RoleArn:           pulumi.Any(firehoseRole.Arn),
    					BucketArn:         pulumi.Any(bucket.Arn),
    					BufferingSize:     pulumi.Int(10),
    					BufferingInterval: pulumi.Int(400),
    					CompressionFormat: pulumi.String("GZIP"),
    				},
    				ProcessingConfiguration: &kinesis.FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationArgs{
    					Enabled: pulumi.Bool(true),
    					Processors: kinesis.FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorArray{
    						&kinesis.FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorArgs{
    							Type: pulumi.String("Lambda"),
    							Parameters: kinesis.FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorParameterArray{
    								&kinesis.FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorParameterArgs{
    									ParameterName:  pulumi.String("LambdaArn"),
    									ParameterValue: pulumi.String(fmt.Sprintf("%v:$LATEST", lambdaProcessor.Arn)),
    								},
    							},
    						},
    					},
    				},
    			},
    		})
    		if err != nil {
    			return err
    		}
    		return nil
    	})
    }
    
    using System.Collections.Generic;
    using System.Linq;
    using Pulumi;
    using Aws = Pulumi.Aws;
    
    return await Deployment.RunAsync(() => 
    {
        var testCluster = new Aws.ElasticSearch.Domain("test_cluster", new()
        {
            DomainName = "firehose-es-test",
        });
    
        var testStream = new Aws.Kinesis.FirehoseDeliveryStream("test_stream", new()
        {
            Name = "kinesis-firehose-test-stream",
            Destination = "elasticsearch",
            ElasticsearchConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamElasticsearchConfigurationArgs
            {
                DomainArn = testCluster.Arn,
                RoleArn = firehoseRole.Arn,
                IndexName = "test",
                TypeName = "test",
                S3Configuration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamElasticsearchConfigurationS3ConfigurationArgs
                {
                    RoleArn = firehoseRole.Arn,
                    BucketArn = bucket.Arn,
                    BufferingSize = 10,
                    BufferingInterval = 400,
                    CompressionFormat = "GZIP",
                },
                ProcessingConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationArgs
                {
                    Enabled = true,
                    Processors = new[]
                    {
                        new Aws.Kinesis.Inputs.FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorArgs
                        {
                            Type = "Lambda",
                            Parameters = new[]
                            {
                                new Aws.Kinesis.Inputs.FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorParameterArgs
                                {
                                    ParameterName = "LambdaArn",
                                    ParameterValue = $"{lambdaProcessor.Arn}:$LATEST",
                                },
                            },
                        },
                    },
                },
            },
        });
    
    });
    
    package generated_program;
    
    import com.pulumi.Context;
    import com.pulumi.Pulumi;
    import com.pulumi.core.Output;
    import com.pulumi.aws.elasticsearch.Domain;
    import com.pulumi.aws.elasticsearch.DomainArgs;
    import com.pulumi.aws.kinesis.FirehoseDeliveryStream;
    import com.pulumi.aws.kinesis.FirehoseDeliveryStreamArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamElasticsearchConfigurationArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamElasticsearchConfigurationS3ConfigurationArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationArgs;
    import java.util.List;
    import java.util.ArrayList;
    import java.util.Map;
    import java.io.File;
    import java.nio.file.Files;
    import java.nio.file.Paths;
    
    public class App {
        public static void main(String[] args) {
            Pulumi.run(App::stack);
        }
    
        public static void stack(Context ctx) {
            var testCluster = new Domain("testCluster", DomainArgs.builder()        
                .domainName("firehose-es-test")
                .build());
    
            var testStream = new FirehoseDeliveryStream("testStream", FirehoseDeliveryStreamArgs.builder()        
                .name("kinesis-firehose-test-stream")
                .destination("elasticsearch")
                .elasticsearchConfiguration(FirehoseDeliveryStreamElasticsearchConfigurationArgs.builder()
                    .domainArn(testCluster.arn())
                    .roleArn(firehoseRole.arn())
                    .indexName("test")
                    .typeName("test")
                    .s3Configuration(FirehoseDeliveryStreamElasticsearchConfigurationS3ConfigurationArgs.builder()
                        .roleArn(firehoseRole.arn())
                        .bucketArn(bucket.arn())
                        .bufferingSize(10)
                        .bufferingInterval(400)
                        .compressionFormat("GZIP")
                        .build())
                    .processingConfiguration(FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationArgs.builder()
                        .enabled("true")
                        .processors(FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorArgs.builder()
                            .type("Lambda")
                            .parameters(FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorParameterArgs.builder()
                                .parameterName("LambdaArn")
                                .parameterValue(String.format("%s:$LATEST", lambdaProcessor.arn()))
                                .build())
                            .build())
                        .build())
                    .build())
                .build());
    
        }
    }
    
    resources:
      testCluster:
        type: aws:elasticsearch:Domain
        name: test_cluster
        properties:
          domainName: firehose-es-test
      testStream:
        type: aws:kinesis:FirehoseDeliveryStream
        name: test_stream
        properties:
          name: kinesis-firehose-test-stream
          destination: elasticsearch
          elasticsearchConfiguration:
            domainArn: ${testCluster.arn}
            roleArn: ${firehoseRole.arn}
            indexName: test
            typeName: test
            s3Configuration:
              roleArn: ${firehoseRole.arn}
              bucketArn: ${bucket.arn}
              bufferingSize: 10
              bufferingInterval: 400
              compressionFormat: GZIP
            processingConfiguration:
              enabled: 'true'
              processors:
                - type: Lambda
                  parameters:
                    - parameterName: LambdaArn
                      parameterValue: ${lambdaProcessor.arn}:$LATEST
    

    Elasticsearch Destination With VPC

    import * as pulumi from "@pulumi/pulumi";
    import * as aws from "@pulumi/aws";
    
    const testCluster = new aws.elasticsearch.Domain("test_cluster", {
        domainName: "es-test",
        clusterConfig: {
            instanceCount: 2,
            zoneAwarenessEnabled: true,
            instanceType: "t2.small.elasticsearch",
        },
        ebsOptions: {
            ebsEnabled: true,
            volumeSize: 10,
        },
        vpcOptions: {
            securityGroupIds: [first.id],
            subnetIds: [
                firstAwsSubnet.id,
                second.id,
            ],
        },
    });
    const firehose-elasticsearch = aws.iam.getPolicyDocumentOutput({
        statements: [
            {
                effect: "Allow",
                actions: ["es:*"],
                resources: [
                    testCluster.arn,
                    pulumi.interpolate`${testCluster.arn}/*`,
                ],
            },
            {
                effect: "Allow",
                actions: [
                    "ec2:DescribeVpcs",
                    "ec2:DescribeVpcAttribute",
                    "ec2:DescribeSubnets",
                    "ec2:DescribeSecurityGroups",
                    "ec2:DescribeNetworkInterfaces",
                    "ec2:CreateNetworkInterface",
                    "ec2:CreateNetworkInterfacePermission",
                    "ec2:DeleteNetworkInterface",
                ],
                resources: ["*"],
            },
        ],
    });
    const firehose_elasticsearchRolePolicy = new aws.iam.RolePolicy("firehose-elasticsearch", {
        name: "elasticsearch",
        role: firehose.id,
        policy: firehose_elasticsearch.apply(firehose_elasticsearch => firehose_elasticsearch.json),
    });
    const test = new aws.kinesis.FirehoseDeliveryStream("test", {
        name: "kinesis-firehose-es",
        destination: "elasticsearch",
        elasticsearchConfiguration: {
            domainArn: testCluster.arn,
            roleArn: firehose.arn,
            indexName: "test",
            typeName: "test",
            s3Configuration: {
                roleArn: firehose.arn,
                bucketArn: bucket.arn,
            },
            vpcConfig: {
                subnetIds: [
                    firstAwsSubnet.id,
                    second.id,
                ],
                securityGroupIds: [first.id],
                roleArn: firehose.arn,
            },
        },
    }, {
        dependsOn: [firehose_elasticsearchRolePolicy],
    });
    
    import pulumi
    import pulumi_aws as aws
    
    test_cluster = aws.elasticsearch.Domain("test_cluster",
        domain_name="es-test",
        cluster_config=aws.elasticsearch.DomainClusterConfigArgs(
            instance_count=2,
            zone_awareness_enabled=True,
            instance_type="t2.small.elasticsearch",
        ),
        ebs_options=aws.elasticsearch.DomainEbsOptionsArgs(
            ebs_enabled=True,
            volume_size=10,
        ),
        vpc_options=aws.elasticsearch.DomainVpcOptionsArgs(
            security_group_ids=[first["id"]],
            subnet_ids=[
                first_aws_subnet["id"],
                second["id"],
            ],
        ))
    firehose_elasticsearch = aws.iam.get_policy_document_output(statements=[
        aws.iam.GetPolicyDocumentStatementArgs(
            effect="Allow",
            actions=["es:*"],
            resources=[
                test_cluster.arn,
                test_cluster.arn.apply(lambda arn: f"{arn}/*"),
            ],
        ),
        aws.iam.GetPolicyDocumentStatementArgs(
            effect="Allow",
            actions=[
                "ec2:DescribeVpcs",
                "ec2:DescribeVpcAttribute",
                "ec2:DescribeSubnets",
                "ec2:DescribeSecurityGroups",
                "ec2:DescribeNetworkInterfaces",
                "ec2:CreateNetworkInterface",
                "ec2:CreateNetworkInterfacePermission",
                "ec2:DeleteNetworkInterface",
            ],
            resources=["*"],
        ),
    ])
    firehose_elasticsearch_role_policy = aws.iam.RolePolicy("firehose-elasticsearch",
        name="elasticsearch",
        role=firehose["id"],
        policy=firehose_elasticsearch.json)
    test = aws.kinesis.FirehoseDeliveryStream("test",
        name="kinesis-firehose-es",
        destination="elasticsearch",
        elasticsearch_configuration=aws.kinesis.FirehoseDeliveryStreamElasticsearchConfigurationArgs(
            domain_arn=test_cluster.arn,
            role_arn=firehose["arn"],
            index_name="test",
            type_name="test",
            s3_configuration=aws.kinesis.FirehoseDeliveryStreamElasticsearchConfigurationS3ConfigurationArgs(
                role_arn=firehose["arn"],
                bucket_arn=bucket["arn"],
            ),
            vpc_config=aws.kinesis.FirehoseDeliveryStreamElasticsearchConfigurationVpcConfigArgs(
                subnet_ids=[
                    first_aws_subnet["id"],
                    second["id"],
                ],
                security_group_ids=[first["id"]],
                role_arn=firehose["arn"],
            ),
        ),
        opts=pulumi.ResourceOptions(depends_on=[firehose_elasticsearch_role_policy]))
    
    package main
    
    import (
    	"fmt"
    
    	"github.com/pulumi/pulumi-aws/sdk/v6/go/aws/elasticsearch"
    	"github.com/pulumi/pulumi-aws/sdk/v6/go/aws/iam"
    	"github.com/pulumi/pulumi-aws/sdk/v6/go/aws/kinesis"
    	"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
    )
    
    func main() {
    	pulumi.Run(func(ctx *pulumi.Context) error {
    		testCluster, err := elasticsearch.NewDomain(ctx, "test_cluster", &elasticsearch.DomainArgs{
    			DomainName: pulumi.String("es-test"),
    			ClusterConfig: &elasticsearch.DomainClusterConfigArgs{
    				InstanceCount:        pulumi.Int(2),
    				ZoneAwarenessEnabled: pulumi.Bool(true),
    				InstanceType:         pulumi.String("t2.small.elasticsearch"),
    			},
    			EbsOptions: &elasticsearch.DomainEbsOptionsArgs{
    				EbsEnabled: pulumi.Bool(true),
    				VolumeSize: pulumi.Int(10),
    			},
    			VpcOptions: &elasticsearch.DomainVpcOptionsArgs{
    				SecurityGroupIds: pulumi.StringArray{
    					first.Id,
    				},
    				SubnetIds: pulumi.StringArray{
    					firstAwsSubnet.Id,
    					second.Id,
    				},
    			},
    		})
    		if err != nil {
    			return err
    		}
    		firehose_elasticsearch := iam.GetPolicyDocumentOutput(ctx, iam.GetPolicyDocumentOutputArgs{
    			Statements: iam.GetPolicyDocumentStatementArray{
    				&iam.GetPolicyDocumentStatementArgs{
    					Effect: pulumi.String("Allow"),
    					Actions: pulumi.StringArray{
    						pulumi.String("es:*"),
    					},
    					Resources: pulumi.StringArray{
    						testCluster.Arn,
    						testCluster.Arn.ApplyT(func(arn string) (string, error) {
    							return fmt.Sprintf("%v/*", arn), nil
    						}).(pulumi.StringOutput),
    					},
    				},
    				&iam.GetPolicyDocumentStatementArgs{
    					Effect: pulumi.String("Allow"),
    					Actions: pulumi.StringArray{
    						pulumi.String("ec2:DescribeVpcs"),
    						pulumi.String("ec2:DescribeVpcAttribute"),
    						pulumi.String("ec2:DescribeSubnets"),
    						pulumi.String("ec2:DescribeSecurityGroups"),
    						pulumi.String("ec2:DescribeNetworkInterfaces"),
    						pulumi.String("ec2:CreateNetworkInterface"),
    						pulumi.String("ec2:CreateNetworkInterfacePermission"),
    						pulumi.String("ec2:DeleteNetworkInterface"),
    					},
    					Resources: pulumi.StringArray{
    						pulumi.String("*"),
    					},
    				},
    			},
    		}, nil)
    		_, err = iam.NewRolePolicy(ctx, "firehose-elasticsearch", &iam.RolePolicyArgs{
    			Name: pulumi.String("elasticsearch"),
    			Role: pulumi.Any(firehose.Id),
    			Policy: firehose_elasticsearch.ApplyT(func(firehose_elasticsearch iam.GetPolicyDocumentResult) (*string, error) {
    				return &firehose_elasticsearch.Json, nil
    			}).(pulumi.StringPtrOutput),
    		})
    		if err != nil {
    			return err
    		}
    		_, err = kinesis.NewFirehoseDeliveryStream(ctx, "test", &kinesis.FirehoseDeliveryStreamArgs{
    			Name:        pulumi.String("kinesis-firehose-es"),
    			Destination: pulumi.String("elasticsearch"),
    			ElasticsearchConfiguration: &kinesis.FirehoseDeliveryStreamElasticsearchConfigurationArgs{
    				DomainArn: testCluster.Arn,
    				RoleArn:   pulumi.Any(firehose.Arn),
    				IndexName: pulumi.String("test"),
    				TypeName:  pulumi.String("test"),
    				S3Configuration: &kinesis.FirehoseDeliveryStreamElasticsearchConfigurationS3ConfigurationArgs{
    					RoleArn:   pulumi.Any(firehose.Arn),
    					BucketArn: pulumi.Any(bucket.Arn),
    				},
    				VpcConfig: &kinesis.FirehoseDeliveryStreamElasticsearchConfigurationVpcConfigArgs{
    					SubnetIds: pulumi.StringArray{
    						firstAwsSubnet.Id,
    						second.Id,
    					},
    					SecurityGroupIds: pulumi.StringArray{
    						first.Id,
    					},
    					RoleArn: pulumi.Any(firehose.Arn),
    				},
    			},
    		}, pulumi.DependsOn([]pulumi.Resource{
    			firehose_elasticsearchRolePolicy,
    		}))
    		if err != nil {
    			return err
    		}
    		return nil
    	})
    }
    
    using System.Collections.Generic;
    using System.Linq;
    using Pulumi;
    using Aws = Pulumi.Aws;
    
    return await Deployment.RunAsync(() => 
    {
        var testCluster = new Aws.ElasticSearch.Domain("test_cluster", new()
        {
            DomainName = "es-test",
            ClusterConfig = new Aws.ElasticSearch.Inputs.DomainClusterConfigArgs
            {
                InstanceCount = 2,
                ZoneAwarenessEnabled = true,
                InstanceType = "t2.small.elasticsearch",
            },
            EbsOptions = new Aws.ElasticSearch.Inputs.DomainEbsOptionsArgs
            {
                EbsEnabled = true,
                VolumeSize = 10,
            },
            VpcOptions = new Aws.ElasticSearch.Inputs.DomainVpcOptionsArgs
            {
                SecurityGroupIds = new[]
                {
                    first.Id,
                },
                SubnetIds = new[]
                {
                    firstAwsSubnet.Id,
                    second.Id,
                },
            },
        });
    
        var firehose_elasticsearch = Aws.Iam.GetPolicyDocument.Invoke(new()
        {
            Statements = new[]
            {
                new Aws.Iam.Inputs.GetPolicyDocumentStatementInputArgs
                {
                    Effect = "Allow",
                    Actions = new[]
                    {
                        "es:*",
                    },
                    Resources = new[]
                    {
                        testCluster.Arn,
                        $"{testCluster.Arn}/*",
                    },
                },
                new Aws.Iam.Inputs.GetPolicyDocumentStatementInputArgs
                {
                    Effect = "Allow",
                    Actions = new[]
                    {
                        "ec2:DescribeVpcs",
                        "ec2:DescribeVpcAttribute",
                        "ec2:DescribeSubnets",
                        "ec2:DescribeSecurityGroups",
                        "ec2:DescribeNetworkInterfaces",
                        "ec2:CreateNetworkInterface",
                        "ec2:CreateNetworkInterfacePermission",
                        "ec2:DeleteNetworkInterface",
                    },
                    Resources = new[]
                    {
                        "*",
                    },
                },
            },
        });
    
        var firehose_elasticsearchRolePolicy = new Aws.Iam.RolePolicy("firehose-elasticsearch", new()
        {
            Name = "elasticsearch",
            Role = firehose.Id,
            Policy = firehose_elasticsearch.Apply(firehose_elasticsearch => firehose_elasticsearch.Apply(getPolicyDocumentResult => getPolicyDocumentResult.Json)),
        });
    
        var test = new Aws.Kinesis.FirehoseDeliveryStream("test", new()
        {
            Name = "kinesis-firehose-es",
            Destination = "elasticsearch",
            ElasticsearchConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamElasticsearchConfigurationArgs
            {
                DomainArn = testCluster.Arn,
                RoleArn = firehose.Arn,
                IndexName = "test",
                TypeName = "test",
                S3Configuration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamElasticsearchConfigurationS3ConfigurationArgs
                {
                    RoleArn = firehose.Arn,
                    BucketArn = bucket.Arn,
                },
                VpcConfig = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamElasticsearchConfigurationVpcConfigArgs
                {
                    SubnetIds = new[]
                    {
                        firstAwsSubnet.Id,
                        second.Id,
                    },
                    SecurityGroupIds = new[]
                    {
                        first.Id,
                    },
                    RoleArn = firehose.Arn,
                },
            },
        }, new CustomResourceOptions
        {
            DependsOn =
            {
                firehose_elasticsearchRolePolicy, 
            },
        });
    
    });
    
    package generated_program;
    
    import com.pulumi.Context;
    import com.pulumi.Pulumi;
    import com.pulumi.core.Output;
    import com.pulumi.aws.elasticsearch.Domain;
    import com.pulumi.aws.elasticsearch.DomainArgs;
    import com.pulumi.aws.elasticsearch.inputs.DomainClusterConfigArgs;
    import com.pulumi.aws.elasticsearch.inputs.DomainEbsOptionsArgs;
    import com.pulumi.aws.elasticsearch.inputs.DomainVpcOptionsArgs;
    import com.pulumi.aws.iam.IamFunctions;
    import com.pulumi.aws.iam.inputs.GetPolicyDocumentArgs;
    import com.pulumi.aws.iam.RolePolicy;
    import com.pulumi.aws.iam.RolePolicyArgs;
    import com.pulumi.aws.kinesis.FirehoseDeliveryStream;
    import com.pulumi.aws.kinesis.FirehoseDeliveryStreamArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamElasticsearchConfigurationArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamElasticsearchConfigurationS3ConfigurationArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamElasticsearchConfigurationVpcConfigArgs;
    import com.pulumi.resources.CustomResourceOptions;
    import java.util.List;
    import java.util.ArrayList;
    import java.util.Map;
    import java.io.File;
    import java.nio.file.Files;
    import java.nio.file.Paths;
    
    public class App {
        public static void main(String[] args) {
            Pulumi.run(App::stack);
        }
    
        public static void stack(Context ctx) {
            var testCluster = new Domain("testCluster", DomainArgs.builder()        
                .domainName("es-test")
                .clusterConfig(DomainClusterConfigArgs.builder()
                    .instanceCount(2)
                    .zoneAwarenessEnabled(true)
                    .instanceType("t2.small.elasticsearch")
                    .build())
                .ebsOptions(DomainEbsOptionsArgs.builder()
                    .ebsEnabled(true)
                    .volumeSize(10)
                    .build())
                .vpcOptions(DomainVpcOptionsArgs.builder()
                    .securityGroupIds(first.id())
                    .subnetIds(                
                        firstAwsSubnet.id(),
                        second.id())
                    .build())
                .build());
    
            final var firehose-elasticsearch = IamFunctions.getPolicyDocument(GetPolicyDocumentArgs.builder()
                .statements(            
                    GetPolicyDocumentStatementArgs.builder()
                        .effect("Allow")
                        .actions("es:*")
                        .resources(                    
                            testCluster.arn(),
                            testCluster.arn().applyValue(arn -> String.format("%s/*", arn)))
                        .build(),
                    GetPolicyDocumentStatementArgs.builder()
                        .effect("Allow")
                        .actions(                    
                            "ec2:DescribeVpcs",
                            "ec2:DescribeVpcAttribute",
                            "ec2:DescribeSubnets",
                            "ec2:DescribeSecurityGroups",
                            "ec2:DescribeNetworkInterfaces",
                            "ec2:CreateNetworkInterface",
                            "ec2:CreateNetworkInterfacePermission",
                            "ec2:DeleteNetworkInterface")
                        .resources("*")
                        .build())
                .build());
    
            var firehose_elasticsearchRolePolicy = new RolePolicy("firehose-elasticsearchRolePolicy", RolePolicyArgs.builder()        
                .name("elasticsearch")
                .role(firehose.id())
                .policy(firehose_elasticsearch.applyValue(firehose_elasticsearch -> firehose_elasticsearch.json()))
                .build());
    
            var test = new FirehoseDeliveryStream("test", FirehoseDeliveryStreamArgs.builder()        
                .name("kinesis-firehose-es")
                .destination("elasticsearch")
                .elasticsearchConfiguration(FirehoseDeliveryStreamElasticsearchConfigurationArgs.builder()
                    .domainArn(testCluster.arn())
                    .roleArn(firehose.arn())
                    .indexName("test")
                    .typeName("test")
                    .s3Configuration(FirehoseDeliveryStreamElasticsearchConfigurationS3ConfigurationArgs.builder()
                        .roleArn(firehose.arn())
                        .bucketArn(bucket.arn())
                        .build())
                    .vpcConfig(FirehoseDeliveryStreamElasticsearchConfigurationVpcConfigArgs.builder()
                        .subnetIds(                    
                            firstAwsSubnet.id(),
                            second.id())
                        .securityGroupIds(first.id())
                        .roleArn(firehose.arn())
                        .build())
                    .build())
                .build(), CustomResourceOptions.builder()
                    .dependsOn(firehose_elasticsearchRolePolicy)
                    .build());
    
        }
    }
    
    resources:
      testCluster:
        type: aws:elasticsearch:Domain
        name: test_cluster
        properties:
          domainName: es-test
          clusterConfig:
            instanceCount: 2
            zoneAwarenessEnabled: true
            instanceType: t2.small.elasticsearch
          ebsOptions:
            ebsEnabled: true
            volumeSize: 10
          vpcOptions:
            securityGroupIds:
              - ${first.id}
            subnetIds:
              - ${firstAwsSubnet.id}
              - ${second.id}
      firehose-elasticsearchRolePolicy:
        type: aws:iam:RolePolicy
        name: firehose-elasticsearch
        properties:
          name: elasticsearch
          role: ${firehose.id}
          policy: ${["firehose-elasticsearch"].json}
      test:
        type: aws:kinesis:FirehoseDeliveryStream
        properties:
          name: kinesis-firehose-es
          destination: elasticsearch
          elasticsearchConfiguration:
            domainArn: ${testCluster.arn}
            roleArn: ${firehose.arn}
            indexName: test
            typeName: test
            s3Configuration:
              roleArn: ${firehose.arn}
              bucketArn: ${bucket.arn}
            vpcConfig:
              subnetIds:
                - ${firstAwsSubnet.id}
                - ${second.id}
              securityGroupIds:
                - ${first.id}
              roleArn: ${firehose.arn}
        options:
          dependson:
            - ${["firehose-elasticsearchRolePolicy"]}
    variables:
      firehose-elasticsearch:
        fn::invoke:
          Function: aws:iam:getPolicyDocument
          Arguments:
            statements:
              - effect: Allow
                actions:
                  - es:*
                resources:
                  - ${testCluster.arn}
                  - ${testCluster.arn}/*
              - effect: Allow
                actions:
                  - ec2:DescribeVpcs
                  - ec2:DescribeVpcAttribute
                  - ec2:DescribeSubnets
                  - ec2:DescribeSecurityGroups
                  - ec2:DescribeNetworkInterfaces
                  - ec2:CreateNetworkInterface
                  - ec2:CreateNetworkInterfacePermission
                  - ec2:DeleteNetworkInterface
                resources:
                  - '*'
    

    OpenSearch Destination

    import * as pulumi from "@pulumi/pulumi";
    import * as aws from "@pulumi/aws";
    
    const testCluster = new aws.opensearch.Domain("test_cluster", {domainName: "firehose-os-test"});
    const testStream = new aws.kinesis.FirehoseDeliveryStream("test_stream", {
        name: "kinesis-firehose-test-stream",
        destination: "opensearch",
        opensearchConfiguration: {
            domainArn: testCluster.arn,
            roleArn: firehoseRole.arn,
            indexName: "test",
            s3Configuration: {
                roleArn: firehoseRole.arn,
                bucketArn: bucket.arn,
                bufferingSize: 10,
                bufferingInterval: 400,
                compressionFormat: "GZIP",
            },
            processingConfiguration: {
                enabled: true,
                processors: [{
                    type: "Lambda",
                    parameters: [{
                        parameterName: "LambdaArn",
                        parameterValue: `${lambdaProcessor.arn}:$LATEST`,
                    }],
                }],
            },
        },
    });
    
    import pulumi
    import pulumi_aws as aws
    
    test_cluster = aws.opensearch.Domain("test_cluster", domain_name="firehose-os-test")
    test_stream = aws.kinesis.FirehoseDeliveryStream("test_stream",
        name="kinesis-firehose-test-stream",
        destination="opensearch",
        opensearch_configuration=aws.kinesis.FirehoseDeliveryStreamOpensearchConfigurationArgs(
            domain_arn=test_cluster.arn,
            role_arn=firehose_role["arn"],
            index_name="test",
            s3_configuration=aws.kinesis.FirehoseDeliveryStreamOpensearchConfigurationS3ConfigurationArgs(
                role_arn=firehose_role["arn"],
                bucket_arn=bucket["arn"],
                buffering_size=10,
                buffering_interval=400,
                compression_format="GZIP",
            ),
            processing_configuration=aws.kinesis.FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationArgs(
                enabled=True,
                processors=[aws.kinesis.FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorArgs(
                    type="Lambda",
                    parameters=[aws.kinesis.FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorParameterArgs(
                        parameter_name="LambdaArn",
                        parameter_value=f"{lambda_processor['arn']}:$LATEST",
                    )],
                )],
            ),
        ))
    
    package main
    
    import (
    	"fmt"
    
    	"github.com/pulumi/pulumi-aws/sdk/v6/go/aws/kinesis"
    	"github.com/pulumi/pulumi-aws/sdk/v6/go/aws/opensearch"
    	"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
    )
    
    func main() {
    	pulumi.Run(func(ctx *pulumi.Context) error {
    		testCluster, err := opensearch.NewDomain(ctx, "test_cluster", &opensearch.DomainArgs{
    			DomainName: pulumi.String("firehose-os-test"),
    		})
    		if err != nil {
    			return err
    		}
    		_, err = kinesis.NewFirehoseDeliveryStream(ctx, "test_stream", &kinesis.FirehoseDeliveryStreamArgs{
    			Name:        pulumi.String("kinesis-firehose-test-stream"),
    			Destination: pulumi.String("opensearch"),
    			OpensearchConfiguration: &kinesis.FirehoseDeliveryStreamOpensearchConfigurationArgs{
    				DomainArn: testCluster.Arn,
    				RoleArn:   pulumi.Any(firehoseRole.Arn),
    				IndexName: pulumi.String("test"),
    				S3Configuration: &kinesis.FirehoseDeliveryStreamOpensearchConfigurationS3ConfigurationArgs{
    					RoleArn:           pulumi.Any(firehoseRole.Arn),
    					BucketArn:         pulumi.Any(bucket.Arn),
    					BufferingSize:     pulumi.Int(10),
    					BufferingInterval: pulumi.Int(400),
    					CompressionFormat: pulumi.String("GZIP"),
    				},
    				ProcessingConfiguration: &kinesis.FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationArgs{
    					Enabled: pulumi.Bool(true),
    					Processors: kinesis.FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorArray{
    						&kinesis.FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorArgs{
    							Type: pulumi.String("Lambda"),
    							Parameters: kinesis.FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorParameterArray{
    								&kinesis.FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorParameterArgs{
    									ParameterName:  pulumi.String("LambdaArn"),
    									ParameterValue: pulumi.String(fmt.Sprintf("%v:$LATEST", lambdaProcessor.Arn)),
    								},
    							},
    						},
    					},
    				},
    			},
    		})
    		if err != nil {
    			return err
    		}
    		return nil
    	})
    }
    
    using System.Collections.Generic;
    using System.Linq;
    using Pulumi;
    using Aws = Pulumi.Aws;
    
    return await Deployment.RunAsync(() => 
    {
        var testCluster = new Aws.OpenSearch.Domain("test_cluster", new()
        {
            DomainName = "firehose-os-test",
        });
    
        var testStream = new Aws.Kinesis.FirehoseDeliveryStream("test_stream", new()
        {
            Name = "kinesis-firehose-test-stream",
            Destination = "opensearch",
            OpensearchConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchConfigurationArgs
            {
                DomainArn = testCluster.Arn,
                RoleArn = firehoseRole.Arn,
                IndexName = "test",
                S3Configuration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchConfigurationS3ConfigurationArgs
                {
                    RoleArn = firehoseRole.Arn,
                    BucketArn = bucket.Arn,
                    BufferingSize = 10,
                    BufferingInterval = 400,
                    CompressionFormat = "GZIP",
                },
                ProcessingConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationArgs
                {
                    Enabled = true,
                    Processors = new[]
                    {
                        new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorArgs
                        {
                            Type = "Lambda",
                            Parameters = new[]
                            {
                                new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorParameterArgs
                                {
                                    ParameterName = "LambdaArn",
                                    ParameterValue = $"{lambdaProcessor.Arn}:$LATEST",
                                },
                            },
                        },
                    },
                },
            },
        });
    
    });
    
    package generated_program;
    
    import com.pulumi.Context;
    import com.pulumi.Pulumi;
    import com.pulumi.core.Output;
    import com.pulumi.aws.opensearch.Domain;
    import com.pulumi.aws.opensearch.DomainArgs;
    import com.pulumi.aws.kinesis.FirehoseDeliveryStream;
    import com.pulumi.aws.kinesis.FirehoseDeliveryStreamArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamOpensearchConfigurationArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamOpensearchConfigurationS3ConfigurationArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationArgs;
    import java.util.List;
    import java.util.ArrayList;
    import java.util.Map;
    import java.io.File;
    import java.nio.file.Files;
    import java.nio.file.Paths;
    
    public class App {
        public static void main(String[] args) {
            Pulumi.run(App::stack);
        }
    
        public static void stack(Context ctx) {
            var testCluster = new Domain("testCluster", DomainArgs.builder()        
                .domainName("firehose-os-test")
                .build());
    
            var testStream = new FirehoseDeliveryStream("testStream", FirehoseDeliveryStreamArgs.builder()        
                .name("kinesis-firehose-test-stream")
                .destination("opensearch")
                .opensearchConfiguration(FirehoseDeliveryStreamOpensearchConfigurationArgs.builder()
                    .domainArn(testCluster.arn())
                    .roleArn(firehoseRole.arn())
                    .indexName("test")
                    .s3Configuration(FirehoseDeliveryStreamOpensearchConfigurationS3ConfigurationArgs.builder()
                        .roleArn(firehoseRole.arn())
                        .bucketArn(bucket.arn())
                        .bufferingSize(10)
                        .bufferingInterval(400)
                        .compressionFormat("GZIP")
                        .build())
                    .processingConfiguration(FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationArgs.builder()
                        .enabled("true")
                        .processors(FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorArgs.builder()
                            .type("Lambda")
                            .parameters(FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorParameterArgs.builder()
                                .parameterName("LambdaArn")
                                .parameterValue(String.format("%s:$LATEST", lambdaProcessor.arn()))
                                .build())
                            .build())
                        .build())
                    .build())
                .build());
    
        }
    }
    
    resources:
      testCluster:
        type: aws:opensearch:Domain
        name: test_cluster
        properties:
          domainName: firehose-os-test
      testStream:
        type: aws:kinesis:FirehoseDeliveryStream
        name: test_stream
        properties:
          name: kinesis-firehose-test-stream
          destination: opensearch
          opensearchConfiguration:
            domainArn: ${testCluster.arn}
            roleArn: ${firehoseRole.arn}
            indexName: test
            s3Configuration:
              roleArn: ${firehoseRole.arn}
              bucketArn: ${bucket.arn}
              bufferingSize: 10
              bufferingInterval: 400
              compressionFormat: GZIP
            processingConfiguration:
              enabled: 'true'
              processors:
                - type: Lambda
                  parameters:
                    - parameterName: LambdaArn
                      parameterValue: ${lambdaProcessor.arn}:$LATEST
    

    OpenSearch Destination With VPC

    import * as pulumi from "@pulumi/pulumi";
    import * as aws from "@pulumi/aws";
    
    const testCluster = new aws.opensearch.Domain("test_cluster", {
        domainName: "es-test",
        clusterConfig: {
            instanceCount: 2,
            zoneAwarenessEnabled: true,
            instanceType: "m4.large.search",
        },
        ebsOptions: {
            ebsEnabled: true,
            volumeSize: 10,
        },
        vpcOptions: {
            securityGroupIds: [first.id],
            subnetIds: [
                firstAwsSubnet.id,
                second.id,
            ],
        },
    });
    const firehose_opensearch = new aws.iam.RolePolicy("firehose-opensearch", {
        name: "opensearch",
        role: firehose.id,
        policy: pulumi.interpolate`{
      "Version": "2012-10-17",
      "Statement": [
        {
          "Effect": "Allow",
          "Action": [
            "es:*"
          ],
          "Resource": [
            "${testCluster.arn}",
            "${testCluster.arn}/*"
          ]
            },
            {
              "Effect": "Allow",
              "Action": [
                "ec2:DescribeVpcs",
                "ec2:DescribeVpcAttribute",
                "ec2:DescribeSubnets",
                "ec2:DescribeSecurityGroups",
                "ec2:DescribeNetworkInterfaces",
                "ec2:CreateNetworkInterface",
                "ec2:CreateNetworkInterfacePermission",
                "ec2:DeleteNetworkInterface"
              ],
              "Resource": [
                "*"
              ]
            }
      ]
    }
    `,
    });
    const test = new aws.kinesis.FirehoseDeliveryStream("test", {
        name: "pulumi-kinesis-firehose-os",
        destination: "opensearch",
        opensearchConfiguration: {
            domainArn: testCluster.arn,
            roleArn: firehose.arn,
            indexName: "test",
            s3Configuration: {
                roleArn: firehose.arn,
                bucketArn: bucket.arn,
            },
            vpcConfig: {
                subnetIds: [
                    firstAwsSubnet.id,
                    second.id,
                ],
                securityGroupIds: [first.id],
                roleArn: firehose.arn,
            },
        },
    }, {
        dependsOn: [firehose_opensearch],
    });
    
    import pulumi
    import pulumi_aws as aws
    
    test_cluster = aws.opensearch.Domain("test_cluster",
        domain_name="es-test",
        cluster_config=aws.opensearch.DomainClusterConfigArgs(
            instance_count=2,
            zone_awareness_enabled=True,
            instance_type="m4.large.search",
        ),
        ebs_options=aws.opensearch.DomainEbsOptionsArgs(
            ebs_enabled=True,
            volume_size=10,
        ),
        vpc_options=aws.opensearch.DomainVpcOptionsArgs(
            security_group_ids=[first["id"]],
            subnet_ids=[
                first_aws_subnet["id"],
                second["id"],
            ],
        ))
    firehose_opensearch = aws.iam.RolePolicy("firehose-opensearch",
        name="opensearch",
        role=firehose["id"],
        policy=pulumi.Output.all(test_cluster.arn, test_cluster.arn).apply(lambda testClusterArn, testClusterArn1: f"""{{
      "Version": "2012-10-17",
      "Statement": [
        {{
          "Effect": "Allow",
          "Action": [
            "es:*"
          ],
          "Resource": [
            "{test_cluster_arn}",
            "{test_cluster_arn1}/*"
          ]
            }},
            {{
              "Effect": "Allow",
              "Action": [
                "ec2:DescribeVpcs",
                "ec2:DescribeVpcAttribute",
                "ec2:DescribeSubnets",
                "ec2:DescribeSecurityGroups",
                "ec2:DescribeNetworkInterfaces",
                "ec2:CreateNetworkInterface",
                "ec2:CreateNetworkInterfacePermission",
                "ec2:DeleteNetworkInterface"
              ],
              "Resource": [
                "*"
              ]
            }}
      ]
    }}
    """))
    test = aws.kinesis.FirehoseDeliveryStream("test",
        name="pulumi-kinesis-firehose-os",
        destination="opensearch",
        opensearch_configuration=aws.kinesis.FirehoseDeliveryStreamOpensearchConfigurationArgs(
            domain_arn=test_cluster.arn,
            role_arn=firehose["arn"],
            index_name="test",
            s3_configuration=aws.kinesis.FirehoseDeliveryStreamOpensearchConfigurationS3ConfigurationArgs(
                role_arn=firehose["arn"],
                bucket_arn=bucket["arn"],
            ),
            vpc_config=aws.kinesis.FirehoseDeliveryStreamOpensearchConfigurationVpcConfigArgs(
                subnet_ids=[
                    first_aws_subnet["id"],
                    second["id"],
                ],
                security_group_ids=[first["id"]],
                role_arn=firehose["arn"],
            ),
        ),
        opts=pulumi.ResourceOptions(depends_on=[firehose_opensearch]))
    
    package main
    
    import (
    	"fmt"
    
    	"github.com/pulumi/pulumi-aws/sdk/v6/go/aws/iam"
    	"github.com/pulumi/pulumi-aws/sdk/v6/go/aws/kinesis"
    	"github.com/pulumi/pulumi-aws/sdk/v6/go/aws/opensearch"
    	"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
    )
    
    func main() {
    	pulumi.Run(func(ctx *pulumi.Context) error {
    		testCluster, err := opensearch.NewDomain(ctx, "test_cluster", &opensearch.DomainArgs{
    			DomainName: pulumi.String("es-test"),
    			ClusterConfig: &opensearch.DomainClusterConfigArgs{
    				InstanceCount:        pulumi.Int(2),
    				ZoneAwarenessEnabled: pulumi.Bool(true),
    				InstanceType:         pulumi.String("m4.large.search"),
    			},
    			EbsOptions: &opensearch.DomainEbsOptionsArgs{
    				EbsEnabled: pulumi.Bool(true),
    				VolumeSize: pulumi.Int(10),
    			},
    			VpcOptions: &opensearch.DomainVpcOptionsArgs{
    				SecurityGroupIds: pulumi.StringArray{
    					first.Id,
    				},
    				SubnetIds: pulumi.StringArray{
    					firstAwsSubnet.Id,
    					second.Id,
    				},
    			},
    		})
    		if err != nil {
    			return err
    		}
    		_, err = iam.NewRolePolicy(ctx, "firehose-opensearch", &iam.RolePolicyArgs{
    			Name: pulumi.String("opensearch"),
    			Role: pulumi.Any(firehose.Id),
    			Policy: pulumi.All(testCluster.Arn, testCluster.Arn).ApplyT(func(_args []interface{}) (string, error) {
    				testClusterArn := _args[0].(string)
    				testClusterArn1 := _args[1].(string)
    				return fmt.Sprintf(`{
      "Version": "2012-10-17",
      "Statement": [
        {
          "Effect": "Allow",
          "Action": [
            "es:*"
          ],
          "Resource": [
            "%v",
            "%v/*"
          ]
            },
            {
              "Effect": "Allow",
              "Action": [
                "ec2:DescribeVpcs",
                "ec2:DescribeVpcAttribute",
                "ec2:DescribeSubnets",
                "ec2:DescribeSecurityGroups",
                "ec2:DescribeNetworkInterfaces",
                "ec2:CreateNetworkInterface",
                "ec2:CreateNetworkInterfacePermission",
                "ec2:DeleteNetworkInterface"
              ],
              "Resource": [
                "*"
              ]
            }
      ]
    }
    `, testClusterArn, testClusterArn1), nil
    			}).(pulumi.StringOutput),
    		})
    		if err != nil {
    			return err
    		}
    		_, err = kinesis.NewFirehoseDeliveryStream(ctx, "test", &kinesis.FirehoseDeliveryStreamArgs{
    			Name:        pulumi.String("pulumi-kinesis-firehose-os"),
    			Destination: pulumi.String("opensearch"),
    			OpensearchConfiguration: &kinesis.FirehoseDeliveryStreamOpensearchConfigurationArgs{
    				DomainArn: testCluster.Arn,
    				RoleArn:   pulumi.Any(firehose.Arn),
    				IndexName: pulumi.String("test"),
    				S3Configuration: &kinesis.FirehoseDeliveryStreamOpensearchConfigurationS3ConfigurationArgs{
    					RoleArn:   pulumi.Any(firehose.Arn),
    					BucketArn: pulumi.Any(bucket.Arn),
    				},
    				VpcConfig: &kinesis.FirehoseDeliveryStreamOpensearchConfigurationVpcConfigArgs{
    					SubnetIds: pulumi.StringArray{
    						firstAwsSubnet.Id,
    						second.Id,
    					},
    					SecurityGroupIds: pulumi.StringArray{
    						first.Id,
    					},
    					RoleArn: pulumi.Any(firehose.Arn),
    				},
    			},
    		}, pulumi.DependsOn([]pulumi.Resource{
    			firehose_opensearch,
    		}))
    		if err != nil {
    			return err
    		}
    		return nil
    	})
    }
    
    using System.Collections.Generic;
    using System.Linq;
    using Pulumi;
    using Aws = Pulumi.Aws;
    
    return await Deployment.RunAsync(() => 
    {
        var testCluster = new Aws.OpenSearch.Domain("test_cluster", new()
        {
            DomainName = "es-test",
            ClusterConfig = new Aws.OpenSearch.Inputs.DomainClusterConfigArgs
            {
                InstanceCount = 2,
                ZoneAwarenessEnabled = true,
                InstanceType = "m4.large.search",
            },
            EbsOptions = new Aws.OpenSearch.Inputs.DomainEbsOptionsArgs
            {
                EbsEnabled = true,
                VolumeSize = 10,
            },
            VpcOptions = new Aws.OpenSearch.Inputs.DomainVpcOptionsArgs
            {
                SecurityGroupIds = new[]
                {
                    first.Id,
                },
                SubnetIds = new[]
                {
                    firstAwsSubnet.Id,
                    second.Id,
                },
            },
        });
    
        var firehose_opensearch = new Aws.Iam.RolePolicy("firehose-opensearch", new()
        {
            Name = "opensearch",
            Role = firehose.Id,
            Policy = Output.Tuple(testCluster.Arn, testCluster.Arn).Apply(values =>
            {
                var testClusterArn = values.Item1;
                var testClusterArn1 = values.Item2;
                return @$"{{
      ""Version"": ""2012-10-17"",
      ""Statement"": [
        {{
          ""Effect"": ""Allow"",
          ""Action"": [
            ""es:*""
          ],
          ""Resource"": [
            ""{testClusterArn}"",
            ""{testClusterArn1}/*""
          ]
            }},
            {{
              ""Effect"": ""Allow"",
              ""Action"": [
                ""ec2:DescribeVpcs"",
                ""ec2:DescribeVpcAttribute"",
                ""ec2:DescribeSubnets"",
                ""ec2:DescribeSecurityGroups"",
                ""ec2:DescribeNetworkInterfaces"",
                ""ec2:CreateNetworkInterface"",
                ""ec2:CreateNetworkInterfacePermission"",
                ""ec2:DeleteNetworkInterface""
              ],
              ""Resource"": [
                ""*""
              ]
            }}
      ]
    }}
    ";
            }),
        });
    
        var test = new Aws.Kinesis.FirehoseDeliveryStream("test", new()
        {
            Name = "pulumi-kinesis-firehose-os",
            Destination = "opensearch",
            OpensearchConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchConfigurationArgs
            {
                DomainArn = testCluster.Arn,
                RoleArn = firehose.Arn,
                IndexName = "test",
                S3Configuration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchConfigurationS3ConfigurationArgs
                {
                    RoleArn = firehose.Arn,
                    BucketArn = bucket.Arn,
                },
                VpcConfig = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchConfigurationVpcConfigArgs
                {
                    SubnetIds = new[]
                    {
                        firstAwsSubnet.Id,
                        second.Id,
                    },
                    SecurityGroupIds = new[]
                    {
                        first.Id,
                    },
                    RoleArn = firehose.Arn,
                },
            },
        }, new CustomResourceOptions
        {
            DependsOn =
            {
                firehose_opensearch, 
            },
        });
    
    });
    
    package generated_program;
    
    import com.pulumi.Context;
    import com.pulumi.Pulumi;
    import com.pulumi.core.Output;
    import com.pulumi.aws.opensearch.Domain;
    import com.pulumi.aws.opensearch.DomainArgs;
    import com.pulumi.aws.opensearch.inputs.DomainClusterConfigArgs;
    import com.pulumi.aws.opensearch.inputs.DomainEbsOptionsArgs;
    import com.pulumi.aws.opensearch.inputs.DomainVpcOptionsArgs;
    import com.pulumi.aws.iam.RolePolicy;
    import com.pulumi.aws.iam.RolePolicyArgs;
    import com.pulumi.aws.kinesis.FirehoseDeliveryStream;
    import com.pulumi.aws.kinesis.FirehoseDeliveryStreamArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamOpensearchConfigurationArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamOpensearchConfigurationS3ConfigurationArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamOpensearchConfigurationVpcConfigArgs;
    import com.pulumi.resources.CustomResourceOptions;
    import java.util.List;
    import java.util.ArrayList;
    import java.util.Map;
    import java.io.File;
    import java.nio.file.Files;
    import java.nio.file.Paths;
    
    public class App {
        public static void main(String[] args) {
            Pulumi.run(App::stack);
        }
    
        public static void stack(Context ctx) {
            var testCluster = new Domain("testCluster", DomainArgs.builder()        
                .domainName("es-test")
                .clusterConfig(DomainClusterConfigArgs.builder()
                    .instanceCount(2)
                    .zoneAwarenessEnabled(true)
                    .instanceType("m4.large.search")
                    .build())
                .ebsOptions(DomainEbsOptionsArgs.builder()
                    .ebsEnabled(true)
                    .volumeSize(10)
                    .build())
                .vpcOptions(DomainVpcOptionsArgs.builder()
                    .securityGroupIds(first.id())
                    .subnetIds(                
                        firstAwsSubnet.id(),
                        second.id())
                    .build())
                .build());
    
            var firehose_opensearch = new RolePolicy("firehose-opensearch", RolePolicyArgs.builder()        
                .name("opensearch")
                .role(firehose.id())
                .policy(Output.tuple(testCluster.arn(), testCluster.arn()).applyValue(values -> {
                    var testClusterArn = values.t1;
                    var testClusterArn1 = values.t2;
                    return """
    {
      "Version": "2012-10-17",
      "Statement": [
        {
          "Effect": "Allow",
          "Action": [
            "es:*"
          ],
          "Resource": [
            "%s",
            "%s/*"
          ]
            },
            {
              "Effect": "Allow",
              "Action": [
                "ec2:DescribeVpcs",
                "ec2:DescribeVpcAttribute",
                "ec2:DescribeSubnets",
                "ec2:DescribeSecurityGroups",
                "ec2:DescribeNetworkInterfaces",
                "ec2:CreateNetworkInterface",
                "ec2:CreateNetworkInterfacePermission",
                "ec2:DeleteNetworkInterface"
              ],
              "Resource": [
                "*"
              ]
            }
      ]
    }
    ", testClusterArn,testClusterArn1);
                }))
                .build());
    
            var test = new FirehoseDeliveryStream("test", FirehoseDeliveryStreamArgs.builder()        
                .name("pulumi-kinesis-firehose-os")
                .destination("opensearch")
                .opensearchConfiguration(FirehoseDeliveryStreamOpensearchConfigurationArgs.builder()
                    .domainArn(testCluster.arn())
                    .roleArn(firehose.arn())
                    .indexName("test")
                    .s3Configuration(FirehoseDeliveryStreamOpensearchConfigurationS3ConfigurationArgs.builder()
                        .roleArn(firehose.arn())
                        .bucketArn(bucket.arn())
                        .build())
                    .vpcConfig(FirehoseDeliveryStreamOpensearchConfigurationVpcConfigArgs.builder()
                        .subnetIds(                    
                            firstAwsSubnet.id(),
                            second.id())
                        .securityGroupIds(first.id())
                        .roleArn(firehose.arn())
                        .build())
                    .build())
                .build(), CustomResourceOptions.builder()
                    .dependsOn(firehose_opensearch)
                    .build());
    
        }
    }
    
    resources:
      testCluster:
        type: aws:opensearch:Domain
        name: test_cluster
        properties:
          domainName: es-test
          clusterConfig:
            instanceCount: 2
            zoneAwarenessEnabled: true
            instanceType: m4.large.search
          ebsOptions:
            ebsEnabled: true
            volumeSize: 10
          vpcOptions:
            securityGroupIds:
              - ${first.id}
            subnetIds:
              - ${firstAwsSubnet.id}
              - ${second.id}
      firehose-opensearch:
        type: aws:iam:RolePolicy
        properties:
          name: opensearch
          role: ${firehose.id}
          policy: |
            {
              "Version": "2012-10-17",
              "Statement": [
                {
                  "Effect": "Allow",
                  "Action": [
                    "es:*"
                  ],
                  "Resource": [
                    "${testCluster.arn}",
                    "${testCluster.arn}/*"
                  ]
                    },
                    {
                      "Effect": "Allow",
                      "Action": [
                        "ec2:DescribeVpcs",
                        "ec2:DescribeVpcAttribute",
                        "ec2:DescribeSubnets",
                        "ec2:DescribeSecurityGroups",
                        "ec2:DescribeNetworkInterfaces",
                        "ec2:CreateNetworkInterface",
                        "ec2:CreateNetworkInterfacePermission",
                        "ec2:DeleteNetworkInterface"
                      ],
                      "Resource": [
                        "*"
                      ]
                    }
              ]
            }        
      test:
        type: aws:kinesis:FirehoseDeliveryStream
        properties:
          name: pulumi-kinesis-firehose-os
          destination: opensearch
          opensearchConfiguration:
            domainArn: ${testCluster.arn}
            roleArn: ${firehose.arn}
            indexName: test
            s3Configuration:
              roleArn: ${firehose.arn}
              bucketArn: ${bucket.arn}
            vpcConfig:
              subnetIds:
                - ${firstAwsSubnet.id}
                - ${second.id}
              securityGroupIds:
                - ${first.id}
              roleArn: ${firehose.arn}
        options:
          dependson:
            - ${["firehose-opensearch"]}
    

    OpenSearch Serverless Destination

    import * as pulumi from "@pulumi/pulumi";
    import * as aws from "@pulumi/aws";
    
    const testCollection = new aws.opensearch.ServerlessCollection("test_collection", {name: "firehose-osserverless-test"});
    const testStream = new aws.kinesis.FirehoseDeliveryStream("test_stream", {
        name: "kinesis-firehose-test-stream",
        destination: "opensearchserverless",
        opensearchserverlessConfiguration: {
            collectionEndpoint: testCollection.collectionEndpoint,
            roleArn: firehoseRole.arn,
            indexName: "test",
            s3Configuration: {
                roleArn: firehoseRole.arn,
                bucketArn: bucket.arn,
                bufferingSize: 10,
                bufferingInterval: 400,
                compressionFormat: "GZIP",
            },
            processingConfiguration: {
                enabled: true,
                processors: [{
                    type: "Lambda",
                    parameters: [{
                        parameterName: "LambdaArn",
                        parameterValue: `${lambdaProcessor.arn}:$LATEST`,
                    }],
                }],
            },
        },
    });
    
    import pulumi
    import pulumi_aws as aws
    
    test_collection = aws.opensearch.ServerlessCollection("test_collection", name="firehose-osserverless-test")
    test_stream = aws.kinesis.FirehoseDeliveryStream("test_stream",
        name="kinesis-firehose-test-stream",
        destination="opensearchserverless",
        opensearchserverless_configuration=aws.kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationArgs(
            collection_endpoint=test_collection.collection_endpoint,
            role_arn=firehose_role["arn"],
            index_name="test",
            s3_configuration=aws.kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationS3ConfigurationArgs(
                role_arn=firehose_role["arn"],
                bucket_arn=bucket["arn"],
                buffering_size=10,
                buffering_interval=400,
                compression_format="GZIP",
            ),
            processing_configuration=aws.kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationArgs(
                enabled=True,
                processors=[aws.kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorArgs(
                    type="Lambda",
                    parameters=[aws.kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorParameterArgs(
                        parameter_name="LambdaArn",
                        parameter_value=f"{lambda_processor['arn']}:$LATEST",
                    )],
                )],
            ),
        ))
    
    package main
    
    import (
    	"fmt"
    
    	"github.com/pulumi/pulumi-aws/sdk/v6/go/aws/kinesis"
    	"github.com/pulumi/pulumi-aws/sdk/v6/go/aws/opensearch"
    	"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
    )
    
    func main() {
    	pulumi.Run(func(ctx *pulumi.Context) error {
    		testCollection, err := opensearch.NewServerlessCollection(ctx, "test_collection", &opensearch.ServerlessCollectionArgs{
    			Name: pulumi.String("firehose-osserverless-test"),
    		})
    		if err != nil {
    			return err
    		}
    		_, err = kinesis.NewFirehoseDeliveryStream(ctx, "test_stream", &kinesis.FirehoseDeliveryStreamArgs{
    			Name:        pulumi.String("kinesis-firehose-test-stream"),
    			Destination: pulumi.String("opensearchserverless"),
    			OpensearchserverlessConfiguration: &kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationArgs{
    				CollectionEndpoint: testCollection.CollectionEndpoint,
    				RoleArn:            pulumi.Any(firehoseRole.Arn),
    				IndexName:          pulumi.String("test"),
    				S3Configuration: &kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationS3ConfigurationArgs{
    					RoleArn:           pulumi.Any(firehoseRole.Arn),
    					BucketArn:         pulumi.Any(bucket.Arn),
    					BufferingSize:     pulumi.Int(10),
    					BufferingInterval: pulumi.Int(400),
    					CompressionFormat: pulumi.String("GZIP"),
    				},
    				ProcessingConfiguration: &kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationArgs{
    					Enabled: pulumi.Bool(true),
    					Processors: kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorArray{
    						&kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorArgs{
    							Type: pulumi.String("Lambda"),
    							Parameters: kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorParameterArray{
    								&kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorParameterArgs{
    									ParameterName:  pulumi.String("LambdaArn"),
    									ParameterValue: pulumi.String(fmt.Sprintf("%v:$LATEST", lambdaProcessor.Arn)),
    								},
    							},
    						},
    					},
    				},
    			},
    		})
    		if err != nil {
    			return err
    		}
    		return nil
    	})
    }
    
    using System.Collections.Generic;
    using System.Linq;
    using Pulumi;
    using Aws = Pulumi.Aws;
    
    return await Deployment.RunAsync(() => 
    {
        var testCollection = new Aws.OpenSearch.ServerlessCollection("test_collection", new()
        {
            Name = "firehose-osserverless-test",
        });
    
        var testStream = new Aws.Kinesis.FirehoseDeliveryStream("test_stream", new()
        {
            Name = "kinesis-firehose-test-stream",
            Destination = "opensearchserverless",
            OpensearchserverlessConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchserverlessConfigurationArgs
            {
                CollectionEndpoint = testCollection.CollectionEndpoint,
                RoleArn = firehoseRole.Arn,
                IndexName = "test",
                S3Configuration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchserverlessConfigurationS3ConfigurationArgs
                {
                    RoleArn = firehoseRole.Arn,
                    BucketArn = bucket.Arn,
                    BufferingSize = 10,
                    BufferingInterval = 400,
                    CompressionFormat = "GZIP",
                },
                ProcessingConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationArgs
                {
                    Enabled = true,
                    Processors = new[]
                    {
                        new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorArgs
                        {
                            Type = "Lambda",
                            Parameters = new[]
                            {
                                new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorParameterArgs
                                {
                                    ParameterName = "LambdaArn",
                                    ParameterValue = $"{lambdaProcessor.Arn}:$LATEST",
                                },
                            },
                        },
                    },
                },
            },
        });
    
    });
    
    package generated_program;
    
    import com.pulumi.Context;
    import com.pulumi.Pulumi;
    import com.pulumi.core.Output;
    import com.pulumi.aws.opensearch.ServerlessCollection;
    import com.pulumi.aws.opensearch.ServerlessCollectionArgs;
    import com.pulumi.aws.kinesis.FirehoseDeliveryStream;
    import com.pulumi.aws.kinesis.FirehoseDeliveryStreamArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamOpensearchserverlessConfigurationArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamOpensearchserverlessConfigurationS3ConfigurationArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationArgs;
    import java.util.List;
    import java.util.ArrayList;
    import java.util.Map;
    import java.io.File;
    import java.nio.file.Files;
    import java.nio.file.Paths;
    
    public class App {
        public static void main(String[] args) {
            Pulumi.run(App::stack);
        }
    
        public static void stack(Context ctx) {
            var testCollection = new ServerlessCollection("testCollection", ServerlessCollectionArgs.builder()        
                .name("firehose-osserverless-test")
                .build());
    
            var testStream = new FirehoseDeliveryStream("testStream", FirehoseDeliveryStreamArgs.builder()        
                .name("kinesis-firehose-test-stream")
                .destination("opensearchserverless")
                .opensearchserverlessConfiguration(FirehoseDeliveryStreamOpensearchserverlessConfigurationArgs.builder()
                    .collectionEndpoint(testCollection.collectionEndpoint())
                    .roleArn(firehoseRole.arn())
                    .indexName("test")
                    .s3Configuration(FirehoseDeliveryStreamOpensearchserverlessConfigurationS3ConfigurationArgs.builder()
                        .roleArn(firehoseRole.arn())
                        .bucketArn(bucket.arn())
                        .bufferingSize(10)
                        .bufferingInterval(400)
                        .compressionFormat("GZIP")
                        .build())
                    .processingConfiguration(FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationArgs.builder()
                        .enabled("true")
                        .processors(FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorArgs.builder()
                            .type("Lambda")
                            .parameters(FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorParameterArgs.builder()
                                .parameterName("LambdaArn")
                                .parameterValue(String.format("%s:$LATEST", lambdaProcessor.arn()))
                                .build())
                            .build())
                        .build())
                    .build())
                .build());
    
        }
    }
    
    resources:
      testCollection:
        type: aws:opensearch:ServerlessCollection
        name: test_collection
        properties:
          name: firehose-osserverless-test
      testStream:
        type: aws:kinesis:FirehoseDeliveryStream
        name: test_stream
        properties:
          name: kinesis-firehose-test-stream
          destination: opensearchserverless
          opensearchserverlessConfiguration:
            collectionEndpoint: ${testCollection.collectionEndpoint}
            roleArn: ${firehoseRole.arn}
            indexName: test
            s3Configuration:
              roleArn: ${firehoseRole.arn}
              bucketArn: ${bucket.arn}
              bufferingSize: 10
              bufferingInterval: 400
              compressionFormat: GZIP
            processingConfiguration:
              enabled: 'true'
              processors:
                - type: Lambda
                  parameters:
                    - parameterName: LambdaArn
                      parameterValue: ${lambdaProcessor.arn}:$LATEST
    

    Splunk Destination

    import * as pulumi from "@pulumi/pulumi";
    import * as aws from "@pulumi/aws";
    
    const testStream = new aws.kinesis.FirehoseDeliveryStream("test_stream", {
        name: "kinesis-firehose-test-stream",
        destination: "splunk",
        splunkConfiguration: {
            hecEndpoint: "https://http-inputs-mydomain.splunkcloud.com:443",
            hecToken: "51D4DA16-C61B-4F5F-8EC7-ED4301342A4A",
            hecAcknowledgmentTimeout: 600,
            hecEndpointType: "Event",
            s3BackupMode: "FailedEventsOnly",
            s3Configuration: {
                roleArn: firehose.arn,
                bucketArn: bucket.arn,
                bufferingSize: 10,
                bufferingInterval: 400,
                compressionFormat: "GZIP",
            },
        },
    });
    
    import pulumi
    import pulumi_aws as aws
    
    test_stream = aws.kinesis.FirehoseDeliveryStream("test_stream",
        name="kinesis-firehose-test-stream",
        destination="splunk",
        splunk_configuration=aws.kinesis.FirehoseDeliveryStreamSplunkConfigurationArgs(
            hec_endpoint="https://http-inputs-mydomain.splunkcloud.com:443",
            hec_token="51D4DA16-C61B-4F5F-8EC7-ED4301342A4A",
            hec_acknowledgment_timeout=600,
            hec_endpoint_type="Event",
            s3_backup_mode="FailedEventsOnly",
            s3_configuration=aws.kinesis.FirehoseDeliveryStreamSplunkConfigurationS3ConfigurationArgs(
                role_arn=firehose["arn"],
                bucket_arn=bucket["arn"],
                buffering_size=10,
                buffering_interval=400,
                compression_format="GZIP",
            ),
        ))
    
    package main
    
    import (
    	"github.com/pulumi/pulumi-aws/sdk/v6/go/aws/kinesis"
    	"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
    )
    
    func main() {
    	pulumi.Run(func(ctx *pulumi.Context) error {
    		_, err := kinesis.NewFirehoseDeliveryStream(ctx, "test_stream", &kinesis.FirehoseDeliveryStreamArgs{
    			Name:        pulumi.String("kinesis-firehose-test-stream"),
    			Destination: pulumi.String("splunk"),
    			SplunkConfiguration: &kinesis.FirehoseDeliveryStreamSplunkConfigurationArgs{
    				HecEndpoint:              pulumi.String("https://http-inputs-mydomain.splunkcloud.com:443"),
    				HecToken:                 pulumi.String("51D4DA16-C61B-4F5F-8EC7-ED4301342A4A"),
    				HecAcknowledgmentTimeout: pulumi.Int(600),
    				HecEndpointType:          pulumi.String("Event"),
    				S3BackupMode:             pulumi.String("FailedEventsOnly"),
    				S3Configuration: &kinesis.FirehoseDeliveryStreamSplunkConfigurationS3ConfigurationArgs{
    					RoleArn:           pulumi.Any(firehose.Arn),
    					BucketArn:         pulumi.Any(bucket.Arn),
    					BufferingSize:     pulumi.Int(10),
    					BufferingInterval: pulumi.Int(400),
    					CompressionFormat: pulumi.String("GZIP"),
    				},
    			},
    		})
    		if err != nil {
    			return err
    		}
    		return nil
    	})
    }
    
    using System.Collections.Generic;
    using System.Linq;
    using Pulumi;
    using Aws = Pulumi.Aws;
    
    return await Deployment.RunAsync(() => 
    {
        var testStream = new Aws.Kinesis.FirehoseDeliveryStream("test_stream", new()
        {
            Name = "kinesis-firehose-test-stream",
            Destination = "splunk",
            SplunkConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamSplunkConfigurationArgs
            {
                HecEndpoint = "https://http-inputs-mydomain.splunkcloud.com:443",
                HecToken = "51D4DA16-C61B-4F5F-8EC7-ED4301342A4A",
                HecAcknowledgmentTimeout = 600,
                HecEndpointType = "Event",
                S3BackupMode = "FailedEventsOnly",
                S3Configuration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamSplunkConfigurationS3ConfigurationArgs
                {
                    RoleArn = firehose.Arn,
                    BucketArn = bucket.Arn,
                    BufferingSize = 10,
                    BufferingInterval = 400,
                    CompressionFormat = "GZIP",
                },
            },
        });
    
    });
    
    package generated_program;
    
    import com.pulumi.Context;
    import com.pulumi.Pulumi;
    import com.pulumi.core.Output;
    import com.pulumi.aws.kinesis.FirehoseDeliveryStream;
    import com.pulumi.aws.kinesis.FirehoseDeliveryStreamArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamSplunkConfigurationArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamSplunkConfigurationS3ConfigurationArgs;
    import java.util.List;
    import java.util.ArrayList;
    import java.util.Map;
    import java.io.File;
    import java.nio.file.Files;
    import java.nio.file.Paths;
    
    public class App {
        public static void main(String[] args) {
            Pulumi.run(App::stack);
        }
    
        public static void stack(Context ctx) {
            var testStream = new FirehoseDeliveryStream("testStream", FirehoseDeliveryStreamArgs.builder()        
                .name("kinesis-firehose-test-stream")
                .destination("splunk")
                .splunkConfiguration(FirehoseDeliveryStreamSplunkConfigurationArgs.builder()
                    .hecEndpoint("https://http-inputs-mydomain.splunkcloud.com:443")
                    .hecToken("51D4DA16-C61B-4F5F-8EC7-ED4301342A4A")
                    .hecAcknowledgmentTimeout(600)
                    .hecEndpointType("Event")
                    .s3BackupMode("FailedEventsOnly")
                    .s3Configuration(FirehoseDeliveryStreamSplunkConfigurationS3ConfigurationArgs.builder()
                        .roleArn(firehose.arn())
                        .bucketArn(bucket.arn())
                        .bufferingSize(10)
                        .bufferingInterval(400)
                        .compressionFormat("GZIP")
                        .build())
                    .build())
                .build());
    
        }
    }
    
    resources:
      testStream:
        type: aws:kinesis:FirehoseDeliveryStream
        name: test_stream
        properties:
          name: kinesis-firehose-test-stream
          destination: splunk
          splunkConfiguration:
            hecEndpoint: https://http-inputs-mydomain.splunkcloud.com:443
            hecToken: 51D4DA16-C61B-4F5F-8EC7-ED4301342A4A
            hecAcknowledgmentTimeout: 600
            hecEndpointType: Event
            s3BackupMode: FailedEventsOnly
            s3Configuration:
              roleArn: ${firehose.arn}
              bucketArn: ${bucket.arn}
              bufferingSize: 10
              bufferingInterval: 400
              compressionFormat: GZIP
    

    HTTP Endpoint (e.g., New Relic) Destination

    import * as pulumi from "@pulumi/pulumi";
    import * as aws from "@pulumi/aws";
    
    const testStream = new aws.kinesis.FirehoseDeliveryStream("test_stream", {
        name: "kinesis-firehose-test-stream",
        destination: "http_endpoint",
        httpEndpointConfiguration: {
            url: "https://aws-api.newrelic.com/firehose/v1",
            name: "New Relic",
            accessKey: "my-key",
            bufferingSize: 15,
            bufferingInterval: 600,
            roleArn: firehose.arn,
            s3BackupMode: "FailedDataOnly",
            s3Configuration: {
                roleArn: firehose.arn,
                bucketArn: bucket.arn,
                bufferingSize: 10,
                bufferingInterval: 400,
                compressionFormat: "GZIP",
            },
            requestConfiguration: {
                contentEncoding: "GZIP",
                commonAttributes: [
                    {
                        name: "testname",
                        value: "testvalue",
                    },
                    {
                        name: "testname2",
                        value: "testvalue2",
                    },
                ],
            },
        },
    });
    
    import pulumi
    import pulumi_aws as aws
    
    test_stream = aws.kinesis.FirehoseDeliveryStream("test_stream",
        name="kinesis-firehose-test-stream",
        destination="http_endpoint",
        http_endpoint_configuration=aws.kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationArgs(
            url="https://aws-api.newrelic.com/firehose/v1",
            name="New Relic",
            access_key="my-key",
            buffering_size=15,
            buffering_interval=600,
            role_arn=firehose["arn"],
            s3_backup_mode="FailedDataOnly",
            s3_configuration=aws.kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationS3ConfigurationArgs(
                role_arn=firehose["arn"],
                bucket_arn=bucket["arn"],
                buffering_size=10,
                buffering_interval=400,
                compression_format="GZIP",
            ),
            request_configuration=aws.kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationArgs(
                content_encoding="GZIP",
                common_attributes=[
                    aws.kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationCommonAttributeArgs(
                        name="testname",
                        value="testvalue",
                    ),
                    aws.kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationCommonAttributeArgs(
                        name="testname2",
                        value="testvalue2",
                    ),
                ],
            ),
        ))
    
    package main
    
    import (
    	"github.com/pulumi/pulumi-aws/sdk/v6/go/aws/kinesis"
    	"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
    )
    
    func main() {
    	pulumi.Run(func(ctx *pulumi.Context) error {
    		_, err := kinesis.NewFirehoseDeliveryStream(ctx, "test_stream", &kinesis.FirehoseDeliveryStreamArgs{
    			Name:        pulumi.String("kinesis-firehose-test-stream"),
    			Destination: pulumi.String("http_endpoint"),
    			HttpEndpointConfiguration: &kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationArgs{
    				Url:               pulumi.String("https://aws-api.newrelic.com/firehose/v1"),
    				Name:              pulumi.String("New Relic"),
    				AccessKey:         pulumi.String("my-key"),
    				BufferingSize:     pulumi.Int(15),
    				BufferingInterval: pulumi.Int(600),
    				RoleArn:           pulumi.Any(firehose.Arn),
    				S3BackupMode:      pulumi.String("FailedDataOnly"),
    				S3Configuration: &kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationS3ConfigurationArgs{
    					RoleArn:           pulumi.Any(firehose.Arn),
    					BucketArn:         pulumi.Any(bucket.Arn),
    					BufferingSize:     pulumi.Int(10),
    					BufferingInterval: pulumi.Int(400),
    					CompressionFormat: pulumi.String("GZIP"),
    				},
    				RequestConfiguration: &kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationArgs{
    					ContentEncoding: pulumi.String("GZIP"),
    					CommonAttributes: kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationCommonAttributeArray{
    						&kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationCommonAttributeArgs{
    							Name:  pulumi.String("testname"),
    							Value: pulumi.String("testvalue"),
    						},
    						&kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationCommonAttributeArgs{
    							Name:  pulumi.String("testname2"),
    							Value: pulumi.String("testvalue2"),
    						},
    					},
    				},
    			},
    		})
    		if err != nil {
    			return err
    		}
    		return nil
    	})
    }
    
    using System.Collections.Generic;
    using System.Linq;
    using Pulumi;
    using Aws = Pulumi.Aws;
    
    return await Deployment.RunAsync(() => 
    {
        var testStream = new Aws.Kinesis.FirehoseDeliveryStream("test_stream", new()
        {
            Name = "kinesis-firehose-test-stream",
            Destination = "http_endpoint",
            HttpEndpointConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamHttpEndpointConfigurationArgs
            {
                Url = "https://aws-api.newrelic.com/firehose/v1",
                Name = "New Relic",
                AccessKey = "my-key",
                BufferingSize = 15,
                BufferingInterval = 600,
                RoleArn = firehose.Arn,
                S3BackupMode = "FailedDataOnly",
                S3Configuration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamHttpEndpointConfigurationS3ConfigurationArgs
                {
                    RoleArn = firehose.Arn,
                    BucketArn = bucket.Arn,
                    BufferingSize = 10,
                    BufferingInterval = 400,
                    CompressionFormat = "GZIP",
                },
                RequestConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationArgs
                {
                    ContentEncoding = "GZIP",
                    CommonAttributes = new[]
                    {
                        new Aws.Kinesis.Inputs.FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationCommonAttributeArgs
                        {
                            Name = "testname",
                            Value = "testvalue",
                        },
                        new Aws.Kinesis.Inputs.FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationCommonAttributeArgs
                        {
                            Name = "testname2",
                            Value = "testvalue2",
                        },
                    },
                },
            },
        });
    
    });
    
    package generated_program;
    
    import com.pulumi.Context;
    import com.pulumi.Pulumi;
    import com.pulumi.core.Output;
    import com.pulumi.aws.kinesis.FirehoseDeliveryStream;
    import com.pulumi.aws.kinesis.FirehoseDeliveryStreamArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamHttpEndpointConfigurationArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamHttpEndpointConfigurationS3ConfigurationArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationArgs;
    import java.util.List;
    import java.util.ArrayList;
    import java.util.Map;
    import java.io.File;
    import java.nio.file.Files;
    import java.nio.file.Paths;
    
    public class App {
        public static void main(String[] args) {
            Pulumi.run(App::stack);
        }
    
        public static void stack(Context ctx) {
            var testStream = new FirehoseDeliveryStream("testStream", FirehoseDeliveryStreamArgs.builder()        
                .name("kinesis-firehose-test-stream")
                .destination("http_endpoint")
                .httpEndpointConfiguration(FirehoseDeliveryStreamHttpEndpointConfigurationArgs.builder()
                    .url("https://aws-api.newrelic.com/firehose/v1")
                    .name("New Relic")
                    .accessKey("my-key")
                    .bufferingSize(15)
                    .bufferingInterval(600)
                    .roleArn(firehose.arn())
                    .s3BackupMode("FailedDataOnly")
                    .s3Configuration(FirehoseDeliveryStreamHttpEndpointConfigurationS3ConfigurationArgs.builder()
                        .roleArn(firehose.arn())
                        .bucketArn(bucket.arn())
                        .bufferingSize(10)
                        .bufferingInterval(400)
                        .compressionFormat("GZIP")
                        .build())
                    .requestConfiguration(FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationArgs.builder()
                        .contentEncoding("GZIP")
                        .commonAttributes(                    
                            FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationCommonAttributeArgs.builder()
                                .name("testname")
                                .value("testvalue")
                                .build(),
                            FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationCommonAttributeArgs.builder()
                                .name("testname2")
                                .value("testvalue2")
                                .build())
                        .build())
                    .build())
                .build());
    
        }
    }
    
    resources:
      testStream:
        type: aws:kinesis:FirehoseDeliveryStream
        name: test_stream
        properties:
          name: kinesis-firehose-test-stream
          destination: http_endpoint
          httpEndpointConfiguration:
            url: https://aws-api.newrelic.com/firehose/v1
            name: New Relic
            accessKey: my-key
            bufferingSize: 15
            bufferingInterval: 600
            roleArn: ${firehose.arn}
            s3BackupMode: FailedDataOnly
            s3Configuration:
              roleArn: ${firehose.arn}
              bucketArn: ${bucket.arn}
              bufferingSize: 10
              bufferingInterval: 400
              compressionFormat: GZIP
            requestConfiguration:
              contentEncoding: GZIP
              commonAttributes:
                - name: testname
                  value: testvalue
                - name: testname2
                  value: testvalue2
    

    Create FirehoseDeliveryStream Resource

    Resources are created with functions called constructors. To learn more about declaring and configuring resources, see Resources.

    Constructor syntax

    new FirehoseDeliveryStream(name: string, args: FirehoseDeliveryStreamArgs, opts?: CustomResourceOptions);
    @overload
    def FirehoseDeliveryStream(resource_name: str,
                               args: FirehoseDeliveryStreamArgs,
                               opts: Optional[ResourceOptions] = None)
    
    @overload
    def FirehoseDeliveryStream(resource_name: str,
                               opts: Optional[ResourceOptions] = None,
                               destination: Optional[str] = None,
                               name: Optional[str] = None,
                               opensearch_configuration: Optional[FirehoseDeliveryStreamOpensearchConfigurationArgs] = None,
                               elasticsearch_configuration: Optional[FirehoseDeliveryStreamElasticsearchConfigurationArgs] = None,
                               extended_s3_configuration: Optional[FirehoseDeliveryStreamExtendedS3ConfigurationArgs] = None,
                               http_endpoint_configuration: Optional[FirehoseDeliveryStreamHttpEndpointConfigurationArgs] = None,
                               kinesis_source_configuration: Optional[FirehoseDeliveryStreamKinesisSourceConfigurationArgs] = None,
                               destination_id: Optional[str] = None,
                               arn: Optional[str] = None,
                               msk_source_configuration: Optional[FirehoseDeliveryStreamMskSourceConfigurationArgs] = None,
                               opensearchserverless_configuration: Optional[FirehoseDeliveryStreamOpensearchserverlessConfigurationArgs] = None,
                               redshift_configuration: Optional[FirehoseDeliveryStreamRedshiftConfigurationArgs] = None,
                               server_side_encryption: Optional[FirehoseDeliveryStreamServerSideEncryptionArgs] = None,
                               splunk_configuration: Optional[FirehoseDeliveryStreamSplunkConfigurationArgs] = None,
                               tags: Optional[Mapping[str, str]] = None,
                               version_id: Optional[str] = None)
    func NewFirehoseDeliveryStream(ctx *Context, name string, args FirehoseDeliveryStreamArgs, opts ...ResourceOption) (*FirehoseDeliveryStream, error)
    public FirehoseDeliveryStream(string name, FirehoseDeliveryStreamArgs args, CustomResourceOptions? opts = null)
    public FirehoseDeliveryStream(String name, FirehoseDeliveryStreamArgs args)
    public FirehoseDeliveryStream(String name, FirehoseDeliveryStreamArgs args, CustomResourceOptions options)
    
    type: aws:kinesis:FirehoseDeliveryStream
    properties: # The arguments to resource properties.
    options: # Bag of options to control resource's behavior.
    
    

    Parameters

    name string
    The unique name of the resource.
    args FirehoseDeliveryStreamArgs
    The arguments to resource properties.
    opts CustomResourceOptions
    Bag of options to control resource's behavior.
    resource_name str
    The unique name of the resource.
    args FirehoseDeliveryStreamArgs
    The arguments to resource properties.
    opts ResourceOptions
    Bag of options to control resource's behavior.
    ctx Context
    Context object for the current deployment.
    name string
    The unique name of the resource.
    args FirehoseDeliveryStreamArgs
    The arguments to resource properties.
    opts ResourceOption
    Bag of options to control resource's behavior.
    name string
    The unique name of the resource.
    args FirehoseDeliveryStreamArgs
    The arguments to resource properties.
    opts CustomResourceOptions
    Bag of options to control resource's behavior.
    name String
    The unique name of the resource.
    args FirehoseDeliveryStreamArgs
    The arguments to resource properties.
    options CustomResourceOptions
    Bag of options to control resource's behavior.

    Example

    The following reference example uses placeholder values for all input properties.

    var firehoseDeliveryStreamResource = new Aws.Kinesis.FirehoseDeliveryStream("firehoseDeliveryStreamResource", new()
    {
        Destination = "string",
        Name = "string",
        OpensearchConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchConfigurationArgs
        {
            IndexName = "string",
            S3Configuration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchConfigurationS3ConfigurationArgs
            {
                BucketArn = "string",
                RoleArn = "string",
                BufferingInterval = 0,
                BufferingSize = 0,
                CloudwatchLoggingOptions = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs
                {
                    Enabled = false,
                    LogGroupName = "string",
                    LogStreamName = "string",
                },
                CompressionFormat = "string",
                ErrorOutputPrefix = "string",
                KmsKeyArn = "string",
                Prefix = "string",
            },
            RoleArn = "string",
            ClusterEndpoint = "string",
            DocumentIdOptions = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchConfigurationDocumentIdOptionsArgs
            {
                DefaultDocumentIdFormat = "string",
            },
            DomainArn = "string",
            BufferingInterval = 0,
            IndexRotationPeriod = "string",
            ProcessingConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationArgs
            {
                Enabled = false,
                Processors = new[]
                {
                    new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorArgs
                    {
                        Type = "string",
                        Parameters = new[]
                        {
                            new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorParameterArgs
                            {
                                ParameterName = "string",
                                ParameterValue = "string",
                            },
                        },
                    },
                },
            },
            RetryDuration = 0,
            CloudwatchLoggingOptions = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchConfigurationCloudwatchLoggingOptionsArgs
            {
                Enabled = false,
                LogGroupName = "string",
                LogStreamName = "string",
            },
            S3BackupMode = "string",
            BufferingSize = 0,
            TypeName = "string",
            VpcConfig = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchConfigurationVpcConfigArgs
            {
                RoleArn = "string",
                SecurityGroupIds = new[]
                {
                    "string",
                },
                SubnetIds = new[]
                {
                    "string",
                },
                VpcId = "string",
            },
        },
        ElasticsearchConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamElasticsearchConfigurationArgs
        {
            IndexName = "string",
            S3Configuration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamElasticsearchConfigurationS3ConfigurationArgs
            {
                BucketArn = "string",
                RoleArn = "string",
                BufferingInterval = 0,
                BufferingSize = 0,
                CloudwatchLoggingOptions = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamElasticsearchConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs
                {
                    Enabled = false,
                    LogGroupName = "string",
                    LogStreamName = "string",
                },
                CompressionFormat = "string",
                ErrorOutputPrefix = "string",
                KmsKeyArn = "string",
                Prefix = "string",
            },
            RoleArn = "string",
            ClusterEndpoint = "string",
            DomainArn = "string",
            BufferingInterval = 0,
            IndexRotationPeriod = "string",
            ProcessingConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationArgs
            {
                Enabled = false,
                Processors = new[]
                {
                    new Aws.Kinesis.Inputs.FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorArgs
                    {
                        Type = "string",
                        Parameters = new[]
                        {
                            new Aws.Kinesis.Inputs.FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorParameterArgs
                            {
                                ParameterName = "string",
                                ParameterValue = "string",
                            },
                        },
                    },
                },
            },
            RetryDuration = 0,
            CloudwatchLoggingOptions = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamElasticsearchConfigurationCloudwatchLoggingOptionsArgs
            {
                Enabled = false,
                LogGroupName = "string",
                LogStreamName = "string",
            },
            S3BackupMode = "string",
            BufferingSize = 0,
            TypeName = "string",
            VpcConfig = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamElasticsearchConfigurationVpcConfigArgs
            {
                RoleArn = "string",
                SecurityGroupIds = new[]
                {
                    "string",
                },
                SubnetIds = new[]
                {
                    "string",
                },
                VpcId = "string",
            },
        },
        ExtendedS3Configuration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationArgs
        {
            BucketArn = "string",
            RoleArn = "string",
            ErrorOutputPrefix = "string",
            FileExtension = "string",
            CompressionFormat = "string",
            CustomTimeZone = "string",
            DataFormatConversionConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationArgs
            {
                InputFormatConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationArgs
                {
                    Deserializer = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializerArgs
                    {
                        HiveJsonSerDe = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializerHiveJsonSerDeArgs
                        {
                            TimestampFormats = new[]
                            {
                                "string",
                            },
                        },
                        OpenXJsonSerDe = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializerOpenXJsonSerDeArgs
                        {
                            CaseInsensitive = false,
                            ColumnToJsonKeyMappings = 
                            {
                                { "string", "string" },
                            },
                            ConvertDotsInJsonKeysToUnderscores = false,
                        },
                    },
                },
                OutputFormatConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationArgs
                {
                    Serializer = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializerArgs
                    {
                        OrcSerDe = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializerOrcSerDeArgs
                        {
                            BlockSizeBytes = 0,
                            BloomFilterColumns = new[]
                            {
                                "string",
                            },
                            BloomFilterFalsePositiveProbability = 0,
                            Compression = "string",
                            DictionaryKeyThreshold = 0,
                            EnablePadding = false,
                            FormatVersion = "string",
                            PaddingTolerance = 0,
                            RowIndexStride = 0,
                            StripeSizeBytes = 0,
                        },
                        ParquetSerDe = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializerParquetSerDeArgs
                        {
                            BlockSizeBytes = 0,
                            Compression = "string",
                            EnableDictionaryCompression = false,
                            MaxPaddingBytes = 0,
                            PageSizeBytes = 0,
                            WriterVersion = "string",
                        },
                    },
                },
                SchemaConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationSchemaConfigurationArgs
                {
                    DatabaseName = "string",
                    RoleArn = "string",
                    TableName = "string",
                    CatalogId = "string",
                    Region = "string",
                    VersionId = "string",
                },
                Enabled = false,
            },
            DynamicPartitioningConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationDynamicPartitioningConfigurationArgs
            {
                Enabled = false,
                RetryDuration = 0,
            },
            BufferingSize = 0,
            CloudwatchLoggingOptions = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationCloudwatchLoggingOptionsArgs
            {
                Enabled = false,
                LogGroupName = "string",
                LogStreamName = "string",
            },
            KmsKeyArn = "string",
            Prefix = "string",
            ProcessingConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationArgs
            {
                Enabled = false,
                Processors = new[]
                {
                    new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArgs
                    {
                        Type = "string",
                        Parameters = new[]
                        {
                            new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs
                            {
                                ParameterName = "string",
                                ParameterValue = "string",
                            },
                        },
                    },
                },
            },
            BufferingInterval = 0,
            S3BackupConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationS3BackupConfigurationArgs
            {
                BucketArn = "string",
                RoleArn = "string",
                BufferingInterval = 0,
                BufferingSize = 0,
                CloudwatchLoggingOptions = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationS3BackupConfigurationCloudwatchLoggingOptionsArgs
                {
                    Enabled = false,
                    LogGroupName = "string",
                    LogStreamName = "string",
                },
                CompressionFormat = "string",
                ErrorOutputPrefix = "string",
                KmsKeyArn = "string",
                Prefix = "string",
            },
            S3BackupMode = "string",
        },
        HttpEndpointConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamHttpEndpointConfigurationArgs
        {
            S3Configuration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamHttpEndpointConfigurationS3ConfigurationArgs
            {
                BucketArn = "string",
                RoleArn = "string",
                BufferingInterval = 0,
                BufferingSize = 0,
                CloudwatchLoggingOptions = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamHttpEndpointConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs
                {
                    Enabled = false,
                    LogGroupName = "string",
                    LogStreamName = "string",
                },
                CompressionFormat = "string",
                ErrorOutputPrefix = "string",
                KmsKeyArn = "string",
                Prefix = "string",
            },
            Url = "string",
            AccessKey = "string",
            BufferingInterval = 0,
            BufferingSize = 0,
            CloudwatchLoggingOptions = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamHttpEndpointConfigurationCloudwatchLoggingOptionsArgs
            {
                Enabled = false,
                LogGroupName = "string",
                LogStreamName = "string",
            },
            Name = "string",
            ProcessingConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationArgs
            {
                Enabled = false,
                Processors = new[]
                {
                    new Aws.Kinesis.Inputs.FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationProcessorArgs
                    {
                        Type = "string",
                        Parameters = new[]
                        {
                            new Aws.Kinesis.Inputs.FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationProcessorParameterArgs
                            {
                                ParameterName = "string",
                                ParameterValue = "string",
                            },
                        },
                    },
                },
            },
            RequestConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationArgs
            {
                CommonAttributes = new[]
                {
                    new Aws.Kinesis.Inputs.FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationCommonAttributeArgs
                    {
                        Name = "string",
                        Value = "string",
                    },
                },
                ContentEncoding = "string",
            },
            RetryDuration = 0,
            RoleArn = "string",
            S3BackupMode = "string",
        },
        KinesisSourceConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamKinesisSourceConfigurationArgs
        {
            KinesisStreamArn = "string",
            RoleArn = "string",
        },
        DestinationId = "string",
        Arn = "string",
        MskSourceConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamMskSourceConfigurationArgs
        {
            AuthenticationConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamMskSourceConfigurationAuthenticationConfigurationArgs
            {
                Connectivity = "string",
                RoleArn = "string",
            },
            MskClusterArn = "string",
            TopicName = "string",
        },
        OpensearchserverlessConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchserverlessConfigurationArgs
        {
            CollectionEndpoint = "string",
            IndexName = "string",
            RoleArn = "string",
            S3Configuration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchserverlessConfigurationS3ConfigurationArgs
            {
                BucketArn = "string",
                RoleArn = "string",
                BufferingInterval = 0,
                BufferingSize = 0,
                CloudwatchLoggingOptions = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchserverlessConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs
                {
                    Enabled = false,
                    LogGroupName = "string",
                    LogStreamName = "string",
                },
                CompressionFormat = "string",
                ErrorOutputPrefix = "string",
                KmsKeyArn = "string",
                Prefix = "string",
            },
            BufferingInterval = 0,
            BufferingSize = 0,
            CloudwatchLoggingOptions = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchserverlessConfigurationCloudwatchLoggingOptionsArgs
            {
                Enabled = false,
                LogGroupName = "string",
                LogStreamName = "string",
            },
            ProcessingConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationArgs
            {
                Enabled = false,
                Processors = new[]
                {
                    new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorArgs
                    {
                        Type = "string",
                        Parameters = new[]
                        {
                            new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorParameterArgs
                            {
                                ParameterName = "string",
                                ParameterValue = "string",
                            },
                        },
                    },
                },
            },
            RetryDuration = 0,
            S3BackupMode = "string",
            VpcConfig = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamOpensearchserverlessConfigurationVpcConfigArgs
            {
                RoleArn = "string",
                SecurityGroupIds = new[]
                {
                    "string",
                },
                SubnetIds = new[]
                {
                    "string",
                },
                VpcId = "string",
            },
        },
        RedshiftConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamRedshiftConfigurationArgs
        {
            RoleArn = "string",
            ClusterJdbcurl = "string",
            Username = "string",
            S3Configuration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamRedshiftConfigurationS3ConfigurationArgs
            {
                BucketArn = "string",
                RoleArn = "string",
                BufferingInterval = 0,
                BufferingSize = 0,
                CloudwatchLoggingOptions = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamRedshiftConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs
                {
                    Enabled = false,
                    LogGroupName = "string",
                    LogStreamName = "string",
                },
                CompressionFormat = "string",
                ErrorOutputPrefix = "string",
                KmsKeyArn = "string",
                Prefix = "string",
            },
            DataTableName = "string",
            Password = "string",
            ProcessingConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationArgs
            {
                Enabled = false,
                Processors = new[]
                {
                    new Aws.Kinesis.Inputs.FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationProcessorArgs
                    {
                        Type = "string",
                        Parameters = new[]
                        {
                            new Aws.Kinesis.Inputs.FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationProcessorParameterArgs
                            {
                                ParameterName = "string",
                                ParameterValue = "string",
                            },
                        },
                    },
                },
            },
            RetryDuration = 0,
            CloudwatchLoggingOptions = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamRedshiftConfigurationCloudwatchLoggingOptionsArgs
            {
                Enabled = false,
                LogGroupName = "string",
                LogStreamName = "string",
            },
            S3BackupConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamRedshiftConfigurationS3BackupConfigurationArgs
            {
                BucketArn = "string",
                RoleArn = "string",
                BufferingInterval = 0,
                BufferingSize = 0,
                CloudwatchLoggingOptions = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamRedshiftConfigurationS3BackupConfigurationCloudwatchLoggingOptionsArgs
                {
                    Enabled = false,
                    LogGroupName = "string",
                    LogStreamName = "string",
                },
                CompressionFormat = "string",
                ErrorOutputPrefix = "string",
                KmsKeyArn = "string",
                Prefix = "string",
            },
            S3BackupMode = "string",
            DataTableColumns = "string",
            CopyOptions = "string",
        },
        ServerSideEncryption = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamServerSideEncryptionArgs
        {
            Enabled = false,
            KeyArn = "string",
            KeyType = "string",
        },
        SplunkConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamSplunkConfigurationArgs
        {
            HecEndpoint = "string",
            HecToken = "string",
            S3Configuration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamSplunkConfigurationS3ConfigurationArgs
            {
                BucketArn = "string",
                RoleArn = "string",
                BufferingInterval = 0,
                BufferingSize = 0,
                CloudwatchLoggingOptions = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamSplunkConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs
                {
                    Enabled = false,
                    LogGroupName = "string",
                    LogStreamName = "string",
                },
                CompressionFormat = "string",
                ErrorOutputPrefix = "string",
                KmsKeyArn = "string",
                Prefix = "string",
            },
            BufferingInterval = 0,
            BufferingSize = 0,
            CloudwatchLoggingOptions = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamSplunkConfigurationCloudwatchLoggingOptionsArgs
            {
                Enabled = false,
                LogGroupName = "string",
                LogStreamName = "string",
            },
            HecAcknowledgmentTimeout = 0,
            HecEndpointType = "string",
            ProcessingConfiguration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationArgs
            {
                Enabled = false,
                Processors = new[]
                {
                    new Aws.Kinesis.Inputs.FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationProcessorArgs
                    {
                        Type = "string",
                        Parameters = new[]
                        {
                            new Aws.Kinesis.Inputs.FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationProcessorParameterArgs
                            {
                                ParameterName = "string",
                                ParameterValue = "string",
                            },
                        },
                    },
                },
            },
            RetryDuration = 0,
            S3BackupMode = "string",
        },
        Tags = 
        {
            { "string", "string" },
        },
        VersionId = "string",
    });
    
    example, err := kinesis.NewFirehoseDeliveryStream(ctx, "firehoseDeliveryStreamResource", &kinesis.FirehoseDeliveryStreamArgs{
    	Destination: pulumi.String("string"),
    	Name:        pulumi.String("string"),
    	OpensearchConfiguration: &kinesis.FirehoseDeliveryStreamOpensearchConfigurationArgs{
    		IndexName: pulumi.String("string"),
    		S3Configuration: &kinesis.FirehoseDeliveryStreamOpensearchConfigurationS3ConfigurationArgs{
    			BucketArn:         pulumi.String("string"),
    			RoleArn:           pulumi.String("string"),
    			BufferingInterval: pulumi.Int(0),
    			BufferingSize:     pulumi.Int(0),
    			CloudwatchLoggingOptions: &kinesis.FirehoseDeliveryStreamOpensearchConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs{
    				Enabled:       pulumi.Bool(false),
    				LogGroupName:  pulumi.String("string"),
    				LogStreamName: pulumi.String("string"),
    			},
    			CompressionFormat: pulumi.String("string"),
    			ErrorOutputPrefix: pulumi.String("string"),
    			KmsKeyArn:         pulumi.String("string"),
    			Prefix:            pulumi.String("string"),
    		},
    		RoleArn:         pulumi.String("string"),
    		ClusterEndpoint: pulumi.String("string"),
    		DocumentIdOptions: &kinesis.FirehoseDeliveryStreamOpensearchConfigurationDocumentIdOptionsArgs{
    			DefaultDocumentIdFormat: pulumi.String("string"),
    		},
    		DomainArn:           pulumi.String("string"),
    		BufferingInterval:   pulumi.Int(0),
    		IndexRotationPeriod: pulumi.String("string"),
    		ProcessingConfiguration: &kinesis.FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationArgs{
    			Enabled: pulumi.Bool(false),
    			Processors: kinesis.FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorArray{
    				&kinesis.FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorArgs{
    					Type: pulumi.String("string"),
    					Parameters: kinesis.FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorParameterArray{
    						&kinesis.FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorParameterArgs{
    							ParameterName:  pulumi.String("string"),
    							ParameterValue: pulumi.String("string"),
    						},
    					},
    				},
    			},
    		},
    		RetryDuration: pulumi.Int(0),
    		CloudwatchLoggingOptions: &kinesis.FirehoseDeliveryStreamOpensearchConfigurationCloudwatchLoggingOptionsArgs{
    			Enabled:       pulumi.Bool(false),
    			LogGroupName:  pulumi.String("string"),
    			LogStreamName: pulumi.String("string"),
    		},
    		S3BackupMode:  pulumi.String("string"),
    		BufferingSize: pulumi.Int(0),
    		TypeName:      pulumi.String("string"),
    		VpcConfig: &kinesis.FirehoseDeliveryStreamOpensearchConfigurationVpcConfigArgs{
    			RoleArn: pulumi.String("string"),
    			SecurityGroupIds: pulumi.StringArray{
    				pulumi.String("string"),
    			},
    			SubnetIds: pulumi.StringArray{
    				pulumi.String("string"),
    			},
    			VpcId: pulumi.String("string"),
    		},
    	},
    	ElasticsearchConfiguration: &kinesis.FirehoseDeliveryStreamElasticsearchConfigurationArgs{
    		IndexName: pulumi.String("string"),
    		S3Configuration: &kinesis.FirehoseDeliveryStreamElasticsearchConfigurationS3ConfigurationArgs{
    			BucketArn:         pulumi.String("string"),
    			RoleArn:           pulumi.String("string"),
    			BufferingInterval: pulumi.Int(0),
    			BufferingSize:     pulumi.Int(0),
    			CloudwatchLoggingOptions: &kinesis.FirehoseDeliveryStreamElasticsearchConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs{
    				Enabled:       pulumi.Bool(false),
    				LogGroupName:  pulumi.String("string"),
    				LogStreamName: pulumi.String("string"),
    			},
    			CompressionFormat: pulumi.String("string"),
    			ErrorOutputPrefix: pulumi.String("string"),
    			KmsKeyArn:         pulumi.String("string"),
    			Prefix:            pulumi.String("string"),
    		},
    		RoleArn:             pulumi.String("string"),
    		ClusterEndpoint:     pulumi.String("string"),
    		DomainArn:           pulumi.String("string"),
    		BufferingInterval:   pulumi.Int(0),
    		IndexRotationPeriod: pulumi.String("string"),
    		ProcessingConfiguration: &kinesis.FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationArgs{
    			Enabled: pulumi.Bool(false),
    			Processors: kinesis.FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorArray{
    				&kinesis.FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorArgs{
    					Type: pulumi.String("string"),
    					Parameters: kinesis.FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorParameterArray{
    						&kinesis.FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorParameterArgs{
    							ParameterName:  pulumi.String("string"),
    							ParameterValue: pulumi.String("string"),
    						},
    					},
    				},
    			},
    		},
    		RetryDuration: pulumi.Int(0),
    		CloudwatchLoggingOptions: &kinesis.FirehoseDeliveryStreamElasticsearchConfigurationCloudwatchLoggingOptionsArgs{
    			Enabled:       pulumi.Bool(false),
    			LogGroupName:  pulumi.String("string"),
    			LogStreamName: pulumi.String("string"),
    		},
    		S3BackupMode:  pulumi.String("string"),
    		BufferingSize: pulumi.Int(0),
    		TypeName:      pulumi.String("string"),
    		VpcConfig: &kinesis.FirehoseDeliveryStreamElasticsearchConfigurationVpcConfigArgs{
    			RoleArn: pulumi.String("string"),
    			SecurityGroupIds: pulumi.StringArray{
    				pulumi.String("string"),
    			},
    			SubnetIds: pulumi.StringArray{
    				pulumi.String("string"),
    			},
    			VpcId: pulumi.String("string"),
    		},
    	},
    	ExtendedS3Configuration: &kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationArgs{
    		BucketArn:         pulumi.String("string"),
    		RoleArn:           pulumi.String("string"),
    		ErrorOutputPrefix: pulumi.String("string"),
    		FileExtension:     pulumi.String("string"),
    		CompressionFormat: pulumi.String("string"),
    		CustomTimeZone:    pulumi.String("string"),
    		DataFormatConversionConfiguration: &kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationArgs{
    			InputFormatConfiguration: &kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationArgs{
    				Deserializer: &kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializerArgs{
    					HiveJsonSerDe: &kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializerHiveJsonSerDeArgs{
    						TimestampFormats: pulumi.StringArray{
    							pulumi.String("string"),
    						},
    					},
    					OpenXJsonSerDe: &kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializerOpenXJsonSerDeArgs{
    						CaseInsensitive: pulumi.Bool(false),
    						ColumnToJsonKeyMappings: pulumi.StringMap{
    							"string": pulumi.String("string"),
    						},
    						ConvertDotsInJsonKeysToUnderscores: pulumi.Bool(false),
    					},
    				},
    			},
    			OutputFormatConfiguration: &kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationArgs{
    				Serializer: &kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializerArgs{
    					OrcSerDe: &kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializerOrcSerDeArgs{
    						BlockSizeBytes: pulumi.Int(0),
    						BloomFilterColumns: pulumi.StringArray{
    							pulumi.String("string"),
    						},
    						BloomFilterFalsePositiveProbability: pulumi.Float64(0),
    						Compression:                         pulumi.String("string"),
    						DictionaryKeyThreshold:              pulumi.Float64(0),
    						EnablePadding:                       pulumi.Bool(false),
    						FormatVersion:                       pulumi.String("string"),
    						PaddingTolerance:                    pulumi.Float64(0),
    						RowIndexStride:                      pulumi.Int(0),
    						StripeSizeBytes:                     pulumi.Int(0),
    					},
    					ParquetSerDe: &kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializerParquetSerDeArgs{
    						BlockSizeBytes:              pulumi.Int(0),
    						Compression:                 pulumi.String("string"),
    						EnableDictionaryCompression: pulumi.Bool(false),
    						MaxPaddingBytes:             pulumi.Int(0),
    						PageSizeBytes:               pulumi.Int(0),
    						WriterVersion:               pulumi.String("string"),
    					},
    				},
    			},
    			SchemaConfiguration: &kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationSchemaConfigurationArgs{
    				DatabaseName: pulumi.String("string"),
    				RoleArn:      pulumi.String("string"),
    				TableName:    pulumi.String("string"),
    				CatalogId:    pulumi.String("string"),
    				Region:       pulumi.String("string"),
    				VersionId:    pulumi.String("string"),
    			},
    			Enabled: pulumi.Bool(false),
    		},
    		DynamicPartitioningConfiguration: &kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationDynamicPartitioningConfigurationArgs{
    			Enabled:       pulumi.Bool(false),
    			RetryDuration: pulumi.Int(0),
    		},
    		BufferingSize: pulumi.Int(0),
    		CloudwatchLoggingOptions: &kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationCloudwatchLoggingOptionsArgs{
    			Enabled:       pulumi.Bool(false),
    			LogGroupName:  pulumi.String("string"),
    			LogStreamName: pulumi.String("string"),
    		},
    		KmsKeyArn: pulumi.String("string"),
    		Prefix:    pulumi.String("string"),
    		ProcessingConfiguration: &kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationArgs{
    			Enabled: pulumi.Bool(false),
    			Processors: kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArray{
    				&kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArgs{
    					Type: pulumi.String("string"),
    					Parameters: kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArray{
    						&kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs{
    							ParameterName:  pulumi.String("string"),
    							ParameterValue: pulumi.String("string"),
    						},
    					},
    				},
    			},
    		},
    		BufferingInterval: pulumi.Int(0),
    		S3BackupConfiguration: &kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationS3BackupConfigurationArgs{
    			BucketArn:         pulumi.String("string"),
    			RoleArn:           pulumi.String("string"),
    			BufferingInterval: pulumi.Int(0),
    			BufferingSize:     pulumi.Int(0),
    			CloudwatchLoggingOptions: &kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationS3BackupConfigurationCloudwatchLoggingOptionsArgs{
    				Enabled:       pulumi.Bool(false),
    				LogGroupName:  pulumi.String("string"),
    				LogStreamName: pulumi.String("string"),
    			},
    			CompressionFormat: pulumi.String("string"),
    			ErrorOutputPrefix: pulumi.String("string"),
    			KmsKeyArn:         pulumi.String("string"),
    			Prefix:            pulumi.String("string"),
    		},
    		S3BackupMode: pulumi.String("string"),
    	},
    	HttpEndpointConfiguration: &kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationArgs{
    		S3Configuration: &kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationS3ConfigurationArgs{
    			BucketArn:         pulumi.String("string"),
    			RoleArn:           pulumi.String("string"),
    			BufferingInterval: pulumi.Int(0),
    			BufferingSize:     pulumi.Int(0),
    			CloudwatchLoggingOptions: &kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs{
    				Enabled:       pulumi.Bool(false),
    				LogGroupName:  pulumi.String("string"),
    				LogStreamName: pulumi.String("string"),
    			},
    			CompressionFormat: pulumi.String("string"),
    			ErrorOutputPrefix: pulumi.String("string"),
    			KmsKeyArn:         pulumi.String("string"),
    			Prefix:            pulumi.String("string"),
    		},
    		Url:               pulumi.String("string"),
    		AccessKey:         pulumi.String("string"),
    		BufferingInterval: pulumi.Int(0),
    		BufferingSize:     pulumi.Int(0),
    		CloudwatchLoggingOptions: &kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationCloudwatchLoggingOptionsArgs{
    			Enabled:       pulumi.Bool(false),
    			LogGroupName:  pulumi.String("string"),
    			LogStreamName: pulumi.String("string"),
    		},
    		Name: pulumi.String("string"),
    		ProcessingConfiguration: &kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationArgs{
    			Enabled: pulumi.Bool(false),
    			Processors: kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationProcessorArray{
    				&kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationProcessorArgs{
    					Type: pulumi.String("string"),
    					Parameters: kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationProcessorParameterArray{
    						&kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationProcessorParameterArgs{
    							ParameterName:  pulumi.String("string"),
    							ParameterValue: pulumi.String("string"),
    						},
    					},
    				},
    			},
    		},
    		RequestConfiguration: &kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationArgs{
    			CommonAttributes: kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationCommonAttributeArray{
    				&kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationCommonAttributeArgs{
    					Name:  pulumi.String("string"),
    					Value: pulumi.String("string"),
    				},
    			},
    			ContentEncoding: pulumi.String("string"),
    		},
    		RetryDuration: pulumi.Int(0),
    		RoleArn:       pulumi.String("string"),
    		S3BackupMode:  pulumi.String("string"),
    	},
    	KinesisSourceConfiguration: &kinesis.FirehoseDeliveryStreamKinesisSourceConfigurationArgs{
    		KinesisStreamArn: pulumi.String("string"),
    		RoleArn:          pulumi.String("string"),
    	},
    	DestinationId: pulumi.String("string"),
    	Arn:           pulumi.String("string"),
    	MskSourceConfiguration: &kinesis.FirehoseDeliveryStreamMskSourceConfigurationArgs{
    		AuthenticationConfiguration: &kinesis.FirehoseDeliveryStreamMskSourceConfigurationAuthenticationConfigurationArgs{
    			Connectivity: pulumi.String("string"),
    			RoleArn:      pulumi.String("string"),
    		},
    		MskClusterArn: pulumi.String("string"),
    		TopicName:     pulumi.String("string"),
    	},
    	OpensearchserverlessConfiguration: &kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationArgs{
    		CollectionEndpoint: pulumi.String("string"),
    		IndexName:          pulumi.String("string"),
    		RoleArn:            pulumi.String("string"),
    		S3Configuration: &kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationS3ConfigurationArgs{
    			BucketArn:         pulumi.String("string"),
    			RoleArn:           pulumi.String("string"),
    			BufferingInterval: pulumi.Int(0),
    			BufferingSize:     pulumi.Int(0),
    			CloudwatchLoggingOptions: &kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs{
    				Enabled:       pulumi.Bool(false),
    				LogGroupName:  pulumi.String("string"),
    				LogStreamName: pulumi.String("string"),
    			},
    			CompressionFormat: pulumi.String("string"),
    			ErrorOutputPrefix: pulumi.String("string"),
    			KmsKeyArn:         pulumi.String("string"),
    			Prefix:            pulumi.String("string"),
    		},
    		BufferingInterval: pulumi.Int(0),
    		BufferingSize:     pulumi.Int(0),
    		CloudwatchLoggingOptions: &kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationCloudwatchLoggingOptionsArgs{
    			Enabled:       pulumi.Bool(false),
    			LogGroupName:  pulumi.String("string"),
    			LogStreamName: pulumi.String("string"),
    		},
    		ProcessingConfiguration: &kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationArgs{
    			Enabled: pulumi.Bool(false),
    			Processors: kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorArray{
    				&kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorArgs{
    					Type: pulumi.String("string"),
    					Parameters: kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorParameterArray{
    						&kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorParameterArgs{
    							ParameterName:  pulumi.String("string"),
    							ParameterValue: pulumi.String("string"),
    						},
    					},
    				},
    			},
    		},
    		RetryDuration: pulumi.Int(0),
    		S3BackupMode:  pulumi.String("string"),
    		VpcConfig: &kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationVpcConfigArgs{
    			RoleArn: pulumi.String("string"),
    			SecurityGroupIds: pulumi.StringArray{
    				pulumi.String("string"),
    			},
    			SubnetIds: pulumi.StringArray{
    				pulumi.String("string"),
    			},
    			VpcId: pulumi.String("string"),
    		},
    	},
    	RedshiftConfiguration: &kinesis.FirehoseDeliveryStreamRedshiftConfigurationArgs{
    		RoleArn:        pulumi.String("string"),
    		ClusterJdbcurl: pulumi.String("string"),
    		Username:       pulumi.String("string"),
    		S3Configuration: &kinesis.FirehoseDeliveryStreamRedshiftConfigurationS3ConfigurationArgs{
    			BucketArn:         pulumi.String("string"),
    			RoleArn:           pulumi.String("string"),
    			BufferingInterval: pulumi.Int(0),
    			BufferingSize:     pulumi.Int(0),
    			CloudwatchLoggingOptions: &kinesis.FirehoseDeliveryStreamRedshiftConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs{
    				Enabled:       pulumi.Bool(false),
    				LogGroupName:  pulumi.String("string"),
    				LogStreamName: pulumi.String("string"),
    			},
    			CompressionFormat: pulumi.String("string"),
    			ErrorOutputPrefix: pulumi.String("string"),
    			KmsKeyArn:         pulumi.String("string"),
    			Prefix:            pulumi.String("string"),
    		},
    		DataTableName: pulumi.String("string"),
    		Password:      pulumi.String("string"),
    		ProcessingConfiguration: &kinesis.FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationArgs{
    			Enabled: pulumi.Bool(false),
    			Processors: kinesis.FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationProcessorArray{
    				&kinesis.FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationProcessorArgs{
    					Type: pulumi.String("string"),
    					Parameters: kinesis.FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationProcessorParameterArray{
    						&kinesis.FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationProcessorParameterArgs{
    							ParameterName:  pulumi.String("string"),
    							ParameterValue: pulumi.String("string"),
    						},
    					},
    				},
    			},
    		},
    		RetryDuration: pulumi.Int(0),
    		CloudwatchLoggingOptions: &kinesis.FirehoseDeliveryStreamRedshiftConfigurationCloudwatchLoggingOptionsArgs{
    			Enabled:       pulumi.Bool(false),
    			LogGroupName:  pulumi.String("string"),
    			LogStreamName: pulumi.String("string"),
    		},
    		S3BackupConfiguration: &kinesis.FirehoseDeliveryStreamRedshiftConfigurationS3BackupConfigurationArgs{
    			BucketArn:         pulumi.String("string"),
    			RoleArn:           pulumi.String("string"),
    			BufferingInterval: pulumi.Int(0),
    			BufferingSize:     pulumi.Int(0),
    			CloudwatchLoggingOptions: &kinesis.FirehoseDeliveryStreamRedshiftConfigurationS3BackupConfigurationCloudwatchLoggingOptionsArgs{
    				Enabled:       pulumi.Bool(false),
    				LogGroupName:  pulumi.String("string"),
    				LogStreamName: pulumi.String("string"),
    			},
    			CompressionFormat: pulumi.String("string"),
    			ErrorOutputPrefix: pulumi.String("string"),
    			KmsKeyArn:         pulumi.String("string"),
    			Prefix:            pulumi.String("string"),
    		},
    		S3BackupMode:     pulumi.String("string"),
    		DataTableColumns: pulumi.String("string"),
    		CopyOptions:      pulumi.String("string"),
    	},
    	ServerSideEncryption: &kinesis.FirehoseDeliveryStreamServerSideEncryptionArgs{
    		Enabled: pulumi.Bool(false),
    		KeyArn:  pulumi.String("string"),
    		KeyType: pulumi.String("string"),
    	},
    	SplunkConfiguration: &kinesis.FirehoseDeliveryStreamSplunkConfigurationArgs{
    		HecEndpoint: pulumi.String("string"),
    		HecToken:    pulumi.String("string"),
    		S3Configuration: &kinesis.FirehoseDeliveryStreamSplunkConfigurationS3ConfigurationArgs{
    			BucketArn:         pulumi.String("string"),
    			RoleArn:           pulumi.String("string"),
    			BufferingInterval: pulumi.Int(0),
    			BufferingSize:     pulumi.Int(0),
    			CloudwatchLoggingOptions: &kinesis.FirehoseDeliveryStreamSplunkConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs{
    				Enabled:       pulumi.Bool(false),
    				LogGroupName:  pulumi.String("string"),
    				LogStreamName: pulumi.String("string"),
    			},
    			CompressionFormat: pulumi.String("string"),
    			ErrorOutputPrefix: pulumi.String("string"),
    			KmsKeyArn:         pulumi.String("string"),
    			Prefix:            pulumi.String("string"),
    		},
    		BufferingInterval: pulumi.Int(0),
    		BufferingSize:     pulumi.Int(0),
    		CloudwatchLoggingOptions: &kinesis.FirehoseDeliveryStreamSplunkConfigurationCloudwatchLoggingOptionsArgs{
    			Enabled:       pulumi.Bool(false),
    			LogGroupName:  pulumi.String("string"),
    			LogStreamName: pulumi.String("string"),
    		},
    		HecAcknowledgmentTimeout: pulumi.Int(0),
    		HecEndpointType:          pulumi.String("string"),
    		ProcessingConfiguration: &kinesis.FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationArgs{
    			Enabled: pulumi.Bool(false),
    			Processors: kinesis.FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationProcessorArray{
    				&kinesis.FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationProcessorArgs{
    					Type: pulumi.String("string"),
    					Parameters: kinesis.FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationProcessorParameterArray{
    						&kinesis.FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationProcessorParameterArgs{
    							ParameterName:  pulumi.String("string"),
    							ParameterValue: pulumi.String("string"),
    						},
    					},
    				},
    			},
    		},
    		RetryDuration: pulumi.Int(0),
    		S3BackupMode:  pulumi.String("string"),
    	},
    	Tags: pulumi.StringMap{
    		"string": pulumi.String("string"),
    	},
    	VersionId: pulumi.String("string"),
    })
    
    var firehoseDeliveryStreamResource = new FirehoseDeliveryStream("firehoseDeliveryStreamResource", FirehoseDeliveryStreamArgs.builder()        
        .destination("string")
        .name("string")
        .opensearchConfiguration(FirehoseDeliveryStreamOpensearchConfigurationArgs.builder()
            .indexName("string")
            .s3Configuration(FirehoseDeliveryStreamOpensearchConfigurationS3ConfigurationArgs.builder()
                .bucketArn("string")
                .roleArn("string")
                .bufferingInterval(0)
                .bufferingSize(0)
                .cloudwatchLoggingOptions(FirehoseDeliveryStreamOpensearchConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs.builder()
                    .enabled(false)
                    .logGroupName("string")
                    .logStreamName("string")
                    .build())
                .compressionFormat("string")
                .errorOutputPrefix("string")
                .kmsKeyArn("string")
                .prefix("string")
                .build())
            .roleArn("string")
            .clusterEndpoint("string")
            .documentIdOptions(FirehoseDeliveryStreamOpensearchConfigurationDocumentIdOptionsArgs.builder()
                .defaultDocumentIdFormat("string")
                .build())
            .domainArn("string")
            .bufferingInterval(0)
            .indexRotationPeriod("string")
            .processingConfiguration(FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationArgs.builder()
                .enabled(false)
                .processors(FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorArgs.builder()
                    .type("string")
                    .parameters(FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorParameterArgs.builder()
                        .parameterName("string")
                        .parameterValue("string")
                        .build())
                    .build())
                .build())
            .retryDuration(0)
            .cloudwatchLoggingOptions(FirehoseDeliveryStreamOpensearchConfigurationCloudwatchLoggingOptionsArgs.builder()
                .enabled(false)
                .logGroupName("string")
                .logStreamName("string")
                .build())
            .s3BackupMode("string")
            .bufferingSize(0)
            .typeName("string")
            .vpcConfig(FirehoseDeliveryStreamOpensearchConfigurationVpcConfigArgs.builder()
                .roleArn("string")
                .securityGroupIds("string")
                .subnetIds("string")
                .vpcId("string")
                .build())
            .build())
        .elasticsearchConfiguration(FirehoseDeliveryStreamElasticsearchConfigurationArgs.builder()
            .indexName("string")
            .s3Configuration(FirehoseDeliveryStreamElasticsearchConfigurationS3ConfigurationArgs.builder()
                .bucketArn("string")
                .roleArn("string")
                .bufferingInterval(0)
                .bufferingSize(0)
                .cloudwatchLoggingOptions(FirehoseDeliveryStreamElasticsearchConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs.builder()
                    .enabled(false)
                    .logGroupName("string")
                    .logStreamName("string")
                    .build())
                .compressionFormat("string")
                .errorOutputPrefix("string")
                .kmsKeyArn("string")
                .prefix("string")
                .build())
            .roleArn("string")
            .clusterEndpoint("string")
            .domainArn("string")
            .bufferingInterval(0)
            .indexRotationPeriod("string")
            .processingConfiguration(FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationArgs.builder()
                .enabled(false)
                .processors(FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorArgs.builder()
                    .type("string")
                    .parameters(FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorParameterArgs.builder()
                        .parameterName("string")
                        .parameterValue("string")
                        .build())
                    .build())
                .build())
            .retryDuration(0)
            .cloudwatchLoggingOptions(FirehoseDeliveryStreamElasticsearchConfigurationCloudwatchLoggingOptionsArgs.builder()
                .enabled(false)
                .logGroupName("string")
                .logStreamName("string")
                .build())
            .s3BackupMode("string")
            .bufferingSize(0)
            .typeName("string")
            .vpcConfig(FirehoseDeliveryStreamElasticsearchConfigurationVpcConfigArgs.builder()
                .roleArn("string")
                .securityGroupIds("string")
                .subnetIds("string")
                .vpcId("string")
                .build())
            .build())
        .extendedS3Configuration(FirehoseDeliveryStreamExtendedS3ConfigurationArgs.builder()
            .bucketArn("string")
            .roleArn("string")
            .errorOutputPrefix("string")
            .fileExtension("string")
            .compressionFormat("string")
            .customTimeZone("string")
            .dataFormatConversionConfiguration(FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationArgs.builder()
                .inputFormatConfiguration(FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationArgs.builder()
                    .deserializer(FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializerArgs.builder()
                        .hiveJsonSerDe(FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializerHiveJsonSerDeArgs.builder()
                            .timestampFormats("string")
                            .build())
                        .openXJsonSerDe(FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializerOpenXJsonSerDeArgs.builder()
                            .caseInsensitive(false)
                            .columnToJsonKeyMappings(Map.of("string", "string"))
                            .convertDotsInJsonKeysToUnderscores(false)
                            .build())
                        .build())
                    .build())
                .outputFormatConfiguration(FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationArgs.builder()
                    .serializer(FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializerArgs.builder()
                        .orcSerDe(FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializerOrcSerDeArgs.builder()
                            .blockSizeBytes(0)
                            .bloomFilterColumns("string")
                            .bloomFilterFalsePositiveProbability(0)
                            .compression("string")
                            .dictionaryKeyThreshold(0)
                            .enablePadding(false)
                            .formatVersion("string")
                            .paddingTolerance(0)
                            .rowIndexStride(0)
                            .stripeSizeBytes(0)
                            .build())
                        .parquetSerDe(FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializerParquetSerDeArgs.builder()
                            .blockSizeBytes(0)
                            .compression("string")
                            .enableDictionaryCompression(false)
                            .maxPaddingBytes(0)
                            .pageSizeBytes(0)
                            .writerVersion("string")
                            .build())
                        .build())
                    .build())
                .schemaConfiguration(FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationSchemaConfigurationArgs.builder()
                    .databaseName("string")
                    .roleArn("string")
                    .tableName("string")
                    .catalogId("string")
                    .region("string")
                    .versionId("string")
                    .build())
                .enabled(false)
                .build())
            .dynamicPartitioningConfiguration(FirehoseDeliveryStreamExtendedS3ConfigurationDynamicPartitioningConfigurationArgs.builder()
                .enabled(false)
                .retryDuration(0)
                .build())
            .bufferingSize(0)
            .cloudwatchLoggingOptions(FirehoseDeliveryStreamExtendedS3ConfigurationCloudwatchLoggingOptionsArgs.builder()
                .enabled(false)
                .logGroupName("string")
                .logStreamName("string")
                .build())
            .kmsKeyArn("string")
            .prefix("string")
            .processingConfiguration(FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationArgs.builder()
                .enabled(false)
                .processors(FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArgs.builder()
                    .type("string")
                    .parameters(FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs.builder()
                        .parameterName("string")
                        .parameterValue("string")
                        .build())
                    .build())
                .build())
            .bufferingInterval(0)
            .s3BackupConfiguration(FirehoseDeliveryStreamExtendedS3ConfigurationS3BackupConfigurationArgs.builder()
                .bucketArn("string")
                .roleArn("string")
                .bufferingInterval(0)
                .bufferingSize(0)
                .cloudwatchLoggingOptions(FirehoseDeliveryStreamExtendedS3ConfigurationS3BackupConfigurationCloudwatchLoggingOptionsArgs.builder()
                    .enabled(false)
                    .logGroupName("string")
                    .logStreamName("string")
                    .build())
                .compressionFormat("string")
                .errorOutputPrefix("string")
                .kmsKeyArn("string")
                .prefix("string")
                .build())
            .s3BackupMode("string")
            .build())
        .httpEndpointConfiguration(FirehoseDeliveryStreamHttpEndpointConfigurationArgs.builder()
            .s3Configuration(FirehoseDeliveryStreamHttpEndpointConfigurationS3ConfigurationArgs.builder()
                .bucketArn("string")
                .roleArn("string")
                .bufferingInterval(0)
                .bufferingSize(0)
                .cloudwatchLoggingOptions(FirehoseDeliveryStreamHttpEndpointConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs.builder()
                    .enabled(false)
                    .logGroupName("string")
                    .logStreamName("string")
                    .build())
                .compressionFormat("string")
                .errorOutputPrefix("string")
                .kmsKeyArn("string")
                .prefix("string")
                .build())
            .url("string")
            .accessKey("string")
            .bufferingInterval(0)
            .bufferingSize(0)
            .cloudwatchLoggingOptions(FirehoseDeliveryStreamHttpEndpointConfigurationCloudwatchLoggingOptionsArgs.builder()
                .enabled(false)
                .logGroupName("string")
                .logStreamName("string")
                .build())
            .name("string")
            .processingConfiguration(FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationArgs.builder()
                .enabled(false)
                .processors(FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationProcessorArgs.builder()
                    .type("string")
                    .parameters(FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationProcessorParameterArgs.builder()
                        .parameterName("string")
                        .parameterValue("string")
                        .build())
                    .build())
                .build())
            .requestConfiguration(FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationArgs.builder()
                .commonAttributes(FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationCommonAttributeArgs.builder()
                    .name("string")
                    .value("string")
                    .build())
                .contentEncoding("string")
                .build())
            .retryDuration(0)
            .roleArn("string")
            .s3BackupMode("string")
            .build())
        .kinesisSourceConfiguration(FirehoseDeliveryStreamKinesisSourceConfigurationArgs.builder()
            .kinesisStreamArn("string")
            .roleArn("string")
            .build())
        .destinationId("string")
        .arn("string")
        .mskSourceConfiguration(FirehoseDeliveryStreamMskSourceConfigurationArgs.builder()
            .authenticationConfiguration(FirehoseDeliveryStreamMskSourceConfigurationAuthenticationConfigurationArgs.builder()
                .connectivity("string")
                .roleArn("string")
                .build())
            .mskClusterArn("string")
            .topicName("string")
            .build())
        .opensearchserverlessConfiguration(FirehoseDeliveryStreamOpensearchserverlessConfigurationArgs.builder()
            .collectionEndpoint("string")
            .indexName("string")
            .roleArn("string")
            .s3Configuration(FirehoseDeliveryStreamOpensearchserverlessConfigurationS3ConfigurationArgs.builder()
                .bucketArn("string")
                .roleArn("string")
                .bufferingInterval(0)
                .bufferingSize(0)
                .cloudwatchLoggingOptions(FirehoseDeliveryStreamOpensearchserverlessConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs.builder()
                    .enabled(false)
                    .logGroupName("string")
                    .logStreamName("string")
                    .build())
                .compressionFormat("string")
                .errorOutputPrefix("string")
                .kmsKeyArn("string")
                .prefix("string")
                .build())
            .bufferingInterval(0)
            .bufferingSize(0)
            .cloudwatchLoggingOptions(FirehoseDeliveryStreamOpensearchserverlessConfigurationCloudwatchLoggingOptionsArgs.builder()
                .enabled(false)
                .logGroupName("string")
                .logStreamName("string")
                .build())
            .processingConfiguration(FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationArgs.builder()
                .enabled(false)
                .processors(FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorArgs.builder()
                    .type("string")
                    .parameters(FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorParameterArgs.builder()
                        .parameterName("string")
                        .parameterValue("string")
                        .build())
                    .build())
                .build())
            .retryDuration(0)
            .s3BackupMode("string")
            .vpcConfig(FirehoseDeliveryStreamOpensearchserverlessConfigurationVpcConfigArgs.builder()
                .roleArn("string")
                .securityGroupIds("string")
                .subnetIds("string")
                .vpcId("string")
                .build())
            .build())
        .redshiftConfiguration(FirehoseDeliveryStreamRedshiftConfigurationArgs.builder()
            .roleArn("string")
            .clusterJdbcurl("string")
            .username("string")
            .s3Configuration(FirehoseDeliveryStreamRedshiftConfigurationS3ConfigurationArgs.builder()
                .bucketArn("string")
                .roleArn("string")
                .bufferingInterval(0)
                .bufferingSize(0)
                .cloudwatchLoggingOptions(FirehoseDeliveryStreamRedshiftConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs.builder()
                    .enabled(false)
                    .logGroupName("string")
                    .logStreamName("string")
                    .build())
                .compressionFormat("string")
                .errorOutputPrefix("string")
                .kmsKeyArn("string")
                .prefix("string")
                .build())
            .dataTableName("string")
            .password("string")
            .processingConfiguration(FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationArgs.builder()
                .enabled(false)
                .processors(FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationProcessorArgs.builder()
                    .type("string")
                    .parameters(FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationProcessorParameterArgs.builder()
                        .parameterName("string")
                        .parameterValue("string")
                        .build())
                    .build())
                .build())
            .retryDuration(0)
            .cloudwatchLoggingOptions(FirehoseDeliveryStreamRedshiftConfigurationCloudwatchLoggingOptionsArgs.builder()
                .enabled(false)
                .logGroupName("string")
                .logStreamName("string")
                .build())
            .s3BackupConfiguration(FirehoseDeliveryStreamRedshiftConfigurationS3BackupConfigurationArgs.builder()
                .bucketArn("string")
                .roleArn("string")
                .bufferingInterval(0)
                .bufferingSize(0)
                .cloudwatchLoggingOptions(FirehoseDeliveryStreamRedshiftConfigurationS3BackupConfigurationCloudwatchLoggingOptionsArgs.builder()
                    .enabled(false)
                    .logGroupName("string")
                    .logStreamName("string")
                    .build())
                .compressionFormat("string")
                .errorOutputPrefix("string")
                .kmsKeyArn("string")
                .prefix("string")
                .build())
            .s3BackupMode("string")
            .dataTableColumns("string")
            .copyOptions("string")
            .build())
        .serverSideEncryption(FirehoseDeliveryStreamServerSideEncryptionArgs.builder()
            .enabled(false)
            .keyArn("string")
            .keyType("string")
            .build())
        .splunkConfiguration(FirehoseDeliveryStreamSplunkConfigurationArgs.builder()
            .hecEndpoint("string")
            .hecToken("string")
            .s3Configuration(FirehoseDeliveryStreamSplunkConfigurationS3ConfigurationArgs.builder()
                .bucketArn("string")
                .roleArn("string")
                .bufferingInterval(0)
                .bufferingSize(0)
                .cloudwatchLoggingOptions(FirehoseDeliveryStreamSplunkConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs.builder()
                    .enabled(false)
                    .logGroupName("string")
                    .logStreamName("string")
                    .build())
                .compressionFormat("string")
                .errorOutputPrefix("string")
                .kmsKeyArn("string")
                .prefix("string")
                .build())
            .bufferingInterval(0)
            .bufferingSize(0)
            .cloudwatchLoggingOptions(FirehoseDeliveryStreamSplunkConfigurationCloudwatchLoggingOptionsArgs.builder()
                .enabled(false)
                .logGroupName("string")
                .logStreamName("string")
                .build())
            .hecAcknowledgmentTimeout(0)
            .hecEndpointType("string")
            .processingConfiguration(FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationArgs.builder()
                .enabled(false)
                .processors(FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationProcessorArgs.builder()
                    .type("string")
                    .parameters(FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationProcessorParameterArgs.builder()
                        .parameterName("string")
                        .parameterValue("string")
                        .build())
                    .build())
                .build())
            .retryDuration(0)
            .s3BackupMode("string")
            .build())
        .tags(Map.of("string", "string"))
        .versionId("string")
        .build());
    
    firehose_delivery_stream_resource = aws.kinesis.FirehoseDeliveryStream("firehoseDeliveryStreamResource",
        destination="string",
        name="string",
        opensearch_configuration=aws.kinesis.FirehoseDeliveryStreamOpensearchConfigurationArgs(
            index_name="string",
            s3_configuration=aws.kinesis.FirehoseDeliveryStreamOpensearchConfigurationS3ConfigurationArgs(
                bucket_arn="string",
                role_arn="string",
                buffering_interval=0,
                buffering_size=0,
                cloudwatch_logging_options=aws.kinesis.FirehoseDeliveryStreamOpensearchConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs(
                    enabled=False,
                    log_group_name="string",
                    log_stream_name="string",
                ),
                compression_format="string",
                error_output_prefix="string",
                kms_key_arn="string",
                prefix="string",
            ),
            role_arn="string",
            cluster_endpoint="string",
            document_id_options=aws.kinesis.FirehoseDeliveryStreamOpensearchConfigurationDocumentIdOptionsArgs(
                default_document_id_format="string",
            ),
            domain_arn="string",
            buffering_interval=0,
            index_rotation_period="string",
            processing_configuration=aws.kinesis.FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationArgs(
                enabled=False,
                processors=[aws.kinesis.FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorArgs(
                    type="string",
                    parameters=[aws.kinesis.FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorParameterArgs(
                        parameter_name="string",
                        parameter_value="string",
                    )],
                )],
            ),
            retry_duration=0,
            cloudwatch_logging_options=aws.kinesis.FirehoseDeliveryStreamOpensearchConfigurationCloudwatchLoggingOptionsArgs(
                enabled=False,
                log_group_name="string",
                log_stream_name="string",
            ),
            s3_backup_mode="string",
            buffering_size=0,
            type_name="string",
            vpc_config=aws.kinesis.FirehoseDeliveryStreamOpensearchConfigurationVpcConfigArgs(
                role_arn="string",
                security_group_ids=["string"],
                subnet_ids=["string"],
                vpc_id="string",
            ),
        ),
        elasticsearch_configuration=aws.kinesis.FirehoseDeliveryStreamElasticsearchConfigurationArgs(
            index_name="string",
            s3_configuration=aws.kinesis.FirehoseDeliveryStreamElasticsearchConfigurationS3ConfigurationArgs(
                bucket_arn="string",
                role_arn="string",
                buffering_interval=0,
                buffering_size=0,
                cloudwatch_logging_options=aws.kinesis.FirehoseDeliveryStreamElasticsearchConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs(
                    enabled=False,
                    log_group_name="string",
                    log_stream_name="string",
                ),
                compression_format="string",
                error_output_prefix="string",
                kms_key_arn="string",
                prefix="string",
            ),
            role_arn="string",
            cluster_endpoint="string",
            domain_arn="string",
            buffering_interval=0,
            index_rotation_period="string",
            processing_configuration=aws.kinesis.FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationArgs(
                enabled=False,
                processors=[aws.kinesis.FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorArgs(
                    type="string",
                    parameters=[aws.kinesis.FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorParameterArgs(
                        parameter_name="string",
                        parameter_value="string",
                    )],
                )],
            ),
            retry_duration=0,
            cloudwatch_logging_options=aws.kinesis.FirehoseDeliveryStreamElasticsearchConfigurationCloudwatchLoggingOptionsArgs(
                enabled=False,
                log_group_name="string",
                log_stream_name="string",
            ),
            s3_backup_mode="string",
            buffering_size=0,
            type_name="string",
            vpc_config=aws.kinesis.FirehoseDeliveryStreamElasticsearchConfigurationVpcConfigArgs(
                role_arn="string",
                security_group_ids=["string"],
                subnet_ids=["string"],
                vpc_id="string",
            ),
        ),
        extended_s3_configuration=aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationArgs(
            bucket_arn="string",
            role_arn="string",
            error_output_prefix="string",
            file_extension="string",
            compression_format="string",
            custom_time_zone="string",
            data_format_conversion_configuration=aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationArgs(
                input_format_configuration=aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationArgs(
                    deserializer=aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializerArgs(
                        hive_json_ser_de=aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializerHiveJsonSerDeArgs(
                            timestamp_formats=["string"],
                        ),
                        open_x_json_ser_de=aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializerOpenXJsonSerDeArgs(
                            case_insensitive=False,
                            column_to_json_key_mappings={
                                "string": "string",
                            },
                            convert_dots_in_json_keys_to_underscores=False,
                        ),
                    ),
                ),
                output_format_configuration=aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationArgs(
                    serializer=aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializerArgs(
                        orc_ser_de=aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializerOrcSerDeArgs(
                            block_size_bytes=0,
                            bloom_filter_columns=["string"],
                            bloom_filter_false_positive_probability=0,
                            compression="string",
                            dictionary_key_threshold=0,
                            enable_padding=False,
                            format_version="string",
                            padding_tolerance=0,
                            row_index_stride=0,
                            stripe_size_bytes=0,
                        ),
                        parquet_ser_de=aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializerParquetSerDeArgs(
                            block_size_bytes=0,
                            compression="string",
                            enable_dictionary_compression=False,
                            max_padding_bytes=0,
                            page_size_bytes=0,
                            writer_version="string",
                        ),
                    ),
                ),
                schema_configuration=aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationSchemaConfigurationArgs(
                    database_name="string",
                    role_arn="string",
                    table_name="string",
                    catalog_id="string",
                    region="string",
                    version_id="string",
                ),
                enabled=False,
            ),
            dynamic_partitioning_configuration=aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationDynamicPartitioningConfigurationArgs(
                enabled=False,
                retry_duration=0,
            ),
            buffering_size=0,
            cloudwatch_logging_options=aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationCloudwatchLoggingOptionsArgs(
                enabled=False,
                log_group_name="string",
                log_stream_name="string",
            ),
            kms_key_arn="string",
            prefix="string",
            processing_configuration=aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationArgs(
                enabled=False,
                processors=[aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArgs(
                    type="string",
                    parameters=[aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs(
                        parameter_name="string",
                        parameter_value="string",
                    )],
                )],
            ),
            buffering_interval=0,
            s3_backup_configuration=aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationS3BackupConfigurationArgs(
                bucket_arn="string",
                role_arn="string",
                buffering_interval=0,
                buffering_size=0,
                cloudwatch_logging_options=aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationS3BackupConfigurationCloudwatchLoggingOptionsArgs(
                    enabled=False,
                    log_group_name="string",
                    log_stream_name="string",
                ),
                compression_format="string",
                error_output_prefix="string",
                kms_key_arn="string",
                prefix="string",
            ),
            s3_backup_mode="string",
        ),
        http_endpoint_configuration=aws.kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationArgs(
            s3_configuration=aws.kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationS3ConfigurationArgs(
                bucket_arn="string",
                role_arn="string",
                buffering_interval=0,
                buffering_size=0,
                cloudwatch_logging_options=aws.kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs(
                    enabled=False,
                    log_group_name="string",
                    log_stream_name="string",
                ),
                compression_format="string",
                error_output_prefix="string",
                kms_key_arn="string",
                prefix="string",
            ),
            url="string",
            access_key="string",
            buffering_interval=0,
            buffering_size=0,
            cloudwatch_logging_options=aws.kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationCloudwatchLoggingOptionsArgs(
                enabled=False,
                log_group_name="string",
                log_stream_name="string",
            ),
            name="string",
            processing_configuration=aws.kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationArgs(
                enabled=False,
                processors=[aws.kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationProcessorArgs(
                    type="string",
                    parameters=[aws.kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationProcessorParameterArgs(
                        parameter_name="string",
                        parameter_value="string",
                    )],
                )],
            ),
            request_configuration=aws.kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationArgs(
                common_attributes=[aws.kinesis.FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationCommonAttributeArgs(
                    name="string",
                    value="string",
                )],
                content_encoding="string",
            ),
            retry_duration=0,
            role_arn="string",
            s3_backup_mode="string",
        ),
        kinesis_source_configuration=aws.kinesis.FirehoseDeliveryStreamKinesisSourceConfigurationArgs(
            kinesis_stream_arn="string",
            role_arn="string",
        ),
        destination_id="string",
        arn="string",
        msk_source_configuration=aws.kinesis.FirehoseDeliveryStreamMskSourceConfigurationArgs(
            authentication_configuration=aws.kinesis.FirehoseDeliveryStreamMskSourceConfigurationAuthenticationConfigurationArgs(
                connectivity="string",
                role_arn="string",
            ),
            msk_cluster_arn="string",
            topic_name="string",
        ),
        opensearchserverless_configuration=aws.kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationArgs(
            collection_endpoint="string",
            index_name="string",
            role_arn="string",
            s3_configuration=aws.kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationS3ConfigurationArgs(
                bucket_arn="string",
                role_arn="string",
                buffering_interval=0,
                buffering_size=0,
                cloudwatch_logging_options=aws.kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs(
                    enabled=False,
                    log_group_name="string",
                    log_stream_name="string",
                ),
                compression_format="string",
                error_output_prefix="string",
                kms_key_arn="string",
                prefix="string",
            ),
            buffering_interval=0,
            buffering_size=0,
            cloudwatch_logging_options=aws.kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationCloudwatchLoggingOptionsArgs(
                enabled=False,
                log_group_name="string",
                log_stream_name="string",
            ),
            processing_configuration=aws.kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationArgs(
                enabled=False,
                processors=[aws.kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorArgs(
                    type="string",
                    parameters=[aws.kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorParameterArgs(
                        parameter_name="string",
                        parameter_value="string",
                    )],
                )],
            ),
            retry_duration=0,
            s3_backup_mode="string",
            vpc_config=aws.kinesis.FirehoseDeliveryStreamOpensearchserverlessConfigurationVpcConfigArgs(
                role_arn="string",
                security_group_ids=["string"],
                subnet_ids=["string"],
                vpc_id="string",
            ),
        ),
        redshift_configuration=aws.kinesis.FirehoseDeliveryStreamRedshiftConfigurationArgs(
            role_arn="string",
            cluster_jdbcurl="string",
            username="string",
            s3_configuration=aws.kinesis.FirehoseDeliveryStreamRedshiftConfigurationS3ConfigurationArgs(
                bucket_arn="string",
                role_arn="string",
                buffering_interval=0,
                buffering_size=0,
                cloudwatch_logging_options=aws.kinesis.FirehoseDeliveryStreamRedshiftConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs(
                    enabled=False,
                    log_group_name="string",
                    log_stream_name="string",
                ),
                compression_format="string",
                error_output_prefix="string",
                kms_key_arn="string",
                prefix="string",
            ),
            data_table_name="string",
            password="string",
            processing_configuration=aws.kinesis.FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationArgs(
                enabled=False,
                processors=[aws.kinesis.FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationProcessorArgs(
                    type="string",
                    parameters=[aws.kinesis.FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationProcessorParameterArgs(
                        parameter_name="string",
                        parameter_value="string",
                    )],
                )],
            ),
            retry_duration=0,
            cloudwatch_logging_options=aws.kinesis.FirehoseDeliveryStreamRedshiftConfigurationCloudwatchLoggingOptionsArgs(
                enabled=False,
                log_group_name="string",
                log_stream_name="string",
            ),
            s3_backup_configuration=aws.kinesis.FirehoseDeliveryStreamRedshiftConfigurationS3BackupConfigurationArgs(
                bucket_arn="string",
                role_arn="string",
                buffering_interval=0,
                buffering_size=0,
                cloudwatch_logging_options=aws.kinesis.FirehoseDeliveryStreamRedshiftConfigurationS3BackupConfigurationCloudwatchLoggingOptionsArgs(
                    enabled=False,
                    log_group_name="string",
                    log_stream_name="string",
                ),
                compression_format="string",
                error_output_prefix="string",
                kms_key_arn="string",
                prefix="string",
            ),
            s3_backup_mode="string",
            data_table_columns="string",
            copy_options="string",
        ),
        server_side_encryption=aws.kinesis.FirehoseDeliveryStreamServerSideEncryptionArgs(
            enabled=False,
            key_arn="string",
            key_type="string",
        ),
        splunk_configuration=aws.kinesis.FirehoseDeliveryStreamSplunkConfigurationArgs(
            hec_endpoint="string",
            hec_token="string",
            s3_configuration=aws.kinesis.FirehoseDeliveryStreamSplunkConfigurationS3ConfigurationArgs(
                bucket_arn="string",
                role_arn="string",
                buffering_interval=0,
                buffering_size=0,
                cloudwatch_logging_options=aws.kinesis.FirehoseDeliveryStreamSplunkConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs(
                    enabled=False,
                    log_group_name="string",
                    log_stream_name="string",
                ),
                compression_format="string",
                error_output_prefix="string",
                kms_key_arn="string",
                prefix="string",
            ),
            buffering_interval=0,
            buffering_size=0,
            cloudwatch_logging_options=aws.kinesis.FirehoseDeliveryStreamSplunkConfigurationCloudwatchLoggingOptionsArgs(
                enabled=False,
                log_group_name="string",
                log_stream_name="string",
            ),
            hec_acknowledgment_timeout=0,
            hec_endpoint_type="string",
            processing_configuration=aws.kinesis.FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationArgs(
                enabled=False,
                processors=[aws.kinesis.FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationProcessorArgs(
                    type="string",
                    parameters=[aws.kinesis.FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationProcessorParameterArgs(
                        parameter_name="string",
                        parameter_value="string",
                    )],
                )],
            ),
            retry_duration=0,
            s3_backup_mode="string",
        ),
        tags={
            "string": "string",
        },
        version_id="string")
    
    const firehoseDeliveryStreamResource = new aws.kinesis.FirehoseDeliveryStream("firehoseDeliveryStreamResource", {
        destination: "string",
        name: "string",
        opensearchConfiguration: {
            indexName: "string",
            s3Configuration: {
                bucketArn: "string",
                roleArn: "string",
                bufferingInterval: 0,
                bufferingSize: 0,
                cloudwatchLoggingOptions: {
                    enabled: false,
                    logGroupName: "string",
                    logStreamName: "string",
                },
                compressionFormat: "string",
                errorOutputPrefix: "string",
                kmsKeyArn: "string",
                prefix: "string",
            },
            roleArn: "string",
            clusterEndpoint: "string",
            documentIdOptions: {
                defaultDocumentIdFormat: "string",
            },
            domainArn: "string",
            bufferingInterval: 0,
            indexRotationPeriod: "string",
            processingConfiguration: {
                enabled: false,
                processors: [{
                    type: "string",
                    parameters: [{
                        parameterName: "string",
                        parameterValue: "string",
                    }],
                }],
            },
            retryDuration: 0,
            cloudwatchLoggingOptions: {
                enabled: false,
                logGroupName: "string",
                logStreamName: "string",
            },
            s3BackupMode: "string",
            bufferingSize: 0,
            typeName: "string",
            vpcConfig: {
                roleArn: "string",
                securityGroupIds: ["string"],
                subnetIds: ["string"],
                vpcId: "string",
            },
        },
        elasticsearchConfiguration: {
            indexName: "string",
            s3Configuration: {
                bucketArn: "string",
                roleArn: "string",
                bufferingInterval: 0,
                bufferingSize: 0,
                cloudwatchLoggingOptions: {
                    enabled: false,
                    logGroupName: "string",
                    logStreamName: "string",
                },
                compressionFormat: "string",
                errorOutputPrefix: "string",
                kmsKeyArn: "string",
                prefix: "string",
            },
            roleArn: "string",
            clusterEndpoint: "string",
            domainArn: "string",
            bufferingInterval: 0,
            indexRotationPeriod: "string",
            processingConfiguration: {
                enabled: false,
                processors: [{
                    type: "string",
                    parameters: [{
                        parameterName: "string",
                        parameterValue: "string",
                    }],
                }],
            },
            retryDuration: 0,
            cloudwatchLoggingOptions: {
                enabled: false,
                logGroupName: "string",
                logStreamName: "string",
            },
            s3BackupMode: "string",
            bufferingSize: 0,
            typeName: "string",
            vpcConfig: {
                roleArn: "string",
                securityGroupIds: ["string"],
                subnetIds: ["string"],
                vpcId: "string",
            },
        },
        extendedS3Configuration: {
            bucketArn: "string",
            roleArn: "string",
            errorOutputPrefix: "string",
            fileExtension: "string",
            compressionFormat: "string",
            customTimeZone: "string",
            dataFormatConversionConfiguration: {
                inputFormatConfiguration: {
                    deserializer: {
                        hiveJsonSerDe: {
                            timestampFormats: ["string"],
                        },
                        openXJsonSerDe: {
                            caseInsensitive: false,
                            columnToJsonKeyMappings: {
                                string: "string",
                            },
                            convertDotsInJsonKeysToUnderscores: false,
                        },
                    },
                },
                outputFormatConfiguration: {
                    serializer: {
                        orcSerDe: {
                            blockSizeBytes: 0,
                            bloomFilterColumns: ["string"],
                            bloomFilterFalsePositiveProbability: 0,
                            compression: "string",
                            dictionaryKeyThreshold: 0,
                            enablePadding: false,
                            formatVersion: "string",
                            paddingTolerance: 0,
                            rowIndexStride: 0,
                            stripeSizeBytes: 0,
                        },
                        parquetSerDe: {
                            blockSizeBytes: 0,
                            compression: "string",
                            enableDictionaryCompression: false,
                            maxPaddingBytes: 0,
                            pageSizeBytes: 0,
                            writerVersion: "string",
                        },
                    },
                },
                schemaConfiguration: {
                    databaseName: "string",
                    roleArn: "string",
                    tableName: "string",
                    catalogId: "string",
                    region: "string",
                    versionId: "string",
                },
                enabled: false,
            },
            dynamicPartitioningConfiguration: {
                enabled: false,
                retryDuration: 0,
            },
            bufferingSize: 0,
            cloudwatchLoggingOptions: {
                enabled: false,
                logGroupName: "string",
                logStreamName: "string",
            },
            kmsKeyArn: "string",
            prefix: "string",
            processingConfiguration: {
                enabled: false,
                processors: [{
                    type: "string",
                    parameters: [{
                        parameterName: "string",
                        parameterValue: "string",
                    }],
                }],
            },
            bufferingInterval: 0,
            s3BackupConfiguration: {
                bucketArn: "string",
                roleArn: "string",
                bufferingInterval: 0,
                bufferingSize: 0,
                cloudwatchLoggingOptions: {
                    enabled: false,
                    logGroupName: "string",
                    logStreamName: "string",
                },
                compressionFormat: "string",
                errorOutputPrefix: "string",
                kmsKeyArn: "string",
                prefix: "string",
            },
            s3BackupMode: "string",
        },
        httpEndpointConfiguration: {
            s3Configuration: {
                bucketArn: "string",
                roleArn: "string",
                bufferingInterval: 0,
                bufferingSize: 0,
                cloudwatchLoggingOptions: {
                    enabled: false,
                    logGroupName: "string",
                    logStreamName: "string",
                },
                compressionFormat: "string",
                errorOutputPrefix: "string",
                kmsKeyArn: "string",
                prefix: "string",
            },
            url: "string",
            accessKey: "string",
            bufferingInterval: 0,
            bufferingSize: 0,
            cloudwatchLoggingOptions: {
                enabled: false,
                logGroupName: "string",
                logStreamName: "string",
            },
            name: "string",
            processingConfiguration: {
                enabled: false,
                processors: [{
                    type: "string",
                    parameters: [{
                        parameterName: "string",
                        parameterValue: "string",
                    }],
                }],
            },
            requestConfiguration: {
                commonAttributes: [{
                    name: "string",
                    value: "string",
                }],
                contentEncoding: "string",
            },
            retryDuration: 0,
            roleArn: "string",
            s3BackupMode: "string",
        },
        kinesisSourceConfiguration: {
            kinesisStreamArn: "string",
            roleArn: "string",
        },
        destinationId: "string",
        arn: "string",
        mskSourceConfiguration: {
            authenticationConfiguration: {
                connectivity: "string",
                roleArn: "string",
            },
            mskClusterArn: "string",
            topicName: "string",
        },
        opensearchserverlessConfiguration: {
            collectionEndpoint: "string",
            indexName: "string",
            roleArn: "string",
            s3Configuration: {
                bucketArn: "string",
                roleArn: "string",
                bufferingInterval: 0,
                bufferingSize: 0,
                cloudwatchLoggingOptions: {
                    enabled: false,
                    logGroupName: "string",
                    logStreamName: "string",
                },
                compressionFormat: "string",
                errorOutputPrefix: "string",
                kmsKeyArn: "string",
                prefix: "string",
            },
            bufferingInterval: 0,
            bufferingSize: 0,
            cloudwatchLoggingOptions: {
                enabled: false,
                logGroupName: "string",
                logStreamName: "string",
            },
            processingConfiguration: {
                enabled: false,
                processors: [{
                    type: "string",
                    parameters: [{
                        parameterName: "string",
                        parameterValue: "string",
                    }],
                }],
            },
            retryDuration: 0,
            s3BackupMode: "string",
            vpcConfig: {
                roleArn: "string",
                securityGroupIds: ["string"],
                subnetIds: ["string"],
                vpcId: "string",
            },
        },
        redshiftConfiguration: {
            roleArn: "string",
            clusterJdbcurl: "string",
            username: "string",
            s3Configuration: {
                bucketArn: "string",
                roleArn: "string",
                bufferingInterval: 0,
                bufferingSize: 0,
                cloudwatchLoggingOptions: {
                    enabled: false,
                    logGroupName: "string",
                    logStreamName: "string",
                },
                compressionFormat: "string",
                errorOutputPrefix: "string",
                kmsKeyArn: "string",
                prefix: "string",
            },
            dataTableName: "string",
            password: "string",
            processingConfiguration: {
                enabled: false,
                processors: [{
                    type: "string",
                    parameters: [{
                        parameterName: "string",
                        parameterValue: "string",
                    }],
                }],
            },
            retryDuration: 0,
            cloudwatchLoggingOptions: {
                enabled: false,
                logGroupName: "string",
                logStreamName: "string",
            },
            s3BackupConfiguration: {
                bucketArn: "string",
                roleArn: "string",
                bufferingInterval: 0,
                bufferingSize: 0,
                cloudwatchLoggingOptions: {
                    enabled: false,
                    logGroupName: "string",
                    logStreamName: "string",
                },
                compressionFormat: "string",
                errorOutputPrefix: "string",
                kmsKeyArn: "string",
                prefix: "string",
            },
            s3BackupMode: "string",
            dataTableColumns: "string",
            copyOptions: "string",
        },
        serverSideEncryption: {
            enabled: false,
            keyArn: "string",
            keyType: "string",
        },
        splunkConfiguration: {
            hecEndpoint: "string",
            hecToken: "string",
            s3Configuration: {
                bucketArn: "string",
                roleArn: "string",
                bufferingInterval: 0,
                bufferingSize: 0,
                cloudwatchLoggingOptions: {
                    enabled: false,
                    logGroupName: "string",
                    logStreamName: "string",
                },
                compressionFormat: "string",
                errorOutputPrefix: "string",
                kmsKeyArn: "string",
                prefix: "string",
            },
            bufferingInterval: 0,
            bufferingSize: 0,
            cloudwatchLoggingOptions: {
                enabled: false,
                logGroupName: "string",
                logStreamName: "string",
            },
            hecAcknowledgmentTimeout: 0,
            hecEndpointType: "string",
            processingConfiguration: {
                enabled: false,
                processors: [{
                    type: "string",
                    parameters: [{
                        parameterName: "string",
                        parameterValue: "string",
                    }],
                }],
            },
            retryDuration: 0,
            s3BackupMode: "string",
        },
        tags: {
            string: "string",
        },
        versionId: "string",
    });
    
    type: aws:kinesis:FirehoseDeliveryStream
    properties:
        arn: string
        destination: string
        destinationId: string
        elasticsearchConfiguration:
            bufferingInterval: 0
            bufferingSize: 0
            cloudwatchLoggingOptions:
                enabled: false
                logGroupName: string
                logStreamName: string
            clusterEndpoint: string
            domainArn: string
            indexName: string
            indexRotationPeriod: string
            processingConfiguration:
                enabled: false
                processors:
                    - parameters:
                        - parameterName: string
                          parameterValue: string
                      type: string
            retryDuration: 0
            roleArn: string
            s3BackupMode: string
            s3Configuration:
                bucketArn: string
                bufferingInterval: 0
                bufferingSize: 0
                cloudwatchLoggingOptions:
                    enabled: false
                    logGroupName: string
                    logStreamName: string
                compressionFormat: string
                errorOutputPrefix: string
                kmsKeyArn: string
                prefix: string
                roleArn: string
            typeName: string
            vpcConfig:
                roleArn: string
                securityGroupIds:
                    - string
                subnetIds:
                    - string
                vpcId: string
        extendedS3Configuration:
            bucketArn: string
            bufferingInterval: 0
            bufferingSize: 0
            cloudwatchLoggingOptions:
                enabled: false
                logGroupName: string
                logStreamName: string
            compressionFormat: string
            customTimeZone: string
            dataFormatConversionConfiguration:
                enabled: false
                inputFormatConfiguration:
                    deserializer:
                        hiveJsonSerDe:
                            timestampFormats:
                                - string
                        openXJsonSerDe:
                            caseInsensitive: false
                            columnToJsonKeyMappings:
                                string: string
                            convertDotsInJsonKeysToUnderscores: false
                outputFormatConfiguration:
                    serializer:
                        orcSerDe:
                            blockSizeBytes: 0
                            bloomFilterColumns:
                                - string
                            bloomFilterFalsePositiveProbability: 0
                            compression: string
                            dictionaryKeyThreshold: 0
                            enablePadding: false
                            formatVersion: string
                            paddingTolerance: 0
                            rowIndexStride: 0
                            stripeSizeBytes: 0
                        parquetSerDe:
                            blockSizeBytes: 0
                            compression: string
                            enableDictionaryCompression: false
                            maxPaddingBytes: 0
                            pageSizeBytes: 0
                            writerVersion: string
                schemaConfiguration:
                    catalogId: string
                    databaseName: string
                    region: string
                    roleArn: string
                    tableName: string
                    versionId: string
            dynamicPartitioningConfiguration:
                enabled: false
                retryDuration: 0
            errorOutputPrefix: string
            fileExtension: string
            kmsKeyArn: string
            prefix: string
            processingConfiguration:
                enabled: false
                processors:
                    - parameters:
                        - parameterName: string
                          parameterValue: string
                      type: string
            roleArn: string
            s3BackupConfiguration:
                bucketArn: string
                bufferingInterval: 0
                bufferingSize: 0
                cloudwatchLoggingOptions:
                    enabled: false
                    logGroupName: string
                    logStreamName: string
                compressionFormat: string
                errorOutputPrefix: string
                kmsKeyArn: string
                prefix: string
                roleArn: string
            s3BackupMode: string
        httpEndpointConfiguration:
            accessKey: string
            bufferingInterval: 0
            bufferingSize: 0
            cloudwatchLoggingOptions:
                enabled: false
                logGroupName: string
                logStreamName: string
            name: string
            processingConfiguration:
                enabled: false
                processors:
                    - parameters:
                        - parameterName: string
                          parameterValue: string
                      type: string
            requestConfiguration:
                commonAttributes:
                    - name: string
                      value: string
                contentEncoding: string
            retryDuration: 0
            roleArn: string
            s3BackupMode: string
            s3Configuration:
                bucketArn: string
                bufferingInterval: 0
                bufferingSize: 0
                cloudwatchLoggingOptions:
                    enabled: false
                    logGroupName: string
                    logStreamName: string
                compressionFormat: string
                errorOutputPrefix: string
                kmsKeyArn: string
                prefix: string
                roleArn: string
            url: string
        kinesisSourceConfiguration:
            kinesisStreamArn: string
            roleArn: string
        mskSourceConfiguration:
            authenticationConfiguration:
                connectivity: string
                roleArn: string
            mskClusterArn: string
            topicName: string
        name: string
        opensearchConfiguration:
            bufferingInterval: 0
            bufferingSize: 0
            cloudwatchLoggingOptions:
                enabled: false
                logGroupName: string
                logStreamName: string
            clusterEndpoint: string
            documentIdOptions:
                defaultDocumentIdFormat: string
            domainArn: string
            indexName: string
            indexRotationPeriod: string
            processingConfiguration:
                enabled: false
                processors:
                    - parameters:
                        - parameterName: string
                          parameterValue: string
                      type: string
            retryDuration: 0
            roleArn: string
            s3BackupMode: string
            s3Configuration:
                bucketArn: string
                bufferingInterval: 0
                bufferingSize: 0
                cloudwatchLoggingOptions:
                    enabled: false
                    logGroupName: string
                    logStreamName: string
                compressionFormat: string
                errorOutputPrefix: string
                kmsKeyArn: string
                prefix: string
                roleArn: string
            typeName: string
            vpcConfig:
                roleArn: string
                securityGroupIds:
                    - string
                subnetIds:
                    - string
                vpcId: string
        opensearchserverlessConfiguration:
            bufferingInterval: 0
            bufferingSize: 0
            cloudwatchLoggingOptions:
                enabled: false
                logGroupName: string
                logStreamName: string
            collectionEndpoint: string
            indexName: string
            processingConfiguration:
                enabled: false
                processors:
                    - parameters:
                        - parameterName: string
                          parameterValue: string
                      type: string
            retryDuration: 0
            roleArn: string
            s3BackupMode: string
            s3Configuration:
                bucketArn: string
                bufferingInterval: 0
                bufferingSize: 0
                cloudwatchLoggingOptions:
                    enabled: false
                    logGroupName: string
                    logStreamName: string
                compressionFormat: string
                errorOutputPrefix: string
                kmsKeyArn: string
                prefix: string
                roleArn: string
            vpcConfig:
                roleArn: string
                securityGroupIds:
                    - string
                subnetIds:
                    - string
                vpcId: string
        redshiftConfiguration:
            cloudwatchLoggingOptions:
                enabled: false
                logGroupName: string
                logStreamName: string
            clusterJdbcurl: string
            copyOptions: string
            dataTableColumns: string
            dataTableName: string
            password: string
            processingConfiguration:
                enabled: false
                processors:
                    - parameters:
                        - parameterName: string
                          parameterValue: string
                      type: string
            retryDuration: 0
            roleArn: string
            s3BackupConfiguration:
                bucketArn: string
                bufferingInterval: 0
                bufferingSize: 0
                cloudwatchLoggingOptions:
                    enabled: false
                    logGroupName: string
                    logStreamName: string
                compressionFormat: string
                errorOutputPrefix: string
                kmsKeyArn: string
                prefix: string
                roleArn: string
            s3BackupMode: string
            s3Configuration:
                bucketArn: string
                bufferingInterval: 0
                bufferingSize: 0
                cloudwatchLoggingOptions:
                    enabled: false
                    logGroupName: string
                    logStreamName: string
                compressionFormat: string
                errorOutputPrefix: string
                kmsKeyArn: string
                prefix: string
                roleArn: string
            username: string
        serverSideEncryption:
            enabled: false
            keyArn: string
            keyType: string
        splunkConfiguration:
            bufferingInterval: 0
            bufferingSize: 0
            cloudwatchLoggingOptions:
                enabled: false
                logGroupName: string
                logStreamName: string
            hecAcknowledgmentTimeout: 0
            hecEndpoint: string
            hecEndpointType: string
            hecToken: string
            processingConfiguration:
                enabled: false
                processors:
                    - parameters:
                        - parameterName: string
                          parameterValue: string
                      type: string
            retryDuration: 0
            s3BackupMode: string
            s3Configuration:
                bucketArn: string
                bufferingInterval: 0
                bufferingSize: 0
                cloudwatchLoggingOptions:
                    enabled: false
                    logGroupName: string
                    logStreamName: string
                compressionFormat: string
                errorOutputPrefix: string
                kmsKeyArn: string
                prefix: string
                roleArn: string
        tags:
            string: string
        versionId: string
    

    FirehoseDeliveryStream Resource Properties

    To learn more about resource properties and how to use them, see Inputs and Outputs in the Architecture and Concepts docs.

    Inputs

    The FirehoseDeliveryStream resource accepts the following input properties:

    Destination string
    This is the destination to where the data is delivered. The only options are s3 (Deprecated, use extended_s3 instead), extended_s3, redshift, elasticsearch, splunk, http_endpoint, opensearch and opensearchserverless.
    Arn string
    The Amazon Resource Name (ARN) specifying the Stream
    DestinationId string
    ElasticsearchConfiguration FirehoseDeliveryStreamElasticsearchConfiguration
    Configuration options when destination is elasticsearch. See elasticsearch_configuration block below for details.
    ExtendedS3Configuration FirehoseDeliveryStreamExtendedS3Configuration
    Enhanced configuration options for the s3 destination. See extended_s3_configuration block below for details.
    HttpEndpointConfiguration FirehoseDeliveryStreamHttpEndpointConfiguration
    Configuration options when destination is http_endpoint. Requires the user to also specify an s3_configuration block. See http_endpoint_configuration block below for details.
    KinesisSourceConfiguration FirehoseDeliveryStreamKinesisSourceConfiguration
    The stream and role Amazon Resource Names (ARNs) for a Kinesis data stream used as the source for a delivery stream. See kinesis_source_configuration block below for details.
    MskSourceConfiguration FirehoseDeliveryStreamMskSourceConfiguration
    The configuration for the Amazon MSK cluster to be used as the source for a delivery stream. See msk_source_configuration block below for details.
    Name string
    A name to identify the stream. This is unique to the AWS account and region the Stream is created in. When using for WAF logging, name must be prefixed with aws-waf-logs-. See AWS Documentation for more details.
    OpensearchConfiguration FirehoseDeliveryStreamOpensearchConfiguration
    Configuration options when destination is opensearch. See opensearch_configuration block below for details.
    OpensearchserverlessConfiguration FirehoseDeliveryStreamOpensearchserverlessConfiguration
    Configuration options when destination is opensearchserverless. See opensearchserverless_configuration block below for details.
    RedshiftConfiguration FirehoseDeliveryStreamRedshiftConfiguration
    Configuration options when destination is redshift. Requires the user to also specify an s3_configuration block. See redshift_configuration block below for details.
    ServerSideEncryption FirehoseDeliveryStreamServerSideEncryption

    Encrypt at rest options. See server_side_encryption block below for details.

    NOTE: Server-side encryption should not be enabled when a kinesis stream is configured as the source of the firehose delivery stream.

    SplunkConfiguration FirehoseDeliveryStreamSplunkConfiguration
    Configuration options when destination is splunk. See splunk_configuration block below for details.
    Tags Dictionary<string, string>
    A map of tags to assign to the resource. If configured with a provider default_tags configuration block present, tags with matching keys will overwrite those defined at the provider-level.
    VersionId string
    Specifies the table version for the output data schema. Defaults to LATEST.
    Destination string
    This is the destination to where the data is delivered. The only options are s3 (Deprecated, use extended_s3 instead), extended_s3, redshift, elasticsearch, splunk, http_endpoint, opensearch and opensearchserverless.
    Arn string
    The Amazon Resource Name (ARN) specifying the Stream
    DestinationId string
    ElasticsearchConfiguration FirehoseDeliveryStreamElasticsearchConfigurationArgs
    Configuration options when destination is elasticsearch. See elasticsearch_configuration block below for details.
    ExtendedS3Configuration FirehoseDeliveryStreamExtendedS3ConfigurationArgs
    Enhanced configuration options for the s3 destination. See extended_s3_configuration block below for details.
    HttpEndpointConfiguration FirehoseDeliveryStreamHttpEndpointConfigurationArgs
    Configuration options when destination is http_endpoint. Requires the user to also specify an s3_configuration block. See http_endpoint_configuration block below for details.
    KinesisSourceConfiguration FirehoseDeliveryStreamKinesisSourceConfigurationArgs
    The stream and role Amazon Resource Names (ARNs) for a Kinesis data stream used as the source for a delivery stream. See kinesis_source_configuration block below for details.
    MskSourceConfiguration FirehoseDeliveryStreamMskSourceConfigurationArgs
    The configuration for the Amazon MSK cluster to be used as the source for a delivery stream. See msk_source_configuration block below for details.
    Name string
    A name to identify the stream. This is unique to the AWS account and region the Stream is created in. When using for WAF logging, name must be prefixed with aws-waf-logs-. See AWS Documentation for more details.
    OpensearchConfiguration FirehoseDeliveryStreamOpensearchConfigurationArgs
    Configuration options when destination is opensearch. See opensearch_configuration block below for details.
    OpensearchserverlessConfiguration FirehoseDeliveryStreamOpensearchserverlessConfigurationArgs
    Configuration options when destination is opensearchserverless. See opensearchserverless_configuration block below for details.
    RedshiftConfiguration FirehoseDeliveryStreamRedshiftConfigurationArgs
    Configuration options when destination is redshift. Requires the user to also specify an s3_configuration block. See redshift_configuration block below for details.
    ServerSideEncryption FirehoseDeliveryStreamServerSideEncryptionArgs

    Encrypt at rest options. See server_side_encryption block below for details.

    NOTE: Server-side encryption should not be enabled when a kinesis stream is configured as the source of the firehose delivery stream.

    SplunkConfiguration FirehoseDeliveryStreamSplunkConfigurationArgs
    Configuration options when destination is splunk. See splunk_configuration block below for details.
    Tags map[string]string
    A map of tags to assign to the resource. If configured with a provider default_tags configuration block present, tags with matching keys will overwrite those defined at the provider-level.
    VersionId string
    Specifies the table version for the output data schema. Defaults to LATEST.
    destination String
    This is the destination to where the data is delivered. The only options are s3 (Deprecated, use extended_s3 instead), extended_s3, redshift, elasticsearch, splunk, http_endpoint, opensearch and opensearchserverless.
    arn String
    The Amazon Resource Name (ARN) specifying the Stream
    destinationId String
    elasticsearchConfiguration FirehoseDeliveryStreamElasticsearchConfiguration
    Configuration options when destination is elasticsearch. See elasticsearch_configuration block below for details.
    extendedS3Configuration FirehoseDeliveryStreamExtendedS3Configuration
    Enhanced configuration options for the s3 destination. See extended_s3_configuration block below for details.
    httpEndpointConfiguration FirehoseDeliveryStreamHttpEndpointConfiguration
    Configuration options when destination is http_endpoint. Requires the user to also specify an s3_configuration block. See http_endpoint_configuration block below for details.
    kinesisSourceConfiguration FirehoseDeliveryStreamKinesisSourceConfiguration
    The stream and role Amazon Resource Names (ARNs) for a Kinesis data stream used as the source for a delivery stream. See kinesis_source_configuration block below for details.
    mskSourceConfiguration FirehoseDeliveryStreamMskSourceConfiguration
    The configuration for the Amazon MSK cluster to be used as the source for a delivery stream. See msk_source_configuration block below for details.
    name String
    A name to identify the stream. This is unique to the AWS account and region the Stream is created in. When using for WAF logging, name must be prefixed with aws-waf-logs-. See AWS Documentation for more details.
    opensearchConfiguration FirehoseDeliveryStreamOpensearchConfiguration
    Configuration options when destination is opensearch. See opensearch_configuration block below for details.
    opensearchserverlessConfiguration FirehoseDeliveryStreamOpensearchserverlessConfiguration
    Configuration options when destination is opensearchserverless. See opensearchserverless_configuration block below for details.
    redshiftConfiguration FirehoseDeliveryStreamRedshiftConfiguration
    Configuration options when destination is redshift. Requires the user to also specify an s3_configuration block. See redshift_configuration block below for details.
    serverSideEncryption FirehoseDeliveryStreamServerSideEncryption

    Encrypt at rest options. See server_side_encryption block below for details.

    NOTE: Server-side encryption should not be enabled when a kinesis stream is configured as the source of the firehose delivery stream.

    splunkConfiguration FirehoseDeliveryStreamSplunkConfiguration
    Configuration options when destination is splunk. See splunk_configuration block below for details.
    tags Map<String,String>
    A map of tags to assign to the resource. If configured with a provider default_tags configuration block present, tags with matching keys will overwrite those defined at the provider-level.
    versionId String
    Specifies the table version for the output data schema. Defaults to LATEST.
    destination string
    This is the destination to where the data is delivered. The only options are s3 (Deprecated, use extended_s3 instead), extended_s3, redshift, elasticsearch, splunk, http_endpoint, opensearch and opensearchserverless.
    arn string
    The Amazon Resource Name (ARN) specifying the Stream
    destinationId string
    elasticsearchConfiguration FirehoseDeliveryStreamElasticsearchConfiguration
    Configuration options when destination is elasticsearch. See elasticsearch_configuration block below for details.
    extendedS3Configuration FirehoseDeliveryStreamExtendedS3Configuration
    Enhanced configuration options for the s3 destination. See extended_s3_configuration block below for details.
    httpEndpointConfiguration FirehoseDeliveryStreamHttpEndpointConfiguration
    Configuration options when destination is http_endpoint. Requires the user to also specify an s3_configuration block. See http_endpoint_configuration block below for details.
    kinesisSourceConfiguration FirehoseDeliveryStreamKinesisSourceConfiguration
    The stream and role Amazon Resource Names (ARNs) for a Kinesis data stream used as the source for a delivery stream. See kinesis_source_configuration block below for details.
    mskSourceConfiguration FirehoseDeliveryStreamMskSourceConfiguration
    The configuration for the Amazon MSK cluster to be used as the source for a delivery stream. See msk_source_configuration block below for details.
    name string
    A name to identify the stream. This is unique to the AWS account and region the Stream is created in. When using for WAF logging, name must be prefixed with aws-waf-logs-. See AWS Documentation for more details.
    opensearchConfiguration FirehoseDeliveryStreamOpensearchConfiguration
    Configuration options when destination is opensearch. See opensearch_configuration block below for details.
    opensearchserverlessConfiguration FirehoseDeliveryStreamOpensearchserverlessConfiguration
    Configuration options when destination is opensearchserverless. See opensearchserverless_configuration block below for details.
    redshiftConfiguration FirehoseDeliveryStreamRedshiftConfiguration
    Configuration options when destination is redshift. Requires the user to also specify an s3_configuration block. See redshift_configuration block below for details.
    serverSideEncryption FirehoseDeliveryStreamServerSideEncryption

    Encrypt at rest options. See server_side_encryption block below for details.

    NOTE: Server-side encryption should not be enabled when a kinesis stream is configured as the source of the firehose delivery stream.

    splunkConfiguration FirehoseDeliveryStreamSplunkConfiguration
    Configuration options when destination is splunk. See splunk_configuration block below for details.
    tags {[key: string]: string}
    A map of tags to assign to the resource. If configured with a provider default_tags configuration block present, tags with matching keys will overwrite those defined at the provider-level.
    versionId string
    Specifies the table version for the output data schema. Defaults to LATEST.
    destination str
    This is the destination to where the data is delivered. The only options are s3 (Deprecated, use extended_s3 instead), extended_s3, redshift, elasticsearch, splunk, http_endpoint, opensearch and opensearchserverless.
    arn str
    The Amazon Resource Name (ARN) specifying the Stream
    destination_id str
    elasticsearch_configuration FirehoseDeliveryStreamElasticsearchConfigurationArgs
    Configuration options when destination is elasticsearch. See elasticsearch_configuration block below for details.
    extended_s3_configuration FirehoseDeliveryStreamExtendedS3ConfigurationArgs
    Enhanced configuration options for the s3 destination. See extended_s3_configuration block below for details.
    http_endpoint_configuration FirehoseDeliveryStreamHttpEndpointConfigurationArgs
    Configuration options when destination is http_endpoint. Requires the user to also specify an s3_configuration block. See http_endpoint_configuration block below for details.
    kinesis_source_configuration FirehoseDeliveryStreamKinesisSourceConfigurationArgs
    The stream and role Amazon Resource Names (ARNs) for a Kinesis data stream used as the source for a delivery stream. See kinesis_source_configuration block below for details.
    msk_source_configuration FirehoseDeliveryStreamMskSourceConfigurationArgs
    The configuration for the Amazon MSK cluster to be used as the source for a delivery stream. See msk_source_configuration block below for details.
    name str
    A name to identify the stream. This is unique to the AWS account and region the Stream is created in. When using for WAF logging, name must be prefixed with aws-waf-logs-. See AWS Documentation for more details.
    opensearch_configuration FirehoseDeliveryStreamOpensearchConfigurationArgs
    Configuration options when destination is opensearch. See opensearch_configuration block below for details.
    opensearchserverless_configuration FirehoseDeliveryStreamOpensearchserverlessConfigurationArgs
    Configuration options when destination is opensearchserverless. See opensearchserverless_configuration block below for details.
    redshift_configuration FirehoseDeliveryStreamRedshiftConfigurationArgs
    Configuration options when destination is redshift. Requires the user to also specify an s3_configuration block. See redshift_configuration block below for details.
    server_side_encryption FirehoseDeliveryStreamServerSideEncryptionArgs

    Encrypt at rest options. See server_side_encryption block below for details.

    NOTE: Server-side encryption should not be enabled when a kinesis stream is configured as the source of the firehose delivery stream.

    splunk_configuration FirehoseDeliveryStreamSplunkConfigurationArgs
    Configuration options when destination is splunk. See splunk_configuration block below for details.
    tags Mapping[str, str]
    A map of tags to assign to the resource. If configured with a provider default_tags configuration block present, tags with matching keys will overwrite those defined at the provider-level.
    version_id str
    Specifies the table version for the output data schema. Defaults to LATEST.
    destination String
    This is the destination to where the data is delivered. The only options are s3 (Deprecated, use extended_s3 instead), extended_s3, redshift, elasticsearch, splunk, http_endpoint, opensearch and opensearchserverless.
    arn String
    The Amazon Resource Name (ARN) specifying the Stream
    destinationId String
    elasticsearchConfiguration Property Map
    Configuration options when destination is elasticsearch. See elasticsearch_configuration block below for details.
    extendedS3Configuration Property Map
    Enhanced configuration options for the s3 destination. See extended_s3_configuration block below for details.
    httpEndpointConfiguration Property Map
    Configuration options when destination is http_endpoint. Requires the user to also specify an s3_configuration block. See http_endpoint_configuration block below for details.
    kinesisSourceConfiguration Property Map
    The stream and role Amazon Resource Names (ARNs) for a Kinesis data stream used as the source for a delivery stream. See kinesis_source_configuration block below for details.
    mskSourceConfiguration Property Map
    The configuration for the Amazon MSK cluster to be used as the source for a delivery stream. See msk_source_configuration block below for details.
    name String
    A name to identify the stream. This is unique to the AWS account and region the Stream is created in. When using for WAF logging, name must be prefixed with aws-waf-logs-. See AWS Documentation for more details.
    opensearchConfiguration Property Map
    Configuration options when destination is opensearch. See opensearch_configuration block below for details.
    opensearchserverlessConfiguration Property Map
    Configuration options when destination is opensearchserverless. See opensearchserverless_configuration block below for details.
    redshiftConfiguration Property Map
    Configuration options when destination is redshift. Requires the user to also specify an s3_configuration block. See redshift_configuration block below for details.
    serverSideEncryption Property Map

    Encrypt at rest options. See server_side_encryption block below for details.

    NOTE: Server-side encryption should not be enabled when a kinesis stream is configured as the source of the firehose delivery stream.

    splunkConfiguration Property Map
    Configuration options when destination is splunk. See splunk_configuration block below for details.
    tags Map<String>
    A map of tags to assign to the resource. If configured with a provider default_tags configuration block present, tags with matching keys will overwrite those defined at the provider-level.
    versionId String
    Specifies the table version for the output data schema. Defaults to LATEST.

    Outputs

    All input properties are implicitly available as output properties. Additionally, the FirehoseDeliveryStream resource produces the following output properties:

    Id string
    The provider-assigned unique ID for this managed resource.
    TagsAll Dictionary<string, string>
    A map of tags assigned to the resource, including those inherited from the provider default_tags configuration block.

    Deprecated: Please use tags instead.

    Id string
    The provider-assigned unique ID for this managed resource.
    TagsAll map[string]string
    A map of tags assigned to the resource, including those inherited from the provider default_tags configuration block.

    Deprecated: Please use tags instead.

    id String
    The provider-assigned unique ID for this managed resource.
    tagsAll Map<String,String>
    A map of tags assigned to the resource, including those inherited from the provider default_tags configuration block.

    Deprecated: Please use tags instead.

    id string
    The provider-assigned unique ID for this managed resource.
    tagsAll {[key: string]: string}
    A map of tags assigned to the resource, including those inherited from the provider default_tags configuration block.

    Deprecated: Please use tags instead.

    id str
    The provider-assigned unique ID for this managed resource.
    tags_all Mapping[str, str]
    A map of tags assigned to the resource, including those inherited from the provider default_tags configuration block.

    Deprecated: Please use tags instead.

    id String
    The provider-assigned unique ID for this managed resource.
    tagsAll Map<String>
    A map of tags assigned to the resource, including those inherited from the provider default_tags configuration block.

    Deprecated: Please use tags instead.

    Look up Existing FirehoseDeliveryStream Resource

    Get an existing FirehoseDeliveryStream resource’s state with the given name, ID, and optional extra properties used to qualify the lookup.

    public static get(name: string, id: Input<ID>, state?: FirehoseDeliveryStreamState, opts?: CustomResourceOptions): FirehoseDeliveryStream
    @staticmethod
    def get(resource_name: str,
            id: str,
            opts: Optional[ResourceOptions] = None,
            arn: Optional[str] = None,
            destination: Optional[str] = None,
            destination_id: Optional[str] = None,
            elasticsearch_configuration: Optional[FirehoseDeliveryStreamElasticsearchConfigurationArgs] = None,
            extended_s3_configuration: Optional[FirehoseDeliveryStreamExtendedS3ConfigurationArgs] = None,
            http_endpoint_configuration: Optional[FirehoseDeliveryStreamHttpEndpointConfigurationArgs] = None,
            kinesis_source_configuration: Optional[FirehoseDeliveryStreamKinesisSourceConfigurationArgs] = None,
            msk_source_configuration: Optional[FirehoseDeliveryStreamMskSourceConfigurationArgs] = None,
            name: Optional[str] = None,
            opensearch_configuration: Optional[FirehoseDeliveryStreamOpensearchConfigurationArgs] = None,
            opensearchserverless_configuration: Optional[FirehoseDeliveryStreamOpensearchserverlessConfigurationArgs] = None,
            redshift_configuration: Optional[FirehoseDeliveryStreamRedshiftConfigurationArgs] = None,
            server_side_encryption: Optional[FirehoseDeliveryStreamServerSideEncryptionArgs] = None,
            splunk_configuration: Optional[FirehoseDeliveryStreamSplunkConfigurationArgs] = None,
            tags: Optional[Mapping[str, str]] = None,
            tags_all: Optional[Mapping[str, str]] = None,
            version_id: Optional[str] = None) -> FirehoseDeliveryStream
    func GetFirehoseDeliveryStream(ctx *Context, name string, id IDInput, state *FirehoseDeliveryStreamState, opts ...ResourceOption) (*FirehoseDeliveryStream, error)
    public static FirehoseDeliveryStream Get(string name, Input<string> id, FirehoseDeliveryStreamState? state, CustomResourceOptions? opts = null)
    public static FirehoseDeliveryStream get(String name, Output<String> id, FirehoseDeliveryStreamState state, CustomResourceOptions options)
    Resource lookup is not supported in YAML
    name
    The unique name of the resulting resource.
    id
    The unique provider ID of the resource to lookup.
    state
    Any extra arguments used during the lookup.
    opts
    A bag of options that control this resource's behavior.
    resource_name
    The unique name of the resulting resource.
    id
    The unique provider ID of the resource to lookup.
    name
    The unique name of the resulting resource.
    id
    The unique provider ID of the resource to lookup.
    state
    Any extra arguments used during the lookup.
    opts
    A bag of options that control this resource's behavior.
    name
    The unique name of the resulting resource.
    id
    The unique provider ID of the resource to lookup.
    state
    Any extra arguments used during the lookup.
    opts
    A bag of options that control this resource's behavior.
    name
    The unique name of the resulting resource.
    id
    The unique provider ID of the resource to lookup.
    state
    Any extra arguments used during the lookup.
    opts
    A bag of options that control this resource's behavior.
    The following state arguments are supported:
    Arn string
    The Amazon Resource Name (ARN) specifying the Stream
    Destination string
    This is the destination to where the data is delivered. The only options are s3 (Deprecated, use extended_s3 instead), extended_s3, redshift, elasticsearch, splunk, http_endpoint, opensearch and opensearchserverless.
    DestinationId string
    ElasticsearchConfiguration FirehoseDeliveryStreamElasticsearchConfiguration
    Configuration options when destination is elasticsearch. See elasticsearch_configuration block below for details.
    ExtendedS3Configuration FirehoseDeliveryStreamExtendedS3Configuration
    Enhanced configuration options for the s3 destination. See extended_s3_configuration block below for details.
    HttpEndpointConfiguration FirehoseDeliveryStreamHttpEndpointConfiguration
    Configuration options when destination is http_endpoint. Requires the user to also specify an s3_configuration block. See http_endpoint_configuration block below for details.
    KinesisSourceConfiguration FirehoseDeliveryStreamKinesisSourceConfiguration
    The stream and role Amazon Resource Names (ARNs) for a Kinesis data stream used as the source for a delivery stream. See kinesis_source_configuration block below for details.
    MskSourceConfiguration FirehoseDeliveryStreamMskSourceConfiguration
    The configuration for the Amazon MSK cluster to be used as the source for a delivery stream. See msk_source_configuration block below for details.
    Name string
    A name to identify the stream. This is unique to the AWS account and region the Stream is created in. When using for WAF logging, name must be prefixed with aws-waf-logs-. See AWS Documentation for more details.
    OpensearchConfiguration FirehoseDeliveryStreamOpensearchConfiguration
    Configuration options when destination is opensearch. See opensearch_configuration block below for details.
    OpensearchserverlessConfiguration FirehoseDeliveryStreamOpensearchserverlessConfiguration
    Configuration options when destination is opensearchserverless. See opensearchserverless_configuration block below for details.
    RedshiftConfiguration FirehoseDeliveryStreamRedshiftConfiguration
    Configuration options when destination is redshift. Requires the user to also specify an s3_configuration block. See redshift_configuration block below for details.
    ServerSideEncryption FirehoseDeliveryStreamServerSideEncryption

    Encrypt at rest options. See server_side_encryption block below for details.

    NOTE: Server-side encryption should not be enabled when a kinesis stream is configured as the source of the firehose delivery stream.

    SplunkConfiguration FirehoseDeliveryStreamSplunkConfiguration
    Configuration options when destination is splunk. See splunk_configuration block below for details.
    Tags Dictionary<string, string>
    A map of tags to assign to the resource. If configured with a provider default_tags configuration block present, tags with matching keys will overwrite those defined at the provider-level.
    TagsAll Dictionary<string, string>
    A map of tags assigned to the resource, including those inherited from the provider default_tags configuration block.

    Deprecated: Please use tags instead.

    VersionId string
    Specifies the table version for the output data schema. Defaults to LATEST.
    Arn string
    The Amazon Resource Name (ARN) specifying the Stream
    Destination string
    This is the destination to where the data is delivered. The only options are s3 (Deprecated, use extended_s3 instead), extended_s3, redshift, elasticsearch, splunk, http_endpoint, opensearch and opensearchserverless.
    DestinationId string
    ElasticsearchConfiguration FirehoseDeliveryStreamElasticsearchConfigurationArgs
    Configuration options when destination is elasticsearch. See elasticsearch_configuration block below for details.
    ExtendedS3Configuration FirehoseDeliveryStreamExtendedS3ConfigurationArgs
    Enhanced configuration options for the s3 destination. See extended_s3_configuration block below for details.
    HttpEndpointConfiguration FirehoseDeliveryStreamHttpEndpointConfigurationArgs
    Configuration options when destination is http_endpoint. Requires the user to also specify an s3_configuration block. See http_endpoint_configuration block below for details.
    KinesisSourceConfiguration FirehoseDeliveryStreamKinesisSourceConfigurationArgs
    The stream and role Amazon Resource Names (ARNs) for a Kinesis data stream used as the source for a delivery stream. See kinesis_source_configuration block below for details.
    MskSourceConfiguration FirehoseDeliveryStreamMskSourceConfigurationArgs
    The configuration for the Amazon MSK cluster to be used as the source for a delivery stream. See msk_source_configuration block below for details.
    Name string
    A name to identify the stream. This is unique to the AWS account and region the Stream is created in. When using for WAF logging, name must be prefixed with aws-waf-logs-. See AWS Documentation for more details.
    OpensearchConfiguration FirehoseDeliveryStreamOpensearchConfigurationArgs
    Configuration options when destination is opensearch. See opensearch_configuration block below for details.
    OpensearchserverlessConfiguration FirehoseDeliveryStreamOpensearchserverlessConfigurationArgs
    Configuration options when destination is opensearchserverless. See opensearchserverless_configuration block below for details.
    RedshiftConfiguration FirehoseDeliveryStreamRedshiftConfigurationArgs
    Configuration options when destination is redshift. Requires the user to also specify an s3_configuration block. See redshift_configuration block below for details.
    ServerSideEncryption FirehoseDeliveryStreamServerSideEncryptionArgs

    Encrypt at rest options. See server_side_encryption block below for details.

    NOTE: Server-side encryption should not be enabled when a kinesis stream is configured as the source of the firehose delivery stream.

    SplunkConfiguration FirehoseDeliveryStreamSplunkConfigurationArgs
    Configuration options when destination is splunk. See splunk_configuration block below for details.
    Tags map[string]string
    A map of tags to assign to the resource. If configured with a provider default_tags configuration block present, tags with matching keys will overwrite those defined at the provider-level.
    TagsAll map[string]string
    A map of tags assigned to the resource, including those inherited from the provider default_tags configuration block.

    Deprecated: Please use tags instead.

    VersionId string
    Specifies the table version for the output data schema. Defaults to LATEST.
    arn String
    The Amazon Resource Name (ARN) specifying the Stream
    destination String
    This is the destination to where the data is delivered. The only options are s3 (Deprecated, use extended_s3 instead), extended_s3, redshift, elasticsearch, splunk, http_endpoint, opensearch and opensearchserverless.
    destinationId String
    elasticsearchConfiguration FirehoseDeliveryStreamElasticsearchConfiguration
    Configuration options when destination is elasticsearch. See elasticsearch_configuration block below for details.
    extendedS3Configuration FirehoseDeliveryStreamExtendedS3Configuration
    Enhanced configuration options for the s3 destination. See extended_s3_configuration block below for details.
    httpEndpointConfiguration FirehoseDeliveryStreamHttpEndpointConfiguration
    Configuration options when destination is http_endpoint. Requires the user to also specify an s3_configuration block. See http_endpoint_configuration block below for details.
    kinesisSourceConfiguration FirehoseDeliveryStreamKinesisSourceConfiguration
    The stream and role Amazon Resource Names (ARNs) for a Kinesis data stream used as the source for a delivery stream. See kinesis_source_configuration block below for details.
    mskSourceConfiguration FirehoseDeliveryStreamMskSourceConfiguration
    The configuration for the Amazon MSK cluster to be used as the source for a delivery stream. See msk_source_configuration block below for details.
    name String
    A name to identify the stream. This is unique to the AWS account and region the Stream is created in. When using for WAF logging, name must be prefixed with aws-waf-logs-. See AWS Documentation for more details.
    opensearchConfiguration FirehoseDeliveryStreamOpensearchConfiguration
    Configuration options when destination is opensearch. See opensearch_configuration block below for details.
    opensearchserverlessConfiguration FirehoseDeliveryStreamOpensearchserverlessConfiguration
    Configuration options when destination is opensearchserverless. See opensearchserverless_configuration block below for details.
    redshiftConfiguration FirehoseDeliveryStreamRedshiftConfiguration
    Configuration options when destination is redshift. Requires the user to also specify an s3_configuration block. See redshift_configuration block below for details.
    serverSideEncryption FirehoseDeliveryStreamServerSideEncryption

    Encrypt at rest options. See server_side_encryption block below for details.

    NOTE: Server-side encryption should not be enabled when a kinesis stream is configured as the source of the firehose delivery stream.

    splunkConfiguration FirehoseDeliveryStreamSplunkConfiguration
    Configuration options when destination is splunk. See splunk_configuration block below for details.
    tags Map<String,String>
    A map of tags to assign to the resource. If configured with a provider default_tags configuration block present, tags with matching keys will overwrite those defined at the provider-level.
    tagsAll Map<String,String>
    A map of tags assigned to the resource, including those inherited from the provider default_tags configuration block.

    Deprecated: Please use tags instead.

    versionId String
    Specifies the table version for the output data schema. Defaults to LATEST.
    arn string
    The Amazon Resource Name (ARN) specifying the Stream
    destination string
    This is the destination to where the data is delivered. The only options are s3 (Deprecated, use extended_s3 instead), extended_s3, redshift, elasticsearch, splunk, http_endpoint, opensearch and opensearchserverless.
    destinationId string
    elasticsearchConfiguration FirehoseDeliveryStreamElasticsearchConfiguration
    Configuration options when destination is elasticsearch. See elasticsearch_configuration block below for details.
    extendedS3Configuration FirehoseDeliveryStreamExtendedS3Configuration
    Enhanced configuration options for the s3 destination. See extended_s3_configuration block below for details.
    httpEndpointConfiguration FirehoseDeliveryStreamHttpEndpointConfiguration
    Configuration options when destination is http_endpoint. Requires the user to also specify an s3_configuration block. See http_endpoint_configuration block below for details.
    kinesisSourceConfiguration FirehoseDeliveryStreamKinesisSourceConfiguration
    The stream and role Amazon Resource Names (ARNs) for a Kinesis data stream used as the source for a delivery stream. See kinesis_source_configuration block below for details.
    mskSourceConfiguration FirehoseDeliveryStreamMskSourceConfiguration
    The configuration for the Amazon MSK cluster to be used as the source for a delivery stream. See msk_source_configuration block below for details.
    name string
    A name to identify the stream. This is unique to the AWS account and region the Stream is created in. When using for WAF logging, name must be prefixed with aws-waf-logs-. See AWS Documentation for more details.
    opensearchConfiguration FirehoseDeliveryStreamOpensearchConfiguration
    Configuration options when destination is opensearch. See opensearch_configuration block below for details.
    opensearchserverlessConfiguration FirehoseDeliveryStreamOpensearchserverlessConfiguration
    Configuration options when destination is opensearchserverless. See opensearchserverless_configuration block below for details.
    redshiftConfiguration FirehoseDeliveryStreamRedshiftConfiguration
    Configuration options when destination is redshift. Requires the user to also specify an s3_configuration block. See redshift_configuration block below for details.
    serverSideEncryption FirehoseDeliveryStreamServerSideEncryption

    Encrypt at rest options. See server_side_encryption block below for details.

    NOTE: Server-side encryption should not be enabled when a kinesis stream is configured as the source of the firehose delivery stream.

    splunkConfiguration FirehoseDeliveryStreamSplunkConfiguration
    Configuration options when destination is splunk. See splunk_configuration block below for details.
    tags {[key: string]: string}
    A map of tags to assign to the resource. If configured with a provider default_tags configuration block present, tags with matching keys will overwrite those defined at the provider-level.
    tagsAll {[key: string]: string}
    A map of tags assigned to the resource, including those inherited from the provider default_tags configuration block.

    Deprecated: Please use tags instead.

    versionId string
    Specifies the table version for the output data schema. Defaults to LATEST.
    arn str
    The Amazon Resource Name (ARN) specifying the Stream
    destination str
    This is the destination to where the data is delivered. The only options are s3 (Deprecated, use extended_s3 instead), extended_s3, redshift, elasticsearch, splunk, http_endpoint, opensearch and opensearchserverless.
    destination_id str
    elasticsearch_configuration FirehoseDeliveryStreamElasticsearchConfigurationArgs
    Configuration options when destination is elasticsearch. See elasticsearch_configuration block below for details.
    extended_s3_configuration FirehoseDeliveryStreamExtendedS3ConfigurationArgs
    Enhanced configuration options for the s3 destination. See extended_s3_configuration block below for details.
    http_endpoint_configuration FirehoseDeliveryStreamHttpEndpointConfigurationArgs
    Configuration options when destination is http_endpoint. Requires the user to also specify an s3_configuration block. See http_endpoint_configuration block below for details.
    kinesis_source_configuration FirehoseDeliveryStreamKinesisSourceConfigurationArgs
    The stream and role Amazon Resource Names (ARNs) for a Kinesis data stream used as the source for a delivery stream. See kinesis_source_configuration block below for details.
    msk_source_configuration FirehoseDeliveryStreamMskSourceConfigurationArgs
    The configuration for the Amazon MSK cluster to be used as the source for a delivery stream. See msk_source_configuration block below for details.
    name str
    A name to identify the stream. This is unique to the AWS account and region the Stream is created in. When using for WAF logging, name must be prefixed with aws-waf-logs-. See AWS Documentation for more details.
    opensearch_configuration FirehoseDeliveryStreamOpensearchConfigurationArgs
    Configuration options when destination is opensearch. See opensearch_configuration block below for details.
    opensearchserverless_configuration FirehoseDeliveryStreamOpensearchserverlessConfigurationArgs
    Configuration options when destination is opensearchserverless. See opensearchserverless_configuration block below for details.
    redshift_configuration FirehoseDeliveryStreamRedshiftConfigurationArgs
    Configuration options when destination is redshift. Requires the user to also specify an s3_configuration block. See redshift_configuration block below for details.
    server_side_encryption FirehoseDeliveryStreamServerSideEncryptionArgs

    Encrypt at rest options. See server_side_encryption block below for details.

    NOTE: Server-side encryption should not be enabled when a kinesis stream is configured as the source of the firehose delivery stream.

    splunk_configuration FirehoseDeliveryStreamSplunkConfigurationArgs
    Configuration options when destination is splunk. See splunk_configuration block below for details.
    tags Mapping[str, str]
    A map of tags to assign to the resource. If configured with a provider default_tags configuration block present, tags with matching keys will overwrite those defined at the provider-level.
    tags_all Mapping[str, str]
    A map of tags assigned to the resource, including those inherited from the provider default_tags configuration block.

    Deprecated: Please use tags instead.

    version_id str
    Specifies the table version for the output data schema. Defaults to LATEST.
    arn String
    The Amazon Resource Name (ARN) specifying the Stream
    destination String
    This is the destination to where the data is delivered. The only options are s3 (Deprecated, use extended_s3 instead), extended_s3, redshift, elasticsearch, splunk, http_endpoint, opensearch and opensearchserverless.
    destinationId String
    elasticsearchConfiguration Property Map
    Configuration options when destination is elasticsearch. See elasticsearch_configuration block below for details.
    extendedS3Configuration Property Map
    Enhanced configuration options for the s3 destination. See extended_s3_configuration block below for details.
    httpEndpointConfiguration Property Map
    Configuration options when destination is http_endpoint. Requires the user to also specify an s3_configuration block. See http_endpoint_configuration block below for details.
    kinesisSourceConfiguration Property Map
    The stream and role Amazon Resource Names (ARNs) for a Kinesis data stream used as the source for a delivery stream. See kinesis_source_configuration block below for details.
    mskSourceConfiguration Property Map
    The configuration for the Amazon MSK cluster to be used as the source for a delivery stream. See msk_source_configuration block below for details.
    name String
    A name to identify the stream. This is unique to the AWS account and region the Stream is created in. When using for WAF logging, name must be prefixed with aws-waf-logs-. See AWS Documentation for more details.
    opensearchConfiguration Property Map
    Configuration options when destination is opensearch. See opensearch_configuration block below for details.
    opensearchserverlessConfiguration Property Map
    Configuration options when destination is opensearchserverless. See opensearchserverless_configuration block below for details.
    redshiftConfiguration Property Map
    Configuration options when destination is redshift. Requires the user to also specify an s3_configuration block. See redshift_configuration block below for details.
    serverSideEncryption Property Map

    Encrypt at rest options. See server_side_encryption block below for details.

    NOTE: Server-side encryption should not be enabled when a kinesis stream is configured as the source of the firehose delivery stream.

    splunkConfiguration Property Map
    Configuration options when destination is splunk. See splunk_configuration block below for details.
    tags Map<String>
    A map of tags to assign to the resource. If configured with a provider default_tags configuration block present, tags with matching keys will overwrite those defined at the provider-level.
    tagsAll Map<String>
    A map of tags assigned to the resource, including those inherited from the provider default_tags configuration block.

    Deprecated: Please use tags instead.

    versionId String
    Specifies the table version for the output data schema. Defaults to LATEST.

    Supporting Types

    FirehoseDeliveryStreamElasticsearchConfiguration, FirehoseDeliveryStreamElasticsearchConfigurationArgs

    IndexName string
    The Elasticsearch index name.
    RoleArn string
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon ES Configuration API and for indexing documents. The IAM role must have permission for DescribeElasticsearchDomain, DescribeElasticsearchDomains, and DescribeElasticsearchDomainConfig. The pattern needs to be arn:.*.
    S3Configuration FirehoseDeliveryStreamElasticsearchConfigurationS3Configuration
    The S3 Configuration. See s3_configuration block below for details.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    BufferingSize int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    CloudwatchLoggingOptions FirehoseDeliveryStreamElasticsearchConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    ClusterEndpoint string
    The endpoint to use when communicating with the cluster. Conflicts with domain_arn.
    DomainArn string
    The ARN of the Amazon ES domain. The pattern needs to be arn:.*. Conflicts with cluster_endpoint.
    IndexRotationPeriod string
    The Elasticsearch index rotation period. Index rotation appends a timestamp to the IndexName to facilitate expiration of old data. Valid values are NoRotation, OneHour, OneDay, OneWeek, and OneMonth. The default value is OneDay.
    ProcessingConfiguration FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    RetryDuration int
    After an initial failure to deliver to Amazon Elasticsearch, the total amount of time, in seconds between 0 to 7200, during which Firehose re-attempts delivery (including the first attempt). After this time has elapsed, the failed documents are written to Amazon S3. The default value is 300s. There will be no retry if the value is 0.
    S3BackupMode string
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDocumentsOnly and AllDocuments. Default value is FailedDocumentsOnly.
    TypeName string
    The Elasticsearch type name with maximum length of 100 characters.
    VpcConfig FirehoseDeliveryStreamElasticsearchConfigurationVpcConfig
    The VPC configuration for the delivery stream to connect to Elastic Search associated with the VPC. See vpc_config block below for details.
    IndexName string
    The Elasticsearch index name.
    RoleArn string
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon ES Configuration API and for indexing documents. The IAM role must have permission for DescribeElasticsearchDomain, DescribeElasticsearchDomains, and DescribeElasticsearchDomainConfig. The pattern needs to be arn:.*.
    S3Configuration FirehoseDeliveryStreamElasticsearchConfigurationS3Configuration
    The S3 Configuration. See s3_configuration block below for details.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    BufferingSize int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    CloudwatchLoggingOptions FirehoseDeliveryStreamElasticsearchConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    ClusterEndpoint string
    The endpoint to use when communicating with the cluster. Conflicts with domain_arn.
    DomainArn string
    The ARN of the Amazon ES domain. The pattern needs to be arn:.*. Conflicts with cluster_endpoint.
    IndexRotationPeriod string
    The Elasticsearch index rotation period. Index rotation appends a timestamp to the IndexName to facilitate expiration of old data. Valid values are NoRotation, OneHour, OneDay, OneWeek, and OneMonth. The default value is OneDay.
    ProcessingConfiguration FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    RetryDuration int
    After an initial failure to deliver to Amazon Elasticsearch, the total amount of time, in seconds between 0 to 7200, during which Firehose re-attempts delivery (including the first attempt). After this time has elapsed, the failed documents are written to Amazon S3. The default value is 300s. There will be no retry if the value is 0.
    S3BackupMode string
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDocumentsOnly and AllDocuments. Default value is FailedDocumentsOnly.
    TypeName string
    The Elasticsearch type name with maximum length of 100 characters.
    VpcConfig FirehoseDeliveryStreamElasticsearchConfigurationVpcConfig
    The VPC configuration for the delivery stream to connect to Elastic Search associated with the VPC. See vpc_config block below for details.
    indexName String
    The Elasticsearch index name.
    roleArn String
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon ES Configuration API and for indexing documents. The IAM role must have permission for DescribeElasticsearchDomain, DescribeElasticsearchDomains, and DescribeElasticsearchDomainConfig. The pattern needs to be arn:.*.
    s3Configuration FirehoseDeliveryStreamElasticsearchConfigurationS3Configuration
    The S3 Configuration. See s3_configuration block below for details.
    bufferingInterval Integer
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize Integer
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions FirehoseDeliveryStreamElasticsearchConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    clusterEndpoint String
    The endpoint to use when communicating with the cluster. Conflicts with domain_arn.
    domainArn String
    The ARN of the Amazon ES domain. The pattern needs to be arn:.*. Conflicts with cluster_endpoint.
    indexRotationPeriod String
    The Elasticsearch index rotation period. Index rotation appends a timestamp to the IndexName to facilitate expiration of old data. Valid values are NoRotation, OneHour, OneDay, OneWeek, and OneMonth. The default value is OneDay.
    processingConfiguration FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    retryDuration Integer
    After an initial failure to deliver to Amazon Elasticsearch, the total amount of time, in seconds between 0 to 7200, during which Firehose re-attempts delivery (including the first attempt). After this time has elapsed, the failed documents are written to Amazon S3. The default value is 300s. There will be no retry if the value is 0.
    s3BackupMode String
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDocumentsOnly and AllDocuments. Default value is FailedDocumentsOnly.
    typeName String
    The Elasticsearch type name with maximum length of 100 characters.
    vpcConfig FirehoseDeliveryStreamElasticsearchConfigurationVpcConfig
    The VPC configuration for the delivery stream to connect to Elastic Search associated with the VPC. See vpc_config block below for details.
    indexName string
    The Elasticsearch index name.
    roleArn string
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon ES Configuration API and for indexing documents. The IAM role must have permission for DescribeElasticsearchDomain, DescribeElasticsearchDomains, and DescribeElasticsearchDomainConfig. The pattern needs to be arn:.*.
    s3Configuration FirehoseDeliveryStreamElasticsearchConfigurationS3Configuration
    The S3 Configuration. See s3_configuration block below for details.
    bufferingInterval number
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize number
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions FirehoseDeliveryStreamElasticsearchConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    clusterEndpoint string
    The endpoint to use when communicating with the cluster. Conflicts with domain_arn.
    domainArn string
    The ARN of the Amazon ES domain. The pattern needs to be arn:.*. Conflicts with cluster_endpoint.
    indexRotationPeriod string
    The Elasticsearch index rotation period. Index rotation appends a timestamp to the IndexName to facilitate expiration of old data. Valid values are NoRotation, OneHour, OneDay, OneWeek, and OneMonth. The default value is OneDay.
    processingConfiguration FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    retryDuration number
    After an initial failure to deliver to Amazon Elasticsearch, the total amount of time, in seconds between 0 to 7200, during which Firehose re-attempts delivery (including the first attempt). After this time has elapsed, the failed documents are written to Amazon S3. The default value is 300s. There will be no retry if the value is 0.
    s3BackupMode string
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDocumentsOnly and AllDocuments. Default value is FailedDocumentsOnly.
    typeName string
    The Elasticsearch type name with maximum length of 100 characters.
    vpcConfig FirehoseDeliveryStreamElasticsearchConfigurationVpcConfig
    The VPC configuration for the delivery stream to connect to Elastic Search associated with the VPC. See vpc_config block below for details.
    index_name str
    The Elasticsearch index name.
    role_arn str
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon ES Configuration API and for indexing documents. The IAM role must have permission for DescribeElasticsearchDomain, DescribeElasticsearchDomains, and DescribeElasticsearchDomainConfig. The pattern needs to be arn:.*.
    s3_configuration FirehoseDeliveryStreamElasticsearchConfigurationS3Configuration
    The S3 Configuration. See s3_configuration block below for details.
    buffering_interval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    buffering_size int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatch_logging_options FirehoseDeliveryStreamElasticsearchConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    cluster_endpoint str
    The endpoint to use when communicating with the cluster. Conflicts with domain_arn.
    domain_arn str
    The ARN of the Amazon ES domain. The pattern needs to be arn:.*. Conflicts with cluster_endpoint.
    index_rotation_period str
    The Elasticsearch index rotation period. Index rotation appends a timestamp to the IndexName to facilitate expiration of old data. Valid values are NoRotation, OneHour, OneDay, OneWeek, and OneMonth. The default value is OneDay.
    processing_configuration FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    retry_duration int
    After an initial failure to deliver to Amazon Elasticsearch, the total amount of time, in seconds between 0 to 7200, during which Firehose re-attempts delivery (including the first attempt). After this time has elapsed, the failed documents are written to Amazon S3. The default value is 300s. There will be no retry if the value is 0.
    s3_backup_mode str
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDocumentsOnly and AllDocuments. Default value is FailedDocumentsOnly.
    type_name str
    The Elasticsearch type name with maximum length of 100 characters.
    vpc_config FirehoseDeliveryStreamElasticsearchConfigurationVpcConfig
    The VPC configuration for the delivery stream to connect to Elastic Search associated with the VPC. See vpc_config block below for details.
    indexName String
    The Elasticsearch index name.
    roleArn String
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon ES Configuration API and for indexing documents. The IAM role must have permission for DescribeElasticsearchDomain, DescribeElasticsearchDomains, and DescribeElasticsearchDomainConfig. The pattern needs to be arn:.*.
    s3Configuration Property Map
    The S3 Configuration. See s3_configuration block below for details.
    bufferingInterval Number
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize Number
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions Property Map
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    clusterEndpoint String
    The endpoint to use when communicating with the cluster. Conflicts with domain_arn.
    domainArn String
    The ARN of the Amazon ES domain. The pattern needs to be arn:.*. Conflicts with cluster_endpoint.
    indexRotationPeriod String
    The Elasticsearch index rotation period. Index rotation appends a timestamp to the IndexName to facilitate expiration of old data. Valid values are NoRotation, OneHour, OneDay, OneWeek, and OneMonth. The default value is OneDay.
    processingConfiguration Property Map
    The data processing configuration. See processing_configuration block below for details.
    retryDuration Number
    After an initial failure to deliver to Amazon Elasticsearch, the total amount of time, in seconds between 0 to 7200, during which Firehose re-attempts delivery (including the first attempt). After this time has elapsed, the failed documents are written to Amazon S3. The default value is 300s. There will be no retry if the value is 0.
    s3BackupMode String
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDocumentsOnly and AllDocuments. Default value is FailedDocumentsOnly.
    typeName String
    The Elasticsearch type name with maximum length of 100 characters.
    vpcConfig Property Map
    The VPC configuration for the delivery stream to connect to Elastic Search associated with the VPC. See vpc_config block below for details.

    FirehoseDeliveryStreamElasticsearchConfigurationCloudwatchLoggingOptions, FirehoseDeliveryStreamElasticsearchConfigurationCloudwatchLoggingOptionsArgs

    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled boolean
    Enables or disables the logging. Defaults to false.
    logGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled bool
    Enables or disables the logging. Defaults to false.
    log_group_name str
    The CloudWatch group name for logging. This value is required if enabled is true.
    log_stream_name str
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.

    FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfiguration, FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationArgs

    Enabled bool
    Enables or disables data processing.
    Processors List<FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessor>
    Specifies the data processors as multiple blocks. See processors block below for details.
    Enabled bool
    Enables or disables data processing.
    Processors []FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessor
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled Boolean
    Enables or disables data processing.
    processors List<FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessor>
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled boolean
    Enables or disables data processing.
    processors FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessor[]
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled bool
    Enables or disables data processing.
    processors Sequence[FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessor]
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled Boolean
    Enables or disables data processing.
    processors List<Property Map>
    Specifies the data processors as multiple blocks. See processors block below for details.

    FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessor, FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorArgs

    Type string
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    Parameters List<FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorParameter>
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    Type string
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    Parameters []FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorParameter
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type String
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters List<FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorParameter>
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type string
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorParameter[]
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type str
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters Sequence[FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorParameter]
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type String
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters List<Property Map>
    Specifies the processor parameters as multiple blocks. See parameters block below for details.

    FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorParameter, FirehoseDeliveryStreamElasticsearchConfigurationProcessingConfigurationProcessorParameterArgs

    ParameterName string
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    ParameterValue string

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    ParameterName string
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    ParameterValue string

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameterName String
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameterValue String

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameterName string
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameterValue string

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameter_name str
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameter_value str

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameterName String
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameterValue String

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    FirehoseDeliveryStreamElasticsearchConfigurationS3Configuration, FirehoseDeliveryStreamElasticsearchConfigurationS3ConfigurationArgs

    BucketArn string
    The ARN of the S3 bucket
    RoleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    BufferingSize int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    CloudwatchLoggingOptions FirehoseDeliveryStreamElasticsearchConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    CompressionFormat string
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    ErrorOutputPrefix string
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    KmsKeyArn string
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    Prefix string
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    BucketArn string
    The ARN of the S3 bucket
    RoleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    BufferingSize int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    CloudwatchLoggingOptions FirehoseDeliveryStreamElasticsearchConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    CompressionFormat string
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    ErrorOutputPrefix string
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    KmsKeyArn string
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    Prefix string
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucketArn String
    The ARN of the S3 bucket
    roleArn String
    The ARN of the role used to access the Amazon MSK cluster.
    bufferingInterval Integer
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize Integer
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions FirehoseDeliveryStreamElasticsearchConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compressionFormat String
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    errorOutputPrefix String
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kmsKeyArn String
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix String
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucketArn string
    The ARN of the S3 bucket
    roleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    bufferingInterval number
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize number
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions FirehoseDeliveryStreamElasticsearchConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compressionFormat string
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    errorOutputPrefix string
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kmsKeyArn string
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix string
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucket_arn str
    The ARN of the S3 bucket
    role_arn str
    The ARN of the role used to access the Amazon MSK cluster.
    buffering_interval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    buffering_size int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatch_logging_options FirehoseDeliveryStreamElasticsearchConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compression_format str
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    error_output_prefix str
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kms_key_arn str
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix str
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucketArn String
    The ARN of the S3 bucket
    roleArn String
    The ARN of the role used to access the Amazon MSK cluster.
    bufferingInterval Number
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize Number
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions Property Map
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compressionFormat String
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    errorOutputPrefix String
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kmsKeyArn String
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix String
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket

    FirehoseDeliveryStreamElasticsearchConfigurationS3ConfigurationCloudwatchLoggingOptions, FirehoseDeliveryStreamElasticsearchConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs

    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled boolean
    Enables or disables the logging. Defaults to false.
    logGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled bool
    Enables or disables the logging. Defaults to false.
    log_group_name str
    The CloudWatch group name for logging. This value is required if enabled is true.
    log_stream_name str
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.

    FirehoseDeliveryStreamElasticsearchConfigurationVpcConfig, FirehoseDeliveryStreamElasticsearchConfigurationVpcConfigArgs

    RoleArn string
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon EC2 configuration API and for creating network interfaces. Make sure role has necessary IAM permissions
    SecurityGroupIds List<string>
    A list of security group IDs to associate with Kinesis Firehose.
    SubnetIds List<string>
    A list of subnet IDs to associate with Kinesis Firehose.
    VpcId string
    RoleArn string
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon EC2 configuration API and for creating network interfaces. Make sure role has necessary IAM permissions
    SecurityGroupIds []string
    A list of security group IDs to associate with Kinesis Firehose.
    SubnetIds []string
    A list of subnet IDs to associate with Kinesis Firehose.
    VpcId string
    roleArn String
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon EC2 configuration API and for creating network interfaces. Make sure role has necessary IAM permissions
    securityGroupIds List<String>
    A list of security group IDs to associate with Kinesis Firehose.
    subnetIds List<String>
    A list of subnet IDs to associate with Kinesis Firehose.
    vpcId String
    roleArn string
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon EC2 configuration API and for creating network interfaces. Make sure role has necessary IAM permissions
    securityGroupIds string[]
    A list of security group IDs to associate with Kinesis Firehose.
    subnetIds string[]
    A list of subnet IDs to associate with Kinesis Firehose.
    vpcId string
    role_arn str
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon EC2 configuration API and for creating network interfaces. Make sure role has necessary IAM permissions
    security_group_ids Sequence[str]
    A list of security group IDs to associate with Kinesis Firehose.
    subnet_ids Sequence[str]
    A list of subnet IDs to associate with Kinesis Firehose.
    vpc_id str
    roleArn String
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon EC2 configuration API and for creating network interfaces. Make sure role has necessary IAM permissions
    securityGroupIds List<String>
    A list of security group IDs to associate with Kinesis Firehose.
    subnetIds List<String>
    A list of subnet IDs to associate with Kinesis Firehose.
    vpcId String

    FirehoseDeliveryStreamExtendedS3Configuration, FirehoseDeliveryStreamExtendedS3ConfigurationArgs

    BucketArn string
    The ARN of the S3 bucket
    RoleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    BufferingSize int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    CloudwatchLoggingOptions FirehoseDeliveryStreamExtendedS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    CompressionFormat string
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    CustomTimeZone string
    The time zone you prefer. Valid values are UTC or a non-3-letter IANA time zones (for example, America/Los_Angeles). Default value is UTC.
    DataFormatConversionConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfiguration
    Nested argument for the serializer, deserializer, and schema for converting data from the JSON format to the Parquet or ORC format before writing it to Amazon S3. See data_format_conversion_configuration block below for details.
    DynamicPartitioningConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationDynamicPartitioningConfiguration
    The configuration for dynamic partitioning. Required when using dynamic partitioning. See dynamic_partitioning_configuration block below for details.
    ErrorOutputPrefix string
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    FileExtension string
    The file extension to override the default file extension (for example, .json).
    KmsKeyArn string
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    Prefix string
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    ProcessingConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    S3BackupConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationS3BackupConfiguration
    The configuration for backup in Amazon S3. Required if s3_backup_mode is Enabled. Supports the same fields as s3_configuration object.
    S3BackupMode string
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDocumentsOnly and AllDocuments. Default value is FailedDocumentsOnly.
    BucketArn string
    The ARN of the S3 bucket
    RoleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    BufferingSize int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    CloudwatchLoggingOptions FirehoseDeliveryStreamExtendedS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    CompressionFormat string
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    CustomTimeZone string
    The time zone you prefer. Valid values are UTC or a non-3-letter IANA time zones (for example, America/Los_Angeles). Default value is UTC.
    DataFormatConversionConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfiguration
    Nested argument for the serializer, deserializer, and schema for converting data from the JSON format to the Parquet or ORC format before writing it to Amazon S3. See data_format_conversion_configuration block below for details.
    DynamicPartitioningConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationDynamicPartitioningConfiguration
    The configuration for dynamic partitioning. Required when using dynamic partitioning. See dynamic_partitioning_configuration block below for details.
    ErrorOutputPrefix string
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    FileExtension string
    The file extension to override the default file extension (for example, .json).
    KmsKeyArn string
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    Prefix string
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    ProcessingConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    S3BackupConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationS3BackupConfiguration
    The configuration for backup in Amazon S3. Required if s3_backup_mode is Enabled. Supports the same fields as s3_configuration object.
    S3BackupMode string
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDocumentsOnly and AllDocuments. Default value is FailedDocumentsOnly.
    bucketArn String
    The ARN of the S3 bucket
    roleArn String
    The ARN of the role used to access the Amazon MSK cluster.
    bufferingInterval Integer
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize Integer
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions FirehoseDeliveryStreamExtendedS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compressionFormat String
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    customTimeZone String
    The time zone you prefer. Valid values are UTC or a non-3-letter IANA time zones (for example, America/Los_Angeles). Default value is UTC.
    dataFormatConversionConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfiguration
    Nested argument for the serializer, deserializer, and schema for converting data from the JSON format to the Parquet or ORC format before writing it to Amazon S3. See data_format_conversion_configuration block below for details.
    dynamicPartitioningConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationDynamicPartitioningConfiguration
    The configuration for dynamic partitioning. Required when using dynamic partitioning. See dynamic_partitioning_configuration block below for details.
    errorOutputPrefix String
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    fileExtension String
    The file extension to override the default file extension (for example, .json).
    kmsKeyArn String
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix String
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    processingConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    s3BackupConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationS3BackupConfiguration
    The configuration for backup in Amazon S3. Required if s3_backup_mode is Enabled. Supports the same fields as s3_configuration object.
    s3BackupMode String
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDocumentsOnly and AllDocuments. Default value is FailedDocumentsOnly.
    bucketArn string
    The ARN of the S3 bucket
    roleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    bufferingInterval number
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize number
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions FirehoseDeliveryStreamExtendedS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compressionFormat string
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    customTimeZone string
    The time zone you prefer. Valid values are UTC or a non-3-letter IANA time zones (for example, America/Los_Angeles). Default value is UTC.
    dataFormatConversionConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfiguration
    Nested argument for the serializer, deserializer, and schema for converting data from the JSON format to the Parquet or ORC format before writing it to Amazon S3. See data_format_conversion_configuration block below for details.
    dynamicPartitioningConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationDynamicPartitioningConfiguration
    The configuration for dynamic partitioning. Required when using dynamic partitioning. See dynamic_partitioning_configuration block below for details.
    errorOutputPrefix string
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    fileExtension string
    The file extension to override the default file extension (for example, .json).
    kmsKeyArn string
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix string
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    processingConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    s3BackupConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationS3BackupConfiguration
    The configuration for backup in Amazon S3. Required if s3_backup_mode is Enabled. Supports the same fields as s3_configuration object.
    s3BackupMode string
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDocumentsOnly and AllDocuments. Default value is FailedDocumentsOnly.
    bucket_arn str
    The ARN of the S3 bucket
    role_arn str
    The ARN of the role used to access the Amazon MSK cluster.
    buffering_interval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    buffering_size int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatch_logging_options FirehoseDeliveryStreamExtendedS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compression_format str
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    custom_time_zone str
    The time zone you prefer. Valid values are UTC or a non-3-letter IANA time zones (for example, America/Los_Angeles). Default value is UTC.
    data_format_conversion_configuration FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfiguration
    Nested argument for the serializer, deserializer, and schema for converting data from the JSON format to the Parquet or ORC format before writing it to Amazon S3. See data_format_conversion_configuration block below for details.
    dynamic_partitioning_configuration FirehoseDeliveryStreamExtendedS3ConfigurationDynamicPartitioningConfiguration
    The configuration for dynamic partitioning. Required when using dynamic partitioning. See dynamic_partitioning_configuration block below for details.
    error_output_prefix str
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    file_extension str
    The file extension to override the default file extension (for example, .json).
    kms_key_arn str
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix str
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    processing_configuration FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    s3_backup_configuration FirehoseDeliveryStreamExtendedS3ConfigurationS3BackupConfiguration
    The configuration for backup in Amazon S3. Required if s3_backup_mode is Enabled. Supports the same fields as s3_configuration object.
    s3_backup_mode str
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDocumentsOnly and AllDocuments. Default value is FailedDocumentsOnly.
    bucketArn String
    The ARN of the S3 bucket
    roleArn String
    The ARN of the role used to access the Amazon MSK cluster.
    bufferingInterval Number
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize Number
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions Property Map
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compressionFormat String
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    customTimeZone String
    The time zone you prefer. Valid values are UTC or a non-3-letter IANA time zones (for example, America/Los_Angeles). Default value is UTC.
    dataFormatConversionConfiguration Property Map
    Nested argument for the serializer, deserializer, and schema for converting data from the JSON format to the Parquet or ORC format before writing it to Amazon S3. See data_format_conversion_configuration block below for details.
    dynamicPartitioningConfiguration Property Map
    The configuration for dynamic partitioning. Required when using dynamic partitioning. See dynamic_partitioning_configuration block below for details.
    errorOutputPrefix String
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    fileExtension String
    The file extension to override the default file extension (for example, .json).
    kmsKeyArn String
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix String
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    processingConfiguration Property Map
    The data processing configuration. See processing_configuration block below for details.
    s3BackupConfiguration Property Map
    The configuration for backup in Amazon S3. Required if s3_backup_mode is Enabled. Supports the same fields as s3_configuration object.
    s3BackupMode String
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDocumentsOnly and AllDocuments. Default value is FailedDocumentsOnly.

    FirehoseDeliveryStreamExtendedS3ConfigurationCloudwatchLoggingOptions, FirehoseDeliveryStreamExtendedS3ConfigurationCloudwatchLoggingOptionsArgs

    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled boolean
    Enables or disables the logging. Defaults to false.
    logGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled bool
    Enables or disables the logging. Defaults to false.
    log_group_name str
    The CloudWatch group name for logging. This value is required if enabled is true.
    log_stream_name str
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.

    FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfiguration, FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationArgs

    InputFormatConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfiguration
    Specifies the deserializer that you want Kinesis Data Firehose to use to convert the format of your data from JSON. See input_format_configuration block below for details.
    OutputFormatConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfiguration
    Specifies the serializer that you want Kinesis Data Firehose to use to convert the format of your data to the Parquet or ORC format. See output_format_configuration block below for details.
    SchemaConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationSchemaConfiguration
    Specifies the AWS Glue Data Catalog table that contains the column information. See schema_configuration block below for details.
    Enabled bool
    Defaults to true. Set it to false if you want to disable format conversion while preserving the configuration details.
    InputFormatConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfiguration
    Specifies the deserializer that you want Kinesis Data Firehose to use to convert the format of your data from JSON. See input_format_configuration block below for details.
    OutputFormatConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfiguration
    Specifies the serializer that you want Kinesis Data Firehose to use to convert the format of your data to the Parquet or ORC format. See output_format_configuration block below for details.
    SchemaConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationSchemaConfiguration
    Specifies the AWS Glue Data Catalog table that contains the column information. See schema_configuration block below for details.
    Enabled bool
    Defaults to true. Set it to false if you want to disable format conversion while preserving the configuration details.
    inputFormatConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfiguration
    Specifies the deserializer that you want Kinesis Data Firehose to use to convert the format of your data from JSON. See input_format_configuration block below for details.
    outputFormatConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfiguration
    Specifies the serializer that you want Kinesis Data Firehose to use to convert the format of your data to the Parquet or ORC format. See output_format_configuration block below for details.
    schemaConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationSchemaConfiguration
    Specifies the AWS Glue Data Catalog table that contains the column information. See schema_configuration block below for details.
    enabled Boolean
    Defaults to true. Set it to false if you want to disable format conversion while preserving the configuration details.
    inputFormatConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfiguration
    Specifies the deserializer that you want Kinesis Data Firehose to use to convert the format of your data from JSON. See input_format_configuration block below for details.
    outputFormatConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfiguration
    Specifies the serializer that you want Kinesis Data Firehose to use to convert the format of your data to the Parquet or ORC format. See output_format_configuration block below for details.
    schemaConfiguration FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationSchemaConfiguration
    Specifies the AWS Glue Data Catalog table that contains the column information. See schema_configuration block below for details.
    enabled boolean
    Defaults to true. Set it to false if you want to disable format conversion while preserving the configuration details.
    input_format_configuration FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfiguration
    Specifies the deserializer that you want Kinesis Data Firehose to use to convert the format of your data from JSON. See input_format_configuration block below for details.
    output_format_configuration FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfiguration
    Specifies the serializer that you want Kinesis Data Firehose to use to convert the format of your data to the Parquet or ORC format. See output_format_configuration block below for details.
    schema_configuration FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationSchemaConfiguration
    Specifies the AWS Glue Data Catalog table that contains the column information. See schema_configuration block below for details.
    enabled bool
    Defaults to true. Set it to false if you want to disable format conversion while preserving the configuration details.
    inputFormatConfiguration Property Map
    Specifies the deserializer that you want Kinesis Data Firehose to use to convert the format of your data from JSON. See input_format_configuration block below for details.
    outputFormatConfiguration Property Map
    Specifies the serializer that you want Kinesis Data Firehose to use to convert the format of your data to the Parquet or ORC format. See output_format_configuration block below for details.
    schemaConfiguration Property Map
    Specifies the AWS Glue Data Catalog table that contains the column information. See schema_configuration block below for details.
    enabled Boolean
    Defaults to true. Set it to false if you want to disable format conversion while preserving the configuration details.

    FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfiguration, FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationArgs

    Deserializer FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializer
    Specifies which deserializer to use. You can choose either the Apache Hive JSON SerDe or the OpenX JSON SerDe. See deserializer block below for details.
    Deserializer FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializer
    Specifies which deserializer to use. You can choose either the Apache Hive JSON SerDe or the OpenX JSON SerDe. See deserializer block below for details.
    deserializer FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializer
    Specifies which deserializer to use. You can choose either the Apache Hive JSON SerDe or the OpenX JSON SerDe. See deserializer block below for details.
    deserializer FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializer
    Specifies which deserializer to use. You can choose either the Apache Hive JSON SerDe or the OpenX JSON SerDe. See deserializer block below for details.
    deserializer FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializer
    Specifies which deserializer to use. You can choose either the Apache Hive JSON SerDe or the OpenX JSON SerDe. See deserializer block below for details.
    deserializer Property Map
    Specifies which deserializer to use. You can choose either the Apache Hive JSON SerDe or the OpenX JSON SerDe. See deserializer block below for details.

    FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializer, FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializerArgs

    HiveJsonSerDe FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializerHiveJsonSerDe
    Specifies the native Hive / HCatalog JsonSerDe. More details below. See hive_json_ser_de block below for details.
    OpenXJsonSerDe FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializerOpenXJsonSerDe
    Specifies the OpenX SerDe. See open_x_json_ser_de block below for details.
    HiveJsonSerDe FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializerHiveJsonSerDe
    Specifies the native Hive / HCatalog JsonSerDe. More details below. See hive_json_ser_de block below for details.
    OpenXJsonSerDe FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializerOpenXJsonSerDe
    Specifies the OpenX SerDe. See open_x_json_ser_de block below for details.
    hiveJsonSerDe FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializerHiveJsonSerDe
    Specifies the native Hive / HCatalog JsonSerDe. More details below. See hive_json_ser_de block below for details.
    openXJsonSerDe FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializerOpenXJsonSerDe
    Specifies the OpenX SerDe. See open_x_json_ser_de block below for details.
    hiveJsonSerDe FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializerHiveJsonSerDe
    Specifies the native Hive / HCatalog JsonSerDe. More details below. See hive_json_ser_de block below for details.
    openXJsonSerDe FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializerOpenXJsonSerDe
    Specifies the OpenX SerDe. See open_x_json_ser_de block below for details.
    hiveJsonSerDe Property Map
    Specifies the native Hive / HCatalog JsonSerDe. More details below. See hive_json_ser_de block below for details.
    openXJsonSerDe Property Map
    Specifies the OpenX SerDe. See open_x_json_ser_de block below for details.

    FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializerHiveJsonSerDe, FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializerHiveJsonSerDeArgs

    TimestampFormats List<string>
    A list of how you want Kinesis Data Firehose to parse the date and time stamps that may be present in your input data JSON. To specify these format strings, follow the pattern syntax of JodaTime's DateTimeFormat format strings. For more information, see Class DateTimeFormat. You can also use the special value millis to parse time stamps in epoch milliseconds. If you don't specify a format, Kinesis Data Firehose uses java.sql.Timestamp::valueOf by default.
    TimestampFormats []string
    A list of how you want Kinesis Data Firehose to parse the date and time stamps that may be present in your input data JSON. To specify these format strings, follow the pattern syntax of JodaTime's DateTimeFormat format strings. For more information, see Class DateTimeFormat. You can also use the special value millis to parse time stamps in epoch milliseconds. If you don't specify a format, Kinesis Data Firehose uses java.sql.Timestamp::valueOf by default.
    timestampFormats List<String>
    A list of how you want Kinesis Data Firehose to parse the date and time stamps that may be present in your input data JSON. To specify these format strings, follow the pattern syntax of JodaTime's DateTimeFormat format strings. For more information, see Class DateTimeFormat. You can also use the special value millis to parse time stamps in epoch milliseconds. If you don't specify a format, Kinesis Data Firehose uses java.sql.Timestamp::valueOf by default.
    timestampFormats string[]
    A list of how you want Kinesis Data Firehose to parse the date and time stamps that may be present in your input data JSON. To specify these format strings, follow the pattern syntax of JodaTime's DateTimeFormat format strings. For more information, see Class DateTimeFormat. You can also use the special value millis to parse time stamps in epoch milliseconds. If you don't specify a format, Kinesis Data Firehose uses java.sql.Timestamp::valueOf by default.
    timestamp_formats Sequence[str]
    A list of how you want Kinesis Data Firehose to parse the date and time stamps that may be present in your input data JSON. To specify these format strings, follow the pattern syntax of JodaTime's DateTimeFormat format strings. For more information, see Class DateTimeFormat. You can also use the special value millis to parse time stamps in epoch milliseconds. If you don't specify a format, Kinesis Data Firehose uses java.sql.Timestamp::valueOf by default.
    timestampFormats List<String>
    A list of how you want Kinesis Data Firehose to parse the date and time stamps that may be present in your input data JSON. To specify these format strings, follow the pattern syntax of JodaTime's DateTimeFormat format strings. For more information, see Class DateTimeFormat. You can also use the special value millis to parse time stamps in epoch milliseconds. If you don't specify a format, Kinesis Data Firehose uses java.sql.Timestamp::valueOf by default.

    FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializerOpenXJsonSerDe, FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationInputFormatConfigurationDeserializerOpenXJsonSerDeArgs

    CaseInsensitive bool
    When set to true, which is the default, Kinesis Data Firehose converts JSON keys to lowercase before deserializing them.
    ColumnToJsonKeyMappings Dictionary<string, string>
    A map of column names to JSON keys that aren't identical to the column names. This is useful when the JSON contains keys that are Hive keywords. For example, timestamp is a Hive keyword. If you have a JSON key named timestamp, set this parameter to { ts = "timestamp" } to map this key to a column named ts.
    ConvertDotsInJsonKeysToUnderscores bool
    When set to true, specifies that the names of the keys include dots and that you want Kinesis Data Firehose to replace them with underscores. This is useful because Apache Hive does not allow dots in column names. For example, if the JSON contains a key whose name is "a.b", you can define the column name to be "a_b" when using this option. Defaults to false.
    CaseInsensitive bool
    When set to true, which is the default, Kinesis Data Firehose converts JSON keys to lowercase before deserializing them.
    ColumnToJsonKeyMappings map[string]string
    A map of column names to JSON keys that aren't identical to the column names. This is useful when the JSON contains keys that are Hive keywords. For example, timestamp is a Hive keyword. If you have a JSON key named timestamp, set this parameter to { ts = "timestamp" } to map this key to a column named ts.
    ConvertDotsInJsonKeysToUnderscores bool
    When set to true, specifies that the names of the keys include dots and that you want Kinesis Data Firehose to replace them with underscores. This is useful because Apache Hive does not allow dots in column names. For example, if the JSON contains a key whose name is "a.b", you can define the column name to be "a_b" when using this option. Defaults to false.
    caseInsensitive Boolean
    When set to true, which is the default, Kinesis Data Firehose converts JSON keys to lowercase before deserializing them.
    columnToJsonKeyMappings Map<String,String>
    A map of column names to JSON keys that aren't identical to the column names. This is useful when the JSON contains keys that are Hive keywords. For example, timestamp is a Hive keyword. If you have a JSON key named timestamp, set this parameter to { ts = "timestamp" } to map this key to a column named ts.
    convertDotsInJsonKeysToUnderscores Boolean
    When set to true, specifies that the names of the keys include dots and that you want Kinesis Data Firehose to replace them with underscores. This is useful because Apache Hive does not allow dots in column names. For example, if the JSON contains a key whose name is "a.b", you can define the column name to be "a_b" when using this option. Defaults to false.
    caseInsensitive boolean
    When set to true, which is the default, Kinesis Data Firehose converts JSON keys to lowercase before deserializing them.
    columnToJsonKeyMappings {[key: string]: string}
    A map of column names to JSON keys that aren't identical to the column names. This is useful when the JSON contains keys that are Hive keywords. For example, timestamp is a Hive keyword. If you have a JSON key named timestamp, set this parameter to { ts = "timestamp" } to map this key to a column named ts.
    convertDotsInJsonKeysToUnderscores boolean
    When set to true, specifies that the names of the keys include dots and that you want Kinesis Data Firehose to replace them with underscores. This is useful because Apache Hive does not allow dots in column names. For example, if the JSON contains a key whose name is "a.b", you can define the column name to be "a_b" when using this option. Defaults to false.
    case_insensitive bool
    When set to true, which is the default, Kinesis Data Firehose converts JSON keys to lowercase before deserializing them.
    column_to_json_key_mappings Mapping[str, str]
    A map of column names to JSON keys that aren't identical to the column names. This is useful when the JSON contains keys that are Hive keywords. For example, timestamp is a Hive keyword. If you have a JSON key named timestamp, set this parameter to { ts = "timestamp" } to map this key to a column named ts.
    convert_dots_in_json_keys_to_underscores bool
    When set to true, specifies that the names of the keys include dots and that you want Kinesis Data Firehose to replace them with underscores. This is useful because Apache Hive does not allow dots in column names. For example, if the JSON contains a key whose name is "a.b", you can define the column name to be "a_b" when using this option. Defaults to false.
    caseInsensitive Boolean
    When set to true, which is the default, Kinesis Data Firehose converts JSON keys to lowercase before deserializing them.
    columnToJsonKeyMappings Map<String>
    A map of column names to JSON keys that aren't identical to the column names. This is useful when the JSON contains keys that are Hive keywords. For example, timestamp is a Hive keyword. If you have a JSON key named timestamp, set this parameter to { ts = "timestamp" } to map this key to a column named ts.
    convertDotsInJsonKeysToUnderscores Boolean
    When set to true, specifies that the names of the keys include dots and that you want Kinesis Data Firehose to replace them with underscores. This is useful because Apache Hive does not allow dots in column names. For example, if the JSON contains a key whose name is "a.b", you can define the column name to be "a_b" when using this option. Defaults to false.

    FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfiguration, FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationArgs

    Serializer FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializer
    Specifies which serializer to use. You can choose either the ORC SerDe or the Parquet SerDe. See serializer block below for details.
    Serializer FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializer
    Specifies which serializer to use. You can choose either the ORC SerDe or the Parquet SerDe. See serializer block below for details.
    serializer FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializer
    Specifies which serializer to use. You can choose either the ORC SerDe or the Parquet SerDe. See serializer block below for details.
    serializer FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializer
    Specifies which serializer to use. You can choose either the ORC SerDe or the Parquet SerDe. See serializer block below for details.
    serializer FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializer
    Specifies which serializer to use. You can choose either the ORC SerDe or the Parquet SerDe. See serializer block below for details.
    serializer Property Map
    Specifies which serializer to use. You can choose either the ORC SerDe or the Parquet SerDe. See serializer block below for details.

    FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializer, FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializerArgs

    OrcSerDe FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializerOrcSerDe
    Specifies converting data to the ORC format before storing it in Amazon S3. For more information, see Apache ORC. See orc_ser_de block below for details.
    ParquetSerDe FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializerParquetSerDe
    Specifies converting data to the Parquet format before storing it in Amazon S3. For more information, see Apache Parquet. More details below.
    OrcSerDe FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializerOrcSerDe
    Specifies converting data to the ORC format before storing it in Amazon S3. For more information, see Apache ORC. See orc_ser_de block below for details.
    ParquetSerDe FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializerParquetSerDe
    Specifies converting data to the Parquet format before storing it in Amazon S3. For more information, see Apache Parquet. More details below.
    orcSerDe FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializerOrcSerDe
    Specifies converting data to the ORC format before storing it in Amazon S3. For more information, see Apache ORC. See orc_ser_de block below for details.
    parquetSerDe FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializerParquetSerDe
    Specifies converting data to the Parquet format before storing it in Amazon S3. For more information, see Apache Parquet. More details below.
    orcSerDe FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializerOrcSerDe
    Specifies converting data to the ORC format before storing it in Amazon S3. For more information, see Apache ORC. See orc_ser_de block below for details.
    parquetSerDe FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializerParquetSerDe
    Specifies converting data to the Parquet format before storing it in Amazon S3. For more information, see Apache Parquet. More details below.
    orc_ser_de FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializerOrcSerDe
    Specifies converting data to the ORC format before storing it in Amazon S3. For more information, see Apache ORC. See orc_ser_de block below for details.
    parquet_ser_de FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializerParquetSerDe
    Specifies converting data to the Parquet format before storing it in Amazon S3. For more information, see Apache Parquet. More details below.
    orcSerDe Property Map
    Specifies converting data to the ORC format before storing it in Amazon S3. For more information, see Apache ORC. See orc_ser_de block below for details.
    parquetSerDe Property Map
    Specifies converting data to the Parquet format before storing it in Amazon S3. For more information, see Apache Parquet. More details below.

    FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializerOrcSerDe, FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializerOrcSerDeArgs

    BlockSizeBytes int
    The Hadoop Distributed File System (HDFS) block size. This is useful if you intend to copy the data from Amazon S3 to HDFS before querying. The default is 256 MiB and the minimum is 64 MiB. Kinesis Data Firehose uses this value for padding calculations.
    BloomFilterColumns List<string>
    A list of column names for which you want Kinesis Data Firehose to create bloom filters.
    BloomFilterFalsePositiveProbability double
    The Bloom filter false positive probability (FPP). The lower the FPP, the bigger the Bloom filter. The default value is 0.05, the minimum is 0, and the maximum is 1.
    Compression string
    The compression code to use over data blocks. The default is SNAPPY.
    DictionaryKeyThreshold double
    A float that represents the fraction of the total number of non-null rows. To turn off dictionary encoding, set this fraction to a number that is less than the number of distinct keys in a dictionary. To always use dictionary encoding, set this threshold to 1.
    EnablePadding bool
    Set this to true to indicate that you want stripes to be padded to the HDFS block boundaries. This is useful if you intend to copy the data from Amazon S3 to HDFS before querying. The default is false.
    FormatVersion string
    The version of the file to write. The possible values are V0_11 and V0_12. The default is V0_12.
    PaddingTolerance double
    A float between 0 and 1 that defines the tolerance for block padding as a decimal fraction of stripe size. The default value is 0.05, which means 5 percent of stripe size. For the default values of 64 MiB ORC stripes and 256 MiB HDFS blocks, the default block padding tolerance of 5 percent reserves a maximum of 3.2 MiB for padding within the 256 MiB block. In such a case, if the available size within the block is more than 3.2 MiB, a new, smaller stripe is inserted to fit within that space. This ensures that no stripe crosses block boundaries and causes remote reads within a node-local task. Kinesis Data Firehose ignores this parameter when enable_padding is false.
    RowIndexStride int
    The number of rows between index entries. The default is 10000 and the minimum is 1000.
    StripeSizeBytes int
    The number of bytes in each stripe. The default is 64 MiB and the minimum is 8 MiB.
    BlockSizeBytes int
    The Hadoop Distributed File System (HDFS) block size. This is useful if you intend to copy the data from Amazon S3 to HDFS before querying. The default is 256 MiB and the minimum is 64 MiB. Kinesis Data Firehose uses this value for padding calculations.
    BloomFilterColumns []string
    A list of column names for which you want Kinesis Data Firehose to create bloom filters.
    BloomFilterFalsePositiveProbability float64
    The Bloom filter false positive probability (FPP). The lower the FPP, the bigger the Bloom filter. The default value is 0.05, the minimum is 0, and the maximum is 1.
    Compression string
    The compression code to use over data blocks. The default is SNAPPY.
    DictionaryKeyThreshold float64
    A float that represents the fraction of the total number of non-null rows. To turn off dictionary encoding, set this fraction to a number that is less than the number of distinct keys in a dictionary. To always use dictionary encoding, set this threshold to 1.
    EnablePadding bool
    Set this to true to indicate that you want stripes to be padded to the HDFS block boundaries. This is useful if you intend to copy the data from Amazon S3 to HDFS before querying. The default is false.
    FormatVersion string
    The version of the file to write. The possible values are V0_11 and V0_12. The default is V0_12.
    PaddingTolerance float64
    A float between 0 and 1 that defines the tolerance for block padding as a decimal fraction of stripe size. The default value is 0.05, which means 5 percent of stripe size. For the default values of 64 MiB ORC stripes and 256 MiB HDFS blocks, the default block padding tolerance of 5 percent reserves a maximum of 3.2 MiB for padding within the 256 MiB block. In such a case, if the available size within the block is more than 3.2 MiB, a new, smaller stripe is inserted to fit within that space. This ensures that no stripe crosses block boundaries and causes remote reads within a node-local task. Kinesis Data Firehose ignores this parameter when enable_padding is false.
    RowIndexStride int
    The number of rows between index entries. The default is 10000 and the minimum is 1000.
    StripeSizeBytes int
    The number of bytes in each stripe. The default is 64 MiB and the minimum is 8 MiB.
    blockSizeBytes Integer
    The Hadoop Distributed File System (HDFS) block size. This is useful if you intend to copy the data from Amazon S3 to HDFS before querying. The default is 256 MiB and the minimum is 64 MiB. Kinesis Data Firehose uses this value for padding calculations.
    bloomFilterColumns List<String>
    A list of column names for which you want Kinesis Data Firehose to create bloom filters.
    bloomFilterFalsePositiveProbability Double
    The Bloom filter false positive probability (FPP). The lower the FPP, the bigger the Bloom filter. The default value is 0.05, the minimum is 0, and the maximum is 1.
    compression String
    The compression code to use over data blocks. The default is SNAPPY.
    dictionaryKeyThreshold Double
    A float that represents the fraction of the total number of non-null rows. To turn off dictionary encoding, set this fraction to a number that is less than the number of distinct keys in a dictionary. To always use dictionary encoding, set this threshold to 1.
    enablePadding Boolean
    Set this to true to indicate that you want stripes to be padded to the HDFS block boundaries. This is useful if you intend to copy the data from Amazon S3 to HDFS before querying. The default is false.
    formatVersion String
    The version of the file to write. The possible values are V0_11 and V0_12. The default is V0_12.
    paddingTolerance Double
    A float between 0 and 1 that defines the tolerance for block padding as a decimal fraction of stripe size. The default value is 0.05, which means 5 percent of stripe size. For the default values of 64 MiB ORC stripes and 256 MiB HDFS blocks, the default block padding tolerance of 5 percent reserves a maximum of 3.2 MiB for padding within the 256 MiB block. In such a case, if the available size within the block is more than 3.2 MiB, a new, smaller stripe is inserted to fit within that space. This ensures that no stripe crosses block boundaries and causes remote reads within a node-local task. Kinesis Data Firehose ignores this parameter when enable_padding is false.
    rowIndexStride Integer
    The number of rows between index entries. The default is 10000 and the minimum is 1000.
    stripeSizeBytes Integer
    The number of bytes in each stripe. The default is 64 MiB and the minimum is 8 MiB.
    blockSizeBytes number
    The Hadoop Distributed File System (HDFS) block size. This is useful if you intend to copy the data from Amazon S3 to HDFS before querying. The default is 256 MiB and the minimum is 64 MiB. Kinesis Data Firehose uses this value for padding calculations.
    bloomFilterColumns string[]
    A list of column names for which you want Kinesis Data Firehose to create bloom filters.
    bloomFilterFalsePositiveProbability number
    The Bloom filter false positive probability (FPP). The lower the FPP, the bigger the Bloom filter. The default value is 0.05, the minimum is 0, and the maximum is 1.
    compression string
    The compression code to use over data blocks. The default is SNAPPY.
    dictionaryKeyThreshold number
    A float that represents the fraction of the total number of non-null rows. To turn off dictionary encoding, set this fraction to a number that is less than the number of distinct keys in a dictionary. To always use dictionary encoding, set this threshold to 1.
    enablePadding boolean
    Set this to true to indicate that you want stripes to be padded to the HDFS block boundaries. This is useful if you intend to copy the data from Amazon S3 to HDFS before querying. The default is false.
    formatVersion string
    The version of the file to write. The possible values are V0_11 and V0_12. The default is V0_12.
    paddingTolerance number
    A float between 0 and 1 that defines the tolerance for block padding as a decimal fraction of stripe size. The default value is 0.05, which means 5 percent of stripe size. For the default values of 64 MiB ORC stripes and 256 MiB HDFS blocks, the default block padding tolerance of 5 percent reserves a maximum of 3.2 MiB for padding within the 256 MiB block. In such a case, if the available size within the block is more than 3.2 MiB, a new, smaller stripe is inserted to fit within that space. This ensures that no stripe crosses block boundaries and causes remote reads within a node-local task. Kinesis Data Firehose ignores this parameter when enable_padding is false.
    rowIndexStride number
    The number of rows between index entries. The default is 10000 and the minimum is 1000.
    stripeSizeBytes number
    The number of bytes in each stripe. The default is 64 MiB and the minimum is 8 MiB.
    block_size_bytes int
    The Hadoop Distributed File System (HDFS) block size. This is useful if you intend to copy the data from Amazon S3 to HDFS before querying. The default is 256 MiB and the minimum is 64 MiB. Kinesis Data Firehose uses this value for padding calculations.
    bloom_filter_columns Sequence[str]
    A list of column names for which you want Kinesis Data Firehose to create bloom filters.
    bloom_filter_false_positive_probability float
    The Bloom filter false positive probability (FPP). The lower the FPP, the bigger the Bloom filter. The default value is 0.05, the minimum is 0, and the maximum is 1.
    compression str
    The compression code to use over data blocks. The default is SNAPPY.
    dictionary_key_threshold float
    A float that represents the fraction of the total number of non-null rows. To turn off dictionary encoding, set this fraction to a number that is less than the number of distinct keys in a dictionary. To always use dictionary encoding, set this threshold to 1.
    enable_padding bool
    Set this to true to indicate that you want stripes to be padded to the HDFS block boundaries. This is useful if you intend to copy the data from Amazon S3 to HDFS before querying. The default is false.
    format_version str
    The version of the file to write. The possible values are V0_11 and V0_12. The default is V0_12.
    padding_tolerance float
    A float between 0 and 1 that defines the tolerance for block padding as a decimal fraction of stripe size. The default value is 0.05, which means 5 percent of stripe size. For the default values of 64 MiB ORC stripes and 256 MiB HDFS blocks, the default block padding tolerance of 5 percent reserves a maximum of 3.2 MiB for padding within the 256 MiB block. In such a case, if the available size within the block is more than 3.2 MiB, a new, smaller stripe is inserted to fit within that space. This ensures that no stripe crosses block boundaries and causes remote reads within a node-local task. Kinesis Data Firehose ignores this parameter when enable_padding is false.
    row_index_stride int
    The number of rows between index entries. The default is 10000 and the minimum is 1000.
    stripe_size_bytes int
    The number of bytes in each stripe. The default is 64 MiB and the minimum is 8 MiB.
    blockSizeBytes Number
    The Hadoop Distributed File System (HDFS) block size. This is useful if you intend to copy the data from Amazon S3 to HDFS before querying. The default is 256 MiB and the minimum is 64 MiB. Kinesis Data Firehose uses this value for padding calculations.
    bloomFilterColumns List<String>
    A list of column names for which you want Kinesis Data Firehose to create bloom filters.
    bloomFilterFalsePositiveProbability Number
    The Bloom filter false positive probability (FPP). The lower the FPP, the bigger the Bloom filter. The default value is 0.05, the minimum is 0, and the maximum is 1.
    compression String
    The compression code to use over data blocks. The default is SNAPPY.
    dictionaryKeyThreshold Number
    A float that represents the fraction of the total number of non-null rows. To turn off dictionary encoding, set this fraction to a number that is less than the number of distinct keys in a dictionary. To always use dictionary encoding, set this threshold to 1.
    enablePadding Boolean
    Set this to true to indicate that you want stripes to be padded to the HDFS block boundaries. This is useful if you intend to copy the data from Amazon S3 to HDFS before querying. The default is false.
    formatVersion String
    The version of the file to write. The possible values are V0_11 and V0_12. The default is V0_12.
    paddingTolerance Number
    A float between 0 and 1 that defines the tolerance for block padding as a decimal fraction of stripe size. The default value is 0.05, which means 5 percent of stripe size. For the default values of 64 MiB ORC stripes and 256 MiB HDFS blocks, the default block padding tolerance of 5 percent reserves a maximum of 3.2 MiB for padding within the 256 MiB block. In such a case, if the available size within the block is more than 3.2 MiB, a new, smaller stripe is inserted to fit within that space. This ensures that no stripe crosses block boundaries and causes remote reads within a node-local task. Kinesis Data Firehose ignores this parameter when enable_padding is false.
    rowIndexStride Number
    The number of rows between index entries. The default is 10000 and the minimum is 1000.
    stripeSizeBytes Number
    The number of bytes in each stripe. The default is 64 MiB and the minimum is 8 MiB.

    FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializerParquetSerDe, FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationOutputFormatConfigurationSerializerParquetSerDeArgs

    BlockSizeBytes int
    The Hadoop Distributed File System (HDFS) block size. This is useful if you intend to copy the data from Amazon S3 to HDFS before querying. The default is 256 MiB and the minimum is 64 MiB. Kinesis Data Firehose uses this value for padding calculations.
    Compression string
    The compression code to use over data blocks. The possible values are UNCOMPRESSED, SNAPPY, and GZIP, with the default being SNAPPY. Use SNAPPY for higher decompression speed. Use GZIP if the compression ratio is more important than speed.
    EnableDictionaryCompression bool
    Indicates whether to enable dictionary compression.
    MaxPaddingBytes int
    The maximum amount of padding to apply. This is useful if you intend to copy the data from Amazon S3 to HDFS before querying. The default is 0.
    PageSizeBytes int
    The Parquet page size. Column chunks are divided into pages. A page is conceptually an indivisible unit (in terms of compression and encoding). The minimum value is 64 KiB and the default is 1 MiB.
    WriterVersion string
    Indicates the version of row format to output. The possible values are V1 and V2. The default is V1.
    BlockSizeBytes int
    The Hadoop Distributed File System (HDFS) block size. This is useful if you intend to copy the data from Amazon S3 to HDFS before querying. The default is 256 MiB and the minimum is 64 MiB. Kinesis Data Firehose uses this value for padding calculations.
    Compression string
    The compression code to use over data blocks. The possible values are UNCOMPRESSED, SNAPPY, and GZIP, with the default being SNAPPY. Use SNAPPY for higher decompression speed. Use GZIP if the compression ratio is more important than speed.
    EnableDictionaryCompression bool
    Indicates whether to enable dictionary compression.
    MaxPaddingBytes int
    The maximum amount of padding to apply. This is useful if you intend to copy the data from Amazon S3 to HDFS before querying. The default is 0.
    PageSizeBytes int
    The Parquet page size. Column chunks are divided into pages. A page is conceptually an indivisible unit (in terms of compression and encoding). The minimum value is 64 KiB and the default is 1 MiB.
    WriterVersion string
    Indicates the version of row format to output. The possible values are V1 and V2. The default is V1.
    blockSizeBytes Integer
    The Hadoop Distributed File System (HDFS) block size. This is useful if you intend to copy the data from Amazon S3 to HDFS before querying. The default is 256 MiB and the minimum is 64 MiB. Kinesis Data Firehose uses this value for padding calculations.
    compression String
    The compression code to use over data blocks. The possible values are UNCOMPRESSED, SNAPPY, and GZIP, with the default being SNAPPY. Use SNAPPY for higher decompression speed. Use GZIP if the compression ratio is more important than speed.
    enableDictionaryCompression Boolean
    Indicates whether to enable dictionary compression.
    maxPaddingBytes Integer
    The maximum amount of padding to apply. This is useful if you intend to copy the data from Amazon S3 to HDFS before querying. The default is 0.
    pageSizeBytes Integer
    The Parquet page size. Column chunks are divided into pages. A page is conceptually an indivisible unit (in terms of compression and encoding). The minimum value is 64 KiB and the default is 1 MiB.
    writerVersion String
    Indicates the version of row format to output. The possible values are V1 and V2. The default is V1.
    blockSizeBytes number
    The Hadoop Distributed File System (HDFS) block size. This is useful if you intend to copy the data from Amazon S3 to HDFS before querying. The default is 256 MiB and the minimum is 64 MiB. Kinesis Data Firehose uses this value for padding calculations.
    compression string
    The compression code to use over data blocks. The possible values are UNCOMPRESSED, SNAPPY, and GZIP, with the default being SNAPPY. Use SNAPPY for higher decompression speed. Use GZIP if the compression ratio is more important than speed.
    enableDictionaryCompression boolean
    Indicates whether to enable dictionary compression.
    maxPaddingBytes number
    The maximum amount of padding to apply. This is useful if you intend to copy the data from Amazon S3 to HDFS before querying. The default is 0.
    pageSizeBytes number
    The Parquet page size. Column chunks are divided into pages. A page is conceptually an indivisible unit (in terms of compression and encoding). The minimum value is 64 KiB and the default is 1 MiB.
    writerVersion string
    Indicates the version of row format to output. The possible values are V1 and V2. The default is V1.
    block_size_bytes int
    The Hadoop Distributed File System (HDFS) block size. This is useful if you intend to copy the data from Amazon S3 to HDFS before querying. The default is 256 MiB and the minimum is 64 MiB. Kinesis Data Firehose uses this value for padding calculations.
    compression str
    The compression code to use over data blocks. The possible values are UNCOMPRESSED, SNAPPY, and GZIP, with the default being SNAPPY. Use SNAPPY for higher decompression speed. Use GZIP if the compression ratio is more important than speed.
    enable_dictionary_compression bool
    Indicates whether to enable dictionary compression.
    max_padding_bytes int
    The maximum amount of padding to apply. This is useful if you intend to copy the data from Amazon S3 to HDFS before querying. The default is 0.
    page_size_bytes int
    The Parquet page size. Column chunks are divided into pages. A page is conceptually an indivisible unit (in terms of compression and encoding). The minimum value is 64 KiB and the default is 1 MiB.
    writer_version str
    Indicates the version of row format to output. The possible values are V1 and V2. The default is V1.
    blockSizeBytes Number
    The Hadoop Distributed File System (HDFS) block size. This is useful if you intend to copy the data from Amazon S3 to HDFS before querying. The default is 256 MiB and the minimum is 64 MiB. Kinesis Data Firehose uses this value for padding calculations.
    compression String
    The compression code to use over data blocks. The possible values are UNCOMPRESSED, SNAPPY, and GZIP, with the default being SNAPPY. Use SNAPPY for higher decompression speed. Use GZIP if the compression ratio is more important than speed.
    enableDictionaryCompression Boolean
    Indicates whether to enable dictionary compression.
    maxPaddingBytes Number
    The maximum amount of padding to apply. This is useful if you intend to copy the data from Amazon S3 to HDFS before querying. The default is 0.
    pageSizeBytes Number
    The Parquet page size. Column chunks are divided into pages. A page is conceptually an indivisible unit (in terms of compression and encoding). The minimum value is 64 KiB and the default is 1 MiB.
    writerVersion String
    Indicates the version of row format to output. The possible values are V1 and V2. The default is V1.

    FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationSchemaConfiguration, FirehoseDeliveryStreamExtendedS3ConfigurationDataFormatConversionConfigurationSchemaConfigurationArgs

    DatabaseName string
    Specifies the name of the AWS Glue database that contains the schema for the output data.
    RoleArn string
    The role that Kinesis Data Firehose can use to access AWS Glue. This role must be in the same account you use for Kinesis Data Firehose. Cross-account roles aren't allowed.
    TableName string
    Specifies the AWS Glue table that contains the column information that constitutes your data schema.
    CatalogId string
    The ID of the AWS Glue Data Catalog. If you don't supply this, the AWS account ID is used by default.
    Region string
    If you don't specify an AWS Region, the default is the current region.
    VersionId string
    Specifies the table version for the output data schema. Defaults to LATEST.
    DatabaseName string
    Specifies the name of the AWS Glue database that contains the schema for the output data.
    RoleArn string
    The role that Kinesis Data Firehose can use to access AWS Glue. This role must be in the same account you use for Kinesis Data Firehose. Cross-account roles aren't allowed.
    TableName string
    Specifies the AWS Glue table that contains the column information that constitutes your data schema.
    CatalogId string
    The ID of the AWS Glue Data Catalog. If you don't supply this, the AWS account ID is used by default.
    Region string
    If you don't specify an AWS Region, the default is the current region.
    VersionId string
    Specifies the table version for the output data schema. Defaults to LATEST.
    databaseName String
    Specifies the name of the AWS Glue database that contains the schema for the output data.
    roleArn String
    The role that Kinesis Data Firehose can use to access AWS Glue. This role must be in the same account you use for Kinesis Data Firehose. Cross-account roles aren't allowed.
    tableName String
    Specifies the AWS Glue table that contains the column information that constitutes your data schema.
    catalogId String
    The ID of the AWS Glue Data Catalog. If you don't supply this, the AWS account ID is used by default.
    region String
    If you don't specify an AWS Region, the default is the current region.
    versionId String
    Specifies the table version for the output data schema. Defaults to LATEST.
    databaseName string
    Specifies the name of the AWS Glue database that contains the schema for the output data.
    roleArn string
    The role that Kinesis Data Firehose can use to access AWS Glue. This role must be in the same account you use for Kinesis Data Firehose. Cross-account roles aren't allowed.
    tableName string
    Specifies the AWS Glue table that contains the column information that constitutes your data schema.
    catalogId string
    The ID of the AWS Glue Data Catalog. If you don't supply this, the AWS account ID is used by default.
    region string
    If you don't specify an AWS Region, the default is the current region.
    versionId string
    Specifies the table version for the output data schema. Defaults to LATEST.
    database_name str
    Specifies the name of the AWS Glue database that contains the schema for the output data.
    role_arn str
    The role that Kinesis Data Firehose can use to access AWS Glue. This role must be in the same account you use for Kinesis Data Firehose. Cross-account roles aren't allowed.
    table_name str
    Specifies the AWS Glue table that contains the column information that constitutes your data schema.
    catalog_id str
    The ID of the AWS Glue Data Catalog. If you don't supply this, the AWS account ID is used by default.
    region str
    If you don't specify an AWS Region, the default is the current region.
    version_id str
    Specifies the table version for the output data schema. Defaults to LATEST.
    databaseName String
    Specifies the name of the AWS Glue database that contains the schema for the output data.
    roleArn String
    The role that Kinesis Data Firehose can use to access AWS Glue. This role must be in the same account you use for Kinesis Data Firehose. Cross-account roles aren't allowed.
    tableName String
    Specifies the AWS Glue table that contains the column information that constitutes your data schema.
    catalogId String
    The ID of the AWS Glue Data Catalog. If you don't supply this, the AWS account ID is used by default.
    region String
    If you don't specify an AWS Region, the default is the current region.
    versionId String
    Specifies the table version for the output data schema. Defaults to LATEST.

    FirehoseDeliveryStreamExtendedS3ConfigurationDynamicPartitioningConfiguration, FirehoseDeliveryStreamExtendedS3ConfigurationDynamicPartitioningConfigurationArgs

    Enabled bool
    Enables or disables dynamic partitioning. Defaults to false.
    RetryDuration int

    Total amount of seconds Firehose spends on retries. Valid values between 0 and 7200. Default is 300.

    NOTE: You can enable dynamic partitioning only when you create a new delivery stream. Once you enable dynamic partitioning on a delivery stream, it cannot be disabled on this delivery stream. Therefore, the provider will recreate the resource whenever dynamic partitioning is enabled or disabled.

    Enabled bool
    Enables or disables dynamic partitioning. Defaults to false.
    RetryDuration int

    Total amount of seconds Firehose spends on retries. Valid values between 0 and 7200. Default is 300.

    NOTE: You can enable dynamic partitioning only when you create a new delivery stream. Once you enable dynamic partitioning on a delivery stream, it cannot be disabled on this delivery stream. Therefore, the provider will recreate the resource whenever dynamic partitioning is enabled or disabled.

    enabled Boolean
    Enables or disables dynamic partitioning. Defaults to false.
    retryDuration Integer

    Total amount of seconds Firehose spends on retries. Valid values between 0 and 7200. Default is 300.

    NOTE: You can enable dynamic partitioning only when you create a new delivery stream. Once you enable dynamic partitioning on a delivery stream, it cannot be disabled on this delivery stream. Therefore, the provider will recreate the resource whenever dynamic partitioning is enabled or disabled.

    enabled boolean
    Enables or disables dynamic partitioning. Defaults to false.
    retryDuration number

    Total amount of seconds Firehose spends on retries. Valid values between 0 and 7200. Default is 300.

    NOTE: You can enable dynamic partitioning only when you create a new delivery stream. Once you enable dynamic partitioning on a delivery stream, it cannot be disabled on this delivery stream. Therefore, the provider will recreate the resource whenever dynamic partitioning is enabled or disabled.

    enabled bool
    Enables or disables dynamic partitioning. Defaults to false.
    retry_duration int

    Total amount of seconds Firehose spends on retries. Valid values between 0 and 7200. Default is 300.

    NOTE: You can enable dynamic partitioning only when you create a new delivery stream. Once you enable dynamic partitioning on a delivery stream, it cannot be disabled on this delivery stream. Therefore, the provider will recreate the resource whenever dynamic partitioning is enabled or disabled.

    enabled Boolean
    Enables or disables dynamic partitioning. Defaults to false.
    retryDuration Number

    Total amount of seconds Firehose spends on retries. Valid values between 0 and 7200. Default is 300.

    NOTE: You can enable dynamic partitioning only when you create a new delivery stream. Once you enable dynamic partitioning on a delivery stream, it cannot be disabled on this delivery stream. Therefore, the provider will recreate the resource whenever dynamic partitioning is enabled or disabled.

    FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfiguration, FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationArgs

    Enabled bool
    Enables or disables data processing.
    Processors List<FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessor>
    Specifies the data processors as multiple blocks. See processors block below for details.
    Enabled bool
    Enables or disables data processing.
    Processors []FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessor
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled Boolean
    Enables or disables data processing.
    processors List<FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessor>
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled boolean
    Enables or disables data processing.
    processors FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessor[]
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled bool
    Enables or disables data processing.
    processors Sequence[FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessor]
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled Boolean
    Enables or disables data processing.
    processors List<Property Map>
    Specifies the data processors as multiple blocks. See processors block below for details.

    FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessor, FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorArgs

    Type string
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    Parameters List<FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameter>
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    Type string
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    Parameters []FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameter
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type String
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters List<FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameter>
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type string
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameter[]
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type str
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters Sequence[FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameter]
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type String
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters List<Property Map>
    Specifies the processor parameters as multiple blocks. See parameters block below for details.

    FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameter, FirehoseDeliveryStreamExtendedS3ConfigurationProcessingConfigurationProcessorParameterArgs

    ParameterName string
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    ParameterValue string

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    ParameterName string
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    ParameterValue string

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameterName String
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameterValue String

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameterName string
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameterValue string

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameter_name str
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameter_value str

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameterName String
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameterValue String

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    FirehoseDeliveryStreamExtendedS3ConfigurationS3BackupConfiguration, FirehoseDeliveryStreamExtendedS3ConfigurationS3BackupConfigurationArgs

    BucketArn string
    The ARN of the S3 bucket
    RoleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    BufferingSize int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    CloudwatchLoggingOptions FirehoseDeliveryStreamExtendedS3ConfigurationS3BackupConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    CompressionFormat string
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    ErrorOutputPrefix string
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    KmsKeyArn string
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    Prefix string
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    BucketArn string
    The ARN of the S3 bucket
    RoleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    BufferingSize int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    CloudwatchLoggingOptions FirehoseDeliveryStreamExtendedS3ConfigurationS3BackupConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    CompressionFormat string
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    ErrorOutputPrefix string
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    KmsKeyArn string
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    Prefix string
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucketArn String
    The ARN of the S3 bucket
    roleArn String
    The ARN of the role used to access the Amazon MSK cluster.
    bufferingInterval Integer
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize Integer
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions FirehoseDeliveryStreamExtendedS3ConfigurationS3BackupConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compressionFormat String
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    errorOutputPrefix String
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kmsKeyArn String
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix String
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucketArn string
    The ARN of the S3 bucket
    roleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    bufferingInterval number
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize number
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions FirehoseDeliveryStreamExtendedS3ConfigurationS3BackupConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compressionFormat string
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    errorOutputPrefix string
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kmsKeyArn string
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix string
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucket_arn str
    The ARN of the S3 bucket
    role_arn str
    The ARN of the role used to access the Amazon MSK cluster.
    buffering_interval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    buffering_size int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatch_logging_options FirehoseDeliveryStreamExtendedS3ConfigurationS3BackupConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compression_format str
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    error_output_prefix str
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kms_key_arn str
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix str
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucketArn String
    The ARN of the S3 bucket
    roleArn String
    The ARN of the role used to access the Amazon MSK cluster.
    bufferingInterval Number
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize Number
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions Property Map
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compressionFormat String
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    errorOutputPrefix String
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kmsKeyArn String
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix String
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket

    FirehoseDeliveryStreamExtendedS3ConfigurationS3BackupConfigurationCloudwatchLoggingOptions, FirehoseDeliveryStreamExtendedS3ConfigurationS3BackupConfigurationCloudwatchLoggingOptionsArgs

    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled boolean
    Enables or disables the logging. Defaults to false.
    logGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled bool
    Enables or disables the logging. Defaults to false.
    log_group_name str
    The CloudWatch group name for logging. This value is required if enabled is true.
    log_stream_name str
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.

    FirehoseDeliveryStreamHttpEndpointConfiguration, FirehoseDeliveryStreamHttpEndpointConfigurationArgs

    S3Configuration FirehoseDeliveryStreamHttpEndpointConfigurationS3Configuration
    The S3 Configuration. See s3_configuration block below for details.
    Url string
    The HTTP endpoint URL to which Kinesis Firehose sends your data.
    AccessKey string
    The access key required for Kinesis Firehose to authenticate with the HTTP endpoint selected as the destination.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds, before delivering it to the destination. The default value is 300 (5 minutes).
    BufferingSize int
    Buffer incoming data to the specified size, in MBs, before delivering it to the destination. The default value is 5.
    CloudwatchLoggingOptions FirehoseDeliveryStreamHttpEndpointConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    Name string
    The HTTP endpoint name.
    ProcessingConfiguration FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    RequestConfiguration FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfiguration
    The request configuration. See request_configuration block below for details.
    RetryDuration int
    Total amount of seconds Firehose spends on retries. This duration starts after the initial attempt fails, It does not include the time periods during which Firehose waits for acknowledgment from the specified destination after each attempt. Valid values between 0 and 7200. Default is 300.
    RoleArn string
    Kinesis Data Firehose uses this IAM role for all the permissions that the delivery stream needs. The pattern needs to be arn:.*.
    S3BackupMode string
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDataOnly and AllData. Default value is FailedDataOnly.
    S3Configuration FirehoseDeliveryStreamHttpEndpointConfigurationS3Configuration
    The S3 Configuration. See s3_configuration block below for details.
    Url string
    The HTTP endpoint URL to which Kinesis Firehose sends your data.
    AccessKey string
    The access key required for Kinesis Firehose to authenticate with the HTTP endpoint selected as the destination.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds, before delivering it to the destination. The default value is 300 (5 minutes).
    BufferingSize int
    Buffer incoming data to the specified size, in MBs, before delivering it to the destination. The default value is 5.
    CloudwatchLoggingOptions FirehoseDeliveryStreamHttpEndpointConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    Name string
    The HTTP endpoint name.
    ProcessingConfiguration FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    RequestConfiguration FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfiguration
    The request configuration. See request_configuration block below for details.
    RetryDuration int
    Total amount of seconds Firehose spends on retries. This duration starts after the initial attempt fails, It does not include the time periods during which Firehose waits for acknowledgment from the specified destination after each attempt. Valid values between 0 and 7200. Default is 300.
    RoleArn string
    Kinesis Data Firehose uses this IAM role for all the permissions that the delivery stream needs. The pattern needs to be arn:.*.
    S3BackupMode string
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDataOnly and AllData. Default value is FailedDataOnly.
    s3Configuration FirehoseDeliveryStreamHttpEndpointConfigurationS3Configuration
    The S3 Configuration. See s3_configuration block below for details.
    url String
    The HTTP endpoint URL to which Kinesis Firehose sends your data.
    accessKey String
    The access key required for Kinesis Firehose to authenticate with the HTTP endpoint selected as the destination.
    bufferingInterval Integer
    Buffer incoming data for the specified period of time, in seconds, before delivering it to the destination. The default value is 300 (5 minutes).
    bufferingSize Integer
    Buffer incoming data to the specified size, in MBs, before delivering it to the destination. The default value is 5.
    cloudwatchLoggingOptions FirehoseDeliveryStreamHttpEndpointConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    name String
    The HTTP endpoint name.
    processingConfiguration FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    requestConfiguration FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfiguration
    The request configuration. See request_configuration block below for details.
    retryDuration Integer
    Total amount of seconds Firehose spends on retries. This duration starts after the initial attempt fails, It does not include the time periods during which Firehose waits for acknowledgment from the specified destination after each attempt. Valid values between 0 and 7200. Default is 300.
    roleArn String
    Kinesis Data Firehose uses this IAM role for all the permissions that the delivery stream needs. The pattern needs to be arn:.*.
    s3BackupMode String
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDataOnly and AllData. Default value is FailedDataOnly.
    s3Configuration FirehoseDeliveryStreamHttpEndpointConfigurationS3Configuration
    The S3 Configuration. See s3_configuration block below for details.
    url string
    The HTTP endpoint URL to which Kinesis Firehose sends your data.
    accessKey string
    The access key required for Kinesis Firehose to authenticate with the HTTP endpoint selected as the destination.
    bufferingInterval number
    Buffer incoming data for the specified period of time, in seconds, before delivering it to the destination. The default value is 300 (5 minutes).
    bufferingSize number
    Buffer incoming data to the specified size, in MBs, before delivering it to the destination. The default value is 5.
    cloudwatchLoggingOptions FirehoseDeliveryStreamHttpEndpointConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    name string
    The HTTP endpoint name.
    processingConfiguration FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    requestConfiguration FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfiguration
    The request configuration. See request_configuration block below for details.
    retryDuration number
    Total amount of seconds Firehose spends on retries. This duration starts after the initial attempt fails, It does not include the time periods during which Firehose waits for acknowledgment from the specified destination after each attempt. Valid values between 0 and 7200. Default is 300.
    roleArn string
    Kinesis Data Firehose uses this IAM role for all the permissions that the delivery stream needs. The pattern needs to be arn:.*.
    s3BackupMode string
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDataOnly and AllData. Default value is FailedDataOnly.
    s3_configuration FirehoseDeliveryStreamHttpEndpointConfigurationS3Configuration
    The S3 Configuration. See s3_configuration block below for details.
    url str
    The HTTP endpoint URL to which Kinesis Firehose sends your data.
    access_key str
    The access key required for Kinesis Firehose to authenticate with the HTTP endpoint selected as the destination.
    buffering_interval int
    Buffer incoming data for the specified period of time, in seconds, before delivering it to the destination. The default value is 300 (5 minutes).
    buffering_size int
    Buffer incoming data to the specified size, in MBs, before delivering it to the destination. The default value is 5.
    cloudwatch_logging_options FirehoseDeliveryStreamHttpEndpointConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    name str
    The HTTP endpoint name.
    processing_configuration FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    request_configuration FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfiguration
    The request configuration. See request_configuration block below for details.
    retry_duration int
    Total amount of seconds Firehose spends on retries. This duration starts after the initial attempt fails, It does not include the time periods during which Firehose waits for acknowledgment from the specified destination after each attempt. Valid values between 0 and 7200. Default is 300.
    role_arn str
    Kinesis Data Firehose uses this IAM role for all the permissions that the delivery stream needs. The pattern needs to be arn:.*.
    s3_backup_mode str
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDataOnly and AllData. Default value is FailedDataOnly.
    s3Configuration Property Map
    The S3 Configuration. See s3_configuration block below for details.
    url String
    The HTTP endpoint URL to which Kinesis Firehose sends your data.
    accessKey String
    The access key required for Kinesis Firehose to authenticate with the HTTP endpoint selected as the destination.
    bufferingInterval Number
    Buffer incoming data for the specified period of time, in seconds, before delivering it to the destination. The default value is 300 (5 minutes).
    bufferingSize Number
    Buffer incoming data to the specified size, in MBs, before delivering it to the destination. The default value is 5.
    cloudwatchLoggingOptions Property Map
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    name String
    The HTTP endpoint name.
    processingConfiguration Property Map
    The data processing configuration. See processing_configuration block below for details.
    requestConfiguration Property Map
    The request configuration. See request_configuration block below for details.
    retryDuration Number
    Total amount of seconds Firehose spends on retries. This duration starts after the initial attempt fails, It does not include the time periods during which Firehose waits for acknowledgment from the specified destination after each attempt. Valid values between 0 and 7200. Default is 300.
    roleArn String
    Kinesis Data Firehose uses this IAM role for all the permissions that the delivery stream needs. The pattern needs to be arn:.*.
    s3BackupMode String
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDataOnly and AllData. Default value is FailedDataOnly.

    FirehoseDeliveryStreamHttpEndpointConfigurationCloudwatchLoggingOptions, FirehoseDeliveryStreamHttpEndpointConfigurationCloudwatchLoggingOptionsArgs

    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled boolean
    Enables or disables the logging. Defaults to false.
    logGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled bool
    Enables or disables the logging. Defaults to false.
    log_group_name str
    The CloudWatch group name for logging. This value is required if enabled is true.
    log_stream_name str
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.

    FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfiguration, FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationArgs

    Enabled bool
    Enables or disables data processing.
    Processors List<FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationProcessor>
    Specifies the data processors as multiple blocks. See processors block below for details.
    Enabled bool
    Enables or disables data processing.
    Processors []FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationProcessor
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled Boolean
    Enables or disables data processing.
    processors List<FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationProcessor>
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled boolean
    Enables or disables data processing.
    processors FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationProcessor[]
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled bool
    Enables or disables data processing.
    processors Sequence[FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationProcessor]
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled Boolean
    Enables or disables data processing.
    processors List<Property Map>
    Specifies the data processors as multiple blocks. See processors block below for details.

    FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationProcessor, FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationProcessorArgs

    Type string
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    Parameters List<FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationProcessorParameter>
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    Type string
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    Parameters []FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationProcessorParameter
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type String
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters List<FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationProcessorParameter>
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type string
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationProcessorParameter[]
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type str
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters Sequence[FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationProcessorParameter]
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type String
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters List<Property Map>
    Specifies the processor parameters as multiple blocks. See parameters block below for details.

    FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationProcessorParameter, FirehoseDeliveryStreamHttpEndpointConfigurationProcessingConfigurationProcessorParameterArgs

    ParameterName string
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    ParameterValue string

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    ParameterName string
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    ParameterValue string

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameterName String
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameterValue String

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameterName string
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameterValue string

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameter_name str
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameter_value str

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameterName String
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameterValue String

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfiguration, FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationArgs

    CommonAttributes List<FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationCommonAttribute>
    Describes the metadata sent to the HTTP endpoint destination. See common_attributes block below for details.
    ContentEncoding string
    Kinesis Data Firehose uses the content encoding to compress the body of a request before sending the request to the destination. Valid values are NONE and GZIP. Default value is NONE.
    CommonAttributes []FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationCommonAttribute
    Describes the metadata sent to the HTTP endpoint destination. See common_attributes block below for details.
    ContentEncoding string
    Kinesis Data Firehose uses the content encoding to compress the body of a request before sending the request to the destination. Valid values are NONE and GZIP. Default value is NONE.
    commonAttributes List<FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationCommonAttribute>
    Describes the metadata sent to the HTTP endpoint destination. See common_attributes block below for details.
    contentEncoding String
    Kinesis Data Firehose uses the content encoding to compress the body of a request before sending the request to the destination. Valid values are NONE and GZIP. Default value is NONE.
    commonAttributes FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationCommonAttribute[]
    Describes the metadata sent to the HTTP endpoint destination. See common_attributes block below for details.
    contentEncoding string
    Kinesis Data Firehose uses the content encoding to compress the body of a request before sending the request to the destination. Valid values are NONE and GZIP. Default value is NONE.
    common_attributes Sequence[FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationCommonAttribute]
    Describes the metadata sent to the HTTP endpoint destination. See common_attributes block below for details.
    content_encoding str
    Kinesis Data Firehose uses the content encoding to compress the body of a request before sending the request to the destination. Valid values are NONE and GZIP. Default value is NONE.
    commonAttributes List<Property Map>
    Describes the metadata sent to the HTTP endpoint destination. See common_attributes block below for details.
    contentEncoding String
    Kinesis Data Firehose uses the content encoding to compress the body of a request before sending the request to the destination. Valid values are NONE and GZIP. Default value is NONE.

    FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationCommonAttribute, FirehoseDeliveryStreamHttpEndpointConfigurationRequestConfigurationCommonAttributeArgs

    Name string
    The name of the HTTP endpoint common attribute.
    Value string
    The value of the HTTP endpoint common attribute.
    Name string
    The name of the HTTP endpoint common attribute.
    Value string
    The value of the HTTP endpoint common attribute.
    name String
    The name of the HTTP endpoint common attribute.
    value String
    The value of the HTTP endpoint common attribute.
    name string
    The name of the HTTP endpoint common attribute.
    value string
    The value of the HTTP endpoint common attribute.
    name str
    The name of the HTTP endpoint common attribute.
    value str
    The value of the HTTP endpoint common attribute.
    name String
    The name of the HTTP endpoint common attribute.
    value String
    The value of the HTTP endpoint common attribute.

    FirehoseDeliveryStreamHttpEndpointConfigurationS3Configuration, FirehoseDeliveryStreamHttpEndpointConfigurationS3ConfigurationArgs

    BucketArn string
    The ARN of the S3 bucket
    RoleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    BufferingSize int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    CloudwatchLoggingOptions FirehoseDeliveryStreamHttpEndpointConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    CompressionFormat string
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    ErrorOutputPrefix string
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    KmsKeyArn string
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    Prefix string
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    BucketArn string
    The ARN of the S3 bucket
    RoleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    BufferingSize int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    CloudwatchLoggingOptions FirehoseDeliveryStreamHttpEndpointConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    CompressionFormat string
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    ErrorOutputPrefix string
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    KmsKeyArn string
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    Prefix string
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucketArn String
    The ARN of the S3 bucket
    roleArn String
    The ARN of the role used to access the Amazon MSK cluster.
    bufferingInterval Integer
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize Integer
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions FirehoseDeliveryStreamHttpEndpointConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compressionFormat String
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    errorOutputPrefix String
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kmsKeyArn String
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix String
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucketArn string
    The ARN of the S3 bucket
    roleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    bufferingInterval number
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize number
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions FirehoseDeliveryStreamHttpEndpointConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compressionFormat string
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    errorOutputPrefix string
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kmsKeyArn string
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix string
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucket_arn str
    The ARN of the S3 bucket
    role_arn str
    The ARN of the role used to access the Amazon MSK cluster.
    buffering_interval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    buffering_size int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatch_logging_options FirehoseDeliveryStreamHttpEndpointConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compression_format str
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    error_output_prefix str
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kms_key_arn str
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix str
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucketArn String
    The ARN of the S3 bucket
    roleArn String
    The ARN of the role used to access the Amazon MSK cluster.
    bufferingInterval Number
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize Number
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions Property Map
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compressionFormat String
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    errorOutputPrefix String
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kmsKeyArn String
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix String
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket

    FirehoseDeliveryStreamHttpEndpointConfigurationS3ConfigurationCloudwatchLoggingOptions, FirehoseDeliveryStreamHttpEndpointConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs

    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled boolean
    Enables or disables the logging. Defaults to false.
    logGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled bool
    Enables or disables the logging. Defaults to false.
    log_group_name str
    The CloudWatch group name for logging. This value is required if enabled is true.
    log_stream_name str
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.

    FirehoseDeliveryStreamKinesisSourceConfiguration, FirehoseDeliveryStreamKinesisSourceConfigurationArgs

    KinesisStreamArn string
    The kinesis stream used as the source of the firehose delivery stream.
    RoleArn string
    The ARN of the role that provides access to the source Kinesis stream.
    KinesisStreamArn string
    The kinesis stream used as the source of the firehose delivery stream.
    RoleArn string
    The ARN of the role that provides access to the source Kinesis stream.
    kinesisStreamArn String
    The kinesis stream used as the source of the firehose delivery stream.
    roleArn String
    The ARN of the role that provides access to the source Kinesis stream.
    kinesisStreamArn string
    The kinesis stream used as the source of the firehose delivery stream.
    roleArn string
    The ARN of the role that provides access to the source Kinesis stream.
    kinesis_stream_arn str
    The kinesis stream used as the source of the firehose delivery stream.
    role_arn str
    The ARN of the role that provides access to the source Kinesis stream.
    kinesisStreamArn String
    The kinesis stream used as the source of the firehose delivery stream.
    roleArn String
    The ARN of the role that provides access to the source Kinesis stream.

    FirehoseDeliveryStreamMskSourceConfiguration, FirehoseDeliveryStreamMskSourceConfigurationArgs

    AuthenticationConfiguration FirehoseDeliveryStreamMskSourceConfigurationAuthenticationConfiguration
    The authentication configuration of the Amazon MSK cluster. See authentication_configuration block below for details.
    MskClusterArn string
    The ARN of the Amazon MSK cluster.
    TopicName string
    The topic name within the Amazon MSK cluster.
    AuthenticationConfiguration FirehoseDeliveryStreamMskSourceConfigurationAuthenticationConfiguration
    The authentication configuration of the Amazon MSK cluster. See authentication_configuration block below for details.
    MskClusterArn string
    The ARN of the Amazon MSK cluster.
    TopicName string
    The topic name within the Amazon MSK cluster.
    authenticationConfiguration FirehoseDeliveryStreamMskSourceConfigurationAuthenticationConfiguration
    The authentication configuration of the Amazon MSK cluster. See authentication_configuration block below for details.
    mskClusterArn String
    The ARN of the Amazon MSK cluster.
    topicName String
    The topic name within the Amazon MSK cluster.
    authenticationConfiguration FirehoseDeliveryStreamMskSourceConfigurationAuthenticationConfiguration
    The authentication configuration of the Amazon MSK cluster. See authentication_configuration block below for details.
    mskClusterArn string
    The ARN of the Amazon MSK cluster.
    topicName string
    The topic name within the Amazon MSK cluster.
    authentication_configuration FirehoseDeliveryStreamMskSourceConfigurationAuthenticationConfiguration
    The authentication configuration of the Amazon MSK cluster. See authentication_configuration block below for details.
    msk_cluster_arn str
    The ARN of the Amazon MSK cluster.
    topic_name str
    The topic name within the Amazon MSK cluster.
    authenticationConfiguration Property Map
    The authentication configuration of the Amazon MSK cluster. See authentication_configuration block below for details.
    mskClusterArn String
    The ARN of the Amazon MSK cluster.
    topicName String
    The topic name within the Amazon MSK cluster.

    FirehoseDeliveryStreamMskSourceConfigurationAuthenticationConfiguration, FirehoseDeliveryStreamMskSourceConfigurationAuthenticationConfigurationArgs

    Connectivity string
    The type of connectivity used to access the Amazon MSK cluster. Valid values: PUBLIC, PRIVATE.
    RoleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    Connectivity string
    The type of connectivity used to access the Amazon MSK cluster. Valid values: PUBLIC, PRIVATE.
    RoleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    connectivity String
    The type of connectivity used to access the Amazon MSK cluster. Valid values: PUBLIC, PRIVATE.
    roleArn String
    The ARN of the role used to access the Amazon MSK cluster.
    connectivity string
    The type of connectivity used to access the Amazon MSK cluster. Valid values: PUBLIC, PRIVATE.
    roleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    connectivity str
    The type of connectivity used to access the Amazon MSK cluster. Valid values: PUBLIC, PRIVATE.
    role_arn str
    The ARN of the role used to access the Amazon MSK cluster.
    connectivity String
    The type of connectivity used to access the Amazon MSK cluster. Valid values: PUBLIC, PRIVATE.
    roleArn String
    The ARN of the role used to access the Amazon MSK cluster.

    FirehoseDeliveryStreamOpensearchConfiguration, FirehoseDeliveryStreamOpensearchConfigurationArgs

    IndexName string
    The OpenSearch index name.
    RoleArn string
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon ES Configuration API and for indexing documents. The IAM role must have permission for DescribeDomain, DescribeDomains, and DescribeDomainConfig. The pattern needs to be arn:.*.
    S3Configuration FirehoseDeliveryStreamOpensearchConfigurationS3Configuration
    The S3 Configuration. See s3_configuration block below for details.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    BufferingSize int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    CloudwatchLoggingOptions FirehoseDeliveryStreamOpensearchConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    ClusterEndpoint string
    The endpoint to use when communicating with the cluster. Conflicts with domain_arn.
    DocumentIdOptions FirehoseDeliveryStreamOpensearchConfigurationDocumentIdOptions
    The method for setting up document ID. See [document_id_options block] below for details.
    DomainArn string
    The ARN of the Amazon ES domain. The pattern needs to be arn:.*. Conflicts with cluster_endpoint.
    IndexRotationPeriod string
    The OpenSearch index rotation period. Index rotation appends a timestamp to the IndexName to facilitate expiration of old data. Valid values are NoRotation, OneHour, OneDay, OneWeek, and OneMonth. The default value is OneDay.
    ProcessingConfiguration FirehoseDeliveryStreamOpensearchConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    RetryDuration int
    After an initial failure to deliver to Amazon OpenSearch, the total amount of time, in seconds between 0 to 7200, during which Firehose re-attempts delivery (including the first attempt). After this time has elapsed, the failed documents are written to Amazon S3. The default value is 300s. There will be no retry if the value is 0.
    S3BackupMode string
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDocumentsOnly and AllDocuments. Default value is FailedDocumentsOnly.
    TypeName string
    The Elasticsearch type name with maximum length of 100 characters. Types are deprecated in OpenSearch_1.1. TypeName must be empty.
    VpcConfig FirehoseDeliveryStreamOpensearchConfigurationVpcConfig
    The VPC configuration for the delivery stream to connect to OpenSearch associated with the VPC. See vpc_config block below for details.
    IndexName string
    The OpenSearch index name.
    RoleArn string
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon ES Configuration API and for indexing documents. The IAM role must have permission for DescribeDomain, DescribeDomains, and DescribeDomainConfig. The pattern needs to be arn:.*.
    S3Configuration FirehoseDeliveryStreamOpensearchConfigurationS3Configuration
    The S3 Configuration. See s3_configuration block below for details.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    BufferingSize int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    CloudwatchLoggingOptions FirehoseDeliveryStreamOpensearchConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    ClusterEndpoint string
    The endpoint to use when communicating with the cluster. Conflicts with domain_arn.
    DocumentIdOptions FirehoseDeliveryStreamOpensearchConfigurationDocumentIdOptions
    The method for setting up document ID. See [document_id_options block] below for details.
    DomainArn string
    The ARN of the Amazon ES domain. The pattern needs to be arn:.*. Conflicts with cluster_endpoint.
    IndexRotationPeriod string
    The OpenSearch index rotation period. Index rotation appends a timestamp to the IndexName to facilitate expiration of old data. Valid values are NoRotation, OneHour, OneDay, OneWeek, and OneMonth. The default value is OneDay.
    ProcessingConfiguration FirehoseDeliveryStreamOpensearchConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    RetryDuration int
    After an initial failure to deliver to Amazon OpenSearch, the total amount of time, in seconds between 0 to 7200, during which Firehose re-attempts delivery (including the first attempt). After this time has elapsed, the failed documents are written to Amazon S3. The default value is 300s. There will be no retry if the value is 0.
    S3BackupMode string
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDocumentsOnly and AllDocuments. Default value is FailedDocumentsOnly.
    TypeName string
    The Elasticsearch type name with maximum length of 100 characters. Types are deprecated in OpenSearch_1.1. TypeName must be empty.
    VpcConfig FirehoseDeliveryStreamOpensearchConfigurationVpcConfig
    The VPC configuration for the delivery stream to connect to OpenSearch associated with the VPC. See vpc_config block below for details.
    indexName String
    The OpenSearch index name.
    roleArn String
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon ES Configuration API and for indexing documents. The IAM role must have permission for DescribeDomain, DescribeDomains, and DescribeDomainConfig. The pattern needs to be arn:.*.
    s3Configuration FirehoseDeliveryStreamOpensearchConfigurationS3Configuration
    The S3 Configuration. See s3_configuration block below for details.
    bufferingInterval Integer
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize Integer
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions FirehoseDeliveryStreamOpensearchConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    clusterEndpoint String
    The endpoint to use when communicating with the cluster. Conflicts with domain_arn.
    documentIdOptions FirehoseDeliveryStreamOpensearchConfigurationDocumentIdOptions
    The method for setting up document ID. See [document_id_options block] below for details.
    domainArn String
    The ARN of the Amazon ES domain. The pattern needs to be arn:.*. Conflicts with cluster_endpoint.
    indexRotationPeriod String
    The OpenSearch index rotation period. Index rotation appends a timestamp to the IndexName to facilitate expiration of old data. Valid values are NoRotation, OneHour, OneDay, OneWeek, and OneMonth. The default value is OneDay.
    processingConfiguration FirehoseDeliveryStreamOpensearchConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    retryDuration Integer
    After an initial failure to deliver to Amazon OpenSearch, the total amount of time, in seconds between 0 to 7200, during which Firehose re-attempts delivery (including the first attempt). After this time has elapsed, the failed documents are written to Amazon S3. The default value is 300s. There will be no retry if the value is 0.
    s3BackupMode String
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDocumentsOnly and AllDocuments. Default value is FailedDocumentsOnly.
    typeName String
    The Elasticsearch type name with maximum length of 100 characters. Types are deprecated in OpenSearch_1.1. TypeName must be empty.
    vpcConfig FirehoseDeliveryStreamOpensearchConfigurationVpcConfig
    The VPC configuration for the delivery stream to connect to OpenSearch associated with the VPC. See vpc_config block below for details.
    indexName string
    The OpenSearch index name.
    roleArn string
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon ES Configuration API and for indexing documents. The IAM role must have permission for DescribeDomain, DescribeDomains, and DescribeDomainConfig. The pattern needs to be arn:.*.
    s3Configuration FirehoseDeliveryStreamOpensearchConfigurationS3Configuration
    The S3 Configuration. See s3_configuration block below for details.
    bufferingInterval number
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize number
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions FirehoseDeliveryStreamOpensearchConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    clusterEndpoint string
    The endpoint to use when communicating with the cluster. Conflicts with domain_arn.
    documentIdOptions FirehoseDeliveryStreamOpensearchConfigurationDocumentIdOptions
    The method for setting up document ID. See [document_id_options block] below for details.
    domainArn string
    The ARN of the Amazon ES domain. The pattern needs to be arn:.*. Conflicts with cluster_endpoint.
    indexRotationPeriod string
    The OpenSearch index rotation period. Index rotation appends a timestamp to the IndexName to facilitate expiration of old data. Valid values are NoRotation, OneHour, OneDay, OneWeek, and OneMonth. The default value is OneDay.
    processingConfiguration FirehoseDeliveryStreamOpensearchConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    retryDuration number
    After an initial failure to deliver to Amazon OpenSearch, the total amount of time, in seconds between 0 to 7200, during which Firehose re-attempts delivery (including the first attempt). After this time has elapsed, the failed documents are written to Amazon S3. The default value is 300s. There will be no retry if the value is 0.
    s3BackupMode string
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDocumentsOnly and AllDocuments. Default value is FailedDocumentsOnly.
    typeName string
    The Elasticsearch type name with maximum length of 100 characters. Types are deprecated in OpenSearch_1.1. TypeName must be empty.
    vpcConfig FirehoseDeliveryStreamOpensearchConfigurationVpcConfig
    The VPC configuration for the delivery stream to connect to OpenSearch associated with the VPC. See vpc_config block below for details.
    index_name str
    The OpenSearch index name.
    role_arn str
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon ES Configuration API and for indexing documents. The IAM role must have permission for DescribeDomain, DescribeDomains, and DescribeDomainConfig. The pattern needs to be arn:.*.
    s3_configuration FirehoseDeliveryStreamOpensearchConfigurationS3Configuration
    The S3 Configuration. See s3_configuration block below for details.
    buffering_interval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    buffering_size int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatch_logging_options FirehoseDeliveryStreamOpensearchConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    cluster_endpoint str
    The endpoint to use when communicating with the cluster. Conflicts with domain_arn.
    document_id_options FirehoseDeliveryStreamOpensearchConfigurationDocumentIdOptions
    The method for setting up document ID. See [document_id_options block] below for details.
    domain_arn str
    The ARN of the Amazon ES domain. The pattern needs to be arn:.*. Conflicts with cluster_endpoint.
    index_rotation_period str
    The OpenSearch index rotation period. Index rotation appends a timestamp to the IndexName to facilitate expiration of old data. Valid values are NoRotation, OneHour, OneDay, OneWeek, and OneMonth. The default value is OneDay.
    processing_configuration FirehoseDeliveryStreamOpensearchConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    retry_duration int
    After an initial failure to deliver to Amazon OpenSearch, the total amount of time, in seconds between 0 to 7200, during which Firehose re-attempts delivery (including the first attempt). After this time has elapsed, the failed documents are written to Amazon S3. The default value is 300s. There will be no retry if the value is 0.
    s3_backup_mode str
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDocumentsOnly and AllDocuments. Default value is FailedDocumentsOnly.
    type_name str
    The Elasticsearch type name with maximum length of 100 characters. Types are deprecated in OpenSearch_1.1. TypeName must be empty.
    vpc_config FirehoseDeliveryStreamOpensearchConfigurationVpcConfig
    The VPC configuration for the delivery stream to connect to OpenSearch associated with the VPC. See vpc_config block below for details.
    indexName String
    The OpenSearch index name.
    roleArn String
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon ES Configuration API and for indexing documents. The IAM role must have permission for DescribeDomain, DescribeDomains, and DescribeDomainConfig. The pattern needs to be arn:.*.
    s3Configuration Property Map
    The S3 Configuration. See s3_configuration block below for details.
    bufferingInterval Number
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize Number
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions Property Map
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    clusterEndpoint String
    The endpoint to use when communicating with the cluster. Conflicts with domain_arn.
    documentIdOptions Property Map
    The method for setting up document ID. See [document_id_options block] below for details.
    domainArn String
    The ARN of the Amazon ES domain. The pattern needs to be arn:.*. Conflicts with cluster_endpoint.
    indexRotationPeriod String
    The OpenSearch index rotation period. Index rotation appends a timestamp to the IndexName to facilitate expiration of old data. Valid values are NoRotation, OneHour, OneDay, OneWeek, and OneMonth. The default value is OneDay.
    processingConfiguration Property Map
    The data processing configuration. See processing_configuration block below for details.
    retryDuration Number
    After an initial failure to deliver to Amazon OpenSearch, the total amount of time, in seconds between 0 to 7200, during which Firehose re-attempts delivery (including the first attempt). After this time has elapsed, the failed documents are written to Amazon S3. The default value is 300s. There will be no retry if the value is 0.
    s3BackupMode String
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDocumentsOnly and AllDocuments. Default value is FailedDocumentsOnly.
    typeName String
    The Elasticsearch type name with maximum length of 100 characters. Types are deprecated in OpenSearch_1.1. TypeName must be empty.
    vpcConfig Property Map
    The VPC configuration for the delivery stream to connect to OpenSearch associated with the VPC. See vpc_config block below for details.

    FirehoseDeliveryStreamOpensearchConfigurationCloudwatchLoggingOptions, FirehoseDeliveryStreamOpensearchConfigurationCloudwatchLoggingOptionsArgs

    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled boolean
    Enables or disables the logging. Defaults to false.
    logGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled bool
    Enables or disables the logging. Defaults to false.
    log_group_name str
    The CloudWatch group name for logging. This value is required if enabled is true.
    log_stream_name str
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.

    FirehoseDeliveryStreamOpensearchConfigurationDocumentIdOptions, FirehoseDeliveryStreamOpensearchConfigurationDocumentIdOptionsArgs

    DefaultDocumentIdFormat string
    The method for setting up document ID. Valid values: FIREHOSE_DEFAULT, NO_DOCUMENT_ID.
    DefaultDocumentIdFormat string
    The method for setting up document ID. Valid values: FIREHOSE_DEFAULT, NO_DOCUMENT_ID.
    defaultDocumentIdFormat String
    The method for setting up document ID. Valid values: FIREHOSE_DEFAULT, NO_DOCUMENT_ID.
    defaultDocumentIdFormat string
    The method for setting up document ID. Valid values: FIREHOSE_DEFAULT, NO_DOCUMENT_ID.
    default_document_id_format str
    The method for setting up document ID. Valid values: FIREHOSE_DEFAULT, NO_DOCUMENT_ID.
    defaultDocumentIdFormat String
    The method for setting up document ID. Valid values: FIREHOSE_DEFAULT, NO_DOCUMENT_ID.

    FirehoseDeliveryStreamOpensearchConfigurationProcessingConfiguration, FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationArgs

    Enabled bool
    Enables or disables data processing.
    Processors List<FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessor>
    Specifies the data processors as multiple blocks. See processors block below for details.
    Enabled bool
    Enables or disables data processing.
    Processors []FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessor
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled Boolean
    Enables or disables data processing.
    processors List<FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessor>
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled boolean
    Enables or disables data processing.
    processors FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessor[]
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled bool
    Enables or disables data processing.
    processors Sequence[FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessor]
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled Boolean
    Enables or disables data processing.
    processors List<Property Map>
    Specifies the data processors as multiple blocks. See processors block below for details.

    FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessor, FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorArgs

    Type string
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    Parameters List<FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorParameter>
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    Type string
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    Parameters []FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorParameter
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type String
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters List<FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorParameter>
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type string
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorParameter[]
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type str
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters Sequence[FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorParameter]
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type String
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters List<Property Map>
    Specifies the processor parameters as multiple blocks. See parameters block below for details.

    FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorParameter, FirehoseDeliveryStreamOpensearchConfigurationProcessingConfigurationProcessorParameterArgs

    ParameterName string
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    ParameterValue string

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    ParameterName string
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    ParameterValue string

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameterName String
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameterValue String

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameterName string
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameterValue string

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameter_name str
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameter_value str

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameterName String
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameterValue String

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    FirehoseDeliveryStreamOpensearchConfigurationS3Configuration, FirehoseDeliveryStreamOpensearchConfigurationS3ConfigurationArgs

    BucketArn string
    The ARN of the S3 bucket
    RoleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    BufferingSize int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    CloudwatchLoggingOptions FirehoseDeliveryStreamOpensearchConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    CompressionFormat string
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    ErrorOutputPrefix string
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    KmsKeyArn string
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    Prefix string
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    BucketArn string
    The ARN of the S3 bucket
    RoleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    BufferingSize int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    CloudwatchLoggingOptions FirehoseDeliveryStreamOpensearchConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    CompressionFormat string
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    ErrorOutputPrefix string
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    KmsKeyArn string
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    Prefix string
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucketArn String
    The ARN of the S3 bucket
    roleArn String
    The ARN of the role used to access the Amazon MSK cluster.
    bufferingInterval Integer
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize Integer
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions FirehoseDeliveryStreamOpensearchConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compressionFormat String
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    errorOutputPrefix String
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kmsKeyArn String
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix String
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucketArn string
    The ARN of the S3 bucket
    roleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    bufferingInterval number
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize number
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions FirehoseDeliveryStreamOpensearchConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compressionFormat string
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    errorOutputPrefix string
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kmsKeyArn string
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix string
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucket_arn str
    The ARN of the S3 bucket
    role_arn str
    The ARN of the role used to access the Amazon MSK cluster.
    buffering_interval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    buffering_size int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatch_logging_options FirehoseDeliveryStreamOpensearchConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compression_format str
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    error_output_prefix str
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kms_key_arn str
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix str
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucketArn String
    The ARN of the S3 bucket
    roleArn String
    The ARN of the role used to access the Amazon MSK cluster.
    bufferingInterval Number
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize Number
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions Property Map
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compressionFormat String
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    errorOutputPrefix String
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kmsKeyArn String
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix String
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket

    FirehoseDeliveryStreamOpensearchConfigurationS3ConfigurationCloudwatchLoggingOptions, FirehoseDeliveryStreamOpensearchConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs

    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled boolean
    Enables or disables the logging. Defaults to false.
    logGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled bool
    Enables or disables the logging. Defaults to false.
    log_group_name str
    The CloudWatch group name for logging. This value is required if enabled is true.
    log_stream_name str
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.

    FirehoseDeliveryStreamOpensearchConfigurationVpcConfig, FirehoseDeliveryStreamOpensearchConfigurationVpcConfigArgs

    RoleArn string
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon EC2 configuration API and for creating network interfaces. Make sure role has necessary IAM permissions
    SecurityGroupIds List<string>
    A list of security group IDs to associate with Kinesis Firehose.
    SubnetIds List<string>
    A list of subnet IDs to associate with Kinesis Firehose.
    VpcId string
    RoleArn string
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon EC2 configuration API and for creating network interfaces. Make sure role has necessary IAM permissions
    SecurityGroupIds []string
    A list of security group IDs to associate with Kinesis Firehose.
    SubnetIds []string
    A list of subnet IDs to associate with Kinesis Firehose.
    VpcId string
    roleArn String
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon EC2 configuration API and for creating network interfaces. Make sure role has necessary IAM permissions
    securityGroupIds List<String>
    A list of security group IDs to associate with Kinesis Firehose.
    subnetIds List<String>
    A list of subnet IDs to associate with Kinesis Firehose.
    vpcId String
    roleArn string
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon EC2 configuration API and for creating network interfaces. Make sure role has necessary IAM permissions
    securityGroupIds string[]
    A list of security group IDs to associate with Kinesis Firehose.
    subnetIds string[]
    A list of subnet IDs to associate with Kinesis Firehose.
    vpcId string
    role_arn str
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon EC2 configuration API and for creating network interfaces. Make sure role has necessary IAM permissions
    security_group_ids Sequence[str]
    A list of security group IDs to associate with Kinesis Firehose.
    subnet_ids Sequence[str]
    A list of subnet IDs to associate with Kinesis Firehose.
    vpc_id str
    roleArn String
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon EC2 configuration API and for creating network interfaces. Make sure role has necessary IAM permissions
    securityGroupIds List<String>
    A list of security group IDs to associate with Kinesis Firehose.
    subnetIds List<String>
    A list of subnet IDs to associate with Kinesis Firehose.
    vpcId String

    FirehoseDeliveryStreamOpensearchserverlessConfiguration, FirehoseDeliveryStreamOpensearchserverlessConfigurationArgs

    CollectionEndpoint string
    The endpoint to use when communicating with the collection in the Serverless offering for Amazon OpenSearch Service.
    IndexName string
    The Serverless offering for Amazon OpenSearch Service index name.
    RoleArn string
    The Amazon Resource Name (ARN) of the IAM role to be assumed by Kinesis Data Firehose for calling the Serverless offering for Amazon OpenSearch Service Configuration API and for indexing documents. The pattern needs to be arn:.*.
    S3Configuration FirehoseDeliveryStreamOpensearchserverlessConfigurationS3Configuration
    The S3 Configuration. See s3_configuration block below for details.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    BufferingSize int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    CloudwatchLoggingOptions FirehoseDeliveryStreamOpensearchserverlessConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    ProcessingConfiguration FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    RetryDuration int
    After an initial failure to deliver to the Serverless offering for Amazon OpenSearch Service, the total amount of time, in seconds between 0 to 7200, during which Kinesis Data Firehose retries delivery (including the first attempt). After this time has elapsed, the failed documents are written to Amazon S3. The default value is 300s. There will be no retry if the value is 0.
    S3BackupMode string
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDocumentsOnly and AllDocuments. Default value is FailedDocumentsOnly.
    VpcConfig FirehoseDeliveryStreamOpensearchserverlessConfigurationVpcConfig
    The VPC configuration for the delivery stream to connect to OpenSearch Serverless associated with the VPC. See vpc_config block below for details.
    CollectionEndpoint string
    The endpoint to use when communicating with the collection in the Serverless offering for Amazon OpenSearch Service.
    IndexName string
    The Serverless offering for Amazon OpenSearch Service index name.
    RoleArn string
    The Amazon Resource Name (ARN) of the IAM role to be assumed by Kinesis Data Firehose for calling the Serverless offering for Amazon OpenSearch Service Configuration API and for indexing documents. The pattern needs to be arn:.*.
    S3Configuration FirehoseDeliveryStreamOpensearchserverlessConfigurationS3Configuration
    The S3 Configuration. See s3_configuration block below for details.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    BufferingSize int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    CloudwatchLoggingOptions FirehoseDeliveryStreamOpensearchserverlessConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    ProcessingConfiguration FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    RetryDuration int
    After an initial failure to deliver to the Serverless offering for Amazon OpenSearch Service, the total amount of time, in seconds between 0 to 7200, during which Kinesis Data Firehose retries delivery (including the first attempt). After this time has elapsed, the failed documents are written to Amazon S3. The default value is 300s. There will be no retry if the value is 0.
    S3BackupMode string
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDocumentsOnly and AllDocuments. Default value is FailedDocumentsOnly.
    VpcConfig FirehoseDeliveryStreamOpensearchserverlessConfigurationVpcConfig
    The VPC configuration for the delivery stream to connect to OpenSearch Serverless associated with the VPC. See vpc_config block below for details.
    collectionEndpoint String
    The endpoint to use when communicating with the collection in the Serverless offering for Amazon OpenSearch Service.
    indexName String
    The Serverless offering for Amazon OpenSearch Service index name.
    roleArn String
    The Amazon Resource Name (ARN) of the IAM role to be assumed by Kinesis Data Firehose for calling the Serverless offering for Amazon OpenSearch Service Configuration API and for indexing documents. The pattern needs to be arn:.*.
    s3Configuration FirehoseDeliveryStreamOpensearchserverlessConfigurationS3Configuration
    The S3 Configuration. See s3_configuration block below for details.
    bufferingInterval Integer
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize Integer
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions FirehoseDeliveryStreamOpensearchserverlessConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    processingConfiguration FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    retryDuration Integer
    After an initial failure to deliver to the Serverless offering for Amazon OpenSearch Service, the total amount of time, in seconds between 0 to 7200, during which Kinesis Data Firehose retries delivery (including the first attempt). After this time has elapsed, the failed documents are written to Amazon S3. The default value is 300s. There will be no retry if the value is 0.
    s3BackupMode String
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDocumentsOnly and AllDocuments. Default value is FailedDocumentsOnly.
    vpcConfig FirehoseDeliveryStreamOpensearchserverlessConfigurationVpcConfig
    The VPC configuration for the delivery stream to connect to OpenSearch Serverless associated with the VPC. See vpc_config block below for details.
    collectionEndpoint string
    The endpoint to use when communicating with the collection in the Serverless offering for Amazon OpenSearch Service.
    indexName string
    The Serverless offering for Amazon OpenSearch Service index name.
    roleArn string
    The Amazon Resource Name (ARN) of the IAM role to be assumed by Kinesis Data Firehose for calling the Serverless offering for Amazon OpenSearch Service Configuration API and for indexing documents. The pattern needs to be arn:.*.
    s3Configuration FirehoseDeliveryStreamOpensearchserverlessConfigurationS3Configuration
    The S3 Configuration. See s3_configuration block below for details.
    bufferingInterval number
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize number
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions FirehoseDeliveryStreamOpensearchserverlessConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    processingConfiguration FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    retryDuration number
    After an initial failure to deliver to the Serverless offering for Amazon OpenSearch Service, the total amount of time, in seconds between 0 to 7200, during which Kinesis Data Firehose retries delivery (including the first attempt). After this time has elapsed, the failed documents are written to Amazon S3. The default value is 300s. There will be no retry if the value is 0.
    s3BackupMode string
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDocumentsOnly and AllDocuments. Default value is FailedDocumentsOnly.
    vpcConfig FirehoseDeliveryStreamOpensearchserverlessConfigurationVpcConfig
    The VPC configuration for the delivery stream to connect to OpenSearch Serverless associated with the VPC. See vpc_config block below for details.
    collection_endpoint str
    The endpoint to use when communicating with the collection in the Serverless offering for Amazon OpenSearch Service.
    index_name str
    The Serverless offering for Amazon OpenSearch Service index name.
    role_arn str
    The Amazon Resource Name (ARN) of the IAM role to be assumed by Kinesis Data Firehose for calling the Serverless offering for Amazon OpenSearch Service Configuration API and for indexing documents. The pattern needs to be arn:.*.
    s3_configuration FirehoseDeliveryStreamOpensearchserverlessConfigurationS3Configuration
    The S3 Configuration. See s3_configuration block below for details.
    buffering_interval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    buffering_size int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatch_logging_options FirehoseDeliveryStreamOpensearchserverlessConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    processing_configuration FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    retry_duration int
    After an initial failure to deliver to the Serverless offering for Amazon OpenSearch Service, the total amount of time, in seconds between 0 to 7200, during which Kinesis Data Firehose retries delivery (including the first attempt). After this time has elapsed, the failed documents are written to Amazon S3. The default value is 300s. There will be no retry if the value is 0.
    s3_backup_mode str
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDocumentsOnly and AllDocuments. Default value is FailedDocumentsOnly.
    vpc_config FirehoseDeliveryStreamOpensearchserverlessConfigurationVpcConfig
    The VPC configuration for the delivery stream to connect to OpenSearch Serverless associated with the VPC. See vpc_config block below for details.
    collectionEndpoint String
    The endpoint to use when communicating with the collection in the Serverless offering for Amazon OpenSearch Service.
    indexName String
    The Serverless offering for Amazon OpenSearch Service index name.
    roleArn String
    The Amazon Resource Name (ARN) of the IAM role to be assumed by Kinesis Data Firehose for calling the Serverless offering for Amazon OpenSearch Service Configuration API and for indexing documents. The pattern needs to be arn:.*.
    s3Configuration Property Map
    The S3 Configuration. See s3_configuration block below for details.
    bufferingInterval Number
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize Number
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions Property Map
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    processingConfiguration Property Map
    The data processing configuration. See processing_configuration block below for details.
    retryDuration Number
    After an initial failure to deliver to the Serverless offering for Amazon OpenSearch Service, the total amount of time, in seconds between 0 to 7200, during which Kinesis Data Firehose retries delivery (including the first attempt). After this time has elapsed, the failed documents are written to Amazon S3. The default value is 300s. There will be no retry if the value is 0.
    s3BackupMode String
    Defines how documents should be delivered to Amazon S3. Valid values are FailedDocumentsOnly and AllDocuments. Default value is FailedDocumentsOnly.
    vpcConfig Property Map
    The VPC configuration for the delivery stream to connect to OpenSearch Serverless associated with the VPC. See vpc_config block below for details.

    FirehoseDeliveryStreamOpensearchserverlessConfigurationCloudwatchLoggingOptions, FirehoseDeliveryStreamOpensearchserverlessConfigurationCloudwatchLoggingOptionsArgs

    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled boolean
    Enables or disables the logging. Defaults to false.
    logGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled bool
    Enables or disables the logging. Defaults to false.
    log_group_name str
    The CloudWatch group name for logging. This value is required if enabled is true.
    log_stream_name str
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.

    FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfiguration, FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationArgs

    Enabled bool
    Enables or disables data processing.
    Processors List<FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessor>
    Specifies the data processors as multiple blocks. See processors block below for details.
    Enabled bool
    Enables or disables data processing.
    Processors []FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessor
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled Boolean
    Enables or disables data processing.
    processors List<FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessor>
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled boolean
    Enables or disables data processing.
    processors FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessor[]
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled bool
    Enables or disables data processing.
    processors Sequence[FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessor]
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled Boolean
    Enables or disables data processing.
    processors List<Property Map>
    Specifies the data processors as multiple blocks. See processors block below for details.

    FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessor, FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorArgs

    Type string
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    Parameters List<FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorParameter>
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    Type string
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    Parameters []FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorParameter
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type String
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters List<FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorParameter>
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type string
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorParameter[]
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type str
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters Sequence[FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorParameter]
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type String
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters List<Property Map>
    Specifies the processor parameters as multiple blocks. See parameters block below for details.

    FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorParameter, FirehoseDeliveryStreamOpensearchserverlessConfigurationProcessingConfigurationProcessorParameterArgs

    ParameterName string
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    ParameterValue string

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    ParameterName string
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    ParameterValue string

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameterName String
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameterValue String

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameterName string
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameterValue string

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameter_name str
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameter_value str

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameterName String
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameterValue String

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    FirehoseDeliveryStreamOpensearchserverlessConfigurationS3Configuration, FirehoseDeliveryStreamOpensearchserverlessConfigurationS3ConfigurationArgs

    BucketArn string
    The ARN of the S3 bucket
    RoleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    BufferingSize int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    CloudwatchLoggingOptions FirehoseDeliveryStreamOpensearchserverlessConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    CompressionFormat string
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    ErrorOutputPrefix string
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    KmsKeyArn string
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    Prefix string
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    BucketArn string
    The ARN of the S3 bucket
    RoleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    BufferingSize int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    CloudwatchLoggingOptions FirehoseDeliveryStreamOpensearchserverlessConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    CompressionFormat string
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    ErrorOutputPrefix string
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    KmsKeyArn string
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    Prefix string
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucketArn String
    The ARN of the S3 bucket
    roleArn String
    The ARN of the role used to access the Amazon MSK cluster.
    bufferingInterval Integer
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize Integer
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions FirehoseDeliveryStreamOpensearchserverlessConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compressionFormat String
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    errorOutputPrefix String
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kmsKeyArn String
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix String
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucketArn string
    The ARN of the S3 bucket
    roleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    bufferingInterval number
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize number
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions FirehoseDeliveryStreamOpensearchserverlessConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compressionFormat string
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    errorOutputPrefix string
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kmsKeyArn string
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix string
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucket_arn str
    The ARN of the S3 bucket
    role_arn str
    The ARN of the role used to access the Amazon MSK cluster.
    buffering_interval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    buffering_size int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatch_logging_options FirehoseDeliveryStreamOpensearchserverlessConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compression_format str
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    error_output_prefix str
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kms_key_arn str
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix str
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucketArn String
    The ARN of the S3 bucket
    roleArn String
    The ARN of the role used to access the Amazon MSK cluster.
    bufferingInterval Number
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize Number
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions Property Map
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compressionFormat String
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    errorOutputPrefix String
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kmsKeyArn String
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix String
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket

    FirehoseDeliveryStreamOpensearchserverlessConfigurationS3ConfigurationCloudwatchLoggingOptions, FirehoseDeliveryStreamOpensearchserverlessConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs

    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled boolean
    Enables or disables the logging. Defaults to false.
    logGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled bool
    Enables or disables the logging. Defaults to false.
    log_group_name str
    The CloudWatch group name for logging. This value is required if enabled is true.
    log_stream_name str
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.

    FirehoseDeliveryStreamOpensearchserverlessConfigurationVpcConfig, FirehoseDeliveryStreamOpensearchserverlessConfigurationVpcConfigArgs

    RoleArn string
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon EC2 configuration API and for creating network interfaces. Make sure role has necessary IAM permissions
    SecurityGroupIds List<string>
    A list of security group IDs to associate with Kinesis Firehose.
    SubnetIds List<string>
    A list of subnet IDs to associate with Kinesis Firehose.
    VpcId string
    RoleArn string
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon EC2 configuration API and for creating network interfaces. Make sure role has necessary IAM permissions
    SecurityGroupIds []string
    A list of security group IDs to associate with Kinesis Firehose.
    SubnetIds []string
    A list of subnet IDs to associate with Kinesis Firehose.
    VpcId string
    roleArn String
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon EC2 configuration API and for creating network interfaces. Make sure role has necessary IAM permissions
    securityGroupIds List<String>
    A list of security group IDs to associate with Kinesis Firehose.
    subnetIds List<String>
    A list of subnet IDs to associate with Kinesis Firehose.
    vpcId String
    roleArn string
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon EC2 configuration API and for creating network interfaces. Make sure role has necessary IAM permissions
    securityGroupIds string[]
    A list of security group IDs to associate with Kinesis Firehose.
    subnetIds string[]
    A list of subnet IDs to associate with Kinesis Firehose.
    vpcId string
    role_arn str
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon EC2 configuration API and for creating network interfaces. Make sure role has necessary IAM permissions
    security_group_ids Sequence[str]
    A list of security group IDs to associate with Kinesis Firehose.
    subnet_ids Sequence[str]
    A list of subnet IDs to associate with Kinesis Firehose.
    vpc_id str
    roleArn String
    The ARN of the IAM role to be assumed by Firehose for calling the Amazon EC2 configuration API and for creating network interfaces. Make sure role has necessary IAM permissions
    securityGroupIds List<String>
    A list of security group IDs to associate with Kinesis Firehose.
    subnetIds List<String>
    A list of subnet IDs to associate with Kinesis Firehose.
    vpcId String

    FirehoseDeliveryStreamRedshiftConfiguration, FirehoseDeliveryStreamRedshiftConfigurationArgs

    ClusterJdbcurl string
    The jdbcurl of the redshift cluster.
    DataTableName string
    The name of the table in the redshift cluster that the s3 bucket will copy to.
    Password string
    The password for the username above.
    RoleArn string
    The arn of the role the stream assumes.
    S3Configuration FirehoseDeliveryStreamRedshiftConfigurationS3Configuration
    The S3 Configuration. See s3_configuration below for details.
    Username string
    The username that the firehose delivery stream will assume. It is strongly recommended that the username and password provided is used exclusively for Amazon Kinesis Firehose purposes, and that the permissions for the account are restricted for Amazon Redshift INSERT permissions.
    CloudwatchLoggingOptions FirehoseDeliveryStreamRedshiftConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    CopyOptions string
    Copy options for copying the data from the s3 intermediate bucket into redshift, for example to change the default delimiter. For valid values, see the AWS documentation
    DataTableColumns string
    The data table columns that will be targeted by the copy command.
    ProcessingConfiguration FirehoseDeliveryStreamRedshiftConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    RetryDuration int
    The length of time during which Firehose retries delivery after a failure, starting from the initial request and including the first attempt. The default value is 3600 seconds (60 minutes). Firehose does not retry if the value of DurationInSeconds is 0 (zero) or if the first delivery attempt takes longer than the current value.
    S3BackupConfiguration FirehoseDeliveryStreamRedshiftConfigurationS3BackupConfiguration
    The configuration for backup in Amazon S3. Required if s3_backup_mode is Enabled. Supports the same fields as s3_configuration object.
    S3BackupMode string
    The Amazon S3 backup mode. Valid values are Disabled and Enabled. Default value is Disabled.
    ClusterJdbcurl string
    The jdbcurl of the redshift cluster.
    DataTableName string
    The name of the table in the redshift cluster that the s3 bucket will copy to.
    Password string
    The password for the username above.
    RoleArn string
    The arn of the role the stream assumes.
    S3Configuration FirehoseDeliveryStreamRedshiftConfigurationS3Configuration
    The S3 Configuration. See s3_configuration below for details.
    Username string
    The username that the firehose delivery stream will assume. It is strongly recommended that the username and password provided is used exclusively for Amazon Kinesis Firehose purposes, and that the permissions for the account are restricted for Amazon Redshift INSERT permissions.
    CloudwatchLoggingOptions FirehoseDeliveryStreamRedshiftConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    CopyOptions string
    Copy options for copying the data from the s3 intermediate bucket into redshift, for example to change the default delimiter. For valid values, see the AWS documentation
    DataTableColumns string
    The data table columns that will be targeted by the copy command.
    ProcessingConfiguration FirehoseDeliveryStreamRedshiftConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    RetryDuration int
    The length of time during which Firehose retries delivery after a failure, starting from the initial request and including the first attempt. The default value is 3600 seconds (60 minutes). Firehose does not retry if the value of DurationInSeconds is 0 (zero) or if the first delivery attempt takes longer than the current value.
    S3BackupConfiguration FirehoseDeliveryStreamRedshiftConfigurationS3BackupConfiguration
    The configuration for backup in Amazon S3. Required if s3_backup_mode is Enabled. Supports the same fields as s3_configuration object.
    S3BackupMode string
    The Amazon S3 backup mode. Valid values are Disabled and Enabled. Default value is Disabled.
    clusterJdbcurl String
    The jdbcurl of the redshift cluster.
    dataTableName String
    The name of the table in the redshift cluster that the s3 bucket will copy to.
    password String
    The password for the username above.
    roleArn String
    The arn of the role the stream assumes.
    s3Configuration FirehoseDeliveryStreamRedshiftConfigurationS3Configuration
    The S3 Configuration. See s3_configuration below for details.
    username String
    The username that the firehose delivery stream will assume. It is strongly recommended that the username and password provided is used exclusively for Amazon Kinesis Firehose purposes, and that the permissions for the account are restricted for Amazon Redshift INSERT permissions.
    cloudwatchLoggingOptions FirehoseDeliveryStreamRedshiftConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    copyOptions String
    Copy options for copying the data from the s3 intermediate bucket into redshift, for example to change the default delimiter. For valid values, see the AWS documentation
    dataTableColumns String
    The data table columns that will be targeted by the copy command.
    processingConfiguration FirehoseDeliveryStreamRedshiftConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    retryDuration Integer
    The length of time during which Firehose retries delivery after a failure, starting from the initial request and including the first attempt. The default value is 3600 seconds (60 minutes). Firehose does not retry if the value of DurationInSeconds is 0 (zero) or if the first delivery attempt takes longer than the current value.
    s3BackupConfiguration FirehoseDeliveryStreamRedshiftConfigurationS3BackupConfiguration
    The configuration for backup in Amazon S3. Required if s3_backup_mode is Enabled. Supports the same fields as s3_configuration object.
    s3BackupMode String
    The Amazon S3 backup mode. Valid values are Disabled and Enabled. Default value is Disabled.
    clusterJdbcurl string
    The jdbcurl of the redshift cluster.
    dataTableName string
    The name of the table in the redshift cluster that the s3 bucket will copy to.
    password string
    The password for the username above.
    roleArn string
    The arn of the role the stream assumes.
    s3Configuration FirehoseDeliveryStreamRedshiftConfigurationS3Configuration
    The S3 Configuration. See s3_configuration below for details.
    username string
    The username that the firehose delivery stream will assume. It is strongly recommended that the username and password provided is used exclusively for Amazon Kinesis Firehose purposes, and that the permissions for the account are restricted for Amazon Redshift INSERT permissions.
    cloudwatchLoggingOptions FirehoseDeliveryStreamRedshiftConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    copyOptions string
    Copy options for copying the data from the s3 intermediate bucket into redshift, for example to change the default delimiter. For valid values, see the AWS documentation
    dataTableColumns string
    The data table columns that will be targeted by the copy command.
    processingConfiguration FirehoseDeliveryStreamRedshiftConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    retryDuration number
    The length of time during which Firehose retries delivery after a failure, starting from the initial request and including the first attempt. The default value is 3600 seconds (60 minutes). Firehose does not retry if the value of DurationInSeconds is 0 (zero) or if the first delivery attempt takes longer than the current value.
    s3BackupConfiguration FirehoseDeliveryStreamRedshiftConfigurationS3BackupConfiguration
    The configuration for backup in Amazon S3. Required if s3_backup_mode is Enabled. Supports the same fields as s3_configuration object.
    s3BackupMode string
    The Amazon S3 backup mode. Valid values are Disabled and Enabled. Default value is Disabled.
    cluster_jdbcurl str
    The jdbcurl of the redshift cluster.
    data_table_name str
    The name of the table in the redshift cluster that the s3 bucket will copy to.
    password str
    The password for the username above.
    role_arn str
    The arn of the role the stream assumes.
    s3_configuration FirehoseDeliveryStreamRedshiftConfigurationS3Configuration
    The S3 Configuration. See s3_configuration below for details.
    username str
    The username that the firehose delivery stream will assume. It is strongly recommended that the username and password provided is used exclusively for Amazon Kinesis Firehose purposes, and that the permissions for the account are restricted for Amazon Redshift INSERT permissions.
    cloudwatch_logging_options FirehoseDeliveryStreamRedshiftConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    copy_options str
    Copy options for copying the data from the s3 intermediate bucket into redshift, for example to change the default delimiter. For valid values, see the AWS documentation
    data_table_columns str
    The data table columns that will be targeted by the copy command.
    processing_configuration FirehoseDeliveryStreamRedshiftConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    retry_duration int
    The length of time during which Firehose retries delivery after a failure, starting from the initial request and including the first attempt. The default value is 3600 seconds (60 minutes). Firehose does not retry if the value of DurationInSeconds is 0 (zero) or if the first delivery attempt takes longer than the current value.
    s3_backup_configuration FirehoseDeliveryStreamRedshiftConfigurationS3BackupConfiguration
    The configuration for backup in Amazon S3. Required if s3_backup_mode is Enabled. Supports the same fields as s3_configuration object.
    s3_backup_mode str
    The Amazon S3 backup mode. Valid values are Disabled and Enabled. Default value is Disabled.
    clusterJdbcurl String
    The jdbcurl of the redshift cluster.
    dataTableName String
    The name of the table in the redshift cluster that the s3 bucket will copy to.
    password String
    The password for the username above.
    roleArn String
    The arn of the role the stream assumes.
    s3Configuration Property Map
    The S3 Configuration. See s3_configuration below for details.
    username String
    The username that the firehose delivery stream will assume. It is strongly recommended that the username and password provided is used exclusively for Amazon Kinesis Firehose purposes, and that the permissions for the account are restricted for Amazon Redshift INSERT permissions.
    cloudwatchLoggingOptions Property Map
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    copyOptions String
    Copy options for copying the data from the s3 intermediate bucket into redshift, for example to change the default delimiter. For valid values, see the AWS documentation
    dataTableColumns String
    The data table columns that will be targeted by the copy command.
    processingConfiguration Property Map
    The data processing configuration. See processing_configuration block below for details.
    retryDuration Number
    The length of time during which Firehose retries delivery after a failure, starting from the initial request and including the first attempt. The default value is 3600 seconds (60 minutes). Firehose does not retry if the value of DurationInSeconds is 0 (zero) or if the first delivery attempt takes longer than the current value.
    s3BackupConfiguration Property Map
    The configuration for backup in Amazon S3. Required if s3_backup_mode is Enabled. Supports the same fields as s3_configuration object.
    s3BackupMode String
    The Amazon S3 backup mode. Valid values are Disabled and Enabled. Default value is Disabled.

    FirehoseDeliveryStreamRedshiftConfigurationCloudwatchLoggingOptions, FirehoseDeliveryStreamRedshiftConfigurationCloudwatchLoggingOptionsArgs

    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled boolean
    Enables or disables the logging. Defaults to false.
    logGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled bool
    Enables or disables the logging. Defaults to false.
    log_group_name str
    The CloudWatch group name for logging. This value is required if enabled is true.
    log_stream_name str
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.

    FirehoseDeliveryStreamRedshiftConfigurationProcessingConfiguration, FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationArgs

    Enabled bool
    Enables or disables data processing.
    Processors List<FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationProcessor>
    Specifies the data processors as multiple blocks. See processors block below for details.
    Enabled bool
    Enables or disables data processing.
    Processors []FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationProcessor
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled Boolean
    Enables or disables data processing.
    processors List<FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationProcessor>
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled boolean
    Enables or disables data processing.
    processors FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationProcessor[]
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled bool
    Enables or disables data processing.
    processors Sequence[FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationProcessor]
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled Boolean
    Enables or disables data processing.
    processors List<Property Map>
    Specifies the data processors as multiple blocks. See processors block below for details.

    FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationProcessor, FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationProcessorArgs

    Type string
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    Parameters List<FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationProcessorParameter>
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    Type string
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    Parameters []FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationProcessorParameter
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type String
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters List<FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationProcessorParameter>
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type string
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationProcessorParameter[]
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type str
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters Sequence[FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationProcessorParameter]
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type String
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters List<Property Map>
    Specifies the processor parameters as multiple blocks. See parameters block below for details.

    FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationProcessorParameter, FirehoseDeliveryStreamRedshiftConfigurationProcessingConfigurationProcessorParameterArgs

    ParameterName string
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    ParameterValue string

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    ParameterName string
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    ParameterValue string

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameterName String
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameterValue String

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameterName string
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameterValue string

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameter_name str
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameter_value str

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameterName String
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameterValue String

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    FirehoseDeliveryStreamRedshiftConfigurationS3BackupConfiguration, FirehoseDeliveryStreamRedshiftConfigurationS3BackupConfigurationArgs

    BucketArn string
    The ARN of the S3 bucket
    RoleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    BufferingSize int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    CloudwatchLoggingOptions FirehoseDeliveryStreamRedshiftConfigurationS3BackupConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    CompressionFormat string
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    ErrorOutputPrefix string
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    KmsKeyArn string
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    Prefix string
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    BucketArn string
    The ARN of the S3 bucket
    RoleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    BufferingSize int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    CloudwatchLoggingOptions FirehoseDeliveryStreamRedshiftConfigurationS3BackupConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    CompressionFormat string
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    ErrorOutputPrefix string
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    KmsKeyArn string
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    Prefix string
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucketArn String
    The ARN of the S3 bucket
    roleArn String
    The ARN of the role used to access the Amazon MSK cluster.
    bufferingInterval Integer
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize Integer
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions FirehoseDeliveryStreamRedshiftConfigurationS3BackupConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compressionFormat String
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    errorOutputPrefix String
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kmsKeyArn String
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix String
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucketArn string
    The ARN of the S3 bucket
    roleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    bufferingInterval number
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize number
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions FirehoseDeliveryStreamRedshiftConfigurationS3BackupConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compressionFormat string
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    errorOutputPrefix string
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kmsKeyArn string
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix string
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucket_arn str
    The ARN of the S3 bucket
    role_arn str
    The ARN of the role used to access the Amazon MSK cluster.
    buffering_interval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    buffering_size int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatch_logging_options FirehoseDeliveryStreamRedshiftConfigurationS3BackupConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compression_format str
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    error_output_prefix str
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kms_key_arn str
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix str
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucketArn String
    The ARN of the S3 bucket
    roleArn String
    The ARN of the role used to access the Amazon MSK cluster.
    bufferingInterval Number
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize Number
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions Property Map
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compressionFormat String
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    errorOutputPrefix String
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kmsKeyArn String
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix String
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket

    FirehoseDeliveryStreamRedshiftConfigurationS3BackupConfigurationCloudwatchLoggingOptions, FirehoseDeliveryStreamRedshiftConfigurationS3BackupConfigurationCloudwatchLoggingOptionsArgs

    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled boolean
    Enables or disables the logging. Defaults to false.
    logGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled bool
    Enables or disables the logging. Defaults to false.
    log_group_name str
    The CloudWatch group name for logging. This value is required if enabled is true.
    log_stream_name str
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.

    FirehoseDeliveryStreamRedshiftConfigurationS3Configuration, FirehoseDeliveryStreamRedshiftConfigurationS3ConfigurationArgs

    BucketArn string
    The ARN of the S3 bucket
    RoleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    BufferingSize int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    CloudwatchLoggingOptions FirehoseDeliveryStreamRedshiftConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    CompressionFormat string
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    ErrorOutputPrefix string
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    KmsKeyArn string
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    Prefix string
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    BucketArn string
    The ARN of the S3 bucket
    RoleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    BufferingSize int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    CloudwatchLoggingOptions FirehoseDeliveryStreamRedshiftConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    CompressionFormat string
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    ErrorOutputPrefix string
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    KmsKeyArn string
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    Prefix string
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucketArn String
    The ARN of the S3 bucket
    roleArn String
    The ARN of the role used to access the Amazon MSK cluster.
    bufferingInterval Integer
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize Integer
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions FirehoseDeliveryStreamRedshiftConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compressionFormat String
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    errorOutputPrefix String
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kmsKeyArn String
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix String
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucketArn string
    The ARN of the S3 bucket
    roleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    bufferingInterval number
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize number
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions FirehoseDeliveryStreamRedshiftConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compressionFormat string
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    errorOutputPrefix string
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kmsKeyArn string
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix string
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucket_arn str
    The ARN of the S3 bucket
    role_arn str
    The ARN of the role used to access the Amazon MSK cluster.
    buffering_interval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    buffering_size int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatch_logging_options FirehoseDeliveryStreamRedshiftConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compression_format str
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    error_output_prefix str
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kms_key_arn str
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix str
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucketArn String
    The ARN of the S3 bucket
    roleArn String
    The ARN of the role used to access the Amazon MSK cluster.
    bufferingInterval Number
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize Number
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions Property Map
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compressionFormat String
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    errorOutputPrefix String
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kmsKeyArn String
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix String
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket

    FirehoseDeliveryStreamRedshiftConfigurationS3ConfigurationCloudwatchLoggingOptions, FirehoseDeliveryStreamRedshiftConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs

    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled boolean
    Enables or disables the logging. Defaults to false.
    logGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled bool
    Enables or disables the logging. Defaults to false.
    log_group_name str
    The CloudWatch group name for logging. This value is required if enabled is true.
    log_stream_name str
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.

    FirehoseDeliveryStreamServerSideEncryption, FirehoseDeliveryStreamServerSideEncryptionArgs

    Enabled bool
    Whether to enable encryption at rest. Default is false.
    KeyArn string
    Amazon Resource Name (ARN) of the encryption key. Required when key_type is CUSTOMER_MANAGED_CMK.
    KeyType string
    Type of encryption key. Default is AWS_OWNED_CMK. Valid values are AWS_OWNED_CMK and CUSTOMER_MANAGED_CMK
    Enabled bool
    Whether to enable encryption at rest. Default is false.
    KeyArn string
    Amazon Resource Name (ARN) of the encryption key. Required when key_type is CUSTOMER_MANAGED_CMK.
    KeyType string
    Type of encryption key. Default is AWS_OWNED_CMK. Valid values are AWS_OWNED_CMK and CUSTOMER_MANAGED_CMK
    enabled Boolean
    Whether to enable encryption at rest. Default is false.
    keyArn String
    Amazon Resource Name (ARN) of the encryption key. Required when key_type is CUSTOMER_MANAGED_CMK.
    keyType String
    Type of encryption key. Default is AWS_OWNED_CMK. Valid values are AWS_OWNED_CMK and CUSTOMER_MANAGED_CMK
    enabled boolean
    Whether to enable encryption at rest. Default is false.
    keyArn string
    Amazon Resource Name (ARN) of the encryption key. Required when key_type is CUSTOMER_MANAGED_CMK.
    keyType string
    Type of encryption key. Default is AWS_OWNED_CMK. Valid values are AWS_OWNED_CMK and CUSTOMER_MANAGED_CMK
    enabled bool
    Whether to enable encryption at rest. Default is false.
    key_arn str
    Amazon Resource Name (ARN) of the encryption key. Required when key_type is CUSTOMER_MANAGED_CMK.
    key_type str
    Type of encryption key. Default is AWS_OWNED_CMK. Valid values are AWS_OWNED_CMK and CUSTOMER_MANAGED_CMK
    enabled Boolean
    Whether to enable encryption at rest. Default is false.
    keyArn String
    Amazon Resource Name (ARN) of the encryption key. Required when key_type is CUSTOMER_MANAGED_CMK.
    keyType String
    Type of encryption key. Default is AWS_OWNED_CMK. Valid values are AWS_OWNED_CMK and CUSTOMER_MANAGED_CMK

    FirehoseDeliveryStreamSplunkConfiguration, FirehoseDeliveryStreamSplunkConfigurationArgs

    HecEndpoint string
    The HTTP Event Collector (HEC) endpoint to which Kinesis Firehose sends your data.
    HecToken string
    The GUID that you obtain from your Splunk cluster when you create a new HEC endpoint.
    S3Configuration FirehoseDeliveryStreamSplunkConfigurationS3Configuration
    The S3 Configuration. See s3_configuration block below for details.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 60, before delivering it to the destination. The default value is 60s.
    BufferingSize int
    Buffer incoming data to the specified size, in MBs between 1 to 5, before delivering it to the destination. The default value is 5MB.
    CloudwatchLoggingOptions FirehoseDeliveryStreamSplunkConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    HecAcknowledgmentTimeout int
    The amount of time, in seconds between 180 and 600, that Kinesis Firehose waits to receive an acknowledgment from Splunk after it sends it data.
    HecEndpointType string
    The HEC endpoint type. Valid values are Raw or Event. The default value is Raw.
    ProcessingConfiguration FirehoseDeliveryStreamSplunkConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    RetryDuration int
    After an initial failure to deliver to Splunk, the total amount of time, in seconds between 0 to 7200, during which Firehose re-attempts delivery (including the first attempt). After this time has elapsed, the failed documents are written to Amazon S3. The default value is 300s. There will be no retry if the value is 0.
    S3BackupMode string
    Defines how documents should be delivered to Amazon S3. Valid values are FailedEventsOnly and AllEvents. Default value is FailedEventsOnly.
    HecEndpoint string
    The HTTP Event Collector (HEC) endpoint to which Kinesis Firehose sends your data.
    HecToken string
    The GUID that you obtain from your Splunk cluster when you create a new HEC endpoint.
    S3Configuration FirehoseDeliveryStreamSplunkConfigurationS3Configuration
    The S3 Configuration. See s3_configuration block below for details.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 60, before delivering it to the destination. The default value is 60s.
    BufferingSize int
    Buffer incoming data to the specified size, in MBs between 1 to 5, before delivering it to the destination. The default value is 5MB.
    CloudwatchLoggingOptions FirehoseDeliveryStreamSplunkConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    HecAcknowledgmentTimeout int
    The amount of time, in seconds between 180 and 600, that Kinesis Firehose waits to receive an acknowledgment from Splunk after it sends it data.
    HecEndpointType string
    The HEC endpoint type. Valid values are Raw or Event. The default value is Raw.
    ProcessingConfiguration FirehoseDeliveryStreamSplunkConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    RetryDuration int
    After an initial failure to deliver to Splunk, the total amount of time, in seconds between 0 to 7200, during which Firehose re-attempts delivery (including the first attempt). After this time has elapsed, the failed documents are written to Amazon S3. The default value is 300s. There will be no retry if the value is 0.
    S3BackupMode string
    Defines how documents should be delivered to Amazon S3. Valid values are FailedEventsOnly and AllEvents. Default value is FailedEventsOnly.
    hecEndpoint String
    The HTTP Event Collector (HEC) endpoint to which Kinesis Firehose sends your data.
    hecToken String
    The GUID that you obtain from your Splunk cluster when you create a new HEC endpoint.
    s3Configuration FirehoseDeliveryStreamSplunkConfigurationS3Configuration
    The S3 Configuration. See s3_configuration block below for details.
    bufferingInterval Integer
    Buffer incoming data for the specified period of time, in seconds between 0 to 60, before delivering it to the destination. The default value is 60s.
    bufferingSize Integer
    Buffer incoming data to the specified size, in MBs between 1 to 5, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions FirehoseDeliveryStreamSplunkConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    hecAcknowledgmentTimeout Integer
    The amount of time, in seconds between 180 and 600, that Kinesis Firehose waits to receive an acknowledgment from Splunk after it sends it data.
    hecEndpointType String
    The HEC endpoint type. Valid values are Raw or Event. The default value is Raw.
    processingConfiguration FirehoseDeliveryStreamSplunkConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    retryDuration Integer
    After an initial failure to deliver to Splunk, the total amount of time, in seconds between 0 to 7200, during which Firehose re-attempts delivery (including the first attempt). After this time has elapsed, the failed documents are written to Amazon S3. The default value is 300s. There will be no retry if the value is 0.
    s3BackupMode String
    Defines how documents should be delivered to Amazon S3. Valid values are FailedEventsOnly and AllEvents. Default value is FailedEventsOnly.
    hecEndpoint string
    The HTTP Event Collector (HEC) endpoint to which Kinesis Firehose sends your data.
    hecToken string
    The GUID that you obtain from your Splunk cluster when you create a new HEC endpoint.
    s3Configuration FirehoseDeliveryStreamSplunkConfigurationS3Configuration
    The S3 Configuration. See s3_configuration block below for details.
    bufferingInterval number
    Buffer incoming data for the specified period of time, in seconds between 0 to 60, before delivering it to the destination. The default value is 60s.
    bufferingSize number
    Buffer incoming data to the specified size, in MBs between 1 to 5, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions FirehoseDeliveryStreamSplunkConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    hecAcknowledgmentTimeout number
    The amount of time, in seconds between 180 and 600, that Kinesis Firehose waits to receive an acknowledgment from Splunk after it sends it data.
    hecEndpointType string
    The HEC endpoint type. Valid values are Raw or Event. The default value is Raw.
    processingConfiguration FirehoseDeliveryStreamSplunkConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    retryDuration number
    After an initial failure to deliver to Splunk, the total amount of time, in seconds between 0 to 7200, during which Firehose re-attempts delivery (including the first attempt). After this time has elapsed, the failed documents are written to Amazon S3. The default value is 300s. There will be no retry if the value is 0.
    s3BackupMode string
    Defines how documents should be delivered to Amazon S3. Valid values are FailedEventsOnly and AllEvents. Default value is FailedEventsOnly.
    hec_endpoint str
    The HTTP Event Collector (HEC) endpoint to which Kinesis Firehose sends your data.
    hec_token str
    The GUID that you obtain from your Splunk cluster when you create a new HEC endpoint.
    s3_configuration FirehoseDeliveryStreamSplunkConfigurationS3Configuration
    The S3 Configuration. See s3_configuration block below for details.
    buffering_interval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 60, before delivering it to the destination. The default value is 60s.
    buffering_size int
    Buffer incoming data to the specified size, in MBs between 1 to 5, before delivering it to the destination. The default value is 5MB.
    cloudwatch_logging_options FirehoseDeliveryStreamSplunkConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    hec_acknowledgment_timeout int
    The amount of time, in seconds between 180 and 600, that Kinesis Firehose waits to receive an acknowledgment from Splunk after it sends it data.
    hec_endpoint_type str
    The HEC endpoint type. Valid values are Raw or Event. The default value is Raw.
    processing_configuration FirehoseDeliveryStreamSplunkConfigurationProcessingConfiguration
    The data processing configuration. See processing_configuration block below for details.
    retry_duration int
    After an initial failure to deliver to Splunk, the total amount of time, in seconds between 0 to 7200, during which Firehose re-attempts delivery (including the first attempt). After this time has elapsed, the failed documents are written to Amazon S3. The default value is 300s. There will be no retry if the value is 0.
    s3_backup_mode str
    Defines how documents should be delivered to Amazon S3. Valid values are FailedEventsOnly and AllEvents. Default value is FailedEventsOnly.
    hecEndpoint String
    The HTTP Event Collector (HEC) endpoint to which Kinesis Firehose sends your data.
    hecToken String
    The GUID that you obtain from your Splunk cluster when you create a new HEC endpoint.
    s3Configuration Property Map
    The S3 Configuration. See s3_configuration block below for details.
    bufferingInterval Number
    Buffer incoming data for the specified period of time, in seconds between 0 to 60, before delivering it to the destination. The default value is 60s.
    bufferingSize Number
    Buffer incoming data to the specified size, in MBs between 1 to 5, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions Property Map
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    hecAcknowledgmentTimeout Number
    The amount of time, in seconds between 180 and 600, that Kinesis Firehose waits to receive an acknowledgment from Splunk after it sends it data.
    hecEndpointType String
    The HEC endpoint type. Valid values are Raw or Event. The default value is Raw.
    processingConfiguration Property Map
    The data processing configuration. See processing_configuration block below for details.
    retryDuration Number
    After an initial failure to deliver to Splunk, the total amount of time, in seconds between 0 to 7200, during which Firehose re-attempts delivery (including the first attempt). After this time has elapsed, the failed documents are written to Amazon S3. The default value is 300s. There will be no retry if the value is 0.
    s3BackupMode String
    Defines how documents should be delivered to Amazon S3. Valid values are FailedEventsOnly and AllEvents. Default value is FailedEventsOnly.

    FirehoseDeliveryStreamSplunkConfigurationCloudwatchLoggingOptions, FirehoseDeliveryStreamSplunkConfigurationCloudwatchLoggingOptionsArgs

    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled boolean
    Enables or disables the logging. Defaults to false.
    logGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled bool
    Enables or disables the logging. Defaults to false.
    log_group_name str
    The CloudWatch group name for logging. This value is required if enabled is true.
    log_stream_name str
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.

    FirehoseDeliveryStreamSplunkConfigurationProcessingConfiguration, FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationArgs

    Enabled bool
    Enables or disables data processing.
    Processors List<FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationProcessor>
    Specifies the data processors as multiple blocks. See processors block below for details.
    Enabled bool
    Enables or disables data processing.
    Processors []FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationProcessor
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled Boolean
    Enables or disables data processing.
    processors List<FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationProcessor>
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled boolean
    Enables or disables data processing.
    processors FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationProcessor[]
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled bool
    Enables or disables data processing.
    processors Sequence[FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationProcessor]
    Specifies the data processors as multiple blocks. See processors block below for details.
    enabled Boolean
    Enables or disables data processing.
    processors List<Property Map>
    Specifies the data processors as multiple blocks. See processors block below for details.

    FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationProcessor, FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationProcessorArgs

    Type string
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    Parameters List<FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationProcessorParameter>
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    Type string
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    Parameters []FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationProcessorParameter
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type String
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters List<FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationProcessorParameter>
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type string
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationProcessorParameter[]
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type str
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters Sequence[FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationProcessorParameter]
    Specifies the processor parameters as multiple blocks. See parameters block below for details.
    type String
    The type of processor. Valid Values: RecordDeAggregation, Lambda, MetadataExtraction, AppendDelimiterToRecord. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameters List<Property Map>
    Specifies the processor parameters as multiple blocks. See parameters block below for details.

    FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationProcessorParameter, FirehoseDeliveryStreamSplunkConfigurationProcessingConfigurationProcessorParameterArgs

    ParameterName string
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    ParameterValue string

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    ParameterName string
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    ParameterValue string

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameterName String
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameterValue String

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameterName string
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameterValue string

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameter_name str
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameter_value str

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    parameterName String
    Parameter name. Valid Values: LambdaArn, NumberOfRetries, MetadataExtractionQuery, JsonParsingEngine, RoleArn, BufferSizeInMBs, BufferIntervalInSeconds, SubRecordType, Delimiter. Validation is done against AWS SDK constants; so that values not explicitly listed may also work.
    parameterValue String

    Parameter value. Must be between 1 and 512 length (inclusive). When providing a Lambda ARN, you should specify the resource version as well.

    NOTE: Parameters with default values, including NumberOfRetries(default: 3), RoleArn(default: firehose role ARN), BufferSizeInMBs(default: 1), and BufferIntervalInSeconds(default: 60), are not stored in Pulumi state. To prevent perpetual differences, it is therefore recommended to only include parameters with non-default values.

    FirehoseDeliveryStreamSplunkConfigurationS3Configuration, FirehoseDeliveryStreamSplunkConfigurationS3ConfigurationArgs

    BucketArn string
    The ARN of the S3 bucket
    RoleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    BufferingSize int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    CloudwatchLoggingOptions FirehoseDeliveryStreamSplunkConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    CompressionFormat string
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    ErrorOutputPrefix string
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    KmsKeyArn string
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    Prefix string
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    BucketArn string
    The ARN of the S3 bucket
    RoleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    BufferingInterval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    BufferingSize int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    CloudwatchLoggingOptions FirehoseDeliveryStreamSplunkConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    CompressionFormat string
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    ErrorOutputPrefix string
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    KmsKeyArn string
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    Prefix string
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucketArn String
    The ARN of the S3 bucket
    roleArn String
    The ARN of the role used to access the Amazon MSK cluster.
    bufferingInterval Integer
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize Integer
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions FirehoseDeliveryStreamSplunkConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compressionFormat String
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    errorOutputPrefix String
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kmsKeyArn String
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix String
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucketArn string
    The ARN of the S3 bucket
    roleArn string
    The ARN of the role used to access the Amazon MSK cluster.
    bufferingInterval number
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize number
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions FirehoseDeliveryStreamSplunkConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compressionFormat string
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    errorOutputPrefix string
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kmsKeyArn string
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix string
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucket_arn str
    The ARN of the S3 bucket
    role_arn str
    The ARN of the role used to access the Amazon MSK cluster.
    buffering_interval int
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    buffering_size int
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatch_logging_options FirehoseDeliveryStreamSplunkConfigurationS3ConfigurationCloudwatchLoggingOptions
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compression_format str
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    error_output_prefix str
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kms_key_arn str
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix str
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket
    bucketArn String
    The ARN of the S3 bucket
    roleArn String
    The ARN of the role used to access the Amazon MSK cluster.
    bufferingInterval Number
    Buffer incoming data for the specified period of time, in seconds between 0 to 900, before delivering it to the destination. The default value is 300s.
    bufferingSize Number
    Buffer incoming data to the specified size, in MBs between 1 to 100, before delivering it to the destination. The default value is 5MB.
    cloudwatchLoggingOptions Property Map
    The CloudWatch Logging Options for the delivery stream. See cloudwatch_logging_options block below for details.
    compressionFormat String
    The compression format. If no value is specified, the default is UNCOMPRESSED. Other supported values are GZIP, ZIP, Snappy, & HADOOP_SNAPPY.
    errorOutputPrefix String
    Prefix added to failed records before writing them to S3. Not currently supported for redshift destination. This prefix appears immediately following the bucket name. For information about how to specify this prefix, see Custom Prefixes for Amazon S3 Objects.
    kmsKeyArn String
    Specifies the KMS key ARN the stream will use to encrypt data. If not set, no encryption will be used.
    prefix String
    The "YYYY/MM/DD/HH" time format prefix is automatically used for delivered S3 files. You can specify an extra prefix to be added in front of the time format prefix. Note that if the prefix ends with a slash, it appears as a folder in the S3 bucket

    FirehoseDeliveryStreamSplunkConfigurationS3ConfigurationCloudwatchLoggingOptions, FirehoseDeliveryStreamSplunkConfigurationS3ConfigurationCloudwatchLoggingOptionsArgs

    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    Enabled bool
    Enables or disables the logging. Defaults to false.
    LogGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    LogStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled boolean
    Enables or disables the logging. Defaults to false.
    logGroupName string
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName string
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled bool
    Enables or disables the logging. Defaults to false.
    log_group_name str
    The CloudWatch group name for logging. This value is required if enabled is true.
    log_stream_name str
    The CloudWatch log stream name for logging. This value is required if enabled is true.
    enabled Boolean
    Enables or disables the logging. Defaults to false.
    logGroupName String
    The CloudWatch group name for logging. This value is required if enabled is true.
    logStreamName String
    The CloudWatch log stream name for logging. This value is required if enabled is true.

    Import

    Using pulumi import, import Kinesis Firehose Delivery streams using the stream ARN. For example:

    $ pulumi import aws:kinesis/firehoseDeliveryStream:FirehoseDeliveryStream foo arn:aws:firehose:us-east-1:XXX:deliverystream/example
    

    Note: Import does not work for stream destination s3. Consider using extended_s3 since s3 destination is deprecated.

    To learn more about importing existing cloud resources, see Importing resources.

    Package Details

    Repository
    AWS Classic pulumi/pulumi-aws
    License
    Apache-2.0
    Notes
    This Pulumi package is based on the aws Terraform Provider.
    aws logo

    Try AWS Native preview for resources not in the classic version.

    AWS Classic v6.31.0 published on Monday, Apr 15, 2024 by Pulumi