com.tuplejump.kafka.connect.cassandra

CassandraSinkTask

class CassandraSinkTask extends SinkTask with CassandraTask

A Cassandra SinkTask run by a Kafka WorkerSinkTask.

Linear Supertypes
CassandraTask, CassandraClusterApi, ConnectorLike, Logging, SinkTask, Task, AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. CassandraSinkTask
  2. CassandraTask
  3. CassandraClusterApi
  4. ConnectorLike
  5. Logging
  6. SinkTask
  7. Task
  8. AnyRef
  9. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Instance Constructors

  1. new CassandraSinkTask()

Value Members

  1. final def !=(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  2. final def !=(arg0: Any): Boolean

    Definition Classes
    Any
  3. final def ##(): Int

    Definition Classes
    AnyRef → Any
  4. final def ==(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  5. final def ==(arg0: Any): Boolean

    Definition Classes
    Any
  6. final def asInstanceOf[T0]: T0

    Definition Classes
    Any
  7. def clone(): AnyRef

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  8. var cluster: Option[CassandraCluster]

    Attributes
    protected
    Definition Classes
    CassandraTask
  9. var configT: Map[String, String]

    Attributes
    protected
    Definition Classes
    ConnectorLike
  10. def configure(conf: Map[String, String], taskClass: Class[_ <: Task]): Unit

    Reads in the user provided configuration for a given source or sink.

    Reads in the user provided configuration for a given source or sink. Fails fast on org.apache.kafka.connect.connector.Connector start if not valid.

    Because user params can be a mine field on bugs farther down stream we attempt to catch as many up front as we can.

    conf

    the user config

    Attributes
    protected
    Definition Classes
    ConnectorLike
    Exceptions thrown
    org.apache.kafka.common.config.ConfigException

    if requirements not met

  11. final def eq(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  12. def equals(arg0: Any): Boolean

    Definition Classes
    AnyRef → Any
  13. def finalize(): Unit

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  14. def flush(offsets: Map[TopicPartition, OffsetAndMetadata]): Unit

    This method is not relevant as we insert every received record in Cassandra.

    This method is not relevant as we insert every received record in Cassandra.

    Definition Classes
    CassandraSinkTask → SinkTask
  15. final def getClass(): Class[_]

    Definition Classes
    AnyRef → Any
  16. def hashCode(): Int

    Definition Classes
    AnyRef → Any
  17. def initialize(arg0: SinkTaskContext): Unit

    Definition Classes
    SinkTask
  18. final def isInstanceOf[T0]: Boolean

    Definition Classes
    Any
  19. def localNode(rpcAddressColumn: String, listenAddressColumn: String): ResultSet

    Attributes
    protected
    Definition Classes
    CassandraClusterApi
  20. val logger: Logger

    Attributes
    protected
    Definition Classes
    Logging
  21. lazy val metadata: Metadata

    Attributes
    protected
    Definition Classes
    CassandraClusterApi
  22. final def ne(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  23. final def notify(): Unit

    Definition Classes
    AnyRef
  24. final def notifyAll(): Unit

    Definition Classes
    AnyRef
  25. def onPartitionsAssigned(arg0: Collection[TopicPartition]): Unit

    Definition Classes
    SinkTask
  26. def onPartitionsRevoked(arg0: Collection[TopicPartition]): Unit

    Definition Classes
    SinkTask
  27. def partitioner: String

    Returns the FQCN of the partitioner, which will NOT be on the classpath.

    Returns the FQCN of the partitioner, which will NOT be on the classpath. org.apache.cassandra.dht.{Murmur3Partitioner, RandomPartitioner...}

    Attributes
    protected
    Definition Classes
    CassandraClusterApi
  28. def put(records: Collection[SinkRecord]): Unit

    Writes records from Kafka to Cassandra asynchronously and non-blocking.

    Writes records from Kafka to Cassandra asynchronously and non-blocking.

    Definition Classes
    CassandraSinkTask → SinkTask
  29. var routes: List[Route]

    Attributes
    protected
    Definition Classes
    ConnectorLike
  30. def session: Session

    Definition Classes
    CassandraTask → CassandraClusterApi
  31. def start(taskConfig: Map[String, String]): Unit

    Restarts call stop() then start().

    Restarts call stop() then start().

    Definition Classes
    CassandraSinkTask → CassandraTask → SinkTask → Task
  32. def stop(): Unit

    Definition Classes
    CassandraTask → Task
  33. final def synchronized[T0](arg0: ⇒ T0): T0

    Definition Classes
    AnyRef
  34. def tableFor(ns: Route): Option[TableMetadata]

    Returns table metadata if the keyspace and table exist in the Cassandra cluster being connected to, and the coordinates have been configured.

    Returns table metadata if the keyspace and table exist in the Cassandra cluster being connected to, and the coordinates have been configured.

    Attributes
    protected
    Definition Classes
    CassandraClusterApi
    Exceptions thrown
    org.apache.kafka.connect.errors.ConnectException

    The datastax java driver returns null Keyspace or null Table if either do not exist, so we alert the user application via ConnectException and do not proceed, to not propagate NPEs.

  35. val taskClass: Class[_ <: Task]

    Attributes
    protected
    Definition Classes
    CassandraSinkTask → CassandraTask
  36. var taskConfig: TaskConfig

    The parsed values based on the config map passed in on start.

    The parsed values based on the config map passed in on start. The Kafka mutable java map is converted to a scala immutable, parsed based on whether this is for a source or sink or task thereof, then validated by type.

    If a source task, this will have one or more SourceConfigs. If a sink task, this will have one or more SinkConfigs. Currently we hand each task a unique topic to keyspace and table mapping. Roadmap: Parallism partitioning strategy configurable by user.

    Attributes
    protected
    Definition Classes
    CassandraTask
  37. var taskStrategy: TaskStrategy

    Initialized as the default, user can override.

    Initialized as the default, user can override.

    Attributes
    protected
    Definition Classes
    ConnectorLike
  38. def toString(): String

    Definition Classes
    AnyRef → Any
  39. final val version: String

    Attributes
    protected
    Definition Classes
    ConnectorLike
  40. final def wait(): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  41. final def wait(arg0: Long, arg1: Int): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  42. final def wait(arg0: Long): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Inherited from CassandraTask

Inherited from CassandraClusterApi

Inherited from ConnectorLike

Inherited from Logging

Inherited from SinkTask

Inherited from Task

Inherited from AnyRef

Inherited from Any

Ungrouped