public class KinesisUtils
extends Object
Constructor and Description |
---|
KinesisUtils() |
Modifier and Type | Method and Description |
---|---|
static JavaReceiverInputDStream<byte[]> |
createStream(JavaStreamingContext jssc,
String kinesisAppName,
String streamName,
String endpointUrl,
String regionName,
com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream initialPositionInStream,
Duration checkpointInterval,
StorageLevel storageLevel)
Deprecated.
Use KinesisInputDStream.builder instead. Since 2.2.0.
|
static <T> JavaReceiverInputDStream<T> |
createStream(JavaStreamingContext jssc,
String kinesisAppName,
String streamName,
String endpointUrl,
String regionName,
com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream initialPositionInStream,
Duration checkpointInterval,
StorageLevel storageLevel,
Function<com.amazonaws.services.kinesis.model.Record,T> messageHandler,
Class<T> recordClass)
Deprecated.
Use KinesisInputDStream.builder instead. Since 2.2.0.
|
static <T> JavaReceiverInputDStream<T> |
createStream(JavaStreamingContext jssc,
String kinesisAppName,
String streamName,
String endpointUrl,
String regionName,
com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream initialPositionInStream,
Duration checkpointInterval,
StorageLevel storageLevel,
Function<com.amazonaws.services.kinesis.model.Record,T> messageHandler,
Class<T> recordClass,
String awsAccessKeyId,
String awsSecretKey)
Deprecated.
Use KinesisInputDStream.builder instead. Since 2.2.0.
|
static <T> JavaReceiverInputDStream<T> |
createStream(JavaStreamingContext jssc,
String kinesisAppName,
String streamName,
String endpointUrl,
String regionName,
com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream initialPositionInStream,
Duration checkpointInterval,
StorageLevel storageLevel,
Function<com.amazonaws.services.kinesis.model.Record,T> messageHandler,
Class<T> recordClass,
String awsAccessKeyId,
String awsSecretKey,
String stsAssumeRoleArn,
String stsSessionName,
String stsExternalId)
Deprecated.
Use KinesisInputDStream.builder instead. Since 2.2.0.
|
static JavaReceiverInputDStream<byte[]> |
createStream(JavaStreamingContext jssc,
String kinesisAppName,
String streamName,
String endpointUrl,
String regionName,
com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream initialPositionInStream,
Duration checkpointInterval,
StorageLevel storageLevel,
String awsAccessKeyId,
String awsSecretKey)
Deprecated.
Use KinesisInputDStream.builder instead. Since 2.2.0.
|
static ReceiverInputDStream<byte[]> |
createStream(StreamingContext ssc,
String kinesisAppName,
String streamName,
String endpointUrl,
String regionName,
com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream initialPositionInStream,
Duration checkpointInterval,
StorageLevel storageLevel)
Deprecated.
Use KinesisInputDStream.builder instead. Since 2.2.0.
|
static <T> ReceiverInputDStream<T> |
createStream(StreamingContext ssc,
String kinesisAppName,
String streamName,
String endpointUrl,
String regionName,
com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream initialPositionInStream,
Duration checkpointInterval,
StorageLevel storageLevel,
scala.Function1<com.amazonaws.services.kinesis.model.Record,T> messageHandler,
scala.reflect.ClassTag<T> evidence$1)
Deprecated.
Use KinesisInputDStream.builder instead. Since 2.2.0.
|
static <T> ReceiverInputDStream<T> |
createStream(StreamingContext ssc,
String kinesisAppName,
String streamName,
String endpointUrl,
String regionName,
com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream initialPositionInStream,
Duration checkpointInterval,
StorageLevel storageLevel,
scala.Function1<com.amazonaws.services.kinesis.model.Record,T> messageHandler,
String awsAccessKeyId,
String awsSecretKey,
scala.reflect.ClassTag<T> evidence$2)
Deprecated.
Use KinesisInputDStream.builder instead. Since 2.2.0.
|
static <T> ReceiverInputDStream<T> |
createStream(StreamingContext ssc,
String kinesisAppName,
String streamName,
String endpointUrl,
String regionName,
com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream initialPositionInStream,
Duration checkpointInterval,
StorageLevel storageLevel,
scala.Function1<com.amazonaws.services.kinesis.model.Record,T> messageHandler,
String awsAccessKeyId,
String awsSecretKey,
String stsAssumeRoleArn,
String stsSessionName,
String stsExternalId,
scala.reflect.ClassTag<T> evidence$3)
Deprecated.
Use KinesisInputDStream.builder instead. Since 2.2.0.
|
static ReceiverInputDStream<byte[]> |
createStream(StreamingContext ssc,
String kinesisAppName,
String streamName,
String endpointUrl,
String regionName,
com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream initialPositionInStream,
Duration checkpointInterval,
StorageLevel storageLevel,
String awsAccessKeyId,
String awsSecretKey)
Deprecated.
Use KinesisInputDStream.builder instead. Since 2.2.0.
|
public static <T> ReceiverInputDStream<T> createStream(StreamingContext ssc, String kinesisAppName, String streamName, String endpointUrl, String regionName, com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream initialPositionInStream, Duration checkpointInterval, StorageLevel storageLevel, scala.Function1<com.amazonaws.services.kinesis.model.Record,T> messageHandler, scala.reflect.ClassTag<T> evidence$1)
ssc
- StreamingContext objectkinesisAppName
- Kinesis application name used by the Kinesis Client Library
(KCL) to update DynamoDBstreamName
- Kinesis stream nameendpointUrl
- Url of Kinesis service (e.g., https://kinesis.us-east-1.amazonaws.com)regionName
- Name of region used by the Kinesis Client Library (KCL) to update
DynamoDB (lease coordination and checkpointing) and CloudWatch (metrics)initialPositionInStream
- In the absence of Kinesis checkpoint info, this is the
worker's initial starting position in the stream.
The values are either the beginning of the stream
per Kinesis' limit of 24 hours
(InitialPositionInStream.TRIM_HORIZON) or
the tip of the stream (InitialPositionInStream.LATEST).checkpointInterval
- Checkpoint interval for Kinesis checkpointing.
See the Kinesis Spark Streaming documentation for more
details on the different types of checkpoints.storageLevel
- Storage level to use for storing the received objects.
StorageLevel.MEMORY_AND_DISK_2 is recommended.messageHandler
- A custom message handler that can generate a generic output from a
Kinesis Record
, which contains both message data, and metadata.
evidence$1
- (undocumented)public static <T> ReceiverInputDStream<T> createStream(StreamingContext ssc, String kinesisAppName, String streamName, String endpointUrl, String regionName, com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream initialPositionInStream, Duration checkpointInterval, StorageLevel storageLevel, scala.Function1<com.amazonaws.services.kinesis.model.Record,T> messageHandler, String awsAccessKeyId, String awsSecretKey, scala.reflect.ClassTag<T> evidence$2)
ssc
- StreamingContext objectkinesisAppName
- Kinesis application name used by the Kinesis Client Library
(KCL) to update DynamoDBstreamName
- Kinesis stream nameendpointUrl
- Url of Kinesis service (e.g., https://kinesis.us-east-1.amazonaws.com)regionName
- Name of region used by the Kinesis Client Library (KCL) to update
DynamoDB (lease coordination and checkpointing) and CloudWatch (metrics)initialPositionInStream
- In the absence of Kinesis checkpoint info, this is the
worker's initial starting position in the stream.
The values are either the beginning of the stream
per Kinesis' limit of 24 hours
(InitialPositionInStream.TRIM_HORIZON) or
the tip of the stream (InitialPositionInStream.LATEST).checkpointInterval
- Checkpoint interval for Kinesis checkpointing.
See the Kinesis Spark Streaming documentation for more
details on the different types of checkpoints.storageLevel
- Storage level to use for storing the received objects.
StorageLevel.MEMORY_AND_DISK_2 is recommended.messageHandler
- A custom message handler that can generate a generic output from a
Kinesis Record
, which contains both message data, and metadata.awsAccessKeyId
- AWS AccessKeyId (if null, will use DefaultAWSCredentialsProviderChain)awsSecretKey
- AWS SecretKey (if null, will use DefaultAWSCredentialsProviderChain)
evidence$2
- (undocumented)public static <T> ReceiverInputDStream<T> createStream(StreamingContext ssc, String kinesisAppName, String streamName, String endpointUrl, String regionName, com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream initialPositionInStream, Duration checkpointInterval, StorageLevel storageLevel, scala.Function1<com.amazonaws.services.kinesis.model.Record,T> messageHandler, String awsAccessKeyId, String awsSecretKey, String stsAssumeRoleArn, String stsSessionName, String stsExternalId, scala.reflect.ClassTag<T> evidence$3)
ssc
- StreamingContext objectkinesisAppName
- Kinesis application name used by the Kinesis Client Library
(KCL) to update DynamoDBstreamName
- Kinesis stream nameendpointUrl
- Url of Kinesis service (e.g., https://kinesis.us-east-1.amazonaws.com)regionName
- Name of region used by the Kinesis Client Library (KCL) to update
DynamoDB (lease coordination and checkpointing) and CloudWatch (metrics)initialPositionInStream
- In the absence of Kinesis checkpoint info, this is the
worker's initial starting position in the stream.
The values are either the beginning of the stream
per Kinesis' limit of 24 hours
(InitialPositionInStream.TRIM_HORIZON) or
the tip of the stream (InitialPositionInStream.LATEST).checkpointInterval
- Checkpoint interval for Kinesis checkpointing.
See the Kinesis Spark Streaming documentation for more
details on the different types of checkpoints.storageLevel
- Storage level to use for storing the received objects.
StorageLevel.MEMORY_AND_DISK_2 is recommended.messageHandler
- A custom message handler that can generate a generic output from a
Kinesis Record
, which contains both message data, and metadata.awsAccessKeyId
- AWS AccessKeyId (if null, will use DefaultAWSCredentialsProviderChain)awsSecretKey
- AWS SecretKey (if null, will use DefaultAWSCredentialsProviderChain)stsAssumeRoleArn
- ARN of IAM role to assume when using STS sessions to read from
Kinesis stream.stsSessionName
- Name to uniquely identify STS sessions if multiple principals assume
the same role.stsExternalId
- External ID that can be used to validate against the assumed IAM role's
trust policy.
evidence$3
- (undocumented)public static ReceiverInputDStream<byte[]> createStream(StreamingContext ssc, String kinesisAppName, String streamName, String endpointUrl, String regionName, com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream initialPositionInStream, Duration checkpointInterval, StorageLevel storageLevel)
ssc
- StreamingContext objectkinesisAppName
- Kinesis application name used by the Kinesis Client Library
(KCL) to update DynamoDBstreamName
- Kinesis stream nameendpointUrl
- Url of Kinesis service (e.g., https://kinesis.us-east-1.amazonaws.com)regionName
- Name of region used by the Kinesis Client Library (KCL) to update
DynamoDB (lease coordination and checkpointing) and CloudWatch (metrics)initialPositionInStream
- In the absence of Kinesis checkpoint info, this is the
worker's initial starting position in the stream.
The values are either the beginning of the stream
per Kinesis' limit of 24 hours
(InitialPositionInStream.TRIM_HORIZON) or
the tip of the stream (InitialPositionInStream.LATEST).checkpointInterval
- Checkpoint interval for Kinesis checkpointing.
See the Kinesis Spark Streaming documentation for more
details on the different types of checkpoints.storageLevel
- Storage level to use for storing the received objects.
StorageLevel.MEMORY_AND_DISK_2 is recommended.
public static ReceiverInputDStream<byte[]> createStream(StreamingContext ssc, String kinesisAppName, String streamName, String endpointUrl, String regionName, com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream initialPositionInStream, Duration checkpointInterval, StorageLevel storageLevel, String awsAccessKeyId, String awsSecretKey)
ssc
- StreamingContext objectkinesisAppName
- Kinesis application name used by the Kinesis Client Library
(KCL) to update DynamoDBstreamName
- Kinesis stream nameendpointUrl
- Url of Kinesis service (e.g., https://kinesis.us-east-1.amazonaws.com)regionName
- Name of region used by the Kinesis Client Library (KCL) to update
DynamoDB (lease coordination and checkpointing) and CloudWatch (metrics)initialPositionInStream
- In the absence of Kinesis checkpoint info, this is the
worker's initial starting position in the stream.
The values are either the beginning of the stream
per Kinesis' limit of 24 hours
(InitialPositionInStream.TRIM_HORIZON) or
the tip of the stream (InitialPositionInStream.LATEST).checkpointInterval
- Checkpoint interval for Kinesis checkpointing.
See the Kinesis Spark Streaming documentation for more
details on the different types of checkpoints.storageLevel
- Storage level to use for storing the received objects.
StorageLevel.MEMORY_AND_DISK_2 is recommended.awsAccessKeyId
- AWS AccessKeyId (if null, will use DefaultAWSCredentialsProviderChain)awsSecretKey
- AWS SecretKey (if null, will use DefaultAWSCredentialsProviderChain)
public static <T> JavaReceiverInputDStream<T> createStream(JavaStreamingContext jssc, String kinesisAppName, String streamName, String endpointUrl, String regionName, com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream initialPositionInStream, Duration checkpointInterval, StorageLevel storageLevel, Function<com.amazonaws.services.kinesis.model.Record,T> messageHandler, Class<T> recordClass)
jssc
- Java StreamingContext objectkinesisAppName
- Kinesis application name used by the Kinesis Client Library
(KCL) to update DynamoDBstreamName
- Kinesis stream nameendpointUrl
- Url of Kinesis service (e.g., https://kinesis.us-east-1.amazonaws.com)regionName
- Name of region used by the Kinesis Client Library (KCL) to update
DynamoDB (lease coordination and checkpointing) and CloudWatch (metrics)initialPositionInStream
- In the absence of Kinesis checkpoint info, this is the
worker's initial starting position in the stream.
The values are either the beginning of the stream
per Kinesis' limit of 24 hours
(InitialPositionInStream.TRIM_HORIZON) or
the tip of the stream (InitialPositionInStream.LATEST).checkpointInterval
- Checkpoint interval for Kinesis checkpointing.
See the Kinesis Spark Streaming documentation for more
details on the different types of checkpoints.storageLevel
- Storage level to use for storing the received objects.
StorageLevel.MEMORY_AND_DISK_2 is recommended.messageHandler
- A custom message handler that can generate a generic output from a
Kinesis Record
, which contains both message data, and metadata.recordClass
- Class of the records in DStream
public static <T> JavaReceiverInputDStream<T> createStream(JavaStreamingContext jssc, String kinesisAppName, String streamName, String endpointUrl, String regionName, com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream initialPositionInStream, Duration checkpointInterval, StorageLevel storageLevel, Function<com.amazonaws.services.kinesis.model.Record,T> messageHandler, Class<T> recordClass, String awsAccessKeyId, String awsSecretKey)
jssc
- Java StreamingContext objectkinesisAppName
- Kinesis application name used by the Kinesis Client Library
(KCL) to update DynamoDBstreamName
- Kinesis stream nameendpointUrl
- Url of Kinesis service (e.g., https://kinesis.us-east-1.amazonaws.com)regionName
- Name of region used by the Kinesis Client Library (KCL) to update
DynamoDB (lease coordination and checkpointing) and CloudWatch (metrics)initialPositionInStream
- In the absence of Kinesis checkpoint info, this is the
worker's initial starting position in the stream.
The values are either the beginning of the stream
per Kinesis' limit of 24 hours
(InitialPositionInStream.TRIM_HORIZON) or
the tip of the stream (InitialPositionInStream.LATEST).checkpointInterval
- Checkpoint interval for Kinesis checkpointing.
See the Kinesis Spark Streaming documentation for more
details on the different types of checkpoints.storageLevel
- Storage level to use for storing the received objects.
StorageLevel.MEMORY_AND_DISK_2 is recommended.messageHandler
- A custom message handler that can generate a generic output from a
Kinesis Record
, which contains both message data, and metadata.recordClass
- Class of the records in DStreamawsAccessKeyId
- AWS AccessKeyId (if null, will use DefaultAWSCredentialsProviderChain)awsSecretKey
- AWS SecretKey (if null, will use DefaultAWSCredentialsProviderChain)
public static <T> JavaReceiverInputDStream<T> createStream(JavaStreamingContext jssc, String kinesisAppName, String streamName, String endpointUrl, String regionName, com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream initialPositionInStream, Duration checkpointInterval, StorageLevel storageLevel, Function<com.amazonaws.services.kinesis.model.Record,T> messageHandler, Class<T> recordClass, String awsAccessKeyId, String awsSecretKey, String stsAssumeRoleArn, String stsSessionName, String stsExternalId)
jssc
- Java StreamingContext objectkinesisAppName
- Kinesis application name used by the Kinesis Client Library
(KCL) to update DynamoDBstreamName
- Kinesis stream nameendpointUrl
- Url of Kinesis service (e.g., https://kinesis.us-east-1.amazonaws.com)regionName
- Name of region used by the Kinesis Client Library (KCL) to update
DynamoDB (lease coordination and checkpointing) and CloudWatch (metrics)initialPositionInStream
- In the absence of Kinesis checkpoint info, this is the
worker's initial starting position in the stream.
The values are either the beginning of the stream
per Kinesis' limit of 24 hours
(InitialPositionInStream.TRIM_HORIZON) or
the tip of the stream (InitialPositionInStream.LATEST).checkpointInterval
- Checkpoint interval for Kinesis checkpointing.
See the Kinesis Spark Streaming documentation for more
details on the different types of checkpoints.storageLevel
- Storage level to use for storing the received objects.
StorageLevel.MEMORY_AND_DISK_2 is recommended.messageHandler
- A custom message handler that can generate a generic output from a
Kinesis Record
, which contains both message data, and metadata.recordClass
- Class of the records in DStreamawsAccessKeyId
- AWS AccessKeyId (if null, will use DefaultAWSCredentialsProviderChain)awsSecretKey
- AWS SecretKey (if null, will use DefaultAWSCredentialsProviderChain)stsAssumeRoleArn
- ARN of IAM role to assume when using STS sessions to read from
Kinesis stream.stsSessionName
- Name to uniquely identify STS sessions if multiple princpals assume
the same role.stsExternalId
- External ID that can be used to validate against the assumed IAM role's
trust policy.
public static JavaReceiverInputDStream<byte[]> createStream(JavaStreamingContext jssc, String kinesisAppName, String streamName, String endpointUrl, String regionName, com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream initialPositionInStream, Duration checkpointInterval, StorageLevel storageLevel)
jssc
- Java StreamingContext objectkinesisAppName
- Kinesis application name used by the Kinesis Client Library
(KCL) to update DynamoDBstreamName
- Kinesis stream nameendpointUrl
- Url of Kinesis service (e.g., https://kinesis.us-east-1.amazonaws.com)regionName
- Name of region used by the Kinesis Client Library (KCL) to update
DynamoDB (lease coordination and checkpointing) and CloudWatch (metrics)initialPositionInStream
- In the absence of Kinesis checkpoint info, this is the
worker's initial starting position in the stream.
The values are either the beginning of the stream
per Kinesis' limit of 24 hours
(InitialPositionInStream.TRIM_HORIZON) or
the tip of the stream (InitialPositionInStream.LATEST).checkpointInterval
- Checkpoint interval for Kinesis checkpointing.
See the Kinesis Spark Streaming documentation for more
details on the different types of checkpoints.storageLevel
- Storage level to use for storing the received objects.
StorageLevel.MEMORY_AND_DISK_2 is recommended.
public static JavaReceiverInputDStream<byte[]> createStream(JavaStreamingContext jssc, String kinesisAppName, String streamName, String endpointUrl, String regionName, com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream initialPositionInStream, Duration checkpointInterval, StorageLevel storageLevel, String awsAccessKeyId, String awsSecretKey)
jssc
- Java StreamingContext objectkinesisAppName
- Kinesis application name used by the Kinesis Client Library
(KCL) to update DynamoDBstreamName
- Kinesis stream nameendpointUrl
- Url of Kinesis service (e.g., https://kinesis.us-east-1.amazonaws.com)regionName
- Name of region used by the Kinesis Client Library (KCL) to update
DynamoDB (lease coordination and checkpointing) and CloudWatch (metrics)initialPositionInStream
- In the absence of Kinesis checkpoint info, this is the
worker's initial starting position in the stream.
The values are either the beginning of the stream
per Kinesis' limit of 24 hours
(InitialPositionInStream.TRIM_HORIZON) or
the tip of the stream (InitialPositionInStream.LATEST).checkpointInterval
- Checkpoint interval for Kinesis checkpointing.
See the Kinesis Spark Streaming documentation for more
details on the different types of checkpoints.storageLevel
- Storage level to use for storing the received objects.
StorageLevel.MEMORY_AND_DISK_2 is recommended.awsAccessKeyId
- AWS AccessKeyId (if null, will use DefaultAWSCredentialsProviderChain)awsSecretKey
- AWS SecretKey (if null, will use DefaultAWSCredentialsProviderChain)