Class

pl.touk.nussknacker.engine.avro.source

SpecificRecordKafkaAvroSourceFactory

Related Doc: package source

Permalink

class SpecificRecordKafkaAvroSourceFactory[V <: SpecificRecord] extends KafkaAvroSourceFactory[Any, V]

Source factory for specific records - mainly generated from schema.

Linear Supertypes
KafkaAvroSourceFactory[Any, V], KafkaAvroBaseTransformer[FlinkSource[ConsumerRecord[Any, V]]], WithCachedTopicsExistenceValidator, TopicsExistenceValidator, SingleInputGenericNodeTransformation[FlinkSource[ConsumerRecord[Any, V]]], GenericNodeTransformation[FlinkSource[ConsumerRecord[Any, V]]], FlinkSourceFactory[ConsumerRecord[Any, V]], SourceFactory[ConsumerRecord[Any, V]], Component, Serializable, Serializable, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. SpecificRecordKafkaAvroSourceFactory
  2. KafkaAvroSourceFactory
  3. KafkaAvroBaseTransformer
  4. WithCachedTopicsExistenceValidator
  5. TopicsExistenceValidator
  6. SingleInputGenericNodeTransformation
  7. GenericNodeTransformation
  8. FlinkSourceFactory
  9. SourceFactory
  10. Component
  11. Serializable
  12. Serializable
  13. AnyRef
  14. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new SpecificRecordKafkaAvroSourceFactory(schemaRegistryProvider: SchemaRegistryProvider, processObjectDependencies: ProcessObjectDependencies, timestampAssigner: Option[TimestampWatermarkHandler[ConsumerRecord[Any, V]]])(implicit arg0: ClassTag[V])

    Permalink

Type Members

  1. type DefinedParameter = DefinedSingleParameter

    Permalink
    Definition Classes
    SingleInputGenericNodeTransformation → GenericNodeTransformation
  2. case class FinalResults extends TransformationStepResult with Product with Serializable

    Permalink
    Definition Classes
    GenericNodeTransformation
  3. type InputContext = ValidationContext

    Permalink
    Definition Classes
    SingleInputGenericNodeTransformation → GenericNodeTransformation
  4. case class NextParameters extends TransformationStepResult with Product with Serializable

    Permalink
    Definition Classes
    GenericNodeTransformation
  5. type NodeTransformationDefinition = PartialFunction[TransformationStep, TransformationStepResult]

    Permalink
    Definition Classes
    GenericNodeTransformation
  6. type State = KafkaAvroSourceFactoryState[Any, V, DefinedParameter]

    Permalink
    Definition Classes
    KafkaAvroSourceFactory → GenericNodeTransformation
  7. case class TransformationStep extends Product with Serializable

    Permalink
    Definition Classes
    GenericNodeTransformation
  8. sealed trait TransformationStepResult extends AnyRef

    Permalink
    Definition Classes
    GenericNodeTransformation
  9. type WithError[V] = WriterT[Id, List[ProcessCompilationError], V]

    Permalink
    Definition Classes
    KafkaAvroBaseTransformer

Value Members

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

    Permalink
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int

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

    Permalink
    Definition Classes
    AnyRef → Any
  4. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  5. def clazz: Class[ConsumerRecord[Any, V]]

    Permalink
    Definition Classes
    FlinkSourceFactory → SourceFactory
  6. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @HotSpotIntrinsicCandidate() @throws( ... )
  7. def contextTransformation(context: ValidationContext, dependencies: List[NodeDependencyValue])(implicit nodeId: NodeId): NodeTransformationDefinition

    Permalink
    Definition Classes
    SpecificRecordKafkaAvroSourceFactoryKafkaAvroSourceFactory → GenericNodeTransformation
  8. def createSource(params: Map[String, Any], dependencies: List[NodeDependencyValue], finalState: Option[State], preparedTopics: List[PreparedKafkaTopic], kafkaConfig: KafkaConfig, deserializationSchema: KafkaDeserializationSchema[ConsumerRecord[Any, V]], timestampAssigner: Option[TimestampWatermarkHandler[ConsumerRecord[Any, V]]], formatter: RecordFormatter, flinkContextInitializer: FlinkContextInitializer[ConsumerRecord[Any, V]]): KafkaSource[ConsumerRecord[Any, V]]

    Permalink

    Basic implementation of new source creation.

    Basic implementation of new source creation. Override this method to create custom KafkaSource.

    Attributes
    protected
    Definition Classes
    KafkaAvroSourceFactory
  9. def determineSchemaAndType(schemaDeterminer: AvroSchemaDeterminer, paramName: Option[String])(implicit nodeId: NodeId): Validated[ProcessCompilationError, (Option[RuntimeSchemaData], TypingResult)]

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaAvroSourceFactory
  10. final def eq(arg0: AnyRef): Boolean

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

    Permalink
    Definition Classes
    AnyRef → Any
  12. def extractPreparedTopic(params: Map[String, Any]): PreparedKafkaTopic

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaAvroBaseTransformer
  13. def extractVersionOption(params: Map[String, Any]): SchemaVersionOption

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaAvroBaseTransformer
  14. val fallbackVersionOptionParam: Parameter

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaAvroBaseTransformer
  15. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
    Annotations
    @HotSpotIntrinsicCandidate()
  16. def getTopicParam(implicit nodeId: NodeId): WithError[Parameter]

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaAvroBaseTransformer
  17. def getVersionParam(versions: List[Integer]): Parameter

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaAvroBaseTransformer
  18. def getVersionParam(preparedTopic: PreparedKafkaTopic)(implicit nodeId: NodeId): WithError[Parameter]

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaAvroBaseTransformer
  19. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
    Annotations
    @HotSpotIntrinsicCandidate()
  20. def implementation(params: Map[String, Any], dependencies: List[NodeDependencyValue], finalState: Option[State]): FlinkSource[ConsumerRecord[Any, V]]

    Permalink
    Definition Classes
    KafkaAvroSourceFactory → GenericNodeTransformation
  21. def initialParameters: List[Parameter]

    Permalink
    Definition Classes
    SpecificRecordKafkaAvroSourceFactoryKafkaAvroBaseTransformer → GenericNodeTransformation
  22. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  23. val kafkaConfig: KafkaConfig

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaAvroBaseTransformer → WithCachedTopicsExistenceValidator
  24. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  25. def nextSteps(context: ValidationContext, dependencies: List[NodeDependencyValue])(implicit nodeId: NodeId): NodeTransformationDefinition

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaAvroSourceFactory
  26. def nodeDependencies: List[NodeDependency]

    Permalink
    Definition Classes
    KafkaAvroSourceFactory → GenericNodeTransformation
  27. final def notify(): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @HotSpotIntrinsicCandidate()
  28. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @HotSpotIntrinsicCandidate()
  29. val nullTopicOption: FixedExpressionValue

    Permalink
    Definition Classes
    KafkaAvroBaseTransformer
  30. def paramsDeterminedAfterSchema: List[Parameter]

    Permalink
  31. def parseVersionOption(versionOptionName: String): SchemaVersionOption

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaAvroBaseTransformer
  32. def prepareKafkaConfig: KafkaConfig

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaAvroBaseTransformer
  33. def prepareKeySchemaDeterminer(preparedTopic: PreparedKafkaTopic): AvroSchemaDeterminer

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaAvroBaseTransformer
  34. def prepareSourceFinalErrors(context: ValidationContext, dependencies: List[NodeDependencyValue], parameters: List[(String, DefinedParameter)], errors: List[ProcessCompilationError])(implicit nodeId: NodeId): FinalResults

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaAvroSourceFactory
  35. def prepareSourceFinalResults(preparedTopic: PreparedKafkaTopic, valueValidationResult: Validated[ProcessCompilationError, (Option[RuntimeSchemaData], TypingResult)], context: ValidationContext, dependencies: List[NodeDependencyValue], parameters: List[(String, DefinedParameter)], errors: List[ProcessCompilationError])(implicit nodeId: NodeId): FinalResults

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaAvroSourceFactory
  36. def prepareTopic(topic: String): PreparedKafkaTopic

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaAvroBaseTransformer
  37. def prepareValueSchemaDeterminer(preparedTopic: PreparedKafkaTopic, version: SchemaVersionOption): AvroSchemaDeterminer

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaAvroBaseTransformer
  38. val processObjectDependencies: ProcessObjectDependencies

    Permalink
  39. def schemaParamStep(implicit nodeId: NodeId): NodeTransformationDefinition

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaAvroBaseTransformer
  40. lazy val schemaRegistryClient: SchemaRegistryClient

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaAvroBaseTransformer
  41. val schemaRegistryProvider: SchemaRegistryProvider

    Permalink

    - provides a set of strategies for serialization and deserialization while event processing and/or testing.

    - provides a set of strategies for serialization and deserialization while event processing and/or testing.

    Definition Classes
    KafkaAvroSourceFactoryKafkaAvroBaseTransformer
  42. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  43. def toString(): String

    Permalink
    Definition Classes
    AnyRef → Any
  44. val topicParamName: String

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaAvroBaseTransformer
  45. def topicParamStep(implicit nodeId: NodeId): NodeTransformationDefinition

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaAvroBaseTransformer
  46. def topicSelectionStrategy: TopicSelectionStrategy

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaAvroBaseTransformer
  47. def typedDependency[C](list: List[NodeDependencyValue])(implicit arg0: ClassTag[C]): C

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaAvroBaseTransformer
  48. final def validateTopic(topic: String): Validated[TopicExistenceValidationException, String]

    Permalink
    Definition Classes
    TopicsExistenceValidator
  49. final def validateTopics(topics: List[String]): Validated[TopicExistenceValidationException, List[String]]

    Permalink
    Definition Classes
    WithCachedTopicsExistenceValidator → TopicsExistenceValidator
  50. lazy val validator: CachedTopicsExistenceValidator

    Permalink
    Attributes
    protected
    Definition Classes
    WithCachedTopicsExistenceValidator
  51. final def wait(arg0: Long, arg1: Int): Unit

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  53. final def wait(): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Deprecated Value Members

  1. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @Deprecated @deprecated @throws( classOf[java.lang.Throwable] )
    Deprecated

    (Since version ) see corresponding Javadoc for more information.

Inherited from KafkaAvroSourceFactory[Any, V]

Inherited from KafkaAvroBaseTransformer[FlinkSource[ConsumerRecord[Any, V]]]

Inherited from WithCachedTopicsExistenceValidator

Inherited from TopicsExistenceValidator

Inherited from SingleInputGenericNodeTransformation[FlinkSource[ConsumerRecord[Any, V]]]

Inherited from GenericNodeTransformation[FlinkSource[ConsumerRecord[Any, V]]]

Inherited from FlinkSourceFactory[ConsumerRecord[Any, V]]

Inherited from SourceFactory[ConsumerRecord[Any, V]]

Inherited from Component

Inherited from Serializable

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped