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

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

AWS Classic v6.13.0 published on Saturday, Dec 2, 2023 by Pulumi

aws.kinesis.AnalyticsApplication

Explore with Pulumi AI

aws logo

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

AWS Classic v6.13.0 published on Saturday, Dec 2, 2023 by Pulumi

    Provides a Kinesis Analytics Application resource. Kinesis Analytics is a managed service that allows processing and analyzing streaming data using standard SQL.

    For more details, see the Amazon Kinesis Analytics Documentation.

    Note: To manage Amazon Kinesis Data Analytics for Apache Flink applications, use the aws.kinesisanalyticsv2.Application resource.

    Example Usage

    Kinesis Stream Input

    using System.Collections.Generic;
    using System.Linq;
    using Pulumi;
    using Aws = Pulumi.Aws;
    
    return await Deployment.RunAsync(() => 
    {
        var testStream = new Aws.Kinesis.Stream("testStream", new()
        {
            ShardCount = 1,
        });
    
        var testApplication = new Aws.Kinesis.AnalyticsApplication("testApplication", new()
        {
            Inputs = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsArgs
            {
                NamePrefix = "test_prefix",
                KinesisStream = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsKinesisStreamArgs
                {
                    ResourceArn = testStream.Arn,
                    RoleArn = aws_iam_role.Test.Arn,
                },
                Parallelism = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsParallelismArgs
                {
                    Count = 1,
                },
                Schema = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsSchemaArgs
                {
                    RecordColumns = new[]
                    {
                        new Aws.Kinesis.Inputs.AnalyticsApplicationInputsSchemaRecordColumnArgs
                        {
                            Mapping = "$.test",
                            Name = "test",
                            SqlType = "VARCHAR(8)",
                        },
                    },
                    RecordEncoding = "UTF-8",
                    RecordFormat = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsSchemaRecordFormatArgs
                    {
                        MappingParameters = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersArgs
                        {
                            Json = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersJsonArgs
                            {
                                RecordRowPath = "$",
                            },
                        },
                    },
                },
            },
        });
    
    });
    
    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 {
    		testStream, err := kinesis.NewStream(ctx, "testStream", &kinesis.StreamArgs{
    			ShardCount: pulumi.Int(1),
    		})
    		if err != nil {
    			return err
    		}
    		_, err = kinesis.NewAnalyticsApplication(ctx, "testApplication", &kinesis.AnalyticsApplicationArgs{
    			Inputs: &kinesis.AnalyticsApplicationInputsArgs{
    				NamePrefix: pulumi.String("test_prefix"),
    				KinesisStream: &kinesis.AnalyticsApplicationInputsKinesisStreamArgs{
    					ResourceArn: testStream.Arn,
    					RoleArn:     pulumi.Any(aws_iam_role.Test.Arn),
    				},
    				Parallelism: &kinesis.AnalyticsApplicationInputsParallelismArgs{
    					Count: pulumi.Int(1),
    				},
    				Schema: &kinesis.AnalyticsApplicationInputsSchemaArgs{
    					RecordColumns: kinesis.AnalyticsApplicationInputsSchemaRecordColumnArray{
    						&kinesis.AnalyticsApplicationInputsSchemaRecordColumnArgs{
    							Mapping: pulumi.String("$.test"),
    							Name:    pulumi.String("test"),
    							SqlType: pulumi.String("VARCHAR(8)"),
    						},
    					},
    					RecordEncoding: pulumi.String("UTF-8"),
    					RecordFormat: &kinesis.AnalyticsApplicationInputsSchemaRecordFormatArgs{
    						MappingParameters: &kinesis.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersArgs{
    							Json: &kinesis.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersJsonArgs{
    								RecordRowPath: pulumi.String("$"),
    							},
    						},
    					},
    				},
    			},
    		})
    		if err != nil {
    			return err
    		}
    		return nil
    	})
    }
    
    package generated_program;
    
    import com.pulumi.Context;
    import com.pulumi.Pulumi;
    import com.pulumi.core.Output;
    import com.pulumi.aws.kinesis.Stream;
    import com.pulumi.aws.kinesis.StreamArgs;
    import com.pulumi.aws.kinesis.AnalyticsApplication;
    import com.pulumi.aws.kinesis.AnalyticsApplicationArgs;
    import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationInputsArgs;
    import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationInputsKinesisStreamArgs;
    import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationInputsParallelismArgs;
    import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationInputsSchemaArgs;
    import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationInputsSchemaRecordFormatArgs;
    import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersArgs;
    import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersJsonArgs;
    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 Stream("testStream", StreamArgs.builder()        
                .shardCount(1)
                .build());
    
            var testApplication = new AnalyticsApplication("testApplication", AnalyticsApplicationArgs.builder()        
                .inputs(AnalyticsApplicationInputsArgs.builder()
                    .namePrefix("test_prefix")
                    .kinesisStream(AnalyticsApplicationInputsKinesisStreamArgs.builder()
                        .resourceArn(testStream.arn())
                        .roleArn(aws_iam_role.test().arn())
                        .build())
                    .parallelism(AnalyticsApplicationInputsParallelismArgs.builder()
                        .count(1)
                        .build())
                    .schema(AnalyticsApplicationInputsSchemaArgs.builder()
                        .recordColumns(AnalyticsApplicationInputsSchemaRecordColumnArgs.builder()
                            .mapping("$.test")
                            .name("test")
                            .sqlType("VARCHAR(8)")
                            .build())
                        .recordEncoding("UTF-8")
                        .recordFormat(AnalyticsApplicationInputsSchemaRecordFormatArgs.builder()
                            .mappingParameters(AnalyticsApplicationInputsSchemaRecordFormatMappingParametersArgs.builder()
                                .json(AnalyticsApplicationInputsSchemaRecordFormatMappingParametersJsonArgs.builder()
                                    .recordRowPath("$")
                                    .build())
                                .build())
                            .build())
                        .build())
                    .build())
                .build());
    
        }
    }
    
    import pulumi
    import pulumi_aws as aws
    
    test_stream = aws.kinesis.Stream("testStream", shard_count=1)
    test_application = aws.kinesis.AnalyticsApplication("testApplication", inputs=aws.kinesis.AnalyticsApplicationInputsArgs(
        name_prefix="test_prefix",
        kinesis_stream=aws.kinesis.AnalyticsApplicationInputsKinesisStreamArgs(
            resource_arn=test_stream.arn,
            role_arn=aws_iam_role["test"]["arn"],
        ),
        parallelism=aws.kinesis.AnalyticsApplicationInputsParallelismArgs(
            count=1,
        ),
        schema=aws.kinesis.AnalyticsApplicationInputsSchemaArgs(
            record_columns=[aws.kinesis.AnalyticsApplicationInputsSchemaRecordColumnArgs(
                mapping="$.test",
                name="test",
                sql_type="VARCHAR(8)",
            )],
            record_encoding="UTF-8",
            record_format=aws.kinesis.AnalyticsApplicationInputsSchemaRecordFormatArgs(
                mapping_parameters=aws.kinesis.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersArgs(
                    json=aws.kinesis.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersJsonArgs(
                        record_row_path="$",
                    ),
                ),
            ),
        ),
    ))
    
    import * as pulumi from "@pulumi/pulumi";
    import * as aws from "@pulumi/aws";
    
    const testStream = new aws.kinesis.Stream("testStream", {shardCount: 1});
    const testApplication = new aws.kinesis.AnalyticsApplication("testApplication", {inputs: {
        namePrefix: "test_prefix",
        kinesisStream: {
            resourceArn: testStream.arn,
            roleArn: aws_iam_role.test.arn,
        },
        parallelism: {
            count: 1,
        },
        schema: {
            recordColumns: [{
                mapping: "$.test",
                name: "test",
                sqlType: "VARCHAR(8)",
            }],
            recordEncoding: "UTF-8",
            recordFormat: {
                mappingParameters: {
                    json: {
                        recordRowPath: "$",
                    },
                },
            },
        },
    }});
    
    resources:
      testStream:
        type: aws:kinesis:Stream
        properties:
          shardCount: 1
      testApplication:
        type: aws:kinesis:AnalyticsApplication
        properties:
          inputs:
            namePrefix: test_prefix
            kinesisStream:
              resourceArn: ${testStream.arn}
              roleArn: ${aws_iam_role.test.arn}
            parallelism:
              count: 1
            schema:
              recordColumns:
                - mapping: $.test
                  name: test
                  sqlType: VARCHAR(8)
              recordEncoding: UTF-8
              recordFormat:
                mappingParameters:
                  json:
                    recordRowPath: $
    

    Starting An Application

    using System.Collections.Generic;
    using System.Linq;
    using Pulumi;
    using Aws = Pulumi.Aws;
    
    return await Deployment.RunAsync(() => 
    {
        var exampleLogGroup = new Aws.CloudWatch.LogGroup("exampleLogGroup");
    
        var exampleLogStream = new Aws.CloudWatch.LogStream("exampleLogStream", new()
        {
            LogGroupName = exampleLogGroup.Name,
        });
    
        var exampleStream = new Aws.Kinesis.Stream("exampleStream", new()
        {
            ShardCount = 1,
        });
    
        var exampleFirehoseDeliveryStream = new Aws.Kinesis.FirehoseDeliveryStream("exampleFirehoseDeliveryStream", new()
        {
            Destination = "extended_s3",
            ExtendedS3Configuration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationArgs
            {
                BucketArn = aws_s3_bucket.Example.Arn,
                RoleArn = aws_iam_role.Example.Arn,
            },
        });
    
        var test = new Aws.Kinesis.AnalyticsApplication("test", new()
        {
            CloudwatchLoggingOptions = new Aws.Kinesis.Inputs.AnalyticsApplicationCloudwatchLoggingOptionsArgs
            {
                LogStreamArn = exampleLogStream.Arn,
                RoleArn = aws_iam_role.Example.Arn,
            },
            Inputs = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsArgs
            {
                NamePrefix = "example_prefix",
                Schema = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsSchemaArgs
                {
                    RecordColumns = new[]
                    {
                        new Aws.Kinesis.Inputs.AnalyticsApplicationInputsSchemaRecordColumnArgs
                        {
                            Name = "COLUMN_1",
                            SqlType = "INTEGER",
                        },
                    },
                    RecordFormat = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsSchemaRecordFormatArgs
                    {
                        MappingParameters = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersArgs
                        {
                            Csv = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersCsvArgs
                            {
                                RecordColumnDelimiter = ",",
                                RecordRowDelimiter = "|",
                            },
                        },
                    },
                },
                KinesisStream = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsKinesisStreamArgs
                {
                    ResourceArn = exampleStream.Arn,
                    RoleArn = aws_iam_role.Example.Arn,
                },
                StartingPositionConfigurations = new[]
                {
                    new Aws.Kinesis.Inputs.AnalyticsApplicationInputsStartingPositionConfigurationArgs
                    {
                        StartingPosition = "NOW",
                    },
                },
            },
            Outputs = new[]
            {
                new Aws.Kinesis.Inputs.AnalyticsApplicationOutputArgs
                {
                    Name = "OUTPUT_1",
                    Schema = new Aws.Kinesis.Inputs.AnalyticsApplicationOutputSchemaArgs
                    {
                        RecordFormatType = "CSV",
                    },
                    KinesisFirehose = new Aws.Kinesis.Inputs.AnalyticsApplicationOutputKinesisFirehoseArgs
                    {
                        ResourceArn = exampleFirehoseDeliveryStream.Arn,
                        RoleArn = aws_iam_role.Example.Arn,
                    },
                },
            },
            StartApplication = true,
        });
    
    });
    
    package main
    
    import (
    	"github.com/pulumi/pulumi-aws/sdk/v6/go/aws/cloudwatch"
    	"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 {
    		exampleLogGroup, err := cloudwatch.NewLogGroup(ctx, "exampleLogGroup", nil)
    		if err != nil {
    			return err
    		}
    		exampleLogStream, err := cloudwatch.NewLogStream(ctx, "exampleLogStream", &cloudwatch.LogStreamArgs{
    			LogGroupName: exampleLogGroup.Name,
    		})
    		if err != nil {
    			return err
    		}
    		exampleStream, err := kinesis.NewStream(ctx, "exampleStream", &kinesis.StreamArgs{
    			ShardCount: pulumi.Int(1),
    		})
    		if err != nil {
    			return err
    		}
    		exampleFirehoseDeliveryStream, err := kinesis.NewFirehoseDeliveryStream(ctx, "exampleFirehoseDeliveryStream", &kinesis.FirehoseDeliveryStreamArgs{
    			Destination: pulumi.String("extended_s3"),
    			ExtendedS3Configuration: &kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationArgs{
    				BucketArn: pulumi.Any(aws_s3_bucket.Example.Arn),
    				RoleArn:   pulumi.Any(aws_iam_role.Example.Arn),
    			},
    		})
    		if err != nil {
    			return err
    		}
    		_, err = kinesis.NewAnalyticsApplication(ctx, "test", &kinesis.AnalyticsApplicationArgs{
    			CloudwatchLoggingOptions: &kinesis.AnalyticsApplicationCloudwatchLoggingOptionsArgs{
    				LogStreamArn: exampleLogStream.Arn,
    				RoleArn:      pulumi.Any(aws_iam_role.Example.Arn),
    			},
    			Inputs: &kinesis.AnalyticsApplicationInputsArgs{
    				NamePrefix: pulumi.String("example_prefix"),
    				Schema: &kinesis.AnalyticsApplicationInputsSchemaArgs{
    					RecordColumns: kinesis.AnalyticsApplicationInputsSchemaRecordColumnArray{
    						&kinesis.AnalyticsApplicationInputsSchemaRecordColumnArgs{
    							Name:    pulumi.String("COLUMN_1"),
    							SqlType: pulumi.String("INTEGER"),
    						},
    					},
    					RecordFormat: &kinesis.AnalyticsApplicationInputsSchemaRecordFormatArgs{
    						MappingParameters: &kinesis.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersArgs{
    							Csv: &kinesis.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersCsvArgs{
    								RecordColumnDelimiter: pulumi.String(","),
    								RecordRowDelimiter:    pulumi.String("|"),
    							},
    						},
    					},
    				},
    				KinesisStream: &kinesis.AnalyticsApplicationInputsKinesisStreamArgs{
    					ResourceArn: exampleStream.Arn,
    					RoleArn:     pulumi.Any(aws_iam_role.Example.Arn),
    				},
    				StartingPositionConfigurations: kinesis.AnalyticsApplicationInputsStartingPositionConfigurationArray{
    					&kinesis.AnalyticsApplicationInputsStartingPositionConfigurationArgs{
    						StartingPosition: pulumi.String("NOW"),
    					},
    				},
    			},
    			Outputs: kinesis.AnalyticsApplicationOutputTypeArray{
    				&kinesis.AnalyticsApplicationOutputTypeArgs{
    					Name: pulumi.String("OUTPUT_1"),
    					Schema: &kinesis.AnalyticsApplicationOutputSchemaArgs{
    						RecordFormatType: pulumi.String("CSV"),
    					},
    					KinesisFirehose: &kinesis.AnalyticsApplicationOutputKinesisFirehoseArgs{
    						ResourceArn: exampleFirehoseDeliveryStream.Arn,
    						RoleArn:     pulumi.Any(aws_iam_role.Example.Arn),
    					},
    				},
    			},
    			StartApplication: pulumi.Bool(true),
    		})
    		if err != nil {
    			return err
    		}
    		return nil
    	})
    }
    
    package generated_program;
    
    import com.pulumi.Context;
    import com.pulumi.Pulumi;
    import com.pulumi.core.Output;
    import com.pulumi.aws.cloudwatch.LogGroup;
    import com.pulumi.aws.cloudwatch.LogStream;
    import com.pulumi.aws.cloudwatch.LogStreamArgs;
    import com.pulumi.aws.kinesis.Stream;
    import com.pulumi.aws.kinesis.StreamArgs;
    import com.pulumi.aws.kinesis.FirehoseDeliveryStream;
    import com.pulumi.aws.kinesis.FirehoseDeliveryStreamArgs;
    import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamExtendedS3ConfigurationArgs;
    import com.pulumi.aws.kinesis.AnalyticsApplication;
    import com.pulumi.aws.kinesis.AnalyticsApplicationArgs;
    import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationCloudwatchLoggingOptionsArgs;
    import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationInputsArgs;
    import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationInputsSchemaArgs;
    import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationInputsSchemaRecordFormatArgs;
    import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersArgs;
    import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersCsvArgs;
    import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationInputsKinesisStreamArgs;
    import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationOutputArgs;
    import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationOutputSchemaArgs;
    import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationOutputKinesisFirehoseArgs;
    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 exampleLogGroup = new LogGroup("exampleLogGroup");
    
            var exampleLogStream = new LogStream("exampleLogStream", LogStreamArgs.builder()        
                .logGroupName(exampleLogGroup.name())
                .build());
    
            var exampleStream = new Stream("exampleStream", StreamArgs.builder()        
                .shardCount(1)
                .build());
    
            var exampleFirehoseDeliveryStream = new FirehoseDeliveryStream("exampleFirehoseDeliveryStream", FirehoseDeliveryStreamArgs.builder()        
                .destination("extended_s3")
                .extendedS3Configuration(FirehoseDeliveryStreamExtendedS3ConfigurationArgs.builder()
                    .bucketArn(aws_s3_bucket.example().arn())
                    .roleArn(aws_iam_role.example().arn())
                    .build())
                .build());
    
            var test = new AnalyticsApplication("test", AnalyticsApplicationArgs.builder()        
                .cloudwatchLoggingOptions(AnalyticsApplicationCloudwatchLoggingOptionsArgs.builder()
                    .logStreamArn(exampleLogStream.arn())
                    .roleArn(aws_iam_role.example().arn())
                    .build())
                .inputs(AnalyticsApplicationInputsArgs.builder()
                    .namePrefix("example_prefix")
                    .schema(AnalyticsApplicationInputsSchemaArgs.builder()
                        .recordColumns(AnalyticsApplicationInputsSchemaRecordColumnArgs.builder()
                            .name("COLUMN_1")
                            .sqlType("INTEGER")
                            .build())
                        .recordFormat(AnalyticsApplicationInputsSchemaRecordFormatArgs.builder()
                            .mappingParameters(AnalyticsApplicationInputsSchemaRecordFormatMappingParametersArgs.builder()
                                .csv(AnalyticsApplicationInputsSchemaRecordFormatMappingParametersCsvArgs.builder()
                                    .recordColumnDelimiter(",")
                                    .recordRowDelimiter("|")
                                    .build())
                                .build())
                            .build())
                        .build())
                    .kinesisStream(AnalyticsApplicationInputsKinesisStreamArgs.builder()
                        .resourceArn(exampleStream.arn())
                        .roleArn(aws_iam_role.example().arn())
                        .build())
                    .startingPositionConfigurations(AnalyticsApplicationInputsStartingPositionConfigurationArgs.builder()
                        .startingPosition("NOW")
                        .build())
                    .build())
                .outputs(AnalyticsApplicationOutputArgs.builder()
                    .name("OUTPUT_1")
                    .schema(AnalyticsApplicationOutputSchemaArgs.builder()
                        .recordFormatType("CSV")
                        .build())
                    .kinesisFirehose(AnalyticsApplicationOutputKinesisFirehoseArgs.builder()
                        .resourceArn(exampleFirehoseDeliveryStream.arn())
                        .roleArn(aws_iam_role.example().arn())
                        .build())
                    .build())
                .startApplication(true)
                .build());
    
        }
    }
    
    import pulumi
    import pulumi_aws as aws
    
    example_log_group = aws.cloudwatch.LogGroup("exampleLogGroup")
    example_log_stream = aws.cloudwatch.LogStream("exampleLogStream", log_group_name=example_log_group.name)
    example_stream = aws.kinesis.Stream("exampleStream", shard_count=1)
    example_firehose_delivery_stream = aws.kinesis.FirehoseDeliveryStream("exampleFirehoseDeliveryStream",
        destination="extended_s3",
        extended_s3_configuration=aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationArgs(
            bucket_arn=aws_s3_bucket["example"]["arn"],
            role_arn=aws_iam_role["example"]["arn"],
        ))
    test = aws.kinesis.AnalyticsApplication("test",
        cloudwatch_logging_options=aws.kinesis.AnalyticsApplicationCloudwatchLoggingOptionsArgs(
            log_stream_arn=example_log_stream.arn,
            role_arn=aws_iam_role["example"]["arn"],
        ),
        inputs=aws.kinesis.AnalyticsApplicationInputsArgs(
            name_prefix="example_prefix",
            schema=aws.kinesis.AnalyticsApplicationInputsSchemaArgs(
                record_columns=[aws.kinesis.AnalyticsApplicationInputsSchemaRecordColumnArgs(
                    name="COLUMN_1",
                    sql_type="INTEGER",
                )],
                record_format=aws.kinesis.AnalyticsApplicationInputsSchemaRecordFormatArgs(
                    mapping_parameters=aws.kinesis.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersArgs(
                        csv=aws.kinesis.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersCsvArgs(
                            record_column_delimiter=",",
                            record_row_delimiter="|",
                        ),
                    ),
                ),
            ),
            kinesis_stream=aws.kinesis.AnalyticsApplicationInputsKinesisStreamArgs(
                resource_arn=example_stream.arn,
                role_arn=aws_iam_role["example"]["arn"],
            ),
            starting_position_configurations=[aws.kinesis.AnalyticsApplicationInputsStartingPositionConfigurationArgs(
                starting_position="NOW",
            )],
        ),
        outputs=[aws.kinesis.AnalyticsApplicationOutputArgs(
            name="OUTPUT_1",
            schema=aws.kinesis.AnalyticsApplicationOutputSchemaArgs(
                record_format_type="CSV",
            ),
            kinesis_firehose=aws.kinesis.AnalyticsApplicationOutputKinesisFirehoseArgs(
                resource_arn=example_firehose_delivery_stream.arn,
                role_arn=aws_iam_role["example"]["arn"],
            ),
        )],
        start_application=True)
    
    import * as pulumi from "@pulumi/pulumi";
    import * as aws from "@pulumi/aws";
    
    const exampleLogGroup = new aws.cloudwatch.LogGroup("exampleLogGroup", {});
    const exampleLogStream = new aws.cloudwatch.LogStream("exampleLogStream", {logGroupName: exampleLogGroup.name});
    const exampleStream = new aws.kinesis.Stream("exampleStream", {shardCount: 1});
    const exampleFirehoseDeliveryStream = new aws.kinesis.FirehoseDeliveryStream("exampleFirehoseDeliveryStream", {
        destination: "extended_s3",
        extendedS3Configuration: {
            bucketArn: aws_s3_bucket.example.arn,
            roleArn: aws_iam_role.example.arn,
        },
    });
    const test = new aws.kinesis.AnalyticsApplication("test", {
        cloudwatchLoggingOptions: {
            logStreamArn: exampleLogStream.arn,
            roleArn: aws_iam_role.example.arn,
        },
        inputs: {
            namePrefix: "example_prefix",
            schema: {
                recordColumns: [{
                    name: "COLUMN_1",
                    sqlType: "INTEGER",
                }],
                recordFormat: {
                    mappingParameters: {
                        csv: {
                            recordColumnDelimiter: ",",
                            recordRowDelimiter: "|",
                        },
                    },
                },
            },
            kinesisStream: {
                resourceArn: exampleStream.arn,
                roleArn: aws_iam_role.example.arn,
            },
            startingPositionConfigurations: [{
                startingPosition: "NOW",
            }],
        },
        outputs: [{
            name: "OUTPUT_1",
            schema: {
                recordFormatType: "CSV",
            },
            kinesisFirehose: {
                resourceArn: exampleFirehoseDeliveryStream.arn,
                roleArn: aws_iam_role.example.arn,
            },
        }],
        startApplication: true,
    });
    
    resources:
      exampleLogGroup:
        type: aws:cloudwatch:LogGroup
      exampleLogStream:
        type: aws:cloudwatch:LogStream
        properties:
          logGroupName: ${exampleLogGroup.name}
      exampleStream:
        type: aws:kinesis:Stream
        properties:
          shardCount: 1
      exampleFirehoseDeliveryStream:
        type: aws:kinesis:FirehoseDeliveryStream
        properties:
          destination: extended_s3
          extendedS3Configuration:
            bucketArn: ${aws_s3_bucket.example.arn}
            roleArn: ${aws_iam_role.example.arn}
      test:
        type: aws:kinesis:AnalyticsApplication
        properties:
          cloudwatchLoggingOptions:
            logStreamArn: ${exampleLogStream.arn}
            roleArn: ${aws_iam_role.example.arn}
          inputs:
            namePrefix: example_prefix
            schema:
              recordColumns:
                - name: COLUMN_1
                  sqlType: INTEGER
              recordFormat:
                mappingParameters:
                  csv:
                    recordColumnDelimiter: ','
                    recordRowDelimiter: '|'
            kinesisStream:
              resourceArn: ${exampleStream.arn}
              roleArn: ${aws_iam_role.example.arn}
            startingPositionConfigurations:
              - startingPosition: NOW
          outputs:
            - name: OUTPUT_1
              schema:
                recordFormatType: CSV
              kinesisFirehose:
                resourceArn: ${exampleFirehoseDeliveryStream.arn}
                roleArn: ${aws_iam_role.example.arn}
          startApplication: true
    

    Create AnalyticsApplication Resource

    new AnalyticsApplication(name: string, args?: AnalyticsApplicationArgs, opts?: CustomResourceOptions);
    @overload
    def AnalyticsApplication(resource_name: str,
                             opts: Optional[ResourceOptions] = None,
                             cloudwatch_logging_options: Optional[AnalyticsApplicationCloudwatchLoggingOptionsArgs] = None,
                             code: Optional[str] = None,
                             description: Optional[str] = None,
                             inputs: Optional[AnalyticsApplicationInputsArgs] = None,
                             name: Optional[str] = None,
                             outputs: Optional[Sequence[AnalyticsApplicationOutputArgs]] = None,
                             reference_data_sources: Optional[AnalyticsApplicationReferenceDataSourcesArgs] = None,
                             start_application: Optional[bool] = None,
                             tags: Optional[Mapping[str, str]] = None)
    @overload
    def AnalyticsApplication(resource_name: str,
                             args: Optional[AnalyticsApplicationArgs] = None,
                             opts: Optional[ResourceOptions] = None)
    func NewAnalyticsApplication(ctx *Context, name string, args *AnalyticsApplicationArgs, opts ...ResourceOption) (*AnalyticsApplication, error)
    public AnalyticsApplication(string name, AnalyticsApplicationArgs? args = null, CustomResourceOptions? opts = null)
    public AnalyticsApplication(String name, AnalyticsApplicationArgs args)
    public AnalyticsApplication(String name, AnalyticsApplicationArgs args, CustomResourceOptions options)
    
    type: aws:kinesis:AnalyticsApplication
    properties: # The arguments to resource properties.
    options: # Bag of options to control resource's behavior.
    
    
    name string
    The unique name of the resource.
    args AnalyticsApplicationArgs
    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 AnalyticsApplicationArgs
    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 AnalyticsApplicationArgs
    The arguments to resource properties.
    opts ResourceOption
    Bag of options to control resource's behavior.
    name string
    The unique name of the resource.
    args AnalyticsApplicationArgs
    The arguments to resource properties.
    opts CustomResourceOptions
    Bag of options to control resource's behavior.
    name String
    The unique name of the resource.
    args AnalyticsApplicationArgs
    The arguments to resource properties.
    options CustomResourceOptions
    Bag of options to control resource's behavior.

    AnalyticsApplication 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 AnalyticsApplication resource accepts the following input properties:

    CloudwatchLoggingOptions AnalyticsApplicationCloudwatchLoggingOptions

    The CloudWatch log stream options to monitor application errors. See CloudWatch Logging Options below for more details.

    Code string

    SQL Code to transform input data, and generate output.

    Description string

    Description of the application.

    Inputs AnalyticsApplicationInputs

    Input configuration of the application. See Inputs below for more details.

    Name string

    Name of the Kinesis Analytics Application.

    Outputs List<AnalyticsApplicationOutput>

    Output destination configuration of the application. See Outputs below for more details.

    ReferenceDataSources AnalyticsApplicationReferenceDataSources

    An S3 Reference Data Source for the application. See Reference Data Sources below for more details.

    StartApplication bool

    Whether to start or stop the Kinesis Analytics Application. To start an application, an input with a defined starting_position must be configured. To modify an application's starting position, first stop the application by setting start_application = false, then update starting_position and set start_application = true.

    Tags Dictionary<string, string>

    Key-value map of tags for the Kinesis Analytics Application. If configured with a provider default_tags configuration block present, tags with matching keys will overwrite those defined at the provider-level.

    CloudwatchLoggingOptions AnalyticsApplicationCloudwatchLoggingOptionsArgs

    The CloudWatch log stream options to monitor application errors. See CloudWatch Logging Options below for more details.

    Code string

    SQL Code to transform input data, and generate output.

    Description string

    Description of the application.

    Inputs AnalyticsApplicationInputsArgs

    Input configuration of the application. See Inputs below for more details.

    Name string

    Name of the Kinesis Analytics Application.

    Outputs []AnalyticsApplicationOutputTypeArgs

    Output destination configuration of the application. See Outputs below for more details.

    ReferenceDataSources AnalyticsApplicationReferenceDataSourcesArgs

    An S3 Reference Data Source for the application. See Reference Data Sources below for more details.

    StartApplication bool

    Whether to start or stop the Kinesis Analytics Application. To start an application, an input with a defined starting_position must be configured. To modify an application's starting position, first stop the application by setting start_application = false, then update starting_position and set start_application = true.

    Tags map[string]string

    Key-value map of tags for the Kinesis Analytics Application. If configured with a provider default_tags configuration block present, tags with matching keys will overwrite those defined at the provider-level.

    cloudwatchLoggingOptions AnalyticsApplicationCloudwatchLoggingOptions

    The CloudWatch log stream options to monitor application errors. See CloudWatch Logging Options below for more details.

    code String

    SQL Code to transform input data, and generate output.

    description String

    Description of the application.

    inputs AnalyticsApplicationInputs

    Input configuration of the application. See Inputs below for more details.

    name String

    Name of the Kinesis Analytics Application.

    outputs List<AnalyticsApplicationOutput>

    Output destination configuration of the application. See Outputs below for more details.

    referenceDataSources AnalyticsApplicationReferenceDataSources

    An S3 Reference Data Source for the application. See Reference Data Sources below for more details.

    startApplication Boolean

    Whether to start or stop the Kinesis Analytics Application. To start an application, an input with a defined starting_position must be configured. To modify an application's starting position, first stop the application by setting start_application = false, then update starting_position and set start_application = true.

    tags Map<String,String>

    Key-value map of tags for the Kinesis Analytics Application. If configured with a provider default_tags configuration block present, tags with matching keys will overwrite those defined at the provider-level.

    cloudwatchLoggingOptions AnalyticsApplicationCloudwatchLoggingOptions

    The CloudWatch log stream options to monitor application errors. See CloudWatch Logging Options below for more details.

    code string

    SQL Code to transform input data, and generate output.

    description string

    Description of the application.

    inputs AnalyticsApplicationInputs

    Input configuration of the application. See Inputs below for more details.

    name string

    Name of the Kinesis Analytics Application.

    outputs AnalyticsApplicationOutput[]

    Output destination configuration of the application. See Outputs below for more details.

    referenceDataSources AnalyticsApplicationReferenceDataSources

    An S3 Reference Data Source for the application. See Reference Data Sources below for more details.

    startApplication boolean

    Whether to start or stop the Kinesis Analytics Application. To start an application, an input with a defined starting_position must be configured. To modify an application's starting position, first stop the application by setting start_application = false, then update starting_position and set start_application = true.

    tags {[key: string]: string}

    Key-value map of tags for the Kinesis Analytics Application. If configured with a provider default_tags configuration block present, tags with matching keys will overwrite those defined at the provider-level.

    cloudwatch_logging_options AnalyticsApplicationCloudwatchLoggingOptionsArgs

    The CloudWatch log stream options to monitor application errors. See CloudWatch Logging Options below for more details.

    code str

    SQL Code to transform input data, and generate output.

    description str

    Description of the application.

    inputs AnalyticsApplicationInputsArgs

    Input configuration of the application. See Inputs below for more details.

    name str

    Name of the Kinesis Analytics Application.

    outputs Sequence[AnalyticsApplicationOutputArgs]

    Output destination configuration of the application. See Outputs below for more details.

    reference_data_sources AnalyticsApplicationReferenceDataSourcesArgs

    An S3 Reference Data Source for the application. See Reference Data Sources below for more details.

    start_application bool

    Whether to start or stop the Kinesis Analytics Application. To start an application, an input with a defined starting_position must be configured. To modify an application's starting position, first stop the application by setting start_application = false, then update starting_position and set start_application = true.

    tags Mapping[str, str]

    Key-value map of tags for the Kinesis Analytics Application. If configured with a provider default_tags configuration block present, tags with matching keys will overwrite those defined at the provider-level.

    cloudwatchLoggingOptions Property Map

    The CloudWatch log stream options to monitor application errors. See CloudWatch Logging Options below for more details.

    code String

    SQL Code to transform input data, and generate output.

    description String

    Description of the application.

    inputs Property Map

    Input configuration of the application. See Inputs below for more details.

    name String

    Name of the Kinesis Analytics Application.

    outputs List<Property Map>

    Output destination configuration of the application. See Outputs below for more details.

    referenceDataSources Property Map

    An S3 Reference Data Source for the application. See Reference Data Sources below for more details.

    startApplication Boolean

    Whether to start or stop the Kinesis Analytics Application. To start an application, an input with a defined starting_position must be configured. To modify an application's starting position, first stop the application by setting start_application = false, then update starting_position and set start_application = true.

    tags Map<String>

    Key-value map of tags for the Kinesis Analytics Application. If configured with a provider default_tags configuration block present, tags with matching keys will overwrite those defined at the provider-level.

    Outputs

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

    Arn string

    The ARN of the Kinesis Analytics Appliation.

    CreateTimestamp string

    The Timestamp when the application version was created.

    Id string

    The provider-assigned unique ID for this managed resource.

    LastUpdateTimestamp string

    The Timestamp when the application was last updated.

    Status string

    The Status of the application.

    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.

    Version int

    The Version of the application.

    Arn string

    The ARN of the Kinesis Analytics Appliation.

    CreateTimestamp string

    The Timestamp when the application version was created.

    Id string

    The provider-assigned unique ID for this managed resource.

    LastUpdateTimestamp string

    The Timestamp when the application was last updated.

    Status string

    The Status of the application.

    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.

    Version int

    The Version of the application.

    arn String

    The ARN of the Kinesis Analytics Appliation.

    createTimestamp String

    The Timestamp when the application version was created.

    id String

    The provider-assigned unique ID for this managed resource.

    lastUpdateTimestamp String

    The Timestamp when the application was last updated.

    status String

    The Status of the application.

    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.

    version Integer

    The Version of the application.

    arn ARN

    The ARN of the Kinesis Analytics Appliation.

    createTimestamp string

    The Timestamp when the application version was created.

    id string

    The provider-assigned unique ID for this managed resource.

    lastUpdateTimestamp string

    The Timestamp when the application was last updated.

    status string

    The Status of the application.

    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.

    version number

    The Version of the application.

    arn str

    The ARN of the Kinesis Analytics Appliation.

    create_timestamp str

    The Timestamp when the application version was created.

    id str

    The provider-assigned unique ID for this managed resource.

    last_update_timestamp str

    The Timestamp when the application was last updated.

    status str

    The Status of the application.

    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 int

    The Version of the application.

    arn

    The ARN of the Kinesis Analytics Appliation.

    createTimestamp String

    The Timestamp when the application version was created.

    id String

    The provider-assigned unique ID for this managed resource.

    lastUpdateTimestamp String

    The Timestamp when the application was last updated.

    status String

    The Status of the application.

    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.

    version Number

    The Version of the application.

    Look up Existing AnalyticsApplication Resource

    Get an existing AnalyticsApplication 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?: AnalyticsApplicationState, opts?: CustomResourceOptions): AnalyticsApplication
    @staticmethod
    def get(resource_name: str,
            id: str,
            opts: Optional[ResourceOptions] = None,
            arn: Optional[str] = None,
            cloudwatch_logging_options: Optional[AnalyticsApplicationCloudwatchLoggingOptionsArgs] = None,
            code: Optional[str] = None,
            create_timestamp: Optional[str] = None,
            description: Optional[str] = None,
            inputs: Optional[AnalyticsApplicationInputsArgs] = None,
            last_update_timestamp: Optional[str] = None,
            name: Optional[str] = None,
            outputs: Optional[Sequence[AnalyticsApplicationOutputArgs]] = None,
            reference_data_sources: Optional[AnalyticsApplicationReferenceDataSourcesArgs] = None,
            start_application: Optional[bool] = None,
            status: Optional[str] = None,
            tags: Optional[Mapping[str, str]] = None,
            tags_all: Optional[Mapping[str, str]] = None,
            version: Optional[int] = None) -> AnalyticsApplication
    func GetAnalyticsApplication(ctx *Context, name string, id IDInput, state *AnalyticsApplicationState, opts ...ResourceOption) (*AnalyticsApplication, error)
    public static AnalyticsApplication Get(string name, Input<string> id, AnalyticsApplicationState? state, CustomResourceOptions? opts = null)
    public static AnalyticsApplication get(String name, Output<String> id, AnalyticsApplicationState 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 ARN of the Kinesis Analytics Appliation.

    CloudwatchLoggingOptions AnalyticsApplicationCloudwatchLoggingOptions

    The CloudWatch log stream options to monitor application errors. See CloudWatch Logging Options below for more details.

    Code string

    SQL Code to transform input data, and generate output.

    CreateTimestamp string

    The Timestamp when the application version was created.

    Description string

    Description of the application.

    Inputs AnalyticsApplicationInputs

    Input configuration of the application. See Inputs below for more details.

    LastUpdateTimestamp string

    The Timestamp when the application was last updated.

    Name string

    Name of the Kinesis Analytics Application.

    Outputs List<AnalyticsApplicationOutput>

    Output destination configuration of the application. See Outputs below for more details.

    ReferenceDataSources AnalyticsApplicationReferenceDataSources

    An S3 Reference Data Source for the application. See Reference Data Sources below for more details.

    StartApplication bool

    Whether to start or stop the Kinesis Analytics Application. To start an application, an input with a defined starting_position must be configured. To modify an application's starting position, first stop the application by setting start_application = false, then update starting_position and set start_application = true.

    Status string

    The Status of the application.

    Tags Dictionary<string, string>

    Key-value map of tags for the Kinesis Analytics Application. 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.

    Version int

    The Version of the application.

    Arn string

    The ARN of the Kinesis Analytics Appliation.

    CloudwatchLoggingOptions AnalyticsApplicationCloudwatchLoggingOptionsArgs

    The CloudWatch log stream options to monitor application errors. See CloudWatch Logging Options below for more details.

    Code string

    SQL Code to transform input data, and generate output.

    CreateTimestamp string

    The Timestamp when the application version was created.

    Description string

    Description of the application.

    Inputs AnalyticsApplicationInputsArgs

    Input configuration of the application. See Inputs below for more details.

    LastUpdateTimestamp string

    The Timestamp when the application was last updated.

    Name string

    Name of the Kinesis Analytics Application.

    Outputs []AnalyticsApplicationOutputTypeArgs

    Output destination configuration of the application. See Outputs below for more details.

    ReferenceDataSources AnalyticsApplicationReferenceDataSourcesArgs

    An S3 Reference Data Source for the application. See Reference Data Sources below for more details.

    StartApplication bool

    Whether to start or stop the Kinesis Analytics Application. To start an application, an input with a defined starting_position must be configured. To modify an application's starting position, first stop the application by setting start_application = false, then update starting_position and set start_application = true.

    Status string

    The Status of the application.

    Tags map[string]string

    Key-value map of tags for the Kinesis Analytics Application. 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.

    Version int

    The Version of the application.

    arn String

    The ARN of the Kinesis Analytics Appliation.

    cloudwatchLoggingOptions AnalyticsApplicationCloudwatchLoggingOptions

    The CloudWatch log stream options to monitor application errors. See CloudWatch Logging Options below for more details.

    code String

    SQL Code to transform input data, and generate output.

    createTimestamp String

    The Timestamp when the application version was created.

    description String

    Description of the application.

    inputs AnalyticsApplicationInputs

    Input configuration of the application. See Inputs below for more details.

    lastUpdateTimestamp String

    The Timestamp when the application was last updated.

    name String

    Name of the Kinesis Analytics Application.

    outputs List<AnalyticsApplicationOutput>

    Output destination configuration of the application. See Outputs below for more details.

    referenceDataSources AnalyticsApplicationReferenceDataSources

    An S3 Reference Data Source for the application. See Reference Data Sources below for more details.

    startApplication Boolean

    Whether to start or stop the Kinesis Analytics Application. To start an application, an input with a defined starting_position must be configured. To modify an application's starting position, first stop the application by setting start_application = false, then update starting_position and set start_application = true.

    status String

    The Status of the application.

    tags Map<String,String>

    Key-value map of tags for the Kinesis Analytics Application. 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.

    version Integer

    The Version of the application.

    arn ARN

    The ARN of the Kinesis Analytics Appliation.

    cloudwatchLoggingOptions AnalyticsApplicationCloudwatchLoggingOptions

    The CloudWatch log stream options to monitor application errors. See CloudWatch Logging Options below for more details.

    code string

    SQL Code to transform input data, and generate output.

    createTimestamp string

    The Timestamp when the application version was created.

    description string

    Description of the application.

    inputs AnalyticsApplicationInputs

    Input configuration of the application. See Inputs below for more details.

    lastUpdateTimestamp string

    The Timestamp when the application was last updated.

    name string

    Name of the Kinesis Analytics Application.

    outputs AnalyticsApplicationOutput[]

    Output destination configuration of the application. See Outputs below for more details.

    referenceDataSources AnalyticsApplicationReferenceDataSources

    An S3 Reference Data Source for the application. See Reference Data Sources below for more details.

    startApplication boolean

    Whether to start or stop the Kinesis Analytics Application. To start an application, an input with a defined starting_position must be configured. To modify an application's starting position, first stop the application by setting start_application = false, then update starting_position and set start_application = true.

    status string

    The Status of the application.

    tags {[key: string]: string}

    Key-value map of tags for the Kinesis Analytics Application. 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.

    version number

    The Version of the application.

    arn str

    The ARN of the Kinesis Analytics Appliation.

    cloudwatch_logging_options AnalyticsApplicationCloudwatchLoggingOptionsArgs

    The CloudWatch log stream options to monitor application errors. See CloudWatch Logging Options below for more details.

    code str

    SQL Code to transform input data, and generate output.

    create_timestamp str

    The Timestamp when the application version was created.

    description str

    Description of the application.

    inputs AnalyticsApplicationInputsArgs

    Input configuration of the application. See Inputs below for more details.

    last_update_timestamp str

    The Timestamp when the application was last updated.

    name str

    Name of the Kinesis Analytics Application.

    outputs Sequence[AnalyticsApplicationOutputArgs]

    Output destination configuration of the application. See Outputs below for more details.

    reference_data_sources AnalyticsApplicationReferenceDataSourcesArgs

    An S3 Reference Data Source for the application. See Reference Data Sources below for more details.

    start_application bool

    Whether to start or stop the Kinesis Analytics Application. To start an application, an input with a defined starting_position must be configured. To modify an application's starting position, first stop the application by setting start_application = false, then update starting_position and set start_application = true.

    status str

    The Status of the application.

    tags Mapping[str, str]

    Key-value map of tags for the Kinesis Analytics Application. 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 int

    The Version of the application.

    arn

    The ARN of the Kinesis Analytics Appliation.

    cloudwatchLoggingOptions Property Map

    The CloudWatch log stream options to monitor application errors. See CloudWatch Logging Options below for more details.

    code String

    SQL Code to transform input data, and generate output.

    createTimestamp String

    The Timestamp when the application version was created.

    description String

    Description of the application.

    inputs Property Map

    Input configuration of the application. See Inputs below for more details.

    lastUpdateTimestamp String

    The Timestamp when the application was last updated.

    name String

    Name of the Kinesis Analytics Application.

    outputs List<Property Map>

    Output destination configuration of the application. See Outputs below for more details.

    referenceDataSources Property Map

    An S3 Reference Data Source for the application. See Reference Data Sources below for more details.

    startApplication Boolean

    Whether to start or stop the Kinesis Analytics Application. To start an application, an input with a defined starting_position must be configured. To modify an application's starting position, first stop the application by setting start_application = false, then update starting_position and set start_application = true.

    status String

    The Status of the application.

    tags Map<String>

    Key-value map of tags for the Kinesis Analytics Application. 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.

    version Number

    The Version of the application.

    Supporting Types

    AnalyticsApplicationCloudwatchLoggingOptions, AnalyticsApplicationCloudwatchLoggingOptionsArgs

    LogStreamArn string

    The ARN of the CloudWatch Log Stream.

    RoleArn string

    The ARN of the IAM Role used to send application messages.

    Id string

    The ARN of the Kinesis Analytics Application.

    LogStreamArn string

    The ARN of the CloudWatch Log Stream.

    RoleArn string

    The ARN of the IAM Role used to send application messages.

    Id string

    The ARN of the Kinesis Analytics Application.

    logStreamArn String

    The ARN of the CloudWatch Log Stream.

    roleArn String

    The ARN of the IAM Role used to send application messages.

    id String

    The ARN of the Kinesis Analytics Application.

    logStreamArn string

    The ARN of the CloudWatch Log Stream.

    roleArn string

    The ARN of the IAM Role used to send application messages.

    id string

    The ARN of the Kinesis Analytics Application.

    log_stream_arn str

    The ARN of the CloudWatch Log Stream.

    role_arn str

    The ARN of the IAM Role used to send application messages.

    id str

    The ARN of the Kinesis Analytics Application.

    logStreamArn String

    The ARN of the CloudWatch Log Stream.

    roleArn String

    The ARN of the IAM Role used to send application messages.

    id String

    The ARN of the Kinesis Analytics Application.

    AnalyticsApplicationInputs, AnalyticsApplicationInputsArgs

    NamePrefix string

    The Name Prefix to use when creating an in-application stream.

    Schema AnalyticsApplicationInputsSchema

    The Schema format of the data in the streaming source. See Source Schema below for more details.

    Id string

    The ARN of the Kinesis Analytics Application.

    KinesisFirehose AnalyticsApplicationInputsKinesisFirehose

    The Kinesis Firehose configuration for the streaming source. Conflicts with kinesis_stream. See Kinesis Firehose below for more details.

    KinesisStream AnalyticsApplicationInputsKinesisStream

    The Kinesis Stream configuration for the streaming source. Conflicts with kinesis_firehose. See Kinesis Stream below for more details.

    Parallelism AnalyticsApplicationInputsParallelism

    The number of Parallel in-application streams to create. See Parallelism below for more details.

    ProcessingConfiguration AnalyticsApplicationInputsProcessingConfiguration

    The Processing Configuration to transform records as they are received from the stream. See Processing Configuration below for more details.

    StartingPositionConfigurations List<AnalyticsApplicationInputsStartingPositionConfiguration>

    The point at which the application starts processing records from the streaming source. See Starting Position Configuration below for more details.

    StreamNames List<string>
    NamePrefix string

    The Name Prefix to use when creating an in-application stream.

    Schema AnalyticsApplicationInputsSchema

    The Schema format of the data in the streaming source. See Source Schema below for more details.

    Id string

    The ARN of the Kinesis Analytics Application.

    KinesisFirehose AnalyticsApplicationInputsKinesisFirehose

    The Kinesis Firehose configuration for the streaming source. Conflicts with kinesis_stream. See Kinesis Firehose below for more details.

    KinesisStream AnalyticsApplicationInputsKinesisStream

    The Kinesis Stream configuration for the streaming source. Conflicts with kinesis_firehose. See Kinesis Stream below for more details.

    Parallelism AnalyticsApplicationInputsParallelism

    The number of Parallel in-application streams to create. See Parallelism below for more details.

    ProcessingConfiguration AnalyticsApplicationInputsProcessingConfiguration

    The Processing Configuration to transform records as they are received from the stream. See Processing Configuration below for more details.

    StartingPositionConfigurations []AnalyticsApplicationInputsStartingPositionConfiguration

    The point at which the application starts processing records from the streaming source. See Starting Position Configuration below for more details.

    StreamNames []string
    namePrefix String

    The Name Prefix to use when creating an in-application stream.

    schema AnalyticsApplicationInputsSchema

    The Schema format of the data in the streaming source. See Source Schema below for more details.

    id String

    The ARN of the Kinesis Analytics Application.

    kinesisFirehose AnalyticsApplicationInputsKinesisFirehose

    The Kinesis Firehose configuration for the streaming source. Conflicts with kinesis_stream. See Kinesis Firehose below for more details.

    kinesisStream AnalyticsApplicationInputsKinesisStream

    The Kinesis Stream configuration for the streaming source. Conflicts with kinesis_firehose. See Kinesis Stream below for more details.

    parallelism AnalyticsApplicationInputsParallelism

    The number of Parallel in-application streams to create. See Parallelism below for more details.

    processingConfiguration AnalyticsApplicationInputsProcessingConfiguration

    The Processing Configuration to transform records as they are received from the stream. See Processing Configuration below for more details.

    startingPositionConfigurations List<AnalyticsApplicationInputsStartingPositionConfiguration>

    The point at which the application starts processing records from the streaming source. See Starting Position Configuration below for more details.

    streamNames List<String>
    namePrefix string

    The Name Prefix to use when creating an in-application stream.

    schema AnalyticsApplicationInputsSchema

    The Schema format of the data in the streaming source. See Source Schema below for more details.

    id string

    The ARN of the Kinesis Analytics Application.

    kinesisFirehose AnalyticsApplicationInputsKinesisFirehose

    The Kinesis Firehose configuration for the streaming source. Conflicts with kinesis_stream. See Kinesis Firehose below for more details.

    kinesisStream AnalyticsApplicationInputsKinesisStream

    The Kinesis Stream configuration for the streaming source. Conflicts with kinesis_firehose. See Kinesis Stream below for more details.

    parallelism AnalyticsApplicationInputsParallelism

    The number of Parallel in-application streams to create. See Parallelism below for more details.

    processingConfiguration AnalyticsApplicationInputsProcessingConfiguration

    The Processing Configuration to transform records as they are received from the stream. See Processing Configuration below for more details.

    startingPositionConfigurations AnalyticsApplicationInputsStartingPositionConfiguration[]

    The point at which the application starts processing records from the streaming source. See Starting Position Configuration below for more details.

    streamNames string[]
    name_prefix str

    The Name Prefix to use when creating an in-application stream.

    schema AnalyticsApplicationInputsSchema

    The Schema format of the data in the streaming source. See Source Schema below for more details.

    id str

    The ARN of the Kinesis Analytics Application.

    kinesis_firehose AnalyticsApplicationInputsKinesisFirehose

    The Kinesis Firehose configuration for the streaming source. Conflicts with kinesis_stream. See Kinesis Firehose below for more details.

    kinesis_stream AnalyticsApplicationInputsKinesisStream

    The Kinesis Stream configuration for the streaming source. Conflicts with kinesis_firehose. See Kinesis Stream below for more details.

    parallelism AnalyticsApplicationInputsParallelism

    The number of Parallel in-application streams to create. See Parallelism below for more details.

    processing_configuration AnalyticsApplicationInputsProcessingConfiguration

    The Processing Configuration to transform records as they are received from the stream. See Processing Configuration below for more details.

    starting_position_configurations Sequence[AnalyticsApplicationInputsStartingPositionConfiguration]

    The point at which the application starts processing records from the streaming source. See Starting Position Configuration below for more details.

    stream_names Sequence[str]
    namePrefix String

    The Name Prefix to use when creating an in-application stream.

    schema Property Map

    The Schema format of the data in the streaming source. See Source Schema below for more details.

    id String

    The ARN of the Kinesis Analytics Application.

    kinesisFirehose Property Map

    The Kinesis Firehose configuration for the streaming source. Conflicts with kinesis_stream. See Kinesis Firehose below for more details.

    kinesisStream Property Map

    The Kinesis Stream configuration for the streaming source. Conflicts with kinesis_firehose. See Kinesis Stream below for more details.

    parallelism Property Map

    The number of Parallel in-application streams to create. See Parallelism below for more details.

    processingConfiguration Property Map

    The Processing Configuration to transform records as they are received from the stream. See Processing Configuration below for more details.

    startingPositionConfigurations List<Property Map>

    The point at which the application starts processing records from the streaming source. See Starting Position Configuration below for more details.

    streamNames List<String>

    AnalyticsApplicationInputsKinesisFirehose, AnalyticsApplicationInputsKinesisFirehoseArgs

    ResourceArn string

    The ARN of the Kinesis Firehose delivery stream.

    RoleArn string

    The ARN of the IAM Role used to access the stream.

    ResourceArn string

    The ARN of the Kinesis Firehose delivery stream.

    RoleArn string

    The ARN of the IAM Role used to access the stream.

    resourceArn String

    The ARN of the Kinesis Firehose delivery stream.

    roleArn String

    The ARN of the IAM Role used to access the stream.

    resourceArn string

    The ARN of the Kinesis Firehose delivery stream.

    roleArn string

    The ARN of the IAM Role used to access the stream.

    resource_arn str

    The ARN of the Kinesis Firehose delivery stream.

    role_arn str

    The ARN of the IAM Role used to access the stream.

    resourceArn String

    The ARN of the Kinesis Firehose delivery stream.

    roleArn String

    The ARN of the IAM Role used to access the stream.

    AnalyticsApplicationInputsKinesisStream, AnalyticsApplicationInputsKinesisStreamArgs

    ResourceArn string

    The ARN of the Kinesis Stream.

    RoleArn string

    The ARN of the IAM Role used to access the stream.

    ResourceArn string

    The ARN of the Kinesis Stream.

    RoleArn string

    The ARN of the IAM Role used to access the stream.

    resourceArn String

    The ARN of the Kinesis Stream.

    roleArn String

    The ARN of the IAM Role used to access the stream.

    resourceArn string

    The ARN of the Kinesis Stream.

    roleArn string

    The ARN of the IAM Role used to access the stream.

    resource_arn str

    The ARN of the Kinesis Stream.

    role_arn str

    The ARN of the IAM Role used to access the stream.

    resourceArn String

    The ARN of the Kinesis Stream.

    roleArn String

    The ARN of the IAM Role used to access the stream.

    AnalyticsApplicationInputsParallelism, AnalyticsApplicationInputsParallelismArgs

    Count int

    The Count of streams.

    Count int

    The Count of streams.

    count Integer

    The Count of streams.

    count number

    The Count of streams.

    count int

    The Count of streams.

    count Number

    The Count of streams.

    AnalyticsApplicationInputsProcessingConfiguration, AnalyticsApplicationInputsProcessingConfigurationArgs

    Lambda AnalyticsApplicationInputsProcessingConfigurationLambda

    The Lambda function configuration. See Lambda below for more details.

    Lambda AnalyticsApplicationInputsProcessingConfigurationLambda

    The Lambda function configuration. See Lambda below for more details.

    lambda AnalyticsApplicationInputsProcessingConfigurationLambda

    The Lambda function configuration. See Lambda below for more details.

    lambda AnalyticsApplicationInputsProcessingConfigurationLambda

    The Lambda function configuration. See Lambda below for more details.

    lambda_ AnalyticsApplicationInputsProcessingConfigurationLambda

    The Lambda function configuration. See Lambda below for more details.

    lambda Property Map

    The Lambda function configuration. See Lambda below for more details.

    AnalyticsApplicationInputsProcessingConfigurationLambda, AnalyticsApplicationInputsProcessingConfigurationLambdaArgs

    ResourceArn string

    The ARN of the Lambda function.

    RoleArn string

    The ARN of the IAM Role used to access the Lambda function.

    ResourceArn string

    The ARN of the Lambda function.

    RoleArn string

    The ARN of the IAM Role used to access the Lambda function.

    resourceArn String

    The ARN of the Lambda function.

    roleArn String

    The ARN of the IAM Role used to access the Lambda function.

    resourceArn string

    The ARN of the Lambda function.

    roleArn string

    The ARN of the IAM Role used to access the Lambda function.

    resource_arn str

    The ARN of the Lambda function.

    role_arn str

    The ARN of the IAM Role used to access the Lambda function.

    resourceArn String

    The ARN of the Lambda function.

    roleArn String

    The ARN of the IAM Role used to access the Lambda function.

    AnalyticsApplicationInputsSchema, AnalyticsApplicationInputsSchemaArgs

    RecordColumns List<AnalyticsApplicationInputsSchemaRecordColumn>

    The Record Column mapping for the streaming source data element. See Record Columns below for more details.

    RecordFormat AnalyticsApplicationInputsSchemaRecordFormat

    The Record Format and mapping information to schematize a record. See Record Format below for more details.

    RecordEncoding string

    The Encoding of the record in the streaming source.

    RecordColumns []AnalyticsApplicationInputsSchemaRecordColumn

    The Record Column mapping for the streaming source data element. See Record Columns below for more details.

    RecordFormat AnalyticsApplicationInputsSchemaRecordFormat

    The Record Format and mapping information to schematize a record. See Record Format below for more details.

    RecordEncoding string

    The Encoding of the record in the streaming source.

    recordColumns List<AnalyticsApplicationInputsSchemaRecordColumn>

    The Record Column mapping for the streaming source data element. See Record Columns below for more details.

    recordFormat AnalyticsApplicationInputsSchemaRecordFormat

    The Record Format and mapping information to schematize a record. See Record Format below for more details.

    recordEncoding String

    The Encoding of the record in the streaming source.

    recordColumns AnalyticsApplicationInputsSchemaRecordColumn[]

    The Record Column mapping for the streaming source data element. See Record Columns below for more details.

    recordFormat AnalyticsApplicationInputsSchemaRecordFormat

    The Record Format and mapping information to schematize a record. See Record Format below for more details.

    recordEncoding string

    The Encoding of the record in the streaming source.

    record_columns Sequence[AnalyticsApplicationInputsSchemaRecordColumn]

    The Record Column mapping for the streaming source data element. See Record Columns below for more details.

    record_format AnalyticsApplicationInputsSchemaRecordFormat

    The Record Format and mapping information to schematize a record. See Record Format below for more details.

    record_encoding str

    The Encoding of the record in the streaming source.

    recordColumns List<Property Map>

    The Record Column mapping for the streaming source data element. See Record Columns below for more details.

    recordFormat Property Map

    The Record Format and mapping information to schematize a record. See Record Format below for more details.

    recordEncoding String

    The Encoding of the record in the streaming source.

    AnalyticsApplicationInputsSchemaRecordColumn, AnalyticsApplicationInputsSchemaRecordColumnArgs

    Name string

    Name of the column.

    SqlType string

    The SQL Type of the column.

    Mapping string

    The Mapping reference to the data element.

    Name string

    Name of the column.

    SqlType string

    The SQL Type of the column.

    Mapping string

    The Mapping reference to the data element.

    name String

    Name of the column.

    sqlType String

    The SQL Type of the column.

    mapping String

    The Mapping reference to the data element.

    name string

    Name of the column.

    sqlType string

    The SQL Type of the column.

    mapping string

    The Mapping reference to the data element.

    name str

    Name of the column.

    sql_type str

    The SQL Type of the column.

    mapping str

    The Mapping reference to the data element.

    name String

    Name of the column.

    sqlType String

    The SQL Type of the column.

    mapping String

    The Mapping reference to the data element.

    AnalyticsApplicationInputsSchemaRecordFormat, AnalyticsApplicationInputsSchemaRecordFormatArgs

    MappingParameters AnalyticsApplicationInputsSchemaRecordFormatMappingParameters

    The Mapping Information for the record format. See Mapping Parameters below for more details.

    RecordFormatType string

    The type of Record Format. Can be CSV or JSON.

    MappingParameters AnalyticsApplicationInputsSchemaRecordFormatMappingParameters

    The Mapping Information for the record format. See Mapping Parameters below for more details.

    RecordFormatType string

    The type of Record Format. Can be CSV or JSON.

    mappingParameters AnalyticsApplicationInputsSchemaRecordFormatMappingParameters

    The Mapping Information for the record format. See Mapping Parameters below for more details.

    recordFormatType String

    The type of Record Format. Can be CSV or JSON.

    mappingParameters AnalyticsApplicationInputsSchemaRecordFormatMappingParameters

    The Mapping Information for the record format. See Mapping Parameters below for more details.

    recordFormatType string

    The type of Record Format. Can be CSV or JSON.

    mapping_parameters AnalyticsApplicationInputsSchemaRecordFormatMappingParameters

    The Mapping Information for the record format. See Mapping Parameters below for more details.

    record_format_type str

    The type of Record Format. Can be CSV or JSON.

    mappingParameters Property Map

    The Mapping Information for the record format. See Mapping Parameters below for more details.

    recordFormatType String

    The type of Record Format. Can be CSV or JSON.

    AnalyticsApplicationInputsSchemaRecordFormatMappingParameters, AnalyticsApplicationInputsSchemaRecordFormatMappingParametersArgs

    Csv AnalyticsApplicationInputsSchemaRecordFormatMappingParametersCsv

    Mapping information when the record format uses delimiters. See CSV Mapping Parameters below for more details.

    Json AnalyticsApplicationInputsSchemaRecordFormatMappingParametersJson

    Mapping information when JSON is the record format on the streaming source. See JSON Mapping Parameters below for more details.

    Csv AnalyticsApplicationInputsSchemaRecordFormatMappingParametersCsv

    Mapping information when the record format uses delimiters. See CSV Mapping Parameters below for more details.

    Json AnalyticsApplicationInputsSchemaRecordFormatMappingParametersJson

    Mapping information when JSON is the record format on the streaming source. See JSON Mapping Parameters below for more details.

    csv AnalyticsApplicationInputsSchemaRecordFormatMappingParametersCsv

    Mapping information when the record format uses delimiters. See CSV Mapping Parameters below for more details.

    json AnalyticsApplicationInputsSchemaRecordFormatMappingParametersJson

    Mapping information when JSON is the record format on the streaming source. See JSON Mapping Parameters below for more details.

    csv AnalyticsApplicationInputsSchemaRecordFormatMappingParametersCsv

    Mapping information when the record format uses delimiters. See CSV Mapping Parameters below for more details.

    json AnalyticsApplicationInputsSchemaRecordFormatMappingParametersJson

    Mapping information when JSON is the record format on the streaming source. See JSON Mapping Parameters below for more details.

    csv AnalyticsApplicationInputsSchemaRecordFormatMappingParametersCsv

    Mapping information when the record format uses delimiters. See CSV Mapping Parameters below for more details.

    json AnalyticsApplicationInputsSchemaRecordFormatMappingParametersJson

    Mapping information when JSON is the record format on the streaming source. See JSON Mapping Parameters below for more details.

    csv Property Map

    Mapping information when the record format uses delimiters. See CSV Mapping Parameters below for more details.

    json Property Map

    Mapping information when JSON is the record format on the streaming source. See JSON Mapping Parameters below for more details.

    AnalyticsApplicationInputsSchemaRecordFormatMappingParametersCsv, AnalyticsApplicationInputsSchemaRecordFormatMappingParametersCsvArgs

    RecordColumnDelimiter string

    The Column Delimiter.

    RecordRowDelimiter string

    The Row Delimiter.

    RecordColumnDelimiter string

    The Column Delimiter.

    RecordRowDelimiter string

    The Row Delimiter.

    recordColumnDelimiter String

    The Column Delimiter.

    recordRowDelimiter String

    The Row Delimiter.

    recordColumnDelimiter string

    The Column Delimiter.

    recordRowDelimiter string

    The Row Delimiter.

    record_column_delimiter str

    The Column Delimiter.

    record_row_delimiter str

    The Row Delimiter.

    recordColumnDelimiter String

    The Column Delimiter.

    recordRowDelimiter String

    The Row Delimiter.

    AnalyticsApplicationInputsSchemaRecordFormatMappingParametersJson, AnalyticsApplicationInputsSchemaRecordFormatMappingParametersJsonArgs

    RecordRowPath string

    Path to the top-level parent that contains the records.

    RecordRowPath string

    Path to the top-level parent that contains the records.

    recordRowPath String

    Path to the top-level parent that contains the records.

    recordRowPath string

    Path to the top-level parent that contains the records.

    record_row_path str

    Path to the top-level parent that contains the records.

    recordRowPath String

    Path to the top-level parent that contains the records.

    AnalyticsApplicationInputsStartingPositionConfiguration, AnalyticsApplicationInputsStartingPositionConfigurationArgs

    StartingPosition string

    The starting position on the stream. Valid values: LAST_STOPPED_POINT, NOW, TRIM_HORIZON.

    StartingPosition string

    The starting position on the stream. Valid values: LAST_STOPPED_POINT, NOW, TRIM_HORIZON.

    startingPosition String

    The starting position on the stream. Valid values: LAST_STOPPED_POINT, NOW, TRIM_HORIZON.

    startingPosition string

    The starting position on the stream. Valid values: LAST_STOPPED_POINT, NOW, TRIM_HORIZON.

    starting_position str

    The starting position on the stream. Valid values: LAST_STOPPED_POINT, NOW, TRIM_HORIZON.

    startingPosition String

    The starting position on the stream. Valid values: LAST_STOPPED_POINT, NOW, TRIM_HORIZON.

    AnalyticsApplicationOutput, AnalyticsApplicationOutputArgs

    Name string

    The Name of the in-application stream.

    Schema AnalyticsApplicationOutputSchema

    The Schema format of the data written to the destination. See Destination Schema below for more details.

    Id string

    The ARN of the Kinesis Analytics Application.

    KinesisFirehose AnalyticsApplicationOutputKinesisFirehose

    The Kinesis Firehose configuration for the destination stream. Conflicts with kinesis_stream. See Kinesis Firehose below for more details.

    KinesisStream AnalyticsApplicationOutputKinesisStream

    The Kinesis Stream configuration for the destination stream. Conflicts with kinesis_firehose. See Kinesis Stream below for more details.

    Lambda AnalyticsApplicationOutputLambda

    The Lambda function destination. See Lambda below for more details.

    Name string

    The Name of the in-application stream.

    Schema AnalyticsApplicationOutputSchema

    The Schema format of the data written to the destination. See Destination Schema below for more details.

    Id string

    The ARN of the Kinesis Analytics Application.

    KinesisFirehose AnalyticsApplicationOutputKinesisFirehose

    The Kinesis Firehose configuration for the destination stream. Conflicts with kinesis_stream. See Kinesis Firehose below for more details.

    KinesisStream AnalyticsApplicationOutputKinesisStream

    The Kinesis Stream configuration for the destination stream. Conflicts with kinesis_firehose. See Kinesis Stream below for more details.

    Lambda AnalyticsApplicationOutputLambda

    The Lambda function destination. See Lambda below for more details.

    name String

    The Name of the in-application stream.

    schema AnalyticsApplicationOutputSchema

    The Schema format of the data written to the destination. See Destination Schema below for more details.

    id String

    The ARN of the Kinesis Analytics Application.

    kinesisFirehose AnalyticsApplicationOutputKinesisFirehose

    The Kinesis Firehose configuration for the destination stream. Conflicts with kinesis_stream. See Kinesis Firehose below for more details.

    kinesisStream AnalyticsApplicationOutputKinesisStream

    The Kinesis Stream configuration for the destination stream. Conflicts with kinesis_firehose. See Kinesis Stream below for more details.

    lambda AnalyticsApplicationOutputLambda

    The Lambda function destination. See Lambda below for more details.

    name string

    The Name of the in-application stream.

    schema AnalyticsApplicationOutputSchema

    The Schema format of the data written to the destination. See Destination Schema below for more details.

    id string

    The ARN of the Kinesis Analytics Application.

    kinesisFirehose AnalyticsApplicationOutputKinesisFirehose

    The Kinesis Firehose configuration for the destination stream. Conflicts with kinesis_stream. See Kinesis Firehose below for more details.

    kinesisStream AnalyticsApplicationOutputKinesisStream

    The Kinesis Stream configuration for the destination stream. Conflicts with kinesis_firehose. See Kinesis Stream below for more details.

    lambda AnalyticsApplicationOutputLambda

    The Lambda function destination. See Lambda below for more details.

    name str

    The Name of the in-application stream.

    schema AnalyticsApplicationOutputSchema

    The Schema format of the data written to the destination. See Destination Schema below for more details.

    id str

    The ARN of the Kinesis Analytics Application.

    kinesis_firehose AnalyticsApplicationOutputKinesisFirehose

    The Kinesis Firehose configuration for the destination stream. Conflicts with kinesis_stream. See Kinesis Firehose below for more details.

    kinesis_stream AnalyticsApplicationOutputKinesisStream

    The Kinesis Stream configuration for the destination stream. Conflicts with kinesis_firehose. See Kinesis Stream below for more details.

    lambda_ AnalyticsApplicationOutputLambda

    The Lambda function destination. See Lambda below for more details.

    name String

    The Name of the in-application stream.

    schema Property Map

    The Schema format of the data written to the destination. See Destination Schema below for more details.

    id String

    The ARN of the Kinesis Analytics Application.

    kinesisFirehose Property Map

    The Kinesis Firehose configuration for the destination stream. Conflicts with kinesis_stream. See Kinesis Firehose below for more details.

    kinesisStream Property Map

    The Kinesis Stream configuration for the destination stream. Conflicts with kinesis_firehose. See Kinesis Stream below for more details.

    lambda Property Map

    The Lambda function destination. See Lambda below for more details.

    AnalyticsApplicationOutputKinesisFirehose, AnalyticsApplicationOutputKinesisFirehoseArgs

    ResourceArn string

    The ARN of the Kinesis Firehose delivery stream.

    RoleArn string

    The ARN of the IAM Role used to access the stream.

    ResourceArn string

    The ARN of the Kinesis Firehose delivery stream.

    RoleArn string

    The ARN of the IAM Role used to access the stream.

    resourceArn String

    The ARN of the Kinesis Firehose delivery stream.

    roleArn String

    The ARN of the IAM Role used to access the stream.

    resourceArn string

    The ARN of the Kinesis Firehose delivery stream.

    roleArn string

    The ARN of the IAM Role used to access the stream.

    resource_arn str

    The ARN of the Kinesis Firehose delivery stream.

    role_arn str

    The ARN of the IAM Role used to access the stream.

    resourceArn String

    The ARN of the Kinesis Firehose delivery stream.

    roleArn String

    The ARN of the IAM Role used to access the stream.

    AnalyticsApplicationOutputKinesisStream, AnalyticsApplicationOutputKinesisStreamArgs

    ResourceArn string

    The ARN of the Kinesis Stream.

    RoleArn string

    The ARN of the IAM Role used to access the stream.

    ResourceArn string

    The ARN of the Kinesis Stream.

    RoleArn string

    The ARN of the IAM Role used to access the stream.

    resourceArn String

    The ARN of the Kinesis Stream.

    roleArn String

    The ARN of the IAM Role used to access the stream.

    resourceArn string

    The ARN of the Kinesis Stream.

    roleArn string

    The ARN of the IAM Role used to access the stream.

    resource_arn str

    The ARN of the Kinesis Stream.

    role_arn str

    The ARN of the IAM Role used to access the stream.

    resourceArn String

    The ARN of the Kinesis Stream.

    roleArn String

    The ARN of the IAM Role used to access the stream.

    AnalyticsApplicationOutputLambda, AnalyticsApplicationOutputLambdaArgs

    ResourceArn string

    The ARN of the Lambda function.

    RoleArn string

    The ARN of the IAM Role used to access the Lambda function.

    ResourceArn string

    The ARN of the Lambda function.

    RoleArn string

    The ARN of the IAM Role used to access the Lambda function.

    resourceArn String

    The ARN of the Lambda function.

    roleArn String

    The ARN of the IAM Role used to access the Lambda function.

    resourceArn string

    The ARN of the Lambda function.

    roleArn string

    The ARN of the IAM Role used to access the Lambda function.

    resource_arn str

    The ARN of the Lambda function.

    role_arn str

    The ARN of the IAM Role used to access the Lambda function.

    resourceArn String

    The ARN of the Lambda function.

    roleArn String

    The ARN of the IAM Role used to access the Lambda function.

    AnalyticsApplicationOutputSchema, AnalyticsApplicationOutputSchemaArgs

    RecordFormatType string

    The Format Type of the records on the output stream. Can be CSV or JSON.

    RecordFormatType string

    The Format Type of the records on the output stream. Can be CSV or JSON.

    recordFormatType String

    The Format Type of the records on the output stream. Can be CSV or JSON.

    recordFormatType string

    The Format Type of the records on the output stream. Can be CSV or JSON.

    record_format_type str

    The Format Type of the records on the output stream. Can be CSV or JSON.

    recordFormatType String

    The Format Type of the records on the output stream. Can be CSV or JSON.

    AnalyticsApplicationReferenceDataSources, AnalyticsApplicationReferenceDataSourcesArgs

    S3 AnalyticsApplicationReferenceDataSourcesS3

    The S3 configuration for the reference data source. See S3 Reference below for more details.

    Schema AnalyticsApplicationReferenceDataSourcesSchema

    The Schema format of the data in the streaming source. See Source Schema below for more details.

    TableName string

    The in-application Table Name.

    Id string

    The ARN of the Kinesis Analytics Application.

    S3 AnalyticsApplicationReferenceDataSourcesS3

    The S3 configuration for the reference data source. See S3 Reference below for more details.

    Schema AnalyticsApplicationReferenceDataSourcesSchema

    The Schema format of the data in the streaming source. See Source Schema below for more details.

    TableName string

    The in-application Table Name.

    Id string

    The ARN of the Kinesis Analytics Application.

    s3 AnalyticsApplicationReferenceDataSourcesS3

    The S3 configuration for the reference data source. See S3 Reference below for more details.

    schema AnalyticsApplicationReferenceDataSourcesSchema

    The Schema format of the data in the streaming source. See Source Schema below for more details.

    tableName String

    The in-application Table Name.

    id String

    The ARN of the Kinesis Analytics Application.

    s3 AnalyticsApplicationReferenceDataSourcesS3

    The S3 configuration for the reference data source. See S3 Reference below for more details.

    schema AnalyticsApplicationReferenceDataSourcesSchema

    The Schema format of the data in the streaming source. See Source Schema below for more details.

    tableName string

    The in-application Table Name.

    id string

    The ARN of the Kinesis Analytics Application.

    s3 AnalyticsApplicationReferenceDataSourcesS3

    The S3 configuration for the reference data source. See S3 Reference below for more details.

    schema AnalyticsApplicationReferenceDataSourcesSchema

    The Schema format of the data in the streaming source. See Source Schema below for more details.

    table_name str

    The in-application Table Name.

    id str

    The ARN of the Kinesis Analytics Application.

    s3 Property Map

    The S3 configuration for the reference data source. See S3 Reference below for more details.

    schema Property Map

    The Schema format of the data in the streaming source. See Source Schema below for more details.

    tableName String

    The in-application Table Name.

    id String

    The ARN of the Kinesis Analytics Application.

    AnalyticsApplicationReferenceDataSourcesS3, AnalyticsApplicationReferenceDataSourcesS3Args

    BucketArn string

    The S3 Bucket ARN.

    FileKey string

    The File Key name containing reference data.

    RoleArn string

    The ARN of the IAM Role used to send application messages.

    BucketArn string

    The S3 Bucket ARN.

    FileKey string

    The File Key name containing reference data.

    RoleArn string

    The ARN of the IAM Role used to send application messages.

    bucketArn String

    The S3 Bucket ARN.

    fileKey String

    The File Key name containing reference data.

    roleArn String

    The ARN of the IAM Role used to send application messages.

    bucketArn string

    The S3 Bucket ARN.

    fileKey string

    The File Key name containing reference data.

    roleArn string

    The ARN of the IAM Role used to send application messages.

    bucket_arn str

    The S3 Bucket ARN.

    file_key str

    The File Key name containing reference data.

    role_arn str

    The ARN of the IAM Role used to send application messages.

    bucketArn String

    The S3 Bucket ARN.

    fileKey String

    The File Key name containing reference data.

    roleArn String

    The ARN of the IAM Role used to send application messages.

    AnalyticsApplicationReferenceDataSourcesSchema, AnalyticsApplicationReferenceDataSourcesSchemaArgs

    RecordColumns List<AnalyticsApplicationReferenceDataSourcesSchemaRecordColumn>

    The Record Column mapping for the streaming source data element. See Record Columns below for more details.

    RecordFormat AnalyticsApplicationReferenceDataSourcesSchemaRecordFormat

    The Record Format and mapping information to schematize a record. See Record Format below for more details.

    RecordEncoding string

    The Encoding of the record in the streaming source.

    RecordColumns []AnalyticsApplicationReferenceDataSourcesSchemaRecordColumn

    The Record Column mapping for the streaming source data element. See Record Columns below for more details.

    RecordFormat AnalyticsApplicationReferenceDataSourcesSchemaRecordFormat

    The Record Format and mapping information to schematize a record. See Record Format below for more details.

    RecordEncoding string

    The Encoding of the record in the streaming source.

    recordColumns List<AnalyticsApplicationReferenceDataSourcesSchemaRecordColumn>

    The Record Column mapping for the streaming source data element. See Record Columns below for more details.

    recordFormat AnalyticsApplicationReferenceDataSourcesSchemaRecordFormat

    The Record Format and mapping information to schematize a record. See Record Format below for more details.

    recordEncoding String

    The Encoding of the record in the streaming source.

    recordColumns AnalyticsApplicationReferenceDataSourcesSchemaRecordColumn[]

    The Record Column mapping for the streaming source data element. See Record Columns below for more details.

    recordFormat AnalyticsApplicationReferenceDataSourcesSchemaRecordFormat

    The Record Format and mapping information to schematize a record. See Record Format below for more details.

    recordEncoding string

    The Encoding of the record in the streaming source.

    record_columns Sequence[AnalyticsApplicationReferenceDataSourcesSchemaRecordColumn]

    The Record Column mapping for the streaming source data element. See Record Columns below for more details.

    record_format AnalyticsApplicationReferenceDataSourcesSchemaRecordFormat

    The Record Format and mapping information to schematize a record. See Record Format below for more details.

    record_encoding str

    The Encoding of the record in the streaming source.

    recordColumns List<Property Map>

    The Record Column mapping for the streaming source data element. See Record Columns below for more details.

    recordFormat Property Map

    The Record Format and mapping information to schematize a record. See Record Format below for more details.

    recordEncoding String

    The Encoding of the record in the streaming source.

    AnalyticsApplicationReferenceDataSourcesSchemaRecordColumn, AnalyticsApplicationReferenceDataSourcesSchemaRecordColumnArgs

    Name string

    Name of the column.

    SqlType string

    The SQL Type of the column.

    Mapping string

    The Mapping reference to the data element.

    Name string

    Name of the column.

    SqlType string

    The SQL Type of the column.

    Mapping string

    The Mapping reference to the data element.

    name String

    Name of the column.

    sqlType String

    The SQL Type of the column.

    mapping String

    The Mapping reference to the data element.

    name string

    Name of the column.

    sqlType string

    The SQL Type of the column.

    mapping string

    The Mapping reference to the data element.

    name str

    Name of the column.

    sql_type str

    The SQL Type of the column.

    mapping str

    The Mapping reference to the data element.

    name String

    Name of the column.

    sqlType String

    The SQL Type of the column.

    mapping String

    The Mapping reference to the data element.

    AnalyticsApplicationReferenceDataSourcesSchemaRecordFormat, AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatArgs

    MappingParameters AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParameters

    The Mapping Information for the record format. See Mapping Parameters below for more details.

    RecordFormatType string

    The type of Record Format. Can be CSV or JSON.

    MappingParameters AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParameters

    The Mapping Information for the record format. See Mapping Parameters below for more details.

    RecordFormatType string

    The type of Record Format. Can be CSV or JSON.

    mappingParameters AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParameters

    The Mapping Information for the record format. See Mapping Parameters below for more details.

    recordFormatType String

    The type of Record Format. Can be CSV or JSON.

    mappingParameters AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParameters

    The Mapping Information for the record format. See Mapping Parameters below for more details.

    recordFormatType string

    The type of Record Format. Can be CSV or JSON.

    mapping_parameters AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParameters

    The Mapping Information for the record format. See Mapping Parameters below for more details.

    record_format_type str

    The type of Record Format. Can be CSV or JSON.

    mappingParameters Property Map

    The Mapping Information for the record format. See Mapping Parameters below for more details.

    recordFormatType String

    The type of Record Format. Can be CSV or JSON.

    AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParameters, AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParametersArgs

    Csv AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParametersCsv

    Mapping information when the record format uses delimiters. See CSV Mapping Parameters below for more details.

    Json AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParametersJson

    Mapping information when JSON is the record format on the streaming source. See JSON Mapping Parameters below for more details.

    Csv AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParametersCsv

    Mapping information when the record format uses delimiters. See CSV Mapping Parameters below for more details.

    Json AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParametersJson

    Mapping information when JSON is the record format on the streaming source. See JSON Mapping Parameters below for more details.

    csv AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParametersCsv

    Mapping information when the record format uses delimiters. See CSV Mapping Parameters below for more details.

    json AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParametersJson

    Mapping information when JSON is the record format on the streaming source. See JSON Mapping Parameters below for more details.

    csv AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParametersCsv

    Mapping information when the record format uses delimiters. See CSV Mapping Parameters below for more details.

    json AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParametersJson

    Mapping information when JSON is the record format on the streaming source. See JSON Mapping Parameters below for more details.

    csv AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParametersCsv

    Mapping information when the record format uses delimiters. See CSV Mapping Parameters below for more details.

    json AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParametersJson

    Mapping information when JSON is the record format on the streaming source. See JSON Mapping Parameters below for more details.

    csv Property Map

    Mapping information when the record format uses delimiters. See CSV Mapping Parameters below for more details.

    json Property Map

    Mapping information when JSON is the record format on the streaming source. See JSON Mapping Parameters below for more details.

    AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParametersCsv, AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParametersCsvArgs

    RecordColumnDelimiter string

    The Column Delimiter.

    RecordRowDelimiter string

    The Row Delimiter.

    RecordColumnDelimiter string

    The Column Delimiter.

    RecordRowDelimiter string

    The Row Delimiter.

    recordColumnDelimiter String

    The Column Delimiter.

    recordRowDelimiter String

    The Row Delimiter.

    recordColumnDelimiter string

    The Column Delimiter.

    recordRowDelimiter string

    The Row Delimiter.

    record_column_delimiter str

    The Column Delimiter.

    record_row_delimiter str

    The Row Delimiter.

    recordColumnDelimiter String

    The Column Delimiter.

    recordRowDelimiter String

    The Row Delimiter.

    AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParametersJson, AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParametersJsonArgs

    RecordRowPath string

    Path to the top-level parent that contains the records.

    RecordRowPath string

    Path to the top-level parent that contains the records.

    recordRowPath String

    Path to the top-level parent that contains the records.

    recordRowPath string

    Path to the top-level parent that contains the records.

    record_row_path str

    Path to the top-level parent that contains the records.

    recordRowPath String

    Path to the top-level parent that contains the records.

    Import

    Using pulumi import, import Kinesis Analytics Application using ARN. For example:

     $ pulumi import aws:kinesis/analyticsApplication:AnalyticsApplication example arn:aws:kinesisanalytics:us-west-2:1234567890:application/example
    

    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.13.0 published on Saturday, Dec 2, 2023 by Pulumi