Modifier and Type | Method and Description |
---|---|
AwsCredentials |
AwsCredentialsJsonDeserializer.deserialize(org.apache.flink.shaded.jackson2.com.fasterxml.jackson.core.JsonParser jsonParser,
org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.DeserializationContext deserializationContext) |
Modifier and Type | Method and Description |
---|---|
GenericKinesisEgressSpec.Builder |
GenericKinesisEgressSpec.Builder.withAwsCredentials(AwsCredentials awsCredentials) |
Modifier and Type | Method and Description |
---|---|
RoutableKinesisIngressSpec.Builder |
RoutableKinesisIngressSpec.Builder.withAwsCredentials(AwsCredentials awsCredentials) |
Modifier and Type | Class and Description |
---|---|
static class |
AwsCredentials.BasicAwsCredentials |
static class |
AwsCredentials.DefaultAwsCredentials |
static class |
AwsCredentials.ProfileAwsCredentials |
Modifier and Type | Method and Description |
---|---|
static AwsCredentials |
AwsCredentials.basic(java.lang.String accessKeyId,
java.lang.String secretAccessKey)
Specifies the AWS credentials directly with provided access key ID and secret access key
strings.
|
static AwsCredentials |
AwsCredentials.fromDefaultProviderChain()
Consults AWS's default provider chain to determine the AWS credentials.
|
static AwsCredentials |
AwsCredentials.profile(java.lang.String profileName)
Specifies the AWS credentials using an AWS configuration profile.
|
static AwsCredentials |
AwsCredentials.profile(java.lang.String profileName,
java.lang.String profilePath)
Specifies the AWS credentials using an AWS configuration profile, along with the profile's
configuration path.
|
Modifier and Type | Method and Description |
---|---|
AwsCredentials |
KinesisEgressSpec.awsCredentials() |
Modifier and Type | Method and Description |
---|---|
KinesisEgressBuilder<T> |
KinesisEgressBuilder.withAwsCredentials(AwsCredentials awsCredentials)
The AWS credentials to use.
|
Modifier and Type | Method and Description |
---|---|
OptionalProperty<AwsCredentials> |
KinesisIngressSpec.awsCredentials() |
Modifier and Type | Method and Description |
---|---|
KinesisIngressBuilder<T> |
KinesisIngressBuilder.withAwsCredentials(AwsCredentials awsCredentials)
The AWS credentials to use.
|
Copyright © 2014–2025 The Apache Software Foundation. All rights reserved.