org.apache.spark.streaming.kinesis.KinesisInputDStream
Create a new instance of KinesisInputDStream with configured parameters and using the default message handler, which returns Array[Byte].
Create a new instance of KinesisInputDStream with configured parameters and using the default message handler, which returns Array[Byte].
Instance of KinesisInputDStream constructed with configured parameters
Create a new instance of KinesisInputDStream with configured parameters and the provided message handler.
Create a new instance of KinesisInputDStream with configured parameters and the provided message handler.
Function converting Record instances read by the KCL to DStream type T
Instance of KinesisInputDStream constructed with configured parameters
Sets the KCL application name to use when checkpointing state to DynamoDB.
Sets the KCL application name to use when checkpointing state to DynamoDB. This is a required parameter.
Value to use for the KCL app name (used when creating the DynamoDB checkpoint table and when writing metrics to CloudWatch)
Reference to this KinesisInputDStream.Builder
Sets how often the KCL application state is checkpointed to DynamoDB.
Sets how often the KCL application state is checkpointed to DynamoDB. Defaults to the Spark Streaming batch interval if no custom value is specified.
Duration specifying how often the KCL state should be checkpointed to DynamoDB.
Reference to this KinesisInputDStream.Builder
Sets the SparkAWSCredentials to use for authenticating to the AWS CloudWatch endpoint.
Sets the SparkAWSCredentials to use for authenticating to the AWS CloudWatch endpoint. Will use the same credentials used for AWS Kinesis if no custom value is set.
SparkAWSCredentials to use for CloudWatch authentication
Sets the SparkAWSCredentials to use for authenticating to the AWS DynamoDB endpoint.
Sets the SparkAWSCredentials to use for authenticating to the AWS DynamoDB endpoint. Will use the same credentials used for AWS Kinesis if no custom value is set.
SparkAWSCredentials to use for DynamoDB authentication
Sets the AWS Kinesis endpoint URL.
Sets the AWS Kinesis endpoint URL. Defaults to "https://kinesis.us-east-1.amazonaws.com" if no custom value is specified
Kinesis endpoint URL to use
Reference to this KinesisInputDStream.Builder
Sets the initial position data is read from in the Kinesis stream.
Sets the initial position data is read from in the Kinesis stream. Defaults to KinesisInitialPositions.Latest if no custom value is specified.
KinesisInitialPosition value specifying where Spark Streaming will start reading records in the Kinesis stream from
Reference to this KinesisInputDStream.Builder
Sets the SparkAWSCredentials to use for authenticating to the AWS Kinesis endpoint.
Sets the SparkAWSCredentials to use for authenticating to the AWS Kinesis endpoint. Defaults to DefaultCredentialsProvider if no custom value is specified.
SparkAWSCredentials to use for Kinesis authentication
Sets the AWS region to construct clients for.
Sets the AWS region to construct clients for. Defaults to "us-east-1" if no custom value is specified.
Name of AWS region to use (e.g. "us-west-2")
Reference to this KinesisInputDStream.Builder
Sets the storage level of the blocks for the DStream created.
Sets the storage level of the blocks for the DStream created. Defaults to StorageLevel.MEMORY_AND_DISK_2 if no custom value is specified.
StorageLevel to use for the DStream data blocks
Reference to this KinesisInputDStream.Builder
Sets the name of the Kinesis stream that the DStream will read from.
Sets the name of the Kinesis stream that the DStream will read from. This is a required parameter.
Name of Kinesis stream that the DStream will read from
Reference to this KinesisInputDStream.Builder
Sets the StreamingContext that will be used to construct the Kinesis DStream.
Sets the StreamingContext that will be used to construct the Kinesis DStream. This is a required parameter.
JavaStreamingContext used to construct Kinesis DStreams
Reference to this KinesisInputDStream.Builder
Sets the StreamingContext that will be used to construct the Kinesis DStream.
Sets the StreamingContext that will be used to construct the Kinesis DStream. This is a required parameter.
StreamingContext used to construct Kinesis DStreams
Reference to this KinesisInputDStream.Builder
Sets the initial position data is read from in the Kinesis stream.
Sets the initial position data is read from in the Kinesis stream. Defaults to InitialPositionInStream.LATEST if no custom value is specified. This function would be removed when we deprecate the KinesisUtils.
InitialPositionInStream value specifying where Spark Streaming will start reading records in the Kinesis stream from
Reference to this KinesisInputDStream.Builder
(Since version 2.3.0) use initialPosition(initialPosition: KinesisInitialPosition)
Builder for KinesisInputDStream instances.
2.2.0