1. Packages
  2. AWS
  3. API Docs
  4. kinesis
  5. AnalyticsApplication
AWS v6.77.0 published on Wednesday, Apr 9, 2025 by Pulumi

aws.kinesis.AnalyticsApplication

Explore with Pulumi AI

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

import * as pulumi from "@pulumi/pulumi";
import * as aws from "@pulumi/aws";

const testStream = new aws.kinesis.Stream("test_stream", {
    name: "kinesis-test",
    shardCount: 1,
});
const testApplication = new aws.kinesis.AnalyticsApplication("test_application", {
    name: "kinesis-analytics-application-test",
    inputs: {
        namePrefix: "test_prefix",
        kinesisStream: {
            resourceArn: testStream.arn,
            roleArn: test.arn,
        },
        parallelism: {
            count: 1,
        },
        schema: {
            recordColumns: [{
                mapping: "$.test",
                name: "test",
                sqlType: "VARCHAR(8)",
            }],
            recordEncoding: "UTF-8",
            recordFormat: {
                mappingParameters: {
                    json: {
                        recordRowPath: "$",
                    },
                },
            },
        },
    },
});
Copy
import pulumi
import pulumi_aws as aws

test_stream = aws.kinesis.Stream("test_stream",
    name="kinesis-test",
    shard_count=1)
test_application = aws.kinesis.AnalyticsApplication("test_application",
    name="kinesis-analytics-application-test",
    inputs={
        "name_prefix": "test_prefix",
        "kinesis_stream": {
            "resource_arn": test_stream.arn,
            "role_arn": test["arn"],
        },
        "parallelism": {
            "count": 1,
        },
        "schema": {
            "record_columns": [{
                "mapping": "$.test",
                "name": "test",
                "sql_type": "VARCHAR(8)",
            }],
            "record_encoding": "UTF-8",
            "record_format": {
                "mapping_parameters": {
                    "json": {
                        "record_row_path": "$",
                    },
                },
            },
        },
    })
Copy
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, "test_stream", &kinesis.StreamArgs{
			Name:       pulumi.String("kinesis-test"),
			ShardCount: pulumi.Int(1),
		})
		if err != nil {
			return err
		}
		_, err = kinesis.NewAnalyticsApplication(ctx, "test_application", &kinesis.AnalyticsApplicationArgs{
			Name: pulumi.String("kinesis-analytics-application-test"),
			Inputs: &kinesis.AnalyticsApplicationInputsArgs{
				NamePrefix: pulumi.String("test_prefix"),
				KinesisStream: &kinesis.AnalyticsApplicationInputsKinesisStreamArgs{
					ResourceArn: testStream.Arn,
					RoleArn:     pulumi.Any(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
	})
}
Copy
using System.Collections.Generic;
using System.Linq;
using Pulumi;
using Aws = Pulumi.Aws;

return await Deployment.RunAsync(() => 
{
    var testStream = new Aws.Kinesis.Stream("test_stream", new()
    {
        Name = "kinesis-test",
        ShardCount = 1,
    });

    var testApplication = new Aws.Kinesis.AnalyticsApplication("test_application", new()
    {
        Name = "kinesis-analytics-application-test",
        Inputs = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsArgs
        {
            NamePrefix = "test_prefix",
            KinesisStream = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsKinesisStreamArgs
            {
                ResourceArn = testStream.Arn,
                RoleArn = 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 = "$",
                        },
                    },
                },
            },
        },
    });

});
Copy
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()
            .name("kinesis-test")
            .shardCount(1)
            .build());

        var testApplication = new AnalyticsApplication("testApplication", AnalyticsApplicationArgs.builder()
            .name("kinesis-analytics-application-test")
            .inputs(AnalyticsApplicationInputsArgs.builder()
                .namePrefix("test_prefix")
                .kinesisStream(AnalyticsApplicationInputsKinesisStreamArgs.builder()
                    .resourceArn(testStream.arn())
                    .roleArn(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());

    }
}
Copy
resources:
  testStream:
    type: aws:kinesis:Stream
    name: test_stream
    properties:
      name: kinesis-test
      shardCount: 1
  testApplication:
    type: aws:kinesis:AnalyticsApplication
    name: test_application
    properties:
      name: kinesis-analytics-application-test
      inputs:
        namePrefix: test_prefix
        kinesisStream:
          resourceArn: ${testStream.arn}
          roleArn: ${test.arn}
        parallelism:
          count: 1
        schema:
          recordColumns:
            - mapping: $.test
              name: test
              sqlType: VARCHAR(8)
          recordEncoding: UTF-8
          recordFormat:
            mappingParameters:
              json:
                recordRowPath: $
Copy

Starting An Application

import * as pulumi from "@pulumi/pulumi";
import * as aws from "@pulumi/aws";

const example = new aws.cloudwatch.LogGroup("example", {name: "analytics"});
const exampleLogStream = new aws.cloudwatch.LogStream("example", {
    name: "example-kinesis-application",
    logGroupName: example.name,
});
const exampleStream = new aws.kinesis.Stream("example", {
    name: "example-kinesis-stream",
    shardCount: 1,
});
const exampleFirehoseDeliveryStream = new aws.kinesis.FirehoseDeliveryStream("example", {
    name: "example-kinesis-delivery-stream",
    destination: "extended_s3",
    extendedS3Configuration: {
        bucketArn: exampleAwsS3Bucket.arn,
        roleArn: exampleAwsIamRole.arn,
    },
});
const test = new aws.kinesis.AnalyticsApplication("test", {
    name: "example-application",
    cloudwatchLoggingOptions: {
        logStreamArn: exampleLogStream.arn,
        roleArn: exampleAwsIamRole.arn,
    },
    inputs: {
        namePrefix: "example_prefix",
        schema: {
            recordColumns: [{
                name: "COLUMN_1",
                sqlType: "INTEGER",
            }],
            recordFormat: {
                mappingParameters: {
                    csv: {
                        recordColumnDelimiter: ",",
                        recordRowDelimiter: "|",
                    },
                },
            },
        },
        kinesisStream: {
            resourceArn: exampleStream.arn,
            roleArn: exampleAwsIamRole.arn,
        },
        startingPositionConfigurations: [{
            startingPosition: "NOW",
        }],
    },
    outputs: [{
        name: "OUTPUT_1",
        schema: {
            recordFormatType: "CSV",
        },
        kinesisFirehose: {
            resourceArn: exampleFirehoseDeliveryStream.arn,
            roleArn: exampleAwsIamRole.arn,
        },
    }],
    startApplication: true,
});
Copy
import pulumi
import pulumi_aws as aws

example = aws.cloudwatch.LogGroup("example", name="analytics")
example_log_stream = aws.cloudwatch.LogStream("example",
    name="example-kinesis-application",
    log_group_name=example.name)
example_stream = aws.kinesis.Stream("example",
    name="example-kinesis-stream",
    shard_count=1)
example_firehose_delivery_stream = aws.kinesis.FirehoseDeliveryStream("example",
    name="example-kinesis-delivery-stream",
    destination="extended_s3",
    extended_s3_configuration={
        "bucket_arn": example_aws_s3_bucket["arn"],
        "role_arn": example_aws_iam_role["arn"],
    })
test = aws.kinesis.AnalyticsApplication("test",
    name="example-application",
    cloudwatch_logging_options={
        "log_stream_arn": example_log_stream.arn,
        "role_arn": example_aws_iam_role["arn"],
    },
    inputs={
        "name_prefix": "example_prefix",
        "schema": {
            "record_columns": [{
                "name": "COLUMN_1",
                "sql_type": "INTEGER",
            }],
            "record_format": {
                "mapping_parameters": {
                    "csv": {
                        "record_column_delimiter": ",",
                        "record_row_delimiter": "|",
                    },
                },
            },
        },
        "kinesis_stream": {
            "resource_arn": example_stream.arn,
            "role_arn": example_aws_iam_role["arn"],
        },
        "starting_position_configurations": [{
            "starting_position": "NOW",
        }],
    },
    outputs=[{
        "name": "OUTPUT_1",
        "schema": {
            "record_format_type": "CSV",
        },
        "kinesis_firehose": {
            "resource_arn": example_firehose_delivery_stream.arn,
            "role_arn": example_aws_iam_role["arn"],
        },
    }],
    start_application=True)
Copy
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 {
		example, err := cloudwatch.NewLogGroup(ctx, "example", &cloudwatch.LogGroupArgs{
			Name: pulumi.String("analytics"),
		})
		if err != nil {
			return err
		}
		exampleLogStream, err := cloudwatch.NewLogStream(ctx, "example", &cloudwatch.LogStreamArgs{
			Name:         pulumi.String("example-kinesis-application"),
			LogGroupName: example.Name,
		})
		if err != nil {
			return err
		}
		exampleStream, err := kinesis.NewStream(ctx, "example", &kinesis.StreamArgs{
			Name:       pulumi.String("example-kinesis-stream"),
			ShardCount: pulumi.Int(1),
		})
		if err != nil {
			return err
		}
		exampleFirehoseDeliveryStream, err := kinesis.NewFirehoseDeliveryStream(ctx, "example", &kinesis.FirehoseDeliveryStreamArgs{
			Name:        pulumi.String("example-kinesis-delivery-stream"),
			Destination: pulumi.String("extended_s3"),
			ExtendedS3Configuration: &kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationArgs{
				BucketArn: pulumi.Any(exampleAwsS3Bucket.Arn),
				RoleArn:   pulumi.Any(exampleAwsIamRole.Arn),
			},
		})
		if err != nil {
			return err
		}
		_, err = kinesis.NewAnalyticsApplication(ctx, "test", &kinesis.AnalyticsApplicationArgs{
			Name: pulumi.String("example-application"),
			CloudwatchLoggingOptions: &kinesis.AnalyticsApplicationCloudwatchLoggingOptionsArgs{
				LogStreamArn: exampleLogStream.Arn,
				RoleArn:      pulumi.Any(exampleAwsIamRole.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(exampleAwsIamRole.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(exampleAwsIamRole.Arn),
					},
				},
			},
			StartApplication: pulumi.Bool(true),
		})
		if err != nil {
			return err
		}
		return nil
	})
}
Copy
using System.Collections.Generic;
using System.Linq;
using Pulumi;
using Aws = Pulumi.Aws;

return await Deployment.RunAsync(() => 
{
    var example = new Aws.CloudWatch.LogGroup("example", new()
    {
        Name = "analytics",
    });

    var exampleLogStream = new Aws.CloudWatch.LogStream("example", new()
    {
        Name = "example-kinesis-application",
        LogGroupName = example.Name,
    });

    var exampleStream = new Aws.Kinesis.Stream("example", new()
    {
        Name = "example-kinesis-stream",
        ShardCount = 1,
    });

    var exampleFirehoseDeliveryStream = new Aws.Kinesis.FirehoseDeliveryStream("example", new()
    {
        Name = "example-kinesis-delivery-stream",
        Destination = "extended_s3",
        ExtendedS3Configuration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationArgs
        {
            BucketArn = exampleAwsS3Bucket.Arn,
            RoleArn = exampleAwsIamRole.Arn,
        },
    });

    var test = new Aws.Kinesis.AnalyticsApplication("test", new()
    {
        Name = "example-application",
        CloudwatchLoggingOptions = new Aws.Kinesis.Inputs.AnalyticsApplicationCloudwatchLoggingOptionsArgs
        {
            LogStreamArn = exampleLogStream.Arn,
            RoleArn = exampleAwsIamRole.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 = exampleAwsIamRole.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 = exampleAwsIamRole.Arn,
                },
            },
        },
        StartApplication = true,
    });

});
Copy
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.LogGroupArgs;
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 example = new LogGroup("example", LogGroupArgs.builder()
            .name("analytics")
            .build());

        var exampleLogStream = new LogStream("exampleLogStream", LogStreamArgs.builder()
            .name("example-kinesis-application")
            .logGroupName(example.name())
            .build());

        var exampleStream = new Stream("exampleStream", StreamArgs.builder()
            .name("example-kinesis-stream")
            .shardCount(1)
            .build());

        var exampleFirehoseDeliveryStream = new FirehoseDeliveryStream("exampleFirehoseDeliveryStream", FirehoseDeliveryStreamArgs.builder()
            .name("example-kinesis-delivery-stream")
            .destination("extended_s3")
            .extendedS3Configuration(FirehoseDeliveryStreamExtendedS3ConfigurationArgs.builder()
                .bucketArn(exampleAwsS3Bucket.arn())
                .roleArn(exampleAwsIamRole.arn())
                .build())
            .build());

        var test = new AnalyticsApplication("test", AnalyticsApplicationArgs.builder()
            .name("example-application")
            .cloudwatchLoggingOptions(AnalyticsApplicationCloudwatchLoggingOptionsArgs.builder()
                .logStreamArn(exampleLogStream.arn())
                .roleArn(exampleAwsIamRole.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(exampleAwsIamRole.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(exampleAwsIamRole.arn())
                    .build())
                .build())
            .startApplication(true)
            .build());

    }
}
Copy
resources:
  example:
    type: aws:cloudwatch:LogGroup
    properties:
      name: analytics
  exampleLogStream:
    type: aws:cloudwatch:LogStream
    name: example
    properties:
      name: example-kinesis-application
      logGroupName: ${example.name}
  exampleStream:
    type: aws:kinesis:Stream
    name: example
    properties:
      name: example-kinesis-stream
      shardCount: 1
  exampleFirehoseDeliveryStream:
    type: aws:kinesis:FirehoseDeliveryStream
    name: example
    properties:
      name: example-kinesis-delivery-stream
      destination: extended_s3
      extendedS3Configuration:
        bucketArn: ${exampleAwsS3Bucket.arn}
        roleArn: ${exampleAwsIamRole.arn}
  test:
    type: aws:kinesis:AnalyticsApplication
    properties:
      name: example-application
      cloudwatchLoggingOptions:
        logStreamArn: ${exampleLogStream.arn}
        roleArn: ${exampleAwsIamRole.arn}
      inputs:
        namePrefix: example_prefix
        schema:
          recordColumns:
            - name: COLUMN_1
              sqlType: INTEGER
          recordFormat:
            mappingParameters:
              csv:
                recordColumnDelimiter: ','
                recordRowDelimiter: '|'
        kinesisStream:
          resourceArn: ${exampleStream.arn}
          roleArn: ${exampleAwsIamRole.arn}
        startingPositionConfigurations:
          - startingPosition: NOW
      outputs:
        - name: OUTPUT_1
          schema:
            recordFormatType: CSV
          kinesisFirehose:
            resourceArn: ${exampleFirehoseDeliveryStream.arn}
            roleArn: ${exampleAwsIamRole.arn}
      startApplication: true
Copy

Create AnalyticsApplication Resource

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

Constructor syntax

new AnalyticsApplication(name: string, args?: AnalyticsApplicationArgs, opts?: CustomResourceOptions);
@overload
def AnalyticsApplication(resource_name: str,
                         args: Optional[AnalyticsApplicationArgs] = None,
                         opts: Optional[ResourceOptions] = None)

@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)
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.

Parameters

name This property is required. 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 This property is required. 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 This property is required. 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 This property is required. 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 This property is required. String
The unique name of the resource.
args This property is required. AnalyticsApplicationArgs
The arguments to resource properties.
options CustomResourceOptions
Bag of options to control resource's behavior.

Constructor example

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

var analyticsApplicationResource = new Aws.Kinesis.AnalyticsApplication("analyticsApplicationResource", new()
{
    CloudwatchLoggingOptions = new Aws.Kinesis.Inputs.AnalyticsApplicationCloudwatchLoggingOptionsArgs
    {
        LogStreamArn = "string",
        RoleArn = "string",
        Id = "string",
    },
    Code = "string",
    Description = "string",
    Inputs = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsArgs
    {
        NamePrefix = "string",
        Schema = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsSchemaArgs
        {
            RecordColumns = new[]
            {
                new Aws.Kinesis.Inputs.AnalyticsApplicationInputsSchemaRecordColumnArgs
                {
                    Name = "string",
                    SqlType = "string",
                    Mapping = "string",
                },
            },
            RecordFormat = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsSchemaRecordFormatArgs
            {
                MappingParameters = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersArgs
                {
                    Csv = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersCsvArgs
                    {
                        RecordColumnDelimiter = "string",
                        RecordRowDelimiter = "string",
                    },
                    Json = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersJsonArgs
                    {
                        RecordRowPath = "string",
                    },
                },
                RecordFormatType = "string",
            },
            RecordEncoding = "string",
        },
        Id = "string",
        KinesisFirehose = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsKinesisFirehoseArgs
        {
            ResourceArn = "string",
            RoleArn = "string",
        },
        KinesisStream = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsKinesisStreamArgs
        {
            ResourceArn = "string",
            RoleArn = "string",
        },
        Parallelism = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsParallelismArgs
        {
            Count = 0,
        },
        ProcessingConfiguration = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsProcessingConfigurationArgs
        {
            Lambda = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsProcessingConfigurationLambdaArgs
            {
                ResourceArn = "string",
                RoleArn = "string",
            },
        },
        StartingPositionConfigurations = new[]
        {
            new Aws.Kinesis.Inputs.AnalyticsApplicationInputsStartingPositionConfigurationArgs
            {
                StartingPosition = "string",
            },
        },
        StreamNames = new[]
        {
            "string",
        },
    },
    Name = "string",
    Outputs = new[]
    {
        new Aws.Kinesis.Inputs.AnalyticsApplicationOutputArgs
        {
            Name = "string",
            Schema = new Aws.Kinesis.Inputs.AnalyticsApplicationOutputSchemaArgs
            {
                RecordFormatType = "string",
            },
            Id = "string",
            KinesisFirehose = new Aws.Kinesis.Inputs.AnalyticsApplicationOutputKinesisFirehoseArgs
            {
                ResourceArn = "string",
                RoleArn = "string",
            },
            KinesisStream = new Aws.Kinesis.Inputs.AnalyticsApplicationOutputKinesisStreamArgs
            {
                ResourceArn = "string",
                RoleArn = "string",
            },
            Lambda = new Aws.Kinesis.Inputs.AnalyticsApplicationOutputLambdaArgs
            {
                ResourceArn = "string",
                RoleArn = "string",
            },
        },
    },
    ReferenceDataSources = new Aws.Kinesis.Inputs.AnalyticsApplicationReferenceDataSourcesArgs
    {
        S3 = new Aws.Kinesis.Inputs.AnalyticsApplicationReferenceDataSourcesS3Args
        {
            BucketArn = "string",
            FileKey = "string",
            RoleArn = "string",
        },
        Schema = new Aws.Kinesis.Inputs.AnalyticsApplicationReferenceDataSourcesSchemaArgs
        {
            RecordColumns = new[]
            {
                new Aws.Kinesis.Inputs.AnalyticsApplicationReferenceDataSourcesSchemaRecordColumnArgs
                {
                    Name = "string",
                    SqlType = "string",
                    Mapping = "string",
                },
            },
            RecordFormat = new Aws.Kinesis.Inputs.AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatArgs
            {
                MappingParameters = new Aws.Kinesis.Inputs.AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParametersArgs
                {
                    Csv = new Aws.Kinesis.Inputs.AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParametersCsvArgs
                    {
                        RecordColumnDelimiter = "string",
                        RecordRowDelimiter = "string",
                    },
                    Json = new Aws.Kinesis.Inputs.AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParametersJsonArgs
                    {
                        RecordRowPath = "string",
                    },
                },
                RecordFormatType = "string",
            },
            RecordEncoding = "string",
        },
        TableName = "string",
        Id = "string",
    },
    StartApplication = false,
    Tags = 
    {
        { "string", "string" },
    },
});
Copy
example, err := kinesis.NewAnalyticsApplication(ctx, "analyticsApplicationResource", &kinesis.AnalyticsApplicationArgs{
	CloudwatchLoggingOptions: &kinesis.AnalyticsApplicationCloudwatchLoggingOptionsArgs{
		LogStreamArn: pulumi.String("string"),
		RoleArn:      pulumi.String("string"),
		Id:           pulumi.String("string"),
	},
	Code:        pulumi.String("string"),
	Description: pulumi.String("string"),
	Inputs: &kinesis.AnalyticsApplicationInputsArgs{
		NamePrefix: pulumi.String("string"),
		Schema: &kinesis.AnalyticsApplicationInputsSchemaArgs{
			RecordColumns: kinesis.AnalyticsApplicationInputsSchemaRecordColumnArray{
				&kinesis.AnalyticsApplicationInputsSchemaRecordColumnArgs{
					Name:    pulumi.String("string"),
					SqlType: pulumi.String("string"),
					Mapping: pulumi.String("string"),
				},
			},
			RecordFormat: &kinesis.AnalyticsApplicationInputsSchemaRecordFormatArgs{
				MappingParameters: &kinesis.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersArgs{
					Csv: &kinesis.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersCsvArgs{
						RecordColumnDelimiter: pulumi.String("string"),
						RecordRowDelimiter:    pulumi.String("string"),
					},
					Json: &kinesis.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersJsonArgs{
						RecordRowPath: pulumi.String("string"),
					},
				},
				RecordFormatType: pulumi.String("string"),
			},
			RecordEncoding: pulumi.String("string"),
		},
		Id: pulumi.String("string"),
		KinesisFirehose: &kinesis.AnalyticsApplicationInputsKinesisFirehoseArgs{
			ResourceArn: pulumi.String("string"),
			RoleArn:     pulumi.String("string"),
		},
		KinesisStream: &kinesis.AnalyticsApplicationInputsKinesisStreamArgs{
			ResourceArn: pulumi.String("string"),
			RoleArn:     pulumi.String("string"),
		},
		Parallelism: &kinesis.AnalyticsApplicationInputsParallelismArgs{
			Count: pulumi.Int(0),
		},
		ProcessingConfiguration: &kinesis.AnalyticsApplicationInputsProcessingConfigurationArgs{
			Lambda: &kinesis.AnalyticsApplicationInputsProcessingConfigurationLambdaArgs{
				ResourceArn: pulumi.String("string"),
				RoleArn:     pulumi.String("string"),
			},
		},
		StartingPositionConfigurations: kinesis.AnalyticsApplicationInputsStartingPositionConfigurationArray{
			&kinesis.AnalyticsApplicationInputsStartingPositionConfigurationArgs{
				StartingPosition: pulumi.String("string"),
			},
		},
		StreamNames: pulumi.StringArray{
			pulumi.String("string"),
		},
	},
	Name: pulumi.String("string"),
	Outputs: kinesis.AnalyticsApplicationOutputTypeArray{
		&kinesis.AnalyticsApplicationOutputTypeArgs{
			Name: pulumi.String("string"),
			Schema: &kinesis.AnalyticsApplicationOutputSchemaArgs{
				RecordFormatType: pulumi.String("string"),
			},
			Id: pulumi.String("string"),
			KinesisFirehose: &kinesis.AnalyticsApplicationOutputKinesisFirehoseArgs{
				ResourceArn: pulumi.String("string"),
				RoleArn:     pulumi.String("string"),
			},
			KinesisStream: &kinesis.AnalyticsApplicationOutputKinesisStreamArgs{
				ResourceArn: pulumi.String("string"),
				RoleArn:     pulumi.String("string"),
			},
			Lambda: &kinesis.AnalyticsApplicationOutputLambdaArgs{
				ResourceArn: pulumi.String("string"),
				RoleArn:     pulumi.String("string"),
			},
		},
	},
	ReferenceDataSources: &kinesis.AnalyticsApplicationReferenceDataSourcesArgs{
		S3: &kinesis.AnalyticsApplicationReferenceDataSourcesS3Args{
			BucketArn: pulumi.String("string"),
			FileKey:   pulumi.String("string"),
			RoleArn:   pulumi.String("string"),
		},
		Schema: &kinesis.AnalyticsApplicationReferenceDataSourcesSchemaArgs{
			RecordColumns: kinesis.AnalyticsApplicationReferenceDataSourcesSchemaRecordColumnArray{
				&kinesis.AnalyticsApplicationReferenceDataSourcesSchemaRecordColumnArgs{
					Name:    pulumi.String("string"),
					SqlType: pulumi.String("string"),
					Mapping: pulumi.String("string"),
				},
			},
			RecordFormat: &kinesis.AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatArgs{
				MappingParameters: &kinesis.AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParametersArgs{
					Csv: &kinesis.AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParametersCsvArgs{
						RecordColumnDelimiter: pulumi.String("string"),
						RecordRowDelimiter:    pulumi.String("string"),
					},
					Json: &kinesis.AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParametersJsonArgs{
						RecordRowPath: pulumi.String("string"),
					},
				},
				RecordFormatType: pulumi.String("string"),
			},
			RecordEncoding: pulumi.String("string"),
		},
		TableName: pulumi.String("string"),
		Id:        pulumi.String("string"),
	},
	StartApplication: pulumi.Bool(false),
	Tags: pulumi.StringMap{
		"string": pulumi.String("string"),
	},
})
Copy
var analyticsApplicationResource = new AnalyticsApplication("analyticsApplicationResource", AnalyticsApplicationArgs.builder()
    .cloudwatchLoggingOptions(AnalyticsApplicationCloudwatchLoggingOptionsArgs.builder()
        .logStreamArn("string")
        .roleArn("string")
        .id("string")
        .build())
    .code("string")
    .description("string")
    .inputs(AnalyticsApplicationInputsArgs.builder()
        .namePrefix("string")
        .schema(AnalyticsApplicationInputsSchemaArgs.builder()
            .recordColumns(AnalyticsApplicationInputsSchemaRecordColumnArgs.builder()
                .name("string")
                .sqlType("string")
                .mapping("string")
                .build())
            .recordFormat(AnalyticsApplicationInputsSchemaRecordFormatArgs.builder()
                .mappingParameters(AnalyticsApplicationInputsSchemaRecordFormatMappingParametersArgs.builder()
                    .csv(AnalyticsApplicationInputsSchemaRecordFormatMappingParametersCsvArgs.builder()
                        .recordColumnDelimiter("string")
                        .recordRowDelimiter("string")
                        .build())
                    .json(AnalyticsApplicationInputsSchemaRecordFormatMappingParametersJsonArgs.builder()
                        .recordRowPath("string")
                        .build())
                    .build())
                .recordFormatType("string")
                .build())
            .recordEncoding("string")
            .build())
        .id("string")
        .kinesisFirehose(AnalyticsApplicationInputsKinesisFirehoseArgs.builder()
            .resourceArn("string")
            .roleArn("string")
            .build())
        .kinesisStream(AnalyticsApplicationInputsKinesisStreamArgs.builder()
            .resourceArn("string")
            .roleArn("string")
            .build())
        .parallelism(AnalyticsApplicationInputsParallelismArgs.builder()
            .count(0)
            .build())
        .processingConfiguration(AnalyticsApplicationInputsProcessingConfigurationArgs.builder()
            .lambda(AnalyticsApplicationInputsProcessingConfigurationLambdaArgs.builder()
                .resourceArn("string")
                .roleArn("string")
                .build())
            .build())
        .startingPositionConfigurations(AnalyticsApplicationInputsStartingPositionConfigurationArgs.builder()
            .startingPosition("string")
            .build())
        .streamNames("string")
        .build())
    .name("string")
    .outputs(AnalyticsApplicationOutputArgs.builder()
        .name("string")
        .schema(AnalyticsApplicationOutputSchemaArgs.builder()
            .recordFormatType("string")
            .build())
        .id("string")
        .kinesisFirehose(AnalyticsApplicationOutputKinesisFirehoseArgs.builder()
            .resourceArn("string")
            .roleArn("string")
            .build())
        .kinesisStream(AnalyticsApplicationOutputKinesisStreamArgs.builder()
            .resourceArn("string")
            .roleArn("string")
            .build())
        .lambda(AnalyticsApplicationOutputLambdaArgs.builder()
            .resourceArn("string")
            .roleArn("string")
            .build())
        .build())
    .referenceDataSources(AnalyticsApplicationReferenceDataSourcesArgs.builder()
        .s3(AnalyticsApplicationReferenceDataSourcesS3Args.builder()
            .bucketArn("string")
            .fileKey("string")
            .roleArn("string")
            .build())
        .schema(AnalyticsApplicationReferenceDataSourcesSchemaArgs.builder()
            .recordColumns(AnalyticsApplicationReferenceDataSourcesSchemaRecordColumnArgs.builder()
                .name("string")
                .sqlType("string")
                .mapping("string")
                .build())
            .recordFormat(AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatArgs.builder()
                .mappingParameters(AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParametersArgs.builder()
                    .csv(AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParametersCsvArgs.builder()
                        .recordColumnDelimiter("string")
                        .recordRowDelimiter("string")
                        .build())
                    .json(AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParametersJsonArgs.builder()
                        .recordRowPath("string")
                        .build())
                    .build())
                .recordFormatType("string")
                .build())
            .recordEncoding("string")
            .build())
        .tableName("string")
        .id("string")
        .build())
    .startApplication(false)
    .tags(Map.of("string", "string"))
    .build());
Copy
analytics_application_resource = aws.kinesis.AnalyticsApplication("analyticsApplicationResource",
    cloudwatch_logging_options={
        "log_stream_arn": "string",
        "role_arn": "string",
        "id": "string",
    },
    code="string",
    description="string",
    inputs={
        "name_prefix": "string",
        "schema": {
            "record_columns": [{
                "name": "string",
                "sql_type": "string",
                "mapping": "string",
            }],
            "record_format": {
                "mapping_parameters": {
                    "csv": {
                        "record_column_delimiter": "string",
                        "record_row_delimiter": "string",
                    },
                    "json": {
                        "record_row_path": "string",
                    },
                },
                "record_format_type": "string",
            },
            "record_encoding": "string",
        },
        "id": "string",
        "kinesis_firehose": {
            "resource_arn": "string",
            "role_arn": "string",
        },
        "kinesis_stream": {
            "resource_arn": "string",
            "role_arn": "string",
        },
        "parallelism": {
            "count": 0,
        },
        "processing_configuration": {
            "lambda_": {
                "resource_arn": "string",
                "role_arn": "string",
            },
        },
        "starting_position_configurations": [{
            "starting_position": "string",
        }],
        "stream_names": ["string"],
    },
    name="string",
    outputs=[{
        "name": "string",
        "schema": {
            "record_format_type": "string",
        },
        "id": "string",
        "kinesis_firehose": {
            "resource_arn": "string",
            "role_arn": "string",
        },
        "kinesis_stream": {
            "resource_arn": "string",
            "role_arn": "string",
        },
        "lambda_": {
            "resource_arn": "string",
            "role_arn": "string",
        },
    }],
    reference_data_sources={
        "s3": {
            "bucket_arn": "string",
            "file_key": "string",
            "role_arn": "string",
        },
        "schema": {
            "record_columns": [{
                "name": "string",
                "sql_type": "string",
                "mapping": "string",
            }],
            "record_format": {
                "mapping_parameters": {
                    "csv": {
                        "record_column_delimiter": "string",
                        "record_row_delimiter": "string",
                    },
                    "json": {
                        "record_row_path": "string",
                    },
                },
                "record_format_type": "string",
            },
            "record_encoding": "string",
        },
        "table_name": "string",
        "id": "string",
    },
    start_application=False,
    tags={
        "string": "string",
    })
Copy
const analyticsApplicationResource = new aws.kinesis.AnalyticsApplication("analyticsApplicationResource", {
    cloudwatchLoggingOptions: {
        logStreamArn: "string",
        roleArn: "string",
        id: "string",
    },
    code: "string",
    description: "string",
    inputs: {
        namePrefix: "string",
        schema: {
            recordColumns: [{
                name: "string",
                sqlType: "string",
                mapping: "string",
            }],
            recordFormat: {
                mappingParameters: {
                    csv: {
                        recordColumnDelimiter: "string",
                        recordRowDelimiter: "string",
                    },
                    json: {
                        recordRowPath: "string",
                    },
                },
                recordFormatType: "string",
            },
            recordEncoding: "string",
        },
        id: "string",
        kinesisFirehose: {
            resourceArn: "string",
            roleArn: "string",
        },
        kinesisStream: {
            resourceArn: "string",
            roleArn: "string",
        },
        parallelism: {
            count: 0,
        },
        processingConfiguration: {
            lambda: {
                resourceArn: "string",
                roleArn: "string",
            },
        },
        startingPositionConfigurations: [{
            startingPosition: "string",
        }],
        streamNames: ["string"],
    },
    name: "string",
    outputs: [{
        name: "string",
        schema: {
            recordFormatType: "string",
        },
        id: "string",
        kinesisFirehose: {
            resourceArn: "string",
            roleArn: "string",
        },
        kinesisStream: {
            resourceArn: "string",
            roleArn: "string",
        },
        lambda: {
            resourceArn: "string",
            roleArn: "string",
        },
    }],
    referenceDataSources: {
        s3: {
            bucketArn: "string",
            fileKey: "string",
            roleArn: "string",
        },
        schema: {
            recordColumns: [{
                name: "string",
                sqlType: "string",
                mapping: "string",
            }],
            recordFormat: {
                mappingParameters: {
                    csv: {
                        recordColumnDelimiter: "string",
                        recordRowDelimiter: "string",
                    },
                    json: {
                        recordRowPath: "string",
                    },
                },
                recordFormatType: "string",
            },
            recordEncoding: "string",
        },
        tableName: "string",
        id: "string",
    },
    startApplication: false,
    tags: {
        string: "string",
    },
});
Copy
type: aws:kinesis:AnalyticsApplication
properties:
    cloudwatchLoggingOptions:
        id: string
        logStreamArn: string
        roleArn: string
    code: string
    description: string
    inputs:
        id: string
        kinesisFirehose:
            resourceArn: string
            roleArn: string
        kinesisStream:
            resourceArn: string
            roleArn: string
        namePrefix: string
        parallelism:
            count: 0
        processingConfiguration:
            lambda:
                resourceArn: string
                roleArn: string
        schema:
            recordColumns:
                - mapping: string
                  name: string
                  sqlType: string
            recordEncoding: string
            recordFormat:
                mappingParameters:
                    csv:
                        recordColumnDelimiter: string
                        recordRowDelimiter: string
                    json:
                        recordRowPath: string
                recordFormatType: string
        startingPositionConfigurations:
            - startingPosition: string
        streamNames:
            - string
    name: string
    outputs:
        - id: string
          kinesisFirehose:
            resourceArn: string
            roleArn: string
          kinesisStream:
            resourceArn: string
            roleArn: string
          lambda:
            resourceArn: string
            roleArn: string
          name: string
          schema:
            recordFormatType: string
    referenceDataSources:
        id: string
        s3:
            bucketArn: string
            fileKey: string
            roleArn: string
        schema:
            recordColumns:
                - mapping: string
                  name: string
                  sqlType: string
            recordEncoding: string
            recordFormat:
                mappingParameters:
                    csv:
                        recordColumnDelimiter: string
                        recordRowDelimiter: string
                    json:
                        recordRowPath: string
                recordFormatType: string
        tableName: string
    startApplication: false
    tags:
        string: string
Copy

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

In Python, inputs that are objects can be passed either as argument classes or as dictionary literals.

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 Changes to this property will trigger replacement. string
Description of the application.
Inputs AnalyticsApplicationInputs
Input configuration of the application. See Inputs below for more details.
Name Changes to this property will trigger replacement. 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 Changes to this property will trigger replacement. string
Description of the application.
Inputs AnalyticsApplicationInputsArgs
Input configuration of the application. See Inputs below for more details.
Name Changes to this property will trigger replacement. 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 Changes to this property will trigger replacement. String
Description of the application.
inputs AnalyticsApplicationInputs
Input configuration of the application. See Inputs below for more details.
name Changes to this property will trigger replacement. 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 Changes to this property will trigger replacement. string
Description of the application.
inputs AnalyticsApplicationInputs
Input configuration of the application. See Inputs below for more details.
name Changes to this property will trigger replacement. 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 Changes to this property will trigger replacement. str
Description of the application.
inputs AnalyticsApplicationInputsArgs
Input configuration of the application. See Inputs below for more details.
name Changes to this property will trigger replacement. 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 Changes to this property will trigger replacement. String
Description of the application.
inputs Property Map
Input configuration of the application. See Inputs below for more details.
name Changes to this property will trigger replacement. 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)
resources:  _:    type: aws:kinesis:AnalyticsApplication    get:      id: ${id}
name This property is required.
The unique name of the resulting resource.
id This property is required.
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 This property is required.
The unique name of the resulting resource.
id This property is required.
The unique provider ID of the resource to lookup.
name This property is required.
The unique name of the resulting resource.
id This property is required.
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 This property is required.
The unique name of the resulting resource.
id This property is required.
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 This property is required.
The unique name of the resulting resource.
id This property is required.
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 Changes to this property will trigger replacement. 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 Changes to this property will trigger replacement. 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 Changes to this property will trigger replacement. 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 Changes to this property will trigger replacement. 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 Changes to this property will trigger replacement. 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 Changes to this property will trigger replacement. 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 Changes to this property will trigger replacement. 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 Changes to this property will trigger replacement. 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 Changes to this property will trigger replacement. 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 Changes to this property will trigger replacement. 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 Changes to this property will trigger replacement. 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 Changes to this property will trigger replacement. 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 This property is required. string
The ARN of the CloudWatch Log Stream.
RoleArn This property is required. string
The ARN of the IAM Role used to send application messages.
Id string
The ARN of the Kinesis Analytics Application.
LogStreamArn This property is required. string
The ARN of the CloudWatch Log Stream.
RoleArn This property is required. string
The ARN of the IAM Role used to send application messages.
Id string
The ARN of the Kinesis Analytics Application.
logStreamArn This property is required. String
The ARN of the CloudWatch Log Stream.
roleArn This property is required. String
The ARN of the IAM Role used to send application messages.
id String
The ARN of the Kinesis Analytics Application.
logStreamArn This property is required. string
The ARN of the CloudWatch Log Stream.
roleArn This property is required. string
The ARN of the IAM Role used to send application messages.
id string
The ARN of the Kinesis Analytics Application.
log_stream_arn This property is required. str
The ARN of the CloudWatch Log Stream.
role_arn This property is required. str
The ARN of the IAM Role used to send application messages.
id str
The ARN of the Kinesis Analytics Application.
logStreamArn This property is required. String
The ARN of the CloudWatch Log Stream.
roleArn This property is required. String
The ARN of the IAM Role used to send application messages.
id String
The ARN of the Kinesis Analytics Application.

AnalyticsApplicationInputs
, AnalyticsApplicationInputsArgs

NamePrefix This property is required. string
The Name Prefix to use when creating an in-application stream.
Schema This property is required. 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 This property is required. string
The Name Prefix to use when creating an in-application stream.
Schema This property is required. 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 This property is required. String
The Name Prefix to use when creating an in-application stream.
schema This property is required. 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 This property is required. string
The Name Prefix to use when creating an in-application stream.
schema This property is required. 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 This property is required. str
The Name Prefix to use when creating an in-application stream.
schema This property is required. 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 This property is required. String
The Name Prefix to use when creating an in-application stream.
schema This property is required. 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 This property is required. string
The ARN of the Kinesis Firehose delivery stream.
RoleArn This property is required. string
The ARN of the IAM Role used to access the stream.
ResourceArn This property is required. string
The ARN of the Kinesis Firehose delivery stream.
RoleArn This property is required. string
The ARN of the IAM Role used to access the stream.
resourceArn This property is required. String
The ARN of the Kinesis Firehose delivery stream.
roleArn This property is required. String
The ARN of the IAM Role used to access the stream.
resourceArn This property is required. string
The ARN of the Kinesis Firehose delivery stream.
roleArn This property is required. string
The ARN of the IAM Role used to access the stream.
resource_arn This property is required. str
The ARN of the Kinesis Firehose delivery stream.
role_arn This property is required. str
The ARN of the IAM Role used to access the stream.
resourceArn This property is required. String
The ARN of the Kinesis Firehose delivery stream.
roleArn This property is required. String
The ARN of the IAM Role used to access the stream.

AnalyticsApplicationInputsKinesisStream
, AnalyticsApplicationInputsKinesisStreamArgs

ResourceArn This property is required. string
The ARN of the Kinesis Stream.
RoleArn This property is required. string
The ARN of the IAM Role used to access the stream.
ResourceArn This property is required. string
The ARN of the Kinesis Stream.
RoleArn This property is required. string
The ARN of the IAM Role used to access the stream.
resourceArn This property is required. String
The ARN of the Kinesis Stream.
roleArn This property is required. String
The ARN of the IAM Role used to access the stream.
resourceArn This property is required. string
The ARN of the Kinesis Stream.
roleArn This property is required. string
The ARN of the IAM Role used to access the stream.
resource_arn This property is required. str
The ARN of the Kinesis Stream.
role_arn This property is required. str
The ARN of the IAM Role used to access the stream.
resourceArn This property is required. String
The ARN of the Kinesis Stream.
roleArn This property is required. 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 This property is required. AnalyticsApplicationInputsProcessingConfigurationLambda
The Lambda function configuration. See Lambda below for more details.
Lambda This property is required. AnalyticsApplicationInputsProcessingConfigurationLambda
The Lambda function configuration. See Lambda below for more details.
lambda This property is required. AnalyticsApplicationInputsProcessingConfigurationLambda
The Lambda function configuration. See Lambda below for more details.
lambda This property is required. AnalyticsApplicationInputsProcessingConfigurationLambda
The Lambda function configuration. See Lambda below for more details.
lambda_ This property is required. AnalyticsApplicationInputsProcessingConfigurationLambda
The Lambda function configuration. See Lambda below for more details.
lambda This property is required. Property Map
The Lambda function configuration. See Lambda below for more details.

AnalyticsApplicationInputsProcessingConfigurationLambda
, AnalyticsApplicationInputsProcessingConfigurationLambdaArgs

ResourceArn This property is required. string
The ARN of the Lambda function.
RoleArn This property is required. string
The ARN of the IAM Role used to access the Lambda function.
ResourceArn This property is required. string
The ARN of the Lambda function.
RoleArn This property is required. string
The ARN of the IAM Role used to access the Lambda function.
resourceArn This property is required. String
The ARN of the Lambda function.
roleArn This property is required. String
The ARN of the IAM Role used to access the Lambda function.
resourceArn This property is required. string
The ARN of the Lambda function.
roleArn This property is required. string
The ARN of the IAM Role used to access the Lambda function.
resource_arn This property is required. str
The ARN of the Lambda function.
role_arn This property is required. str
The ARN of the IAM Role used to access the Lambda function.
resourceArn This property is required. String
The ARN of the Lambda function.
roleArn This property is required. String
The ARN of the IAM Role used to access the Lambda function.

AnalyticsApplicationInputsSchema
, AnalyticsApplicationInputsSchemaArgs

RecordColumns This property is required. List<AnalyticsApplicationInputsSchemaRecordColumn>
The Record Column mapping for the streaming source data element. See Record Columns below for more details.
RecordFormat This property is required. 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 This property is required. []AnalyticsApplicationInputsSchemaRecordColumn
The Record Column mapping for the streaming source data element. See Record Columns below for more details.
RecordFormat This property is required. 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 This property is required. List<AnalyticsApplicationInputsSchemaRecordColumn>
The Record Column mapping for the streaming source data element. See Record Columns below for more details.
recordFormat This property is required. 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 This property is required. AnalyticsApplicationInputsSchemaRecordColumn[]
The Record Column mapping for the streaming source data element. See Record Columns below for more details.
recordFormat This property is required. 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 This property is required. Sequence[AnalyticsApplicationInputsSchemaRecordColumn]
The Record Column mapping for the streaming source data element. See Record Columns below for more details.
record_format This property is required. 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 This property is required. List<Property Map>
The Record Column mapping for the streaming source data element. See Record Columns below for more details.
recordFormat This property is required. 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 This property is required. string
Name of the column.
SqlType This property is required. string
The SQL Type of the column.
Mapping string
The Mapping reference to the data element.
Name This property is required. string
Name of the column.
SqlType This property is required. string
The SQL Type of the column.
Mapping string
The Mapping reference to the data element.
name This property is required. String
Name of the column.
sqlType This property is required. String
The SQL Type of the column.
mapping String
The Mapping reference to the data element.
name This property is required. string
Name of the column.
sqlType This property is required. string
The SQL Type of the column.
mapping string
The Mapping reference to the data element.
name This property is required. str
Name of the column.
sql_type This property is required. str
The SQL Type of the column.
mapping str
The Mapping reference to the data element.
name This property is required. String
Name of the column.
sqlType This property is required. 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 This property is required. string
The Column Delimiter.
RecordRowDelimiter This property is required. string
The Row Delimiter.
RecordColumnDelimiter This property is required. string
The Column Delimiter.
RecordRowDelimiter This property is required. string
The Row Delimiter.
recordColumnDelimiter This property is required. String
The Column Delimiter.
recordRowDelimiter This property is required. String
The Row Delimiter.
recordColumnDelimiter This property is required. string
The Column Delimiter.
recordRowDelimiter This property is required. string
The Row Delimiter.
record_column_delimiter This property is required. str
The Column Delimiter.
record_row_delimiter This property is required. str
The Row Delimiter.
recordColumnDelimiter This property is required. String
The Column Delimiter.
recordRowDelimiter This property is required. String
The Row Delimiter.

AnalyticsApplicationInputsSchemaRecordFormatMappingParametersJson
, AnalyticsApplicationInputsSchemaRecordFormatMappingParametersJsonArgs

RecordRowPath This property is required. string
Path to the top-level parent that contains the records.
RecordRowPath This property is required. string
Path to the top-level parent that contains the records.
recordRowPath This property is required. String
Path to the top-level parent that contains the records.
recordRowPath This property is required. string
Path to the top-level parent that contains the records.
record_row_path This property is required. str
Path to the top-level parent that contains the records.
recordRowPath This property is required. 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 This property is required. string
The Name of the in-application stream.
Schema This property is required. 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 This property is required. string
The Name of the in-application stream.
Schema This property is required. 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 This property is required. String
The Name of the in-application stream.
schema This property is required. 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 This property is required. string
The Name of the in-application stream.
schema This property is required. 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 This property is required. str
The Name of the in-application stream.
schema This property is required. 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 This property is required. String
The Name of the in-application stream.
schema This property is required. 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 This property is required. string
The ARN of the Kinesis Firehose delivery stream.
RoleArn This property is required. string
The ARN of the IAM Role used to access the stream.
ResourceArn This property is required. string
The ARN of the Kinesis Firehose delivery stream.
RoleArn This property is required. string
The ARN of the IAM Role used to access the stream.
resourceArn This property is required. String
The ARN of the Kinesis Firehose delivery stream.
roleArn This property is required. String
The ARN of the IAM Role used to access the stream.
resourceArn This property is required. string
The ARN of the Kinesis Firehose delivery stream.
roleArn This property is required. string
The ARN of the IAM Role used to access the stream.
resource_arn This property is required. str
The ARN of the Kinesis Firehose delivery stream.
role_arn This property is required. str
The ARN of the IAM Role used to access the stream.
resourceArn This property is required. String
The ARN of the Kinesis Firehose delivery stream.
roleArn This property is required. String
The ARN of the IAM Role used to access the stream.

AnalyticsApplicationOutputKinesisStream
, AnalyticsApplicationOutputKinesisStreamArgs

ResourceArn This property is required. string
The ARN of the Kinesis Stream.
RoleArn This property is required. string
The ARN of the IAM Role used to access the stream.
ResourceArn This property is required. string
The ARN of the Kinesis Stream.
RoleArn This property is required. string
The ARN of the IAM Role used to access the stream.
resourceArn This property is required. String
The ARN of the Kinesis Stream.
roleArn This property is required. String
The ARN of the IAM Role used to access the stream.
resourceArn This property is required. string
The ARN of the Kinesis Stream.
roleArn This property is required. string
The ARN of the IAM Role used to access the stream.
resource_arn This property is required. str
The ARN of the Kinesis Stream.
role_arn This property is required. str
The ARN of the IAM Role used to access the stream.
resourceArn This property is required. String
The ARN of the Kinesis Stream.
roleArn This property is required. String
The ARN of the IAM Role used to access the stream.

AnalyticsApplicationOutputLambda
, AnalyticsApplicationOutputLambdaArgs

ResourceArn This property is required. string
The ARN of the Lambda function.
RoleArn This property is required. string
The ARN of the IAM Role used to access the Lambda function.
ResourceArn This property is required. string
The ARN of the Lambda function.
RoleArn This property is required. string
The ARN of the IAM Role used to access the Lambda function.
resourceArn This property is required. String
The ARN of the Lambda function.
roleArn This property is required. String
The ARN of the IAM Role used to access the Lambda function.
resourceArn This property is required. string
The ARN of the Lambda function.
roleArn This property is required. string
The ARN of the IAM Role used to access the Lambda function.
resource_arn This property is required. str
The ARN of the Lambda function.
role_arn This property is required. str
The ARN of the IAM Role used to access the Lambda function.
resourceArn This property is required. String
The ARN of the Lambda function.
roleArn This property is required. String
The ARN of the IAM Role used to access the Lambda function.

AnalyticsApplicationOutputSchema
, AnalyticsApplicationOutputSchemaArgs

RecordFormatType This property is required. string
The Format Type of the records on the output stream. Can be CSV or JSON.
RecordFormatType This property is required. string
The Format Type of the records on the output stream. Can be CSV or JSON.
recordFormatType This property is required. String
The Format Type of the records on the output stream. Can be CSV or JSON.
recordFormatType This property is required. string
The Format Type of the records on the output stream. Can be CSV or JSON.
record_format_type This property is required. str
The Format Type of the records on the output stream. Can be CSV or JSON.
recordFormatType This property is required. String
The Format Type of the records on the output stream. Can be CSV or JSON.

AnalyticsApplicationReferenceDataSources
, AnalyticsApplicationReferenceDataSourcesArgs

S3 This property is required. AnalyticsApplicationReferenceDataSourcesS3
The S3 configuration for the reference data source. See S3 Reference below for more details.
Schema This property is required. AnalyticsApplicationReferenceDataSourcesSchema
The Schema format of the data in the streaming source. See Source Schema below for more details.
TableName This property is required. string
The in-application Table Name.
Id string
The ARN of the Kinesis Analytics Application.
S3 This property is required. AnalyticsApplicationReferenceDataSourcesS3
The S3 configuration for the reference data source. See S3 Reference below for more details.
Schema This property is required. AnalyticsApplicationReferenceDataSourcesSchema
The Schema format of the data in the streaming source. See Source Schema below for more details.
TableName This property is required. string
The in-application Table Name.
Id string
The ARN of the Kinesis Analytics Application.
s3 This property is required. AnalyticsApplicationReferenceDataSourcesS3
The S3 configuration for the reference data source. See S3 Reference below for more details.
schema This property is required. AnalyticsApplicationReferenceDataSourcesSchema
The Schema format of the data in the streaming source. See Source Schema below for more details.
tableName This property is required. String
The in-application Table Name.
id String
The ARN of the Kinesis Analytics Application.
s3 This property is required. AnalyticsApplicationReferenceDataSourcesS3
The S3 configuration for the reference data source. See S3 Reference below for more details.
schema This property is required. AnalyticsApplicationReferenceDataSourcesSchema
The Schema format of the data in the streaming source. See Source Schema below for more details.
tableName This property is required. string
The in-application Table Name.
id string
The ARN of the Kinesis Analytics Application.
s3 This property is required. AnalyticsApplicationReferenceDataSourcesS3
The S3 configuration for the reference data source. See S3 Reference below for more details.
schema This property is required. AnalyticsApplicationReferenceDataSourcesSchema
The Schema format of the data in the streaming source. See Source Schema below for more details.
table_name This property is required. str
The in-application Table Name.
id str
The ARN of the Kinesis Analytics Application.
s3 This property is required. Property Map
The S3 configuration for the reference data source. See S3 Reference below for more details.
schema This property is required. Property Map
The Schema format of the data in the streaming source. See Source Schema below for more details.
tableName This property is required. String
The in-application Table Name.
id String
The ARN of the Kinesis Analytics Application.

AnalyticsApplicationReferenceDataSourcesS3
, AnalyticsApplicationReferenceDataSourcesS3Args

BucketArn This property is required. string
The S3 Bucket ARN.
FileKey This property is required. string
The File Key name containing reference data.
RoleArn This property is required. string
The IAM Role ARN to read the data.
BucketArn This property is required. string
The S3 Bucket ARN.
FileKey This property is required. string
The File Key name containing reference data.
RoleArn This property is required. string
The IAM Role ARN to read the data.
bucketArn This property is required. String
The S3 Bucket ARN.
fileKey This property is required. String
The File Key name containing reference data.
roleArn This property is required. String
The IAM Role ARN to read the data.
bucketArn This property is required. string
The S3 Bucket ARN.
fileKey This property is required. string
The File Key name containing reference data.
roleArn This property is required. string
The IAM Role ARN to read the data.
bucket_arn This property is required. str
The S3 Bucket ARN.
file_key This property is required. str
The File Key name containing reference data.
role_arn This property is required. str
The IAM Role ARN to read the data.
bucketArn This property is required. String
The S3 Bucket ARN.
fileKey This property is required. String
The File Key name containing reference data.
roleArn This property is required. String
The IAM Role ARN to read the data.

AnalyticsApplicationReferenceDataSourcesSchema
, AnalyticsApplicationReferenceDataSourcesSchemaArgs

RecordColumns This property is required. List<AnalyticsApplicationReferenceDataSourcesSchemaRecordColumn>
The Record Column mapping for the streaming source data element. See Record Columns below for more details.
RecordFormat This property is required. 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 This property is required. []AnalyticsApplicationReferenceDataSourcesSchemaRecordColumn
The Record Column mapping for the streaming source data element. See Record Columns below for more details.
RecordFormat This property is required. 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 This property is required. List<AnalyticsApplicationReferenceDataSourcesSchemaRecordColumn>
The Record Column mapping for the streaming source data element. See Record Columns below for more details.
recordFormat This property is required. 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 This property is required. AnalyticsApplicationReferenceDataSourcesSchemaRecordColumn[]
The Record Column mapping for the streaming source data element. See Record Columns below for more details.
recordFormat This property is required. 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 This property is required. Sequence[AnalyticsApplicationReferenceDataSourcesSchemaRecordColumn]
The Record Column mapping for the streaming source data element. See Record Columns below for more details.
record_format This property is required. 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 This property is required. List<Property Map>
The Record Column mapping for the streaming source data element. See Record Columns below for more details.
recordFormat This property is required. 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 This property is required. string
Name of the column.
SqlType This property is required. string
The SQL Type of the column.
Mapping string
The Mapping reference to the data element.
Name This property is required. string
Name of the column.
SqlType This property is required. string
The SQL Type of the column.
Mapping string
The Mapping reference to the data element.
name This property is required. String
Name of the column.
sqlType This property is required. String
The SQL Type of the column.
mapping String
The Mapping reference to the data element.
name This property is required. string
Name of the column.
sqlType This property is required. string
The SQL Type of the column.
mapping string
The Mapping reference to the data element.
name This property is required. str
Name of the column.
sql_type This property is required. str
The SQL Type of the column.
mapping str
The Mapping reference to the data element.
name This property is required. String
Name of the column.
sqlType This property is required. 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 This property is required. string
The Column Delimiter.
RecordRowDelimiter This property is required. string
The Row Delimiter.
RecordColumnDelimiter This property is required. string
The Column Delimiter.
RecordRowDelimiter This property is required. string
The Row Delimiter.
recordColumnDelimiter This property is required. String
The Column Delimiter.
recordRowDelimiter This property is required. String
The Row Delimiter.
recordColumnDelimiter This property is required. string
The Column Delimiter.
recordRowDelimiter This property is required. string
The Row Delimiter.
record_column_delimiter This property is required. str
The Column Delimiter.
record_row_delimiter This property is required. str
The Row Delimiter.
recordColumnDelimiter This property is required. String
The Column Delimiter.
recordRowDelimiter This property is required. String
The Row Delimiter.

AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParametersJson
, AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParametersJsonArgs

RecordRowPath This property is required. string
Path to the top-level parent that contains the records.
RecordRowPath This property is required. string
Path to the top-level parent that contains the records.
recordRowPath This property is required. String
Path to the top-level parent that contains the records.
recordRowPath This property is required. string
Path to the top-level parent that contains the records.
record_row_path This property is required. str
Path to the top-level parent that contains the records.
recordRowPath This property is required. 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
Copy

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

Package Details

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