IN
- Type of the elements emitted by this sink, it must extend Product
public class CassandraScalaProductSink<IN extends scala.Product> extends AbstractCassandraTupleSink<IN>
SinkFunction.Context<T>
cluster, log, session
Constructor and Description |
---|
CassandraScalaProductSink(String insertQuery,
ClusterBuilder builder) |
Modifier and Type | Method and Description |
---|---|
protected Object[] |
extract(IN record) |
open, send
close, createSession, initializeState, invoke, snapshotState
getIterationRuntimeContext, getRuntimeContext, setRuntimeContext
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
invoke
public CassandraScalaProductSink(String insertQuery, ClusterBuilder builder)
protected Object[] extract(IN record)
extract
in class AbstractCassandraTupleSink<IN extends scala.Product>
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.