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
using System.Collections.Generic;
using System.Linq;
using Pulumi;
using Aws = Pulumi.Aws;
return await Deployment.RunAsync(() =>
{
var testStream = new Aws.Kinesis.Stream("testStream", new()
{
ShardCount = 1,
});
var testApplication = new Aws.Kinesis.AnalyticsApplication("testApplication", new()
{
Inputs = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsArgs
{
NamePrefix = "test_prefix",
KinesisStream = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsKinesisStreamArgs
{
ResourceArn = testStream.Arn,
RoleArn = aws_iam_role.Test.Arn,
},
Parallelism = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsParallelismArgs
{
Count = 1,
},
Schema = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsSchemaArgs
{
RecordColumns = new[]
{
new Aws.Kinesis.Inputs.AnalyticsApplicationInputsSchemaRecordColumnArgs
{
Mapping = "$.test",
Name = "test",
SqlType = "VARCHAR(8)",
},
},
RecordEncoding = "UTF-8",
RecordFormat = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsSchemaRecordFormatArgs
{
MappingParameters = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersArgs
{
Json = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersJsonArgs
{
RecordRowPath = "$",
},
},
},
},
},
});
});
package main
import (
"github.com/pulumi/pulumi-aws/sdk/v5/go/aws/kinesis"
"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
)
func main() {
pulumi.Run(func(ctx *pulumi.Context) error {
testStream, err := kinesis.NewStream(ctx, "testStream", &kinesis.StreamArgs{
ShardCount: pulumi.Int(1),
})
if err != nil {
return err
}
_, err = kinesis.NewAnalyticsApplication(ctx, "testApplication", &kinesis.AnalyticsApplicationArgs{
Inputs: &kinesis.AnalyticsApplicationInputsArgs{
NamePrefix: pulumi.String("test_prefix"),
KinesisStream: &kinesis.AnalyticsApplicationInputsKinesisStreamArgs{
ResourceArn: testStream.Arn,
RoleArn: pulumi.Any(aws_iam_role.Test.Arn),
},
Parallelism: &kinesis.AnalyticsApplicationInputsParallelismArgs{
Count: pulumi.Int(1),
},
Schema: &kinesis.AnalyticsApplicationInputsSchemaArgs{
RecordColumns: kinesis.AnalyticsApplicationInputsSchemaRecordColumnArray{
&kinesis.AnalyticsApplicationInputsSchemaRecordColumnArgs{
Mapping: pulumi.String("$.test"),
Name: pulumi.String("test"),
SqlType: pulumi.String("VARCHAR(8)"),
},
},
RecordEncoding: pulumi.String("UTF-8"),
RecordFormat: &kinesis.AnalyticsApplicationInputsSchemaRecordFormatArgs{
MappingParameters: &kinesis.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersArgs{
Json: &kinesis.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersJsonArgs{
RecordRowPath: pulumi.String("$"),
},
},
},
},
},
})
if err != nil {
return err
}
return nil
})
}
package generated_program;
import com.pulumi.Context;
import com.pulumi.Pulumi;
import com.pulumi.core.Output;
import com.pulumi.aws.kinesis.Stream;
import com.pulumi.aws.kinesis.StreamArgs;
import com.pulumi.aws.kinesis.AnalyticsApplication;
import com.pulumi.aws.kinesis.AnalyticsApplicationArgs;
import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationInputsArgs;
import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationInputsKinesisStreamArgs;
import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationInputsParallelismArgs;
import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationInputsSchemaArgs;
import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationInputsSchemaRecordFormatArgs;
import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersArgs;
import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersJsonArgs;
import java.util.List;
import java.util.ArrayList;
import java.util.Map;
import java.io.File;
import java.nio.file.Files;
import java.nio.file.Paths;
public class App {
public static void main(String[] args) {
Pulumi.run(App::stack);
}
public static void stack(Context ctx) {
var testStream = new Stream("testStream", StreamArgs.builder()
.shardCount(1)
.build());
var testApplication = new AnalyticsApplication("testApplication", AnalyticsApplicationArgs.builder()
.inputs(AnalyticsApplicationInputsArgs.builder()
.namePrefix("test_prefix")
.kinesisStream(AnalyticsApplicationInputsKinesisStreamArgs.builder()
.resourceArn(testStream.arn())
.roleArn(aws_iam_role.test().arn())
.build())
.parallelism(AnalyticsApplicationInputsParallelismArgs.builder()
.count(1)
.build())
.schema(AnalyticsApplicationInputsSchemaArgs.builder()
.recordColumns(AnalyticsApplicationInputsSchemaRecordColumnArgs.builder()
.mapping("$.test")
.name("test")
.sqlType("VARCHAR(8)")
.build())
.recordEncoding("UTF-8")
.recordFormat(AnalyticsApplicationInputsSchemaRecordFormatArgs.builder()
.mappingParameters(AnalyticsApplicationInputsSchemaRecordFormatMappingParametersArgs.builder()
.json(AnalyticsApplicationInputsSchemaRecordFormatMappingParametersJsonArgs.builder()
.recordRowPath("$")
.build())
.build())
.build())
.build())
.build())
.build());
}
}
import pulumi
import pulumi_aws as aws
test_stream = aws.kinesis.Stream("testStream", shard_count=1)
test_application = aws.kinesis.AnalyticsApplication("testApplication", inputs=aws.kinesis.AnalyticsApplicationInputsArgs(
name_prefix="test_prefix",
kinesis_stream=aws.kinesis.AnalyticsApplicationInputsKinesisStreamArgs(
resource_arn=test_stream.arn,
role_arn=aws_iam_role["test"]["arn"],
),
parallelism=aws.kinesis.AnalyticsApplicationInputsParallelismArgs(
count=1,
),
schema=aws.kinesis.AnalyticsApplicationInputsSchemaArgs(
record_columns=[aws.kinesis.AnalyticsApplicationInputsSchemaRecordColumnArgs(
mapping="$.test",
name="test",
sql_type="VARCHAR(8)",
)],
record_encoding="UTF-8",
record_format=aws.kinesis.AnalyticsApplicationInputsSchemaRecordFormatArgs(
mapping_parameters=aws.kinesis.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersArgs(
json=aws.kinesis.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersJsonArgs(
record_row_path="$",
),
),
),
),
))
import * as pulumi from "@pulumi/pulumi";
import * as aws from "@pulumi/aws";
const testStream = new aws.kinesis.Stream("testStream", {shardCount: 1});
const testApplication = new aws.kinesis.AnalyticsApplication("testApplication", {inputs: {
namePrefix: "test_prefix",
kinesisStream: {
resourceArn: testStream.arn,
roleArn: aws_iam_role.test.arn,
},
parallelism: {
count: 1,
},
schema: {
recordColumns: [{
mapping: "$.test",
name: "test",
sqlType: "VARCHAR(8)",
}],
recordEncoding: "UTF-8",
recordFormat: {
mappingParameters: {
json: {
recordRowPath: "$",
},
},
},
},
}});
resources:
testStream:
type: aws:kinesis:Stream
properties:
shardCount: 1
testApplication:
type: aws:kinesis:AnalyticsApplication
properties:
inputs:
namePrefix: test_prefix
kinesisStream:
resourceArn: ${testStream.arn}
roleArn: ${aws_iam_role.test.arn}
parallelism:
count: 1
schema:
recordColumns:
- mapping: $.test
name: test
sqlType: VARCHAR(8)
recordEncoding: UTF-8
recordFormat:
mappingParameters:
json:
recordRowPath: $
Starting An Application
using System.Collections.Generic;
using System.Linq;
using Pulumi;
using Aws = Pulumi.Aws;
return await Deployment.RunAsync(() =>
{
var exampleLogGroup = new Aws.CloudWatch.LogGroup("exampleLogGroup");
var exampleLogStream = new Aws.CloudWatch.LogStream("exampleLogStream", new()
{
LogGroupName = exampleLogGroup.Name,
});
var exampleStream = new Aws.Kinesis.Stream("exampleStream", new()
{
ShardCount = 1,
});
var exampleFirehoseDeliveryStream = new Aws.Kinesis.FirehoseDeliveryStream("exampleFirehoseDeliveryStream", new()
{
Destination = "extended_s3",
ExtendedS3Configuration = new Aws.Kinesis.Inputs.FirehoseDeliveryStreamExtendedS3ConfigurationArgs
{
BucketArn = aws_s3_bucket.Example.Arn,
RoleArn = aws_iam_role.Example.Arn,
},
});
var test = new Aws.Kinesis.AnalyticsApplication("test", new()
{
CloudwatchLoggingOptions = new Aws.Kinesis.Inputs.AnalyticsApplicationCloudwatchLoggingOptionsArgs
{
LogStreamArn = exampleLogStream.Arn,
RoleArn = aws_iam_role.Example.Arn,
},
Inputs = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsArgs
{
NamePrefix = "example_prefix",
Schema = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsSchemaArgs
{
RecordColumns = new[]
{
new Aws.Kinesis.Inputs.AnalyticsApplicationInputsSchemaRecordColumnArgs
{
Name = "COLUMN_1",
SqlType = "INTEGER",
},
},
RecordFormat = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsSchemaRecordFormatArgs
{
MappingParameters = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersArgs
{
Csv = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersCsvArgs
{
RecordColumnDelimiter = ",",
RecordRowDelimiter = "|",
},
},
},
},
KinesisStream = new Aws.Kinesis.Inputs.AnalyticsApplicationInputsKinesisStreamArgs
{
ResourceArn = exampleStream.Arn,
RoleArn = aws_iam_role.Example.Arn,
},
StartingPositionConfigurations = new[]
{
new Aws.Kinesis.Inputs.AnalyticsApplicationInputsStartingPositionConfigurationArgs
{
StartingPosition = "NOW",
},
},
},
Outputs = new[]
{
new Aws.Kinesis.Inputs.AnalyticsApplicationOutputArgs
{
Name = "OUTPUT_1",
Schema = new Aws.Kinesis.Inputs.AnalyticsApplicationOutputSchemaArgs
{
RecordFormatType = "CSV",
},
KinesisFirehose = new Aws.Kinesis.Inputs.AnalyticsApplicationOutputKinesisFirehoseArgs
{
ResourceArn = exampleFirehoseDeliveryStream.Arn,
RoleArn = aws_iam_role.Example.Arn,
},
},
},
StartApplication = true,
});
});
package main
import (
"github.com/pulumi/pulumi-aws/sdk/v5/go/aws/cloudwatch"
"github.com/pulumi/pulumi-aws/sdk/v5/go/aws/kinesis"
"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
)
func main() {
pulumi.Run(func(ctx *pulumi.Context) error {
exampleLogGroup, err := cloudwatch.NewLogGroup(ctx, "exampleLogGroup", nil)
if err != nil {
return err
}
exampleLogStream, err := cloudwatch.NewLogStream(ctx, "exampleLogStream", &cloudwatch.LogStreamArgs{
LogGroupName: exampleLogGroup.Name,
})
if err != nil {
return err
}
exampleStream, err := kinesis.NewStream(ctx, "exampleStream", &kinesis.StreamArgs{
ShardCount: pulumi.Int(1),
})
if err != nil {
return err
}
exampleFirehoseDeliveryStream, err := kinesis.NewFirehoseDeliveryStream(ctx, "exampleFirehoseDeliveryStream", &kinesis.FirehoseDeliveryStreamArgs{
Destination: pulumi.String("extended_s3"),
ExtendedS3Configuration: &kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationArgs{
BucketArn: pulumi.Any(aws_s3_bucket.Example.Arn),
RoleArn: pulumi.Any(aws_iam_role.Example.Arn),
},
})
if err != nil {
return err
}
_, err = kinesis.NewAnalyticsApplication(ctx, "test", &kinesis.AnalyticsApplicationArgs{
CloudwatchLoggingOptions: &kinesis.AnalyticsApplicationCloudwatchLoggingOptionsArgs{
LogStreamArn: exampleLogStream.Arn,
RoleArn: pulumi.Any(aws_iam_role.Example.Arn),
},
Inputs: &kinesis.AnalyticsApplicationInputsArgs{
NamePrefix: pulumi.String("example_prefix"),
Schema: &kinesis.AnalyticsApplicationInputsSchemaArgs{
RecordColumns: kinesis.AnalyticsApplicationInputsSchemaRecordColumnArray{
&kinesis.AnalyticsApplicationInputsSchemaRecordColumnArgs{
Name: pulumi.String("COLUMN_1"),
SqlType: pulumi.String("INTEGER"),
},
},
RecordFormat: &kinesis.AnalyticsApplicationInputsSchemaRecordFormatArgs{
MappingParameters: &kinesis.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersArgs{
Csv: &kinesis.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersCsvArgs{
RecordColumnDelimiter: pulumi.String(","),
RecordRowDelimiter: pulumi.String("|"),
},
},
},
},
KinesisStream: &kinesis.AnalyticsApplicationInputsKinesisStreamArgs{
ResourceArn: exampleStream.Arn,
RoleArn: pulumi.Any(aws_iam_role.Example.Arn),
},
StartingPositionConfigurations: kinesis.AnalyticsApplicationInputsStartingPositionConfigurationArray{
&kinesis.AnalyticsApplicationInputsStartingPositionConfigurationArgs{
StartingPosition: pulumi.String("NOW"),
},
},
},
Outputs: kinesis.AnalyticsApplicationOutputTypeArray{
&kinesis.AnalyticsApplicationOutputTypeArgs{
Name: pulumi.String("OUTPUT_1"),
Schema: &kinesis.AnalyticsApplicationOutputSchemaArgs{
RecordFormatType: pulumi.String("CSV"),
},
KinesisFirehose: &kinesis.AnalyticsApplicationOutputKinesisFirehoseArgs{
ResourceArn: exampleFirehoseDeliveryStream.Arn,
RoleArn: pulumi.Any(aws_iam_role.Example.Arn),
},
},
},
StartApplication: pulumi.Bool(true),
})
if err != nil {
return err
}
return nil
})
}
package generated_program;
import com.pulumi.Context;
import com.pulumi.Pulumi;
import com.pulumi.core.Output;
import com.pulumi.aws.cloudwatch.LogGroup;
import com.pulumi.aws.cloudwatch.LogStream;
import com.pulumi.aws.cloudwatch.LogStreamArgs;
import com.pulumi.aws.kinesis.Stream;
import com.pulumi.aws.kinesis.StreamArgs;
import com.pulumi.aws.kinesis.FirehoseDeliveryStream;
import com.pulumi.aws.kinesis.FirehoseDeliveryStreamArgs;
import com.pulumi.aws.kinesis.inputs.FirehoseDeliveryStreamExtendedS3ConfigurationArgs;
import com.pulumi.aws.kinesis.AnalyticsApplication;
import com.pulumi.aws.kinesis.AnalyticsApplicationArgs;
import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationCloudwatchLoggingOptionsArgs;
import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationInputsArgs;
import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationInputsSchemaArgs;
import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationInputsSchemaRecordFormatArgs;
import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersArgs;
import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersCsvArgs;
import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationInputsKinesisStreamArgs;
import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationOutputArgs;
import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationOutputSchemaArgs;
import com.pulumi.aws.kinesis.inputs.AnalyticsApplicationOutputKinesisFirehoseArgs;
import java.util.List;
import java.util.ArrayList;
import java.util.Map;
import java.io.File;
import java.nio.file.Files;
import java.nio.file.Paths;
public class App {
public static void main(String[] args) {
Pulumi.run(App::stack);
}
public static void stack(Context ctx) {
var exampleLogGroup = new LogGroup("exampleLogGroup");
var exampleLogStream = new LogStream("exampleLogStream", LogStreamArgs.builder()
.logGroupName(exampleLogGroup.name())
.build());
var exampleStream = new Stream("exampleStream", StreamArgs.builder()
.shardCount(1)
.build());
var exampleFirehoseDeliveryStream = new FirehoseDeliveryStream("exampleFirehoseDeliveryStream", FirehoseDeliveryStreamArgs.builder()
.destination("extended_s3")
.extendedS3Configuration(FirehoseDeliveryStreamExtendedS3ConfigurationArgs.builder()
.bucketArn(aws_s3_bucket.example().arn())
.roleArn(aws_iam_role.example().arn())
.build())
.build());
var test = new AnalyticsApplication("test", AnalyticsApplicationArgs.builder()
.cloudwatchLoggingOptions(AnalyticsApplicationCloudwatchLoggingOptionsArgs.builder()
.logStreamArn(exampleLogStream.arn())
.roleArn(aws_iam_role.example().arn())
.build())
.inputs(AnalyticsApplicationInputsArgs.builder()
.namePrefix("example_prefix")
.schema(AnalyticsApplicationInputsSchemaArgs.builder()
.recordColumns(AnalyticsApplicationInputsSchemaRecordColumnArgs.builder()
.name("COLUMN_1")
.sqlType("INTEGER")
.build())
.recordFormat(AnalyticsApplicationInputsSchemaRecordFormatArgs.builder()
.mappingParameters(AnalyticsApplicationInputsSchemaRecordFormatMappingParametersArgs.builder()
.csv(AnalyticsApplicationInputsSchemaRecordFormatMappingParametersCsvArgs.builder()
.recordColumnDelimiter(",")
.recordRowDelimiter("|")
.build())
.build())
.build())
.build())
.kinesisStream(AnalyticsApplicationInputsKinesisStreamArgs.builder()
.resourceArn(exampleStream.arn())
.roleArn(aws_iam_role.example().arn())
.build())
.startingPositionConfigurations(AnalyticsApplicationInputsStartingPositionConfigurationArgs.builder()
.startingPosition("NOW")
.build())
.build())
.outputs(AnalyticsApplicationOutputArgs.builder()
.name("OUTPUT_1")
.schema(AnalyticsApplicationOutputSchemaArgs.builder()
.recordFormatType("CSV")
.build())
.kinesisFirehose(AnalyticsApplicationOutputKinesisFirehoseArgs.builder()
.resourceArn(exampleFirehoseDeliveryStream.arn())
.roleArn(aws_iam_role.example().arn())
.build())
.build())
.startApplication(true)
.build());
}
}
import pulumi
import pulumi_aws as aws
example_log_group = aws.cloudwatch.LogGroup("exampleLogGroup")
example_log_stream = aws.cloudwatch.LogStream("exampleLogStream", log_group_name=example_log_group.name)
example_stream = aws.kinesis.Stream("exampleStream", shard_count=1)
example_firehose_delivery_stream = aws.kinesis.FirehoseDeliveryStream("exampleFirehoseDeliveryStream",
destination="extended_s3",
extended_s3_configuration=aws.kinesis.FirehoseDeliveryStreamExtendedS3ConfigurationArgs(
bucket_arn=aws_s3_bucket["example"]["arn"],
role_arn=aws_iam_role["example"]["arn"],
))
test = aws.kinesis.AnalyticsApplication("test",
cloudwatch_logging_options=aws.kinesis.AnalyticsApplicationCloudwatchLoggingOptionsArgs(
log_stream_arn=example_log_stream.arn,
role_arn=aws_iam_role["example"]["arn"],
),
inputs=aws.kinesis.AnalyticsApplicationInputsArgs(
name_prefix="example_prefix",
schema=aws.kinesis.AnalyticsApplicationInputsSchemaArgs(
record_columns=[aws.kinesis.AnalyticsApplicationInputsSchemaRecordColumnArgs(
name="COLUMN_1",
sql_type="INTEGER",
)],
record_format=aws.kinesis.AnalyticsApplicationInputsSchemaRecordFormatArgs(
mapping_parameters=aws.kinesis.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersArgs(
csv=aws.kinesis.AnalyticsApplicationInputsSchemaRecordFormatMappingParametersCsvArgs(
record_column_delimiter=",",
record_row_delimiter="|",
),
),
),
),
kinesis_stream=aws.kinesis.AnalyticsApplicationInputsKinesisStreamArgs(
resource_arn=example_stream.arn,
role_arn=aws_iam_role["example"]["arn"],
),
starting_position_configurations=[aws.kinesis.AnalyticsApplicationInputsStartingPositionConfigurationArgs(
starting_position="NOW",
)],
),
outputs=[aws.kinesis.AnalyticsApplicationOutputArgs(
name="OUTPUT_1",
schema=aws.kinesis.AnalyticsApplicationOutputSchemaArgs(
record_format_type="CSV",
),
kinesis_firehose=aws.kinesis.AnalyticsApplicationOutputKinesisFirehoseArgs(
resource_arn=example_firehose_delivery_stream.arn,
role_arn=aws_iam_role["example"]["arn"],
),
)],
start_application=True)
import * as pulumi from "@pulumi/pulumi";
import * as aws from "@pulumi/aws";
const exampleLogGroup = new aws.cloudwatch.LogGroup("exampleLogGroup", {});
const exampleLogStream = new aws.cloudwatch.LogStream("exampleLogStream", {logGroupName: exampleLogGroup.name});
const exampleStream = new aws.kinesis.Stream("exampleStream", {shardCount: 1});
const exampleFirehoseDeliveryStream = new aws.kinesis.FirehoseDeliveryStream("exampleFirehoseDeliveryStream", {
destination: "extended_s3",
extendedS3Configuration: {
bucketArn: aws_s3_bucket.example.arn,
roleArn: aws_iam_role.example.arn,
},
});
const test = new aws.kinesis.AnalyticsApplication("test", {
cloudwatchLoggingOptions: {
logStreamArn: exampleLogStream.arn,
roleArn: aws_iam_role.example.arn,
},
inputs: {
namePrefix: "example_prefix",
schema: {
recordColumns: [{
name: "COLUMN_1",
sqlType: "INTEGER",
}],
recordFormat: {
mappingParameters: {
csv: {
recordColumnDelimiter: ",",
recordRowDelimiter: "|",
},
},
},
},
kinesisStream: {
resourceArn: exampleStream.arn,
roleArn: aws_iam_role.example.arn,
},
startingPositionConfigurations: [{
startingPosition: "NOW",
}],
},
outputs: [{
name: "OUTPUT_1",
schema: {
recordFormatType: "CSV",
},
kinesisFirehose: {
resourceArn: exampleFirehoseDeliveryStream.arn,
roleArn: aws_iam_role.example.arn,
},
}],
startApplication: true,
});
resources:
exampleLogGroup:
type: aws:cloudwatch:LogGroup
exampleLogStream:
type: aws:cloudwatch:LogStream
properties:
logGroupName: ${exampleLogGroup.name}
exampleStream:
type: aws:kinesis:Stream
properties:
shardCount: 1
exampleFirehoseDeliveryStream:
type: aws:kinesis:FirehoseDeliveryStream
properties:
destination: extended_s3
extendedS3Configuration:
bucketArn: ${aws_s3_bucket.example.arn}
roleArn: ${aws_iam_role.example.arn}
test:
type: aws:kinesis:AnalyticsApplication
properties:
cloudwatchLoggingOptions:
logStreamArn: ${exampleLogStream.arn}
roleArn: ${aws_iam_role.example.arn}
inputs:
namePrefix: example_prefix
schema:
recordColumns:
- name: COLUMN_1
sqlType: INTEGER
recordFormat:
mappingParameters:
csv:
recordColumnDelimiter: ','
recordRowDelimiter: '|'
kinesisStream:
resourceArn: ${exampleStream.arn}
roleArn: ${aws_iam_role.example.arn}
startingPositionConfigurations:
- startingPosition: NOW
outputs:
- name: OUTPUT_1
schema:
recordFormatType: CSV
kinesisFirehose:
resourceArn: ${exampleFirehoseDeliveryStream.arn}
roleArn: ${aws_iam_role.example.arn}
startApplication: true
Create AnalyticsApplication Resource
new AnalyticsApplication(name: string, args?: AnalyticsApplicationArgs, opts?: CustomResourceOptions);
@overload
def AnalyticsApplication(resource_name: str,
opts: Optional[ResourceOptions] = None,
cloudwatch_logging_options: Optional[AnalyticsApplicationCloudwatchLoggingOptionsArgs] = None,
code: Optional[str] = None,
description: Optional[str] = None,
inputs: Optional[AnalyticsApplicationInputsArgs] = None,
name: Optional[str] = None,
outputs: Optional[Sequence[AnalyticsApplicationOutputArgs]] = None,
reference_data_sources: Optional[AnalyticsApplicationReferenceDataSourcesArgs] = None,
start_application: Optional[bool] = None,
tags: Optional[Mapping[str, str]] = None)
@overload
def AnalyticsApplication(resource_name: str,
args: Optional[AnalyticsApplicationArgs] = None,
opts: Optional[ResourceOptions] = None)
func NewAnalyticsApplication(ctx *Context, name string, args *AnalyticsApplicationArgs, opts ...ResourceOption) (*AnalyticsApplication, error)
public AnalyticsApplication(string name, AnalyticsApplicationArgs? args = null, CustomResourceOptions? opts = null)
public AnalyticsApplication(String name, AnalyticsApplicationArgs args)
public AnalyticsApplication(String name, AnalyticsApplicationArgs args, CustomResourceOptions options)
type: aws:kinesis:AnalyticsApplication
properties: # The arguments to resource properties.
options: # Bag of options to control resource's behavior.
- name string
- The unique name of the resource.
- args AnalyticsApplicationArgs
- The arguments to resource properties.
- opts CustomResourceOptions
- Bag of options to control resource's behavior.
- resource_name str
- The unique name of the resource.
- args AnalyticsApplicationArgs
- The arguments to resource properties.
- opts ResourceOptions
- Bag of options to control resource's behavior.
- ctx Context
- Context object for the current deployment.
- name string
- The unique name of the resource.
- args AnalyticsApplicationArgs
- The arguments to resource properties.
- opts ResourceOption
- Bag of options to control resource's behavior.
- name string
- The unique name of the resource.
- args AnalyticsApplicationArgs
- The arguments to resource properties.
- opts CustomResourceOptions
- Bag of options to control resource's behavior.
- name String
- The unique name of the resource.
- args AnalyticsApplicationArgs
- The arguments to resource properties.
- options CustomResourceOptions
- Bag of options to control resource's behavior.
AnalyticsApplication Resource Properties
To learn more about resource properties and how to use them, see Inputs and Outputs in the Architecture and Concepts docs.
Inputs
The AnalyticsApplication resource accepts the following input properties:
- Cloudwatch
Logging AnalyticsOptions Application Cloudwatch Logging Options Args The CloudWatch log stream options to monitor application errors. See CloudWatch Logging Options below for more details.
- Code string
SQL Code to transform input data, and generate output.
- Description string
Description of the application.
- Inputs
Analytics
Application Inputs Args Input configuration of the application. See Inputs below for more details.
- Name string
Name of the Kinesis Analytics Application.
- Outputs
List<Analytics
Application Output Args> Output destination configuration of the application. See Outputs below for more details.
- Reference
Data AnalyticsSources Application Reference Data Sources Args 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 settingstart_application = false
, then updatestarting_position
and setstart_application = true
.- 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.
- Cloudwatch
Logging AnalyticsOptions Application Cloudwatch Logging Options Args The CloudWatch log stream options to monitor application errors. See CloudWatch Logging Options below for more details.
- Code string
SQL Code to transform input data, and generate output.
- Description string
Description of the application.
- Inputs
Analytics
Application Inputs Args Input configuration of the application. See Inputs below for more details.
- Name string
Name of the Kinesis Analytics Application.
- Outputs
[]Analytics
Application Output Type Args Output destination configuration of the application. See Outputs below for more details.
- Reference
Data AnalyticsSources Application Reference Data Sources Args 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 settingstart_application = false
, then updatestarting_position
and setstart_application = true
.- 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.
- cloudwatch
Logging AnalyticsOptions Application Cloudwatch Logging Options Args The CloudWatch log stream options to monitor application errors. See CloudWatch Logging Options below for more details.
- code String
SQL Code to transform input data, and generate output.
- description String
Description of the application.
- inputs
Analytics
Application Inputs Args Input configuration of the application. See Inputs below for more details.
- name String
Name of the Kinesis Analytics Application.
- outputs
List<Analytics
Application Output Args> Output destination configuration of the application. See Outputs below for more details.
- reference
Data AnalyticsSources Application Reference Data Sources Args An S3 Reference Data Source for the application. See Reference Data Sources below for more details.
- start
Application 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 settingstart_application = false
, then updatestarting_position
and setstart_application = true
.- 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.
- cloudwatch
Logging AnalyticsOptions Application Cloudwatch Logging Options Args The CloudWatch log stream options to monitor application errors. See CloudWatch Logging Options below for more details.
- code string
SQL Code to transform input data, and generate output.
- description string
Description of the application.
- inputs
Analytics
Application Inputs Args Input configuration of the application. See Inputs below for more details.
- name string
Name of the Kinesis Analytics Application.
- outputs
Analytics
Application Output Args[] Output destination configuration of the application. See Outputs below for more details.
- reference
Data AnalyticsSources Application Reference Data Sources Args An S3 Reference Data Source for the application. See Reference Data Sources below for more details.
- start
Application 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 settingstart_application = false
, then updatestarting_position
and setstart_application = true
.- {[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_ Analyticsoptions Application Cloudwatch Logging Options Args The CloudWatch log stream options to monitor application errors. See CloudWatch Logging Options below for more details.
- code str
SQL Code to transform input data, and generate output.
- description str
Description of the application.
- inputs
Analytics
Application Inputs Args Input configuration of the application. See Inputs below for more details.
- name str
Name of the Kinesis Analytics Application.
- outputs
Sequence[Analytics
Application Output Args] Output destination configuration of the application. See Outputs below for more details.
- reference_
data_ Analyticssources Application Reference Data Sources Args 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 settingstart_application = false
, then updatestarting_position
and setstart_application = true
.- 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.
- cloudwatch
Logging Property MapOptions The CloudWatch log stream options to monitor application errors. See CloudWatch Logging Options below for more details.
- code String
SQL Code to transform input data, and generate output.
- description String
Description of the application.
- inputs Property Map
Input configuration of the application. See Inputs below for more details.
- name String
Name of the Kinesis Analytics Application.
- outputs List<Property Map>
Output destination configuration of the application. See Outputs below for more details.
- reference
Data Property MapSources An S3 Reference Data Source for the application. See Reference Data Sources below for more details.
- start
Application 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 settingstart_application = false
, then updatestarting_position
and setstart_application = true
.- 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.
- Create
Timestamp string The Timestamp when the application version was created.
- Id string
The provider-assigned unique ID for this managed resource.
- Last
Update stringTimestamp The Timestamp when the application was last updated.
- Status string
The Status of the application.
- Dictionary<string, string>
A map of tags assigned to the resource, including those inherited from the provider
default_tags
configuration block.- Version int
The Version of the application.
- Arn string
The ARN of the Kinesis Analytics Appliation.
- Create
Timestamp string The Timestamp when the application version was created.
- Id string
The provider-assigned unique ID for this managed resource.
- Last
Update stringTimestamp The Timestamp when the application was last updated.
- Status string
The Status of the application.
- map[string]string
A map of tags assigned to the resource, including those inherited from the provider
default_tags
configuration block.- Version int
The Version of the application.
- arn String
The ARN of the Kinesis Analytics Appliation.
- create
Timestamp String The Timestamp when the application version was created.
- id String
The provider-assigned unique ID for this managed resource.
- last
Update StringTimestamp The Timestamp when the application was last updated.
- status String
The Status of the application.
- Map<String,String>
A map of tags assigned to the resource, including those inherited from the provider
default_tags
configuration block.- version Integer
The Version of the application.
- arn ARN
The ARN of the Kinesis Analytics Appliation.
- create
Timestamp string The Timestamp when the application version was created.
- id string
The provider-assigned unique ID for this managed resource.
- last
Update stringTimestamp The Timestamp when the application was last updated.
- status string
The Status of the application.
- {[key: string]: string}
A map of tags assigned to the resource, including those inherited from the provider
default_tags
configuration block.- 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_ strtimestamp The Timestamp when the application was last updated.
- status str
The Status of the application.
- Mapping[str, str]
A map of tags assigned to the resource, including those inherited from the provider
default_tags
configuration block.- version int
The Version of the application.
- arn
The ARN of the Kinesis Analytics Appliation.
- create
Timestamp String The Timestamp when the application version was created.
- id String
The provider-assigned unique ID for this managed resource.
- last
Update StringTimestamp The Timestamp when the application was last updated.
- status String
The Status of the application.
- Map<String>
A map of tags assigned to the resource, including those inherited from the provider
default_tags
configuration block.- version Number
The Version of the application.
Look up Existing AnalyticsApplication Resource
Get an existing AnalyticsApplication resource’s state with the given name, ID, and optional extra properties used to qualify the lookup.
public static get(name: string, id: Input<ID>, state?: AnalyticsApplicationState, opts?: CustomResourceOptions): AnalyticsApplication
@staticmethod
def get(resource_name: str,
id: str,
opts: Optional[ResourceOptions] = None,
arn: Optional[str] = None,
cloudwatch_logging_options: Optional[AnalyticsApplicationCloudwatchLoggingOptionsArgs] = None,
code: Optional[str] = None,
create_timestamp: Optional[str] = None,
description: Optional[str] = None,
inputs: Optional[AnalyticsApplicationInputsArgs] = None,
last_update_timestamp: Optional[str] = None,
name: Optional[str] = None,
outputs: Optional[Sequence[AnalyticsApplicationOutputArgs]] = None,
reference_data_sources: Optional[AnalyticsApplicationReferenceDataSourcesArgs] = None,
start_application: Optional[bool] = None,
status: Optional[str] = None,
tags: Optional[Mapping[str, str]] = None,
tags_all: Optional[Mapping[str, str]] = None,
version: Optional[int] = None) -> AnalyticsApplication
func GetAnalyticsApplication(ctx *Context, name string, id IDInput, state *AnalyticsApplicationState, opts ...ResourceOption) (*AnalyticsApplication, error)
public static AnalyticsApplication Get(string name, Input<string> id, AnalyticsApplicationState? state, CustomResourceOptions? opts = null)
public static AnalyticsApplication get(String name, Output<String> id, AnalyticsApplicationState state, CustomResourceOptions options)
Resource lookup is not supported in YAML
- name
- The unique name of the resulting resource.
- id
- The unique provider ID of the resource to lookup.
- state
- Any extra arguments used during the lookup.
- opts
- A bag of options that control this resource's behavior.
- resource_name
- The unique name of the resulting resource.
- id
- The unique provider ID of the resource to lookup.
- name
- The unique name of the resulting resource.
- id
- The unique provider ID of the resource to lookup.
- state
- Any extra arguments used during the lookup.
- opts
- A bag of options that control this resource's behavior.
- name
- The unique name of the resulting resource.
- id
- The unique provider ID of the resource to lookup.
- state
- Any extra arguments used during the lookup.
- opts
- A bag of options that control this resource's behavior.
- name
- The unique name of the resulting resource.
- id
- The unique provider ID of the resource to lookup.
- state
- Any extra arguments used during the lookup.
- opts
- A bag of options that control this resource's behavior.
- Arn string
The ARN of the Kinesis Analytics Appliation.
- Cloudwatch
Logging AnalyticsOptions Application Cloudwatch Logging Options Args 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.
- Create
Timestamp string The Timestamp when the application version was created.
- Description string
Description of the application.
- Inputs
Analytics
Application Inputs Args Input configuration of the application. See Inputs below for more details.
- Last
Update stringTimestamp The Timestamp when the application was last updated.
- Name string
Name of the Kinesis Analytics Application.
- Outputs
List<Analytics
Application Output Args> Output destination configuration of the application. See Outputs below for more details.
- Reference
Data AnalyticsSources Application Reference Data Sources Args 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 settingstart_application = false
, then updatestarting_position
and setstart_application = true
.- Status string
The Status of the application.
- 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.- Dictionary<string, string>
A map of tags assigned to the resource, including those inherited from the provider
default_tags
configuration block.- Version int
The Version of the application.
- Arn string
The ARN of the Kinesis Analytics Appliation.
- Cloudwatch
Logging AnalyticsOptions Application Cloudwatch Logging Options Args 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.
- Create
Timestamp string The Timestamp when the application version was created.
- Description string
Description of the application.
- Inputs
Analytics
Application Inputs Args Input configuration of the application. See Inputs below for more details.
- Last
Update stringTimestamp The Timestamp when the application was last updated.
- Name string
Name of the Kinesis Analytics Application.
- Outputs
[]Analytics
Application Output Type Args Output destination configuration of the application. See Outputs below for more details.
- Reference
Data AnalyticsSources Application Reference Data Sources Args 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 settingstart_application = false
, then updatestarting_position
and setstart_application = true
.- Status string
The Status of the application.
- 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.- map[string]string
A map of tags assigned to the resource, including those inherited from the provider
default_tags
configuration block.- Version int
The Version of the application.
- arn String
The ARN of the Kinesis Analytics Appliation.
- cloudwatch
Logging AnalyticsOptions Application Cloudwatch Logging Options Args 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.
- create
Timestamp String The Timestamp when the application version was created.
- description String
Description of the application.
- inputs
Analytics
Application Inputs Args Input configuration of the application. See Inputs below for more details.
- last
Update StringTimestamp The Timestamp when the application was last updated.
- name String
Name of the Kinesis Analytics Application.
- outputs
List<Analytics
Application Output Args> Output destination configuration of the application. See Outputs below for more details.
- reference
Data AnalyticsSources Application Reference Data Sources Args An S3 Reference Data Source for the application. See Reference Data Sources below for more details.
- start
Application 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 settingstart_application = false
, then updatestarting_position
and setstart_application = true
.- status String
The Status of the application.
- 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.- Map<String,String>
A map of tags assigned to the resource, including those inherited from the provider
default_tags
configuration block.- version Integer
The Version of the application.
- arn ARN
The ARN of the Kinesis Analytics Appliation.
- cloudwatch
Logging AnalyticsOptions Application Cloudwatch Logging Options Args 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.
- create
Timestamp string The Timestamp when the application version was created.
- description string
Description of the application.
- inputs
Analytics
Application Inputs Args Input configuration of the application. See Inputs below for more details.
- last
Update stringTimestamp The Timestamp when the application was last updated.
- name string
Name of the Kinesis Analytics Application.
- outputs
Analytics
Application Output Args[] Output destination configuration of the application. See Outputs below for more details.
- reference
Data AnalyticsSources Application Reference Data Sources Args An S3 Reference Data Source for the application. See Reference Data Sources below for more details.
- start
Application 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 settingstart_application = false
, then updatestarting_position
and setstart_application = true
.- status string
The Status of the application.
- {[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.- {[key: string]: string}
A map of tags assigned to the resource, including those inherited from the provider
default_tags
configuration block.- version number
The Version of the application.
- arn str
The ARN of the Kinesis Analytics Appliation.
- cloudwatch_
logging_ Analyticsoptions Application Cloudwatch Logging Options Args The CloudWatch log stream options to monitor application errors. See CloudWatch Logging Options below for more details.
- code str
SQL Code to transform input data, and generate output.
- create_
timestamp str The Timestamp when the application version was created.
- description str
Description of the application.
- inputs
Analytics
Application Inputs Args Input configuration of the application. See Inputs below for more details.
- last_
update_ strtimestamp The Timestamp when the application was last updated.
- name str
Name of the Kinesis Analytics Application.
- outputs
Sequence[Analytics
Application Output Args] Output destination configuration of the application. See Outputs below for more details.
- reference_
data_ Analyticssources Application Reference Data Sources Args 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 settingstart_application = false
, then updatestarting_position
and setstart_application = true
.- status str
The Status of the application.
- 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.- Mapping[str, str]
A map of tags assigned to the resource, including those inherited from the provider
default_tags
configuration block.- version int
The Version of the application.
- arn
The ARN of the Kinesis Analytics Appliation.
- cloudwatch
Logging Property MapOptions 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.
- create
Timestamp String The Timestamp when the application version was created.
- description String
Description of the application.
- inputs Property Map
Input configuration of the application. See Inputs below for more details.
- last
Update StringTimestamp The Timestamp when the application was last updated.
- name String
Name of the Kinesis Analytics Application.
- outputs List<Property Map>
Output destination configuration of the application. See Outputs below for more details.
- reference
Data Property MapSources An S3 Reference Data Source for the application. See Reference Data Sources below for more details.
- start
Application 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 settingstart_application = false
, then updatestarting_position
and setstart_application = true
.- status String
The Status of the application.
- 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.- Map<String>
A map of tags assigned to the resource, including those inherited from the provider
default_tags
configuration block.- version Number
The Version of the application.
Supporting Types
AnalyticsApplicationCloudwatchLoggingOptions
- Log
Stream stringArn The ARN of the CloudWatch Log Stream.
- Role
Arn string The ARN of the IAM Role used to send application messages.
- Id string
The ARN of the Kinesis Analytics Application.
- Log
Stream stringArn The ARN of the CloudWatch Log Stream.
- Role
Arn string The ARN of the IAM Role used to send application messages.
- Id string
The ARN of the Kinesis Analytics Application.
- log
Stream StringArn The ARN of the CloudWatch Log Stream.
- role
Arn String The ARN of the IAM Role used to send application messages.
- id String
The ARN of the Kinesis Analytics Application.
- log
Stream stringArn The ARN of the CloudWatch Log Stream.
- role
Arn string The ARN of the IAM Role used to send application messages.
- id string
The ARN of the Kinesis Analytics Application.
- log_
stream_ strarn The ARN of the CloudWatch Log Stream.
- role_
arn str The ARN of the IAM Role used to send application messages.
- id str
The ARN of the Kinesis Analytics Application.
- log
Stream StringArn The ARN of the CloudWatch Log Stream.
- role
Arn String The ARN of the IAM Role used to send application messages.
- id String
The ARN of the Kinesis Analytics Application.
AnalyticsApplicationInputs
- Name
Prefix string The Name Prefix to use when creating an in-application stream.
- Schema
Analytics
Application Inputs Schema 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.
- Kinesis
Firehose AnalyticsApplication Inputs Kinesis Firehose The Kinesis Firehose configuration for the streaming source. Conflicts with
kinesis_stream
. See Kinesis Firehose below for more details.- Kinesis
Stream AnalyticsApplication Inputs Kinesis Stream The Kinesis Stream configuration for the streaming source. Conflicts with
kinesis_firehose
. See Kinesis Stream below for more details.- Parallelism
Analytics
Application Inputs Parallelism The number of Parallel in-application streams to create. See Parallelism below for more details.
- Processing
Configuration AnalyticsApplication Inputs Processing Configuration The Processing Configuration to transform records as they are received from the stream. See Processing Configuration below for more details.
- Starting
Position List<AnalyticsConfigurations Application Inputs Starting Position Configuration> The point at which the application starts processing records from the streaming source. See Starting Position Configuration below for more details.
- Stream
Names List<string>
- Name
Prefix string The Name Prefix to use when creating an in-application stream.
- Schema
Analytics
Application Inputs Schema 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.
- Kinesis
Firehose AnalyticsApplication Inputs Kinesis Firehose The Kinesis Firehose configuration for the streaming source. Conflicts with
kinesis_stream
. See Kinesis Firehose below for more details.- Kinesis
Stream AnalyticsApplication Inputs Kinesis Stream The Kinesis Stream configuration for the streaming source. Conflicts with
kinesis_firehose
. See Kinesis Stream below for more details.- Parallelism
Analytics
Application Inputs Parallelism The number of Parallel in-application streams to create. See Parallelism below for more details.
- Processing
Configuration AnalyticsApplication Inputs Processing Configuration The Processing Configuration to transform records as they are received from the stream. See Processing Configuration below for more details.
- Starting
Position []AnalyticsConfigurations Application Inputs Starting Position Configuration The point at which the application starts processing records from the streaming source. See Starting Position Configuration below for more details.
- Stream
Names []string
- name
Prefix String The Name Prefix to use when creating an in-application stream.
- schema
Analytics
Application Inputs Schema 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.
- kinesis
Firehose AnalyticsApplication Inputs Kinesis Firehose The Kinesis Firehose configuration for the streaming source. Conflicts with
kinesis_stream
. See Kinesis Firehose below for more details.- kinesis
Stream AnalyticsApplication Inputs Kinesis Stream The Kinesis Stream configuration for the streaming source. Conflicts with
kinesis_firehose
. See Kinesis Stream below for more details.- parallelism
Analytics
Application Inputs Parallelism The number of Parallel in-application streams to create. See Parallelism below for more details.
- processing
Configuration AnalyticsApplication Inputs Processing Configuration The Processing Configuration to transform records as they are received from the stream. See Processing Configuration below for more details.
- starting
Position List<AnalyticsConfigurations Application Inputs Starting Position Configuration> The point at which the application starts processing records from the streaming source. See Starting Position Configuration below for more details.
- stream
Names List<String>
- name
Prefix string The Name Prefix to use when creating an in-application stream.
- schema
Analytics
Application Inputs Schema 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.
- kinesis
Firehose AnalyticsApplication Inputs Kinesis Firehose The Kinesis Firehose configuration for the streaming source. Conflicts with
kinesis_stream
. See Kinesis Firehose below for more details.- kinesis
Stream AnalyticsApplication Inputs Kinesis Stream The Kinesis Stream configuration for the streaming source. Conflicts with
kinesis_firehose
. See Kinesis Stream below for more details.- parallelism
Analytics
Application Inputs Parallelism The number of Parallel in-application streams to create. See Parallelism below for more details.
- processing
Configuration AnalyticsApplication Inputs Processing Configuration The Processing Configuration to transform records as they are received from the stream. See Processing Configuration below for more details.
- starting
Position AnalyticsConfigurations Application Inputs Starting Position Configuration[] The point at which the application starts processing records from the streaming source. See Starting Position Configuration below for more details.
- stream
Names string[]
- name_
prefix str The Name Prefix to use when creating an in-application stream.
- schema
Analytics
Application Inputs Schema 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 AnalyticsApplication Inputs Kinesis Firehose The Kinesis Firehose configuration for the streaming source. Conflicts with
kinesis_stream
. See Kinesis Firehose below for more details.- kinesis_
stream AnalyticsApplication Inputs Kinesis Stream The Kinesis Stream configuration for the streaming source. Conflicts with
kinesis_firehose
. See Kinesis Stream below for more details.- parallelism
Analytics
Application Inputs Parallelism The number of Parallel in-application streams to create. See Parallelism below for more details.
- processing_
configuration AnalyticsApplication Inputs Processing Configuration The Processing Configuration to transform records as they are received from the stream. See Processing Configuration below for more details.
- starting_
position_ Sequence[Analyticsconfigurations Application Inputs Starting Position Configuration] 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]
- name
Prefix String The Name Prefix to use when creating an in-application stream.
- schema Property Map
The Schema format of the data in the streaming source. See Source Schema below for more details.
- id String
The ARN of the Kinesis Analytics Application.
- kinesis
Firehose Property Map The Kinesis Firehose configuration for the streaming source. Conflicts with
kinesis_stream
. See Kinesis Firehose below for more details.- kinesis
Stream 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.
- processing
Configuration Property Map The Processing Configuration to transform records as they are received from the stream. See Processing Configuration below for more details.
- starting
Position List<Property Map>Configurations The point at which the application starts processing records from the streaming source. See Starting Position Configuration below for more details.
- stream
Names List<String>
AnalyticsApplicationInputsKinesisFirehose
- Resource
Arn string The ARN of the Kinesis Firehose delivery stream.
- Role
Arn string The ARN of the IAM Role used to access the stream.
- Resource
Arn string The ARN of the Kinesis Firehose delivery stream.
- Role
Arn string The ARN of the IAM Role used to access the stream.
- resource
Arn String The ARN of the Kinesis Firehose delivery stream.
- role
Arn String The ARN of the IAM Role used to access the stream.
- resource
Arn string The ARN of the Kinesis Firehose delivery stream.
- role
Arn string The ARN of the IAM Role used to access the stream.
- resource_
arn str The ARN of the Kinesis Firehose delivery stream.
- role_
arn str The ARN of the IAM Role used to access the stream.
- resource
Arn String The ARN of the Kinesis Firehose delivery stream.
- role
Arn String The ARN of the IAM Role used to access the stream.
AnalyticsApplicationInputsKinesisStream
- Resource
Arn string The ARN of the Kinesis Stream.
- Role
Arn string The ARN of the IAM Role used to access the stream.
- Resource
Arn string The ARN of the Kinesis Stream.
- Role
Arn string The ARN of the IAM Role used to access the stream.
- resource
Arn String The ARN of the Kinesis Stream.
- role
Arn String The ARN of the IAM Role used to access the stream.
- resource
Arn string The ARN of the Kinesis Stream.
- role
Arn string The ARN of the IAM Role used to access the stream.
- resource_
arn str The ARN of the Kinesis Stream.
- role_
arn str The ARN of the IAM Role used to access the stream.
- resource
Arn String The ARN of the Kinesis Stream.
- role
Arn String The ARN of the IAM Role used to access the stream.
AnalyticsApplicationInputsParallelism
- 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
- Lambda
Analytics
Application Inputs Processing Configuration Lambda The Lambda function configuration. See Lambda below for more details.
- Lambda
Analytics
Application Inputs Processing Configuration Lambda The Lambda function configuration. See Lambda below for more details.
- lambda
Analytics
Application Inputs Processing Configuration Lambda The Lambda function configuration. See Lambda below for more details.
- lambda
Analytics
Application Inputs Processing Configuration Lambda The Lambda function configuration. See Lambda below for more details.
- lambda_
Analytics
Application Inputs Processing Configuration Lambda The Lambda function configuration. See Lambda below for more details.
- lambda Property Map
The Lambda function configuration. See Lambda below for more details.
AnalyticsApplicationInputsProcessingConfigurationLambda
- Resource
Arn string The ARN of the Lambda function.
- Role
Arn string The ARN of the IAM Role used to access the Lambda function.
- Resource
Arn string The ARN of the Lambda function.
- Role
Arn string The ARN of the IAM Role used to access the Lambda function.
- resource
Arn String The ARN of the Lambda function.
- role
Arn String The ARN of the IAM Role used to access the Lambda function.
- resource
Arn string The ARN of the Lambda function.
- role
Arn string The ARN of the IAM Role used to access the Lambda function.
- resource_
arn str The ARN of the Lambda function.
- role_
arn str The ARN of the IAM Role used to access the Lambda function.
- resource
Arn String The ARN of the Lambda function.
- role
Arn String The ARN of the IAM Role used to access the Lambda function.
AnalyticsApplicationInputsSchema
- Record
Columns List<AnalyticsApplication Inputs Schema Record Column> The Record Column mapping for the streaming source data element. See Record Columns below for more details.
- Record
Format AnalyticsApplication Inputs Schema Record Format The Record Format and mapping information to schematize a record. See Record Format below for more details.
- Record
Encoding string The Encoding of the record in the streaming source.
- Record
Columns []AnalyticsApplication Inputs Schema Record Column The Record Column mapping for the streaming source data element. See Record Columns below for more details.
- Record
Format AnalyticsApplication Inputs Schema Record Format The Record Format and mapping information to schematize a record. See Record Format below for more details.
- Record
Encoding string The Encoding of the record in the streaming source.
- record
Columns List<AnalyticsApplication Inputs Schema Record Column> The Record Column mapping for the streaming source data element. See Record Columns below for more details.
- record
Format AnalyticsApplication Inputs Schema Record Format The Record Format and mapping information to schematize a record. See Record Format below for more details.
- record
Encoding String The Encoding of the record in the streaming source.
- record
Columns AnalyticsApplication Inputs Schema Record Column[] The Record Column mapping for the streaming source data element. See Record Columns below for more details.
- record
Format AnalyticsApplication Inputs Schema Record Format The Record Format and mapping information to schematize a record. See Record Format below for more details.
- record
Encoding string The Encoding of the record in the streaming source.
- record_
columns Sequence[AnalyticsApplication Inputs Schema Record Column] The Record Column mapping for the streaming source data element. See Record Columns below for more details.
- record_
format AnalyticsApplication Inputs Schema Record Format 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.
- record
Columns List<Property Map> The Record Column mapping for the streaming source data element. See Record Columns below for more details.
- record
Format Property Map The Record Format and mapping information to schematize a record. See Record Format below for more details.
- record
Encoding String The Encoding of the record in the streaming source.
AnalyticsApplicationInputsSchemaRecordColumn
AnalyticsApplicationInputsSchemaRecordFormat
- Mapping
Parameters AnalyticsApplication Inputs Schema Record Format Mapping Parameters The Mapping Information for the record format. See Mapping Parameters below for more details.
- Record
Format stringType The type of Record Format. Can be
CSV
orJSON
.
- Mapping
Parameters AnalyticsApplication Inputs Schema Record Format Mapping Parameters The Mapping Information for the record format. See Mapping Parameters below for more details.
- Record
Format stringType The type of Record Format. Can be
CSV
orJSON
.
- mapping
Parameters AnalyticsApplication Inputs Schema Record Format Mapping Parameters The Mapping Information for the record format. See Mapping Parameters below for more details.
- record
Format StringType The type of Record Format. Can be
CSV
orJSON
.
- mapping
Parameters AnalyticsApplication Inputs Schema Record Format Mapping Parameters The Mapping Information for the record format. See Mapping Parameters below for more details.
- record
Format stringType The type of Record Format. Can be
CSV
orJSON
.
- mapping_
parameters AnalyticsApplication Inputs Schema Record Format Mapping Parameters The Mapping Information for the record format. See Mapping Parameters below for more details.
- record_
format_ strtype The type of Record Format. Can be
CSV
orJSON
.
- mapping
Parameters Property Map The Mapping Information for the record format. See Mapping Parameters below for more details.
- record
Format StringType The type of Record Format. Can be
CSV
orJSON
.
AnalyticsApplicationInputsSchemaRecordFormatMappingParameters
- Csv
Analytics
Application Inputs Schema Record Format Mapping Parameters Csv Mapping information when the record format uses delimiters. See CSV Mapping Parameters below for more details.
- Json
Analytics
Application Inputs Schema Record Format Mapping Parameters Json Mapping information when JSON is the record format on the streaming source. See JSON Mapping Parameters below for more details.
- Csv
Analytics
Application Inputs Schema Record Format Mapping Parameters Csv Mapping information when the record format uses delimiters. See CSV Mapping Parameters below for more details.
- Json
Analytics
Application Inputs Schema Record Format Mapping Parameters Json Mapping information when JSON is the record format on the streaming source. See JSON Mapping Parameters below for more details.
- csv
Analytics
Application Inputs Schema Record Format Mapping Parameters Csv Mapping information when the record format uses delimiters. See CSV Mapping Parameters below for more details.
- json
Analytics
Application Inputs Schema Record Format Mapping Parameters Json Mapping information when JSON is the record format on the streaming source. See JSON Mapping Parameters below for more details.
- csv
Analytics
Application Inputs Schema Record Format Mapping Parameters Csv Mapping information when the record format uses delimiters. See CSV Mapping Parameters below for more details.
- json
Analytics
Application Inputs Schema Record Format Mapping Parameters Json Mapping information when JSON is the record format on the streaming source. See JSON Mapping Parameters below for more details.
- csv
Analytics
Application Inputs Schema Record Format Mapping Parameters Csv Mapping information when the record format uses delimiters. See CSV Mapping Parameters below for more details.
- json
Analytics
Application Inputs Schema Record Format Mapping Parameters Json 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
- Record
Column stringDelimiter The Column Delimiter.
- Record
Row stringDelimiter The Row Delimiter.
- Record
Column stringDelimiter The Column Delimiter.
- Record
Row stringDelimiter The Row Delimiter.
- record
Column StringDelimiter The Column Delimiter.
- record
Row StringDelimiter The Row Delimiter.
- record
Column stringDelimiter The Column Delimiter.
- record
Row stringDelimiter The Row Delimiter.
- record_
column_ strdelimiter The Column Delimiter.
- record_
row_ strdelimiter The Row Delimiter.
- record
Column StringDelimiter The Column Delimiter.
- record
Row StringDelimiter The Row Delimiter.
AnalyticsApplicationInputsSchemaRecordFormatMappingParametersJson
- Record
Row stringPath Path to the top-level parent that contains the records.
- Record
Row stringPath Path to the top-level parent that contains the records.
- record
Row StringPath Path to the top-level parent that contains the records.
- record
Row stringPath Path to the top-level parent that contains the records.
- record_
row_ strpath Path to the top-level parent that contains the records.
- record
Row StringPath Path to the top-level parent that contains the records.
AnalyticsApplicationInputsStartingPositionConfiguration
- Starting
Position string The starting position on the stream. Valid values:
LAST_STOPPED_POINT
,NOW
,TRIM_HORIZON
.
- Starting
Position string The starting position on the stream. Valid values:
LAST_STOPPED_POINT
,NOW
,TRIM_HORIZON
.
- starting
Position String The starting position on the stream. Valid values:
LAST_STOPPED_POINT
,NOW
,TRIM_HORIZON
.
- starting
Position 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
.
- starting
Position String The starting position on the stream. Valid values:
LAST_STOPPED_POINT
,NOW
,TRIM_HORIZON
.
AnalyticsApplicationOutput
- Name string
The Name of the in-application stream.
- Schema
Analytics
Application Output Schema 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.
- Kinesis
Firehose AnalyticsApplication Output Kinesis Firehose The Kinesis Firehose configuration for the destination stream. Conflicts with
kinesis_stream
. See Kinesis Firehose below for more details.- Kinesis
Stream AnalyticsApplication Output Kinesis Stream The Kinesis Stream configuration for the destination stream. Conflicts with
kinesis_firehose
. See Kinesis Stream below for more details.- Lambda
Analytics
Application Output Lambda The Lambda function destination. See Lambda below for more details.
- Name string
The Name of the in-application stream.
- Schema
Analytics
Application Output Schema 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.
- Kinesis
Firehose AnalyticsApplication Output Kinesis Firehose The Kinesis Firehose configuration for the destination stream. Conflicts with
kinesis_stream
. See Kinesis Firehose below for more details.- Kinesis
Stream AnalyticsApplication Output Kinesis Stream The Kinesis Stream configuration for the destination stream. Conflicts with
kinesis_firehose
. See Kinesis Stream below for more details.- Lambda
Analytics
Application Output Lambda The Lambda function destination. See Lambda below for more details.
- name String
The Name of the in-application stream.
- schema
Analytics
Application Output Schema 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.
- kinesis
Firehose AnalyticsApplication Output Kinesis Firehose The Kinesis Firehose configuration for the destination stream. Conflicts with
kinesis_stream
. See Kinesis Firehose below for more details.- kinesis
Stream AnalyticsApplication Output Kinesis Stream The Kinesis Stream configuration for the destination stream. Conflicts with
kinesis_firehose
. See Kinesis Stream below for more details.- lambda
Analytics
Application Output Lambda The Lambda function destination. See Lambda below for more details.
- name string
The Name of the in-application stream.
- schema
Analytics
Application Output Schema 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.
- kinesis
Firehose AnalyticsApplication Output Kinesis Firehose The Kinesis Firehose configuration for the destination stream. Conflicts with
kinesis_stream
. See Kinesis Firehose below for more details.- kinesis
Stream AnalyticsApplication Output Kinesis Stream The Kinesis Stream configuration for the destination stream. Conflicts with
kinesis_firehose
. See Kinesis Stream below for more details.- lambda
Analytics
Application Output Lambda The Lambda function destination. See Lambda below for more details.
- name str
The Name of the in-application stream.
- schema
Analytics
Application Output Schema 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 AnalyticsApplication Output Kinesis Firehose The Kinesis Firehose configuration for the destination stream. Conflicts with
kinesis_stream
. See Kinesis Firehose below for more details.- kinesis_
stream AnalyticsApplication Output Kinesis Stream The Kinesis Stream configuration for the destination stream. Conflicts with
kinesis_firehose
. See Kinesis Stream below for more details.- lambda_
Analytics
Application Output Lambda The Lambda function destination. See Lambda below for more details.
- name String
The Name of the in-application stream.
- schema Property Map
The Schema format of the data written to the destination. See Destination Schema below for more details.
- id String
The ARN of the Kinesis Analytics Application.
- kinesis
Firehose Property Map The Kinesis Firehose configuration for the destination stream. Conflicts with
kinesis_stream
. See Kinesis Firehose below for more details.- kinesis
Stream 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
- Resource
Arn string The ARN of the Kinesis Firehose delivery stream.
- Role
Arn string The ARN of the IAM Role used to access the stream.
- Resource
Arn string The ARN of the Kinesis Firehose delivery stream.
- Role
Arn string The ARN of the IAM Role used to access the stream.
- resource
Arn String The ARN of the Kinesis Firehose delivery stream.
- role
Arn String The ARN of the IAM Role used to access the stream.
- resource
Arn string The ARN of the Kinesis Firehose delivery stream.
- role
Arn string The ARN of the IAM Role used to access the stream.
- resource_
arn str The ARN of the Kinesis Firehose delivery stream.
- role_
arn str The ARN of the IAM Role used to access the stream.
- resource
Arn String The ARN of the Kinesis Firehose delivery stream.
- role
Arn String The ARN of the IAM Role used to access the stream.
AnalyticsApplicationOutputKinesisStream
- Resource
Arn string The ARN of the Kinesis Stream.
- Role
Arn string The ARN of the IAM Role used to access the stream.
- Resource
Arn string The ARN of the Kinesis Stream.
- Role
Arn string The ARN of the IAM Role used to access the stream.
- resource
Arn String The ARN of the Kinesis Stream.
- role
Arn String The ARN of the IAM Role used to access the stream.
- resource
Arn string The ARN of the Kinesis Stream.
- role
Arn string The ARN of the IAM Role used to access the stream.
- resource_
arn str The ARN of the Kinesis Stream.
- role_
arn str The ARN of the IAM Role used to access the stream.
- resource
Arn String The ARN of the Kinesis Stream.
- role
Arn String The ARN of the IAM Role used to access the stream.
AnalyticsApplicationOutputLambda
- Resource
Arn string The ARN of the Lambda function.
- Role
Arn string The ARN of the IAM Role used to access the Lambda function.
- Resource
Arn string The ARN of the Lambda function.
- Role
Arn string The ARN of the IAM Role used to access the Lambda function.
- resource
Arn String The ARN of the Lambda function.
- role
Arn String The ARN of the IAM Role used to access the Lambda function.
- resource
Arn string The ARN of the Lambda function.
- role
Arn string The ARN of the IAM Role used to access the Lambda function.
- resource_
arn str The ARN of the Lambda function.
- role_
arn str The ARN of the IAM Role used to access the Lambda function.
- resource
Arn String The ARN of the Lambda function.
- role
Arn String The ARN of the IAM Role used to access the Lambda function.
AnalyticsApplicationOutputSchema
- Record
Format stringType The Format Type of the records on the output stream. Can be
CSV
orJSON
.
- Record
Format stringType The Format Type of the records on the output stream. Can be
CSV
orJSON
.
- record
Format StringType The Format Type of the records on the output stream. Can be
CSV
orJSON
.
- record
Format stringType The Format Type of the records on the output stream. Can be
CSV
orJSON
.
- record_
format_ strtype The Format Type of the records on the output stream. Can be
CSV
orJSON
.
- record
Format StringType The Format Type of the records on the output stream. Can be
CSV
orJSON
.
AnalyticsApplicationReferenceDataSources
- S3
Analytics
Application Reference Data Sources S3 The S3 configuration for the reference data source. See S3 Reference below for more details.
- Schema
Analytics
Application Reference Data Sources Schema The Schema format of the data in the streaming source. See Source Schema below for more details.
- Table
Name string The in-application Table Name.
- Id string
The ARN of the Kinesis Analytics Application.
- S3
Analytics
Application Reference Data Sources S3 The S3 configuration for the reference data source. See S3 Reference below for more details.
- Schema
Analytics
Application Reference Data Sources Schema The Schema format of the data in the streaming source. See Source Schema below for more details.
- Table
Name string The in-application Table Name.
- Id string
The ARN of the Kinesis Analytics Application.
- s3
Analytics
Application Reference Data Sources S3 The S3 configuration for the reference data source. See S3 Reference below for more details.
- schema
Analytics
Application Reference Data Sources Schema The Schema format of the data in the streaming source. See Source Schema below for more details.
- table
Name String The in-application Table Name.
- id String
The ARN of the Kinesis Analytics Application.
- s3
Analytics
Application Reference Data Sources S3 The S3 configuration for the reference data source. See S3 Reference below for more details.
- schema
Analytics
Application Reference Data Sources Schema The Schema format of the data in the streaming source. See Source Schema below for more details.
- table
Name string The in-application Table Name.
- id string
The ARN of the Kinesis Analytics Application.
- s3
Analytics
Application Reference Data Sources S3 The S3 configuration for the reference data source. See S3 Reference below for more details.
- schema
Analytics
Application Reference Data Sources Schema The Schema format of the data in the streaming source. See Source Schema below for more details.
- table_
name str The in-application Table Name.
- id str
The ARN of the Kinesis Analytics Application.
- s3 Property Map
The S3 configuration for the reference data source. See S3 Reference below for more details.
- schema Property Map
The Schema format of the data in the streaming source. See Source Schema below for more details.
- table
Name String The in-application Table Name.
- id String
The ARN of the Kinesis Analytics Application.
AnalyticsApplicationReferenceDataSourcesS3
- bucket_
arn str The S3 Bucket ARN.
- file_
key str The File Key name containing reference data.
- role_
arn str The ARN of the IAM Role used to send application messages.
AnalyticsApplicationReferenceDataSourcesSchema
- Record
Columns List<AnalyticsApplication Reference Data Sources Schema Record Column> The Record Column mapping for the streaming source data element. See Record Columns below for more details.
- Record
Format AnalyticsApplication Reference Data Sources Schema Record Format The Record Format and mapping information to schematize a record. See Record Format below for more details.
- Record
Encoding string The Encoding of the record in the streaming source.
- Record
Columns []AnalyticsApplication Reference Data Sources Schema Record Column The Record Column mapping for the streaming source data element. See Record Columns below for more details.
- Record
Format AnalyticsApplication Reference Data Sources Schema Record Format The Record Format and mapping information to schematize a record. See Record Format below for more details.
- Record
Encoding string The Encoding of the record in the streaming source.
- record
Columns List<AnalyticsApplication Reference Data Sources Schema Record Column> The Record Column mapping for the streaming source data element. See Record Columns below for more details.
- record
Format AnalyticsApplication Reference Data Sources Schema Record Format The Record Format and mapping information to schematize a record. See Record Format below for more details.
- record
Encoding String The Encoding of the record in the streaming source.
- record
Columns AnalyticsApplication Reference Data Sources Schema Record Column[] The Record Column mapping for the streaming source data element. See Record Columns below for more details.
- record
Format AnalyticsApplication Reference Data Sources Schema Record Format The Record Format and mapping information to schematize a record. See Record Format below for more details.
- record
Encoding string The Encoding of the record in the streaming source.
- record_
columns Sequence[AnalyticsApplication Reference Data Sources Schema Record Column] The Record Column mapping for the streaming source data element. See Record Columns below for more details.
- record_
format AnalyticsApplication Reference Data Sources Schema Record Format 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.
- record
Columns List<Property Map> The Record Column mapping for the streaming source data element. See Record Columns below for more details.
- record
Format Property Map The Record Format and mapping information to schematize a record. See Record Format below for more details.
- record
Encoding String The Encoding of the record in the streaming source.
AnalyticsApplicationReferenceDataSourcesSchemaRecordColumn
AnalyticsApplicationReferenceDataSourcesSchemaRecordFormat
- Mapping
Parameters AnalyticsApplication Reference Data Sources Schema Record Format Mapping Parameters The Mapping Information for the record format. See Mapping Parameters below for more details.
- Record
Format stringType The type of Record Format. Can be
CSV
orJSON
.
- Mapping
Parameters AnalyticsApplication Reference Data Sources Schema Record Format Mapping Parameters The Mapping Information for the record format. See Mapping Parameters below for more details.
- Record
Format stringType The type of Record Format. Can be
CSV
orJSON
.
- mapping
Parameters AnalyticsApplication Reference Data Sources Schema Record Format Mapping Parameters The Mapping Information for the record format. See Mapping Parameters below for more details.
- record
Format StringType The type of Record Format. Can be
CSV
orJSON
.
- mapping
Parameters AnalyticsApplication Reference Data Sources Schema Record Format Mapping Parameters The Mapping Information for the record format. See Mapping Parameters below for more details.
- record
Format stringType The type of Record Format. Can be
CSV
orJSON
.
- mapping_
parameters AnalyticsApplication Reference Data Sources Schema Record Format Mapping Parameters The Mapping Information for the record format. See Mapping Parameters below for more details.
- record_
format_ strtype The type of Record Format. Can be
CSV
orJSON
.
- mapping
Parameters Property Map The Mapping Information for the record format. See Mapping Parameters below for more details.
- record
Format StringType The type of Record Format. Can be
CSV
orJSON
.
AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParameters
- Csv
Analytics
Application Reference Data Sources Schema Record Format Mapping Parameters Csv Mapping information when the record format uses delimiters. See CSV Mapping Parameters below for more details.
- Json
Analytics
Application Reference Data Sources Schema Record Format Mapping Parameters Json Mapping information when JSON is the record format on the streaming source. See JSON Mapping Parameters below for more details.
- Csv
Analytics
Application Reference Data Sources Schema Record Format Mapping Parameters Csv Mapping information when the record format uses delimiters. See CSV Mapping Parameters below for more details.
- Json
Analytics
Application Reference Data Sources Schema Record Format Mapping Parameters Json Mapping information when JSON is the record format on the streaming source. See JSON Mapping Parameters below for more details.
- csv
Analytics
Application Reference Data Sources Schema Record Format Mapping Parameters Csv Mapping information when the record format uses delimiters. See CSV Mapping Parameters below for more details.
- json
Analytics
Application Reference Data Sources Schema Record Format Mapping Parameters Json Mapping information when JSON is the record format on the streaming source. See JSON Mapping Parameters below for more details.
- csv
Analytics
Application Reference Data Sources Schema Record Format Mapping Parameters Csv Mapping information when the record format uses delimiters. See CSV Mapping Parameters below for more details.
- json
Analytics
Application Reference Data Sources Schema Record Format Mapping Parameters Json Mapping information when JSON is the record format on the streaming source. See JSON Mapping Parameters below for more details.
- csv
Analytics
Application Reference Data Sources Schema Record Format Mapping Parameters Csv Mapping information when the record format uses delimiters. See CSV Mapping Parameters below for more details.
- json
Analytics
Application Reference Data Sources Schema Record Format Mapping Parameters Json 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
- Record
Column stringDelimiter The Column Delimiter.
- Record
Row stringDelimiter The Row Delimiter.
- Record
Column stringDelimiter The Column Delimiter.
- Record
Row stringDelimiter The Row Delimiter.
- record
Column StringDelimiter The Column Delimiter.
- record
Row StringDelimiter The Row Delimiter.
- record
Column stringDelimiter The Column Delimiter.
- record
Row stringDelimiter The Row Delimiter.
- record_
column_ strdelimiter The Column Delimiter.
- record_
row_ strdelimiter The Row Delimiter.
- record
Column StringDelimiter The Column Delimiter.
- record
Row StringDelimiter The Row Delimiter.
AnalyticsApplicationReferenceDataSourcesSchemaRecordFormatMappingParametersJson
- Record
Row stringPath Path to the top-level parent that contains the records.
- Record
Row stringPath Path to the top-level parent that contains the records.
- record
Row StringPath Path to the top-level parent that contains the records.
- record
Row stringPath Path to the top-level parent that contains the records.
- record_
row_ strpath Path to the top-level parent that contains the records.
- record
Row StringPath Path to the top-level parent that contains the records.
Import
Kinesis Analytics Application can be imported by using ARN, e.g.,
$ pulumi import aws:kinesis/analyticsApplication:AnalyticsApplication example arn:aws:kinesisanalytics:us-west-2:1234567890:application/example
Package Details
- Repository
- AWS Classic pulumi/pulumi-aws
- License
- Apache-2.0
- Notes
This Pulumi package is based on the
aws
Terraform Provider.