IN
- input typepublic class CassandraSink<IN> extends Object
Modifier and Type | Class and Description |
---|---|
static class |
CassandraSink.CassandraPojoSinkBuilder<IN>
Builder for a
CassandraPojoSink . |
static class |
CassandraSink.CassandraRowSinkBuilder
Builder for a
CassandraRowSink . |
static class |
CassandraSink.CassandraScalaProductSinkBuilder<IN extends scala.Product>
Builder for a
CassandraScalaProductSink . |
static class |
CassandraSink.CassandraSinkBuilder<IN>
Builder for a
CassandraSink . |
static class |
CassandraSink.CassandraTupleSinkBuilder<IN extends Tuple>
Builder for a
CassandraTupleSink . |
Modifier and Type | Method and Description |
---|---|
static <IN> CassandraSink.CassandraSinkBuilder<IN> |
addSink(org.apache.flink.streaming.api.scala.DataStream<IN> input)
Writes a DataStream into a Cassandra database.
|
static <IN> CassandraSink.CassandraSinkBuilder<IN> |
addSink(DataStream<IN> input)
Writes a DataStream into a Cassandra database.
|
CassandraSink<IN> |
disableChaining()
Turns off chaining for this operator so thread co-location will not be used as an
optimization.
|
CassandraSink<IN> |
name(String name)
Sets the name of this sink.
|
CassandraSink<IN> |
setParallelism(int parallelism)
Sets the parallelism for this sink.
|
CassandraSink<IN> |
setUidHash(String uidHash)
Sets an user provided hash for this operator.
|
CassandraSink<IN> |
slotSharingGroup(String slotSharingGroup)
Sets the slot sharing group of this operation.
|
CassandraSink<IN> |
uid(String uid)
Sets an ID for this operator.
|
public CassandraSink<IN> name(String name)
@PublicEvolving public CassandraSink<IN> uid(String uid)
The specified ID is used to assign the same operator ID across job submissions (for example when starting a job from a savepoint).
Important: this ID needs to be unique per transformation and job. Otherwise, job submission will fail.
uid
- The unique user-specified ID of this transformation.@PublicEvolving public CassandraSink<IN> setUidHash(String uidHash)
The user provided hash is an alternative to the generated hashes, that is considered when identifying an operator through the default hash mechanics fails (e.g. because of changes between Flink versions).
Important: this should be used as a workaround or for trouble shooting. The provided hash needs to be unique per transformation and job. Otherwise, job submission will fail. Furthermore, you cannot assign user-specified hash to intermediate nodes in an operator chain and trying so will let your job fail.
A use case for this is in migration between Flink versions or changing the jobs in a way that changes the automatically generated hashes. In this case, providing the previous hashes directly through this method (e.g. obtained from old logs) can help to reestablish a lost mapping from states to their target operator.
uidHash
- The user provided hash for this operator. This will become the JobVertexID,
which is shown in the logs and web ui.public CassandraSink<IN> setParallelism(int parallelism)
parallelism
- The parallelism for this sink.public CassandraSink<IN> disableChaining()
Chaining can be turned off for the whole job by StreamExecutionEnvironment.disableOperatorChaining()
however it is not advised for performance considerations.
public CassandraSink<IN> slotSharingGroup(String slotSharingGroup)
Operations inherit the slot sharing group of input operations if all input operations are in the same slot sharing group and no slot sharing group was explicitly specified.
Initially an operation is in the default slot sharing group. An operation can be put into
the default group explicitly by setting the slot sharing group to "default"
.
slotSharingGroup
- The slot sharing group name.public static <IN> CassandraSink.CassandraSinkBuilder<IN> addSink(org.apache.flink.streaming.api.scala.DataStream<IN> input)
IN
- input typeinput
- input DataStreampublic static <IN> CassandraSink.CassandraSinkBuilder<IN> addSink(DataStream<IN> input)
IN
- input typeinput
- input DataStreamCopyright © 2014–2023 The Apache Software Foundation. All rights reserved.