Index

A B C D E F G H I K L N O P R S T U V W 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

A

accept(T) - Method in interface co.decodable.sdk.pipeline.testing.KeyedPipelineTestContext.ThrowingConsumer
 
accept(T) - Method in interface co.decodable.sdk.pipeline.testing.PipelineTestContext.ThrowingConsumer
 
add(KeyedStreamRecord<K, V>) - Method in interface co.decodable.sdk.pipeline.testing.KeyedDecodableStream
Adds the given keyed stream record to this stream.
add(StreamRecord<T>) - Method in interface co.decodable.sdk.pipeline.testing.DecodableStream
Adds the given stream record to this stream.

B

bootstrapServers() - Method in class co.decodable.sdk.pipeline.testing.TestEnvironment
Returns the Kafka bootstrap server(s) configured for this environment.
build() - Method in interface co.decodable.sdk.pipeline.DecodableStreamSinkBuilder
Returns a new DecodableStreamSink for the given configuration.
build() - Method in interface co.decodable.sdk.pipeline.DecodableStreamSourceBuilder
Returns a new DecodableStreamSource for the given configuration.
build() - Method in class co.decodable.sdk.pipeline.testing.TestEnvironment.Builder
Returns a new TestEnvironment for the given configuration.
builder() - Static method in interface co.decodable.sdk.pipeline.DecodableStreamSink
Returns a builder for creating a new DecodableStreamSink.
builder() - Static method in interface co.decodable.sdk.pipeline.DecodableStreamSource
Returns a builder for creating a new DecodableStreamSource.
builder() - Static method in class co.decodable.sdk.pipeline.testing.TestEnvironment
Returns a builder for creating a new TestEnvironment.
Builder() - Constructor for class co.decodable.sdk.pipeline.testing.TestEnvironment.Builder
 

C

C - Enum constant in enum class co.decodable.sdk.pipeline.DecodableDebeziumEnvelope.CDC_OP_TYPE
 
checkAllKeyFieldsPresentInValue(Class<?>, Class<?>) - Static method in class co.decodable.sdk.pipeline.serde.SerializationConstraintsValidator
 
close() - Method in class co.decodable.sdk.pipeline.testing.KeyedPipelineTestContext
 
close() - Method in class co.decodable.sdk.pipeline.testing.PipelineTestContext
 
co.decodable.sdk.pipeline - package co.decodable.sdk.pipeline
An SDK for implementing Apache Flink jobs and running them on Decodable.
co.decodable.sdk.pipeline.exception - package co.decodable.sdk.pipeline.exception
 
co.decodable.sdk.pipeline.metadata - package co.decodable.sdk.pipeline.metadata
Annotations for linking custom pipelines to managed Decodable streams.
co.decodable.sdk.pipeline.serde - package co.decodable.sdk.pipeline.serde
 
co.decodable.sdk.pipeline.testing - package co.decodable.sdk.pipeline.testing
Infrastructure and utilities for (integration) testing custom Decodable pipelines.
co.decodable.sdk.pipeline.util - package co.decodable.sdk.pipeline.util
Miscellaneous utilities.
createTime() - Method in interface co.decodable.sdk.pipeline.DecodableSecret
Returns the creation time of the secret.
createWriter(Sink.InitContext) - Method in interface co.decodable.sdk.pipeline.DecodableStreamSink
Custom Metrics - Search tag in package co.decodable.sdk.pipeline
Section

D

D - Enum constant in enum class co.decodable.sdk.pipeline.DecodableDebeziumEnvelope.CDC_OP_TYPE
 
DecodableAppendStreamRecord<K,V> - Class in co.decodable.sdk.pipeline
Abstract base class to represent one record as a key-value pair in a Decodable append stream.
DecodableAppendStreamRecord() - Constructor for class co.decodable.sdk.pipeline.DecodableAppendStreamRecord
 
DecodableAppendStreamRecord(K, V) - Constructor for class co.decodable.sdk.pipeline.DecodableAppendStreamRecord
 
DecodableAppendStreamRecord(V) - Constructor for class co.decodable.sdk.pipeline.DecodableAppendStreamRecord
 
DecodableChangeStreamRecord<K,V> - Class in co.decodable.sdk.pipeline
Abstract base class to represent one record as a key-value pair in a Decodable change stream.
DecodableChangeStreamRecord() - Constructor for class co.decodable.sdk.pipeline.DecodableChangeStreamRecord
 
DecodableChangeStreamRecord(K, V) - Constructor for class co.decodable.sdk.pipeline.DecodableChangeStreamRecord
 
DecodableDebeziumEnvelope<V> - Class in co.decodable.sdk.pipeline
Base class to represent any custom POJO value type wrapped in a Debezium CDC envelope.
DecodableDebeziumEnvelope() - Constructor for class co.decodable.sdk.pipeline.DecodableDebeziumEnvelope
 
DecodableDebeziumEnvelope(V, V, String, long) - Constructor for class co.decodable.sdk.pipeline.DecodableDebeziumEnvelope
 
DecodableDebeziumEnvelope.CDC_OP_TYPE - Enum Class in co.decodable.sdk.pipeline
 
DecodableKeyedStreamRecord<K,V> - Interface in co.decodable.sdk.pipeline
Interface to represent one record in a Decodable stream as a key-value pair.
DecodableRecordDeserializationSchema<T> - Class in co.decodable.sdk.pipeline.serde
 
DecodableRecordDeserializationSchema(Class<T>) - Constructor for class co.decodable.sdk.pipeline.serde.DecodableRecordDeserializationSchema
 
DecodableRecordSerializationSchema<T> - Class in co.decodable.sdk.pipeline.serde
 
DecodableRecordSerializationSchema(Class<?>) - Constructor for class co.decodable.sdk.pipeline.serde.DecodableRecordSerializationSchema
 
DecodableRecordSerializationSchema(Class<?>, Class<?>) - Constructor for class co.decodable.sdk.pipeline.serde.DecodableRecordSerializationSchema
 
DecodableRecordSerializationSchema(String, Class<?>) - Constructor for class co.decodable.sdk.pipeline.serde.DecodableRecordSerializationSchema
 
DecodableRecordSerializationSchema(String, Class<?>, Class<?>) - Constructor for class co.decodable.sdk.pipeline.serde.DecodableRecordSerializationSchema
 
DecodableSecret - Interface in co.decodable.sdk.pipeline
Represents a Decodable secret.
DecodableSourceEnumeratorState - Interface in co.decodable.sdk.pipeline
Enumerator state used with DecodableStreamSource.
DecodableSourceSplit - Interface in co.decodable.sdk.pipeline
A source split used with DecodableStreamSource.
DecodableStream<T> - Interface in co.decodable.sdk.pipeline.testing
Represents a data stream on the Decodable platform.
DecodableStreamSink<T> - Interface in co.decodable.sdk.pipeline
A StatefulSink which allows to write to a Decodable stream from within a Flink job.
DecodableStreamSinkBuilder<T> - Interface in co.decodable.sdk.pipeline
Builder for creating DecodableStreamSink instances.
DecodableStreamSource<T> - Interface in co.decodable.sdk.pipeline
A Source which allows to retrieve the contents of a Decodable stream from within a Flink job.
DecodableStreamSourceBuilder<T> - Interface in co.decodable.sdk.pipeline
Builder for creating DecodableStreamSource instances.
DecodableWriter<T> - Interface in co.decodable.sdk.pipeline
Sink writer used by DecodableStreamSink.
DEFAULT_KEY_FIELD_NAME - Static variable in interface co.decodable.sdk.pipeline.DecodableKeyedStreamRecord
 
DEFAULT_VALUE_FIELD_NAME - Static variable in interface co.decodable.sdk.pipeline.DecodableKeyedStreamRecord
 
description() - Method in interface co.decodable.sdk.pipeline.DecodableSecret
Returns the secret description.
deserialize(ConsumerRecord<byte[], byte[]>, Collector<T>) - Method in class co.decodable.sdk.pipeline.serde.DecodableRecordDeserializationSchema
 

E

EARLIEST_OFFSET - Enum constant in enum class co.decodable.sdk.pipeline.StartupMode
Consume the stream starting at the earliest available offset.
EnvironmentAccess - Class in co.decodable.sdk.pipeline
Provides access to the environment from within a custom Flink job.
EnvironmentAccess.Environment - Interface in co.decodable.sdk.pipeline
Exposes the environment variables of the current process.
equals(Object) - Method in class co.decodable.sdk.pipeline.DecodableAppendStreamRecord
 
equals(Object) - Method in class co.decodable.sdk.pipeline.DecodableChangeStreamRecord
 
equals(Object) - Method in class co.decodable.sdk.pipeline.DecodableDebeziumEnvelope
 

F

fromString(String) - Static method in enum class co.decodable.sdk.pipeline.StartupMode
Parses the given string value into StartupMode instance.

G

getAfter() - Method in class co.decodable.sdk.pipeline.DecodableDebeziumEnvelope
 
getBefore() - Method in class co.decodable.sdk.pipeline.DecodableDebeziumEnvelope
 
getEnvironment() - Static method in class co.decodable.sdk.pipeline.EnvironmentAccess
Returns the current environment.
getEnvironmentConfiguration() - Method in interface co.decodable.sdk.pipeline.EnvironmentAccess.Environment
Returns the current environment variables, keyed by name.
getEnvironmentConfiguration() - Method in class co.decodable.sdk.pipeline.testing.TestEnvironment
Returns the current environment variables, keyed by name.
getKey() - Method in class co.decodable.sdk.pipeline.DecodableAppendStreamRecord
 
getKey() - Method in class co.decodable.sdk.pipeline.DecodableChangeStreamRecord
 
getKey() - Method in interface co.decodable.sdk.pipeline.DecodableKeyedStreamRecord
 
getOp() - Method in class co.decodable.sdk.pipeline.DecodableDebeziumEnvelope
 
getProducedType() - Method in class co.decodable.sdk.pipeline.serde.DecodableRecordDeserializationSchema
 
getTargetTopic() - Method in class co.decodable.sdk.pipeline.serde.DecodableRecordSerializationSchema
 
getTs_ms() - Method in class co.decodable.sdk.pipeline.DecodableDebeziumEnvelope
 
getValue() - Method in class co.decodable.sdk.pipeline.DecodableAppendStreamRecord
 
getValue() - Method in class co.decodable.sdk.pipeline.DecodableChangeStreamRecord
 
getValue() - Method in interface co.decodable.sdk.pipeline.DecodableKeyedStreamRecord
 

H

hashCode() - Method in class co.decodable.sdk.pipeline.DecodableAppendStreamRecord
 
hashCode() - Method in class co.decodable.sdk.pipeline.DecodableChangeStreamRecord
 
hashCode() - Method in class co.decodable.sdk.pipeline.DecodableDebeziumEnvelope
 

I

Incubating - Annotation Interface in co.decodable.sdk.pipeline.util
Denotes that the annotated element (type, method, etc.) is under active development and that its API surface may be changed in backwards incompatible ways in future releases.

K

key() - Method in class co.decodable.sdk.pipeline.testing.KeyedStreamRecord
Returns the key of this keyed stream record.
KeyedDecodableStream<K,V> - Interface in co.decodable.sdk.pipeline.testing
Represents a keyed data stream on the Decodable platform.
KeyedPipelineTestContext - Class in co.decodable.sdk.pipeline.testing
Provides access to keyed Decodable streams during testing as well as the ability to run custom Flink jobs.
KeyedPipelineTestContext(TestEnvironment) - Constructor for class co.decodable.sdk.pipeline.testing.KeyedPipelineTestContext
Creates a new testing context, using the given TestEnvironment.
KeyedPipelineTestContext.ThrowingConsumer<T> - Interface in co.decodable.sdk.pipeline.testing
A Consumer variant which allows for declared checked exception types.
KeyedStreamRecord<K,V> - Class in co.decodable.sdk.pipeline.testing
Represents one element on a keyed Decodable stream.
KeyedStreamRecord(K, V) - Constructor for class co.decodable.sdk.pipeline.testing.KeyedStreamRecord
Creates a new stream record with the given value.

L

LATEST_OFFSET - Enum constant in enum class co.decodable.sdk.pipeline.StartupMode
Consume the stream starting at the latest available offset.

N

name() - Method in interface co.decodable.sdk.pipeline.DecodableSecret
Returns the name of the secret.

O

open(DeserializationSchema.InitializationContext) - Method in class co.decodable.sdk.pipeline.serde.DecodableRecordDeserializationSchema
 
open(SerializationSchema.InitializationContext, KafkaRecordSerializationSchema.KafkaSinkContext) - Method in class co.decodable.sdk.pipeline.serde.DecodableRecordSerializationSchema
 
Operator naming convention - Search tag in package co.decodable.sdk.pipeline
Section

P

PipelineTestContext - Class in co.decodable.sdk.pipeline.testing
Provides access to Decodable streams during testing as well as the ability to run custom Flink jobs.
PipelineTestContext(TestEnvironment) - Constructor for class co.decodable.sdk.pipeline.testing.PipelineTestContext
Creates a new testing context, using the given TestEnvironment.
PipelineTestContext.ThrowingConsumer<T> - Interface in co.decodable.sdk.pipeline.testing
A Consumer variant which allows for declared checked exception types.

R

R - Enum constant in enum class co.decodable.sdk.pipeline.DecodableDebeziumEnvelope.CDC_OP_TYPE
 
resetEnvironment() - Static method in class co.decodable.sdk.pipeline.EnvironmentAccess
Resets active the environment to the system environment.
runJobAsync(KeyedPipelineTestContext.ThrowingConsumer<String[]>, String...) - Method in class co.decodable.sdk.pipeline.testing.KeyedPipelineTestContext
Asynchronously executes the given Flink job main method.
runJobAsync(PipelineTestContext.ThrowingConsumer<String[]>, String...) - Method in class co.decodable.sdk.pipeline.testing.PipelineTestContext
Asynchronously executes the given Flink job main method.

S

SecretNotFoundException - Exception Class in co.decodable.sdk.pipeline.exception
This exception is thrown when a Decodable secret cannot be accessed.
SecretNotFoundException(String) - Constructor for exception class co.decodable.sdk.pipeline.exception.SecretNotFoundException
 
SecretNotFoundException(String, Throwable) - Constructor for exception class co.decodable.sdk.pipeline.exception.SecretNotFoundException
 
SerializationConstraintsValidator - Class in co.decodable.sdk.pipeline.serde
 
SerializationConstraintsValidator() - Constructor for class co.decodable.sdk.pipeline.serde.SerializationConstraintsValidator
 
serialize(T, KafkaRecordSerializationSchema.KafkaSinkContext, Long) - Method in class co.decodable.sdk.pipeline.serde.DecodableRecordSerializationSchema
 
setAfter(V) - Method in class co.decodable.sdk.pipeline.DecodableDebeziumEnvelope
 
setBefore(V) - Method in class co.decodable.sdk.pipeline.DecodableDebeziumEnvelope
 
setEnvironment(EnvironmentAccess.Environment) - Static method in class co.decodable.sdk.pipeline.EnvironmentAccess
Sets the given environment as the active one.
setKey(K) - Method in class co.decodable.sdk.pipeline.DecodableAppendStreamRecord
 
setKey(K) - Method in class co.decodable.sdk.pipeline.DecodableChangeStreamRecord
 
setOp(String) - Method in class co.decodable.sdk.pipeline.DecodableDebeziumEnvelope
 
setTargetTopic(String) - Method in class co.decodable.sdk.pipeline.serde.DecodableRecordSerializationSchema
 
setTs_ms(long) - Method in class co.decodable.sdk.pipeline.DecodableDebeziumEnvelope
 
setValue(V) - Method in class co.decodable.sdk.pipeline.DecodableAppendStreamRecord
 
setValue(V) - Method in class co.decodable.sdk.pipeline.DecodableChangeStreamRecord
 
SinkStreams - Annotation Interface in co.decodable.sdk.pipeline.metadata
Denotes the sink streams accessed by a custom pipeline.
SourceStreams - Annotation Interface in co.decodable.sdk.pipeline.metadata
Denotes the source streams accessed by a custom pipeline.
StartupMode - Enum Class in co.decodable.sdk.pipeline
Defines from which offset to consume the underlying stream when starting up a DecodableStreamSource.
stream(String) - Method in class co.decodable.sdk.pipeline.testing.KeyedPipelineTestContext
Returns a stream for the given name.
stream(String) - Method in class co.decodable.sdk.pipeline.testing.PipelineTestContext
Returns a stream for the given name.
Stream Metadata - Search tag in package co.decodable.sdk.pipeline
Section
StreamRecord<T> - Class in co.decodable.sdk.pipeline.testing
Represents one element on a Decodable stream.
StreamRecord(T) - Constructor for class co.decodable.sdk.pipeline.testing.StreamRecord
Creates a new stream record with the given value.

T

take(int) - Method in interface co.decodable.sdk.pipeline.testing.DecodableStream
Retrieves n elements from this stream.
take(int) - Method in interface co.decodable.sdk.pipeline.testing.KeyedDecodableStream
Retrieves n keyed records from this stream.
takeOne() - Method in interface co.decodable.sdk.pipeline.testing.DecodableStream
Retrieves one element from this stream.
takeOne() - Method in interface co.decodable.sdk.pipeline.testing.KeyedDecodableStream
Retrieves one keyed record from this stream.
TestEnvironment - Class in co.decodable.sdk.pipeline.testing
An EnvironmentAccess.Environment implementation for testing purposes, allowing to define one or more Decodable streams which then can be accessed from the job under test.
TestEnvironment.Builder - Class in co.decodable.sdk.pipeline.testing
A builder for creating new TestEnvironment instances.
topicFor(String) - Method in class co.decodable.sdk.pipeline.testing.TestEnvironment
Returns the name of the Kafka topic backing the given stream.
toString() - Method in class co.decodable.sdk.pipeline.DecodableAppendStreamRecord
 
toString() - Method in class co.decodable.sdk.pipeline.DecodableChangeStreamRecord
 
toString() - Method in class co.decodable.sdk.pipeline.DecodableDebeziumEnvelope
 

U

U - Enum constant in enum class co.decodable.sdk.pipeline.DecodableDebeziumEnvelope.CDC_OP_TYPE
 
Unmodifiable - Annotation Interface in co.decodable.sdk.pipeline.util
Denotes that the annotated field is unmodifiable.
unwrap() - Method in class co.decodable.sdk.pipeline.DecodableDebeziumEnvelope
 
updateTime() - Method in interface co.decodable.sdk.pipeline.DecodableSecret
Returns the time the secret was last updated.

V

value() - Method in interface co.decodable.sdk.pipeline.DecodableSecret
Returns the plaintext secret value.
value() - Element in annotation interface co.decodable.sdk.pipeline.metadata.SinkStreams
Names of the sink streams.
value() - Element in annotation interface co.decodable.sdk.pipeline.metadata.SourceStreams
Names of the source streams.
value() - Method in class co.decodable.sdk.pipeline.testing.KeyedStreamRecord
Returns the value of this keyed stream record.
value() - Method in class co.decodable.sdk.pipeline.testing.StreamRecord
Returns the value of this stream record.
valueOf(String) - Static method in enum class co.decodable.sdk.pipeline.DecodableDebeziumEnvelope.CDC_OP_TYPE
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class co.decodable.sdk.pipeline.StartupMode
Returns the enum constant of this class with the specified name.
values() - Static method in enum class co.decodable.sdk.pipeline.DecodableDebeziumEnvelope.CDC_OP_TYPE
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class co.decodable.sdk.pipeline.StartupMode
Returns an array containing the constants of this enum class, in the order they are declared.
VisibleForTesting - Annotation Interface in co.decodable.sdk.pipeline.util
Denotes that the annotated element is exposed for testing purposes only and should not be referenced from production code.

W

withBootstrapServers(String) - Method in class co.decodable.sdk.pipeline.testing.TestEnvironment.Builder
Specifies the bootstrap server(s) to be used.
withDeserializationSchema(DeserializationSchema<T>) - Method in interface co.decodable.sdk.pipeline.DecodableStreamSourceBuilder
Deprecated.
Specifies the value only deserialization schema to be used. Use DecodableStreamSourceBuilder.withRecordDeserializationSchema(DecodableRecordDeserializationSchema) instead.
withName(String) - Static method in interface co.decodable.sdk.pipeline.DecodableSecret
Looks up the secret by name and returns a DecodableSecret instance.
withRecordDeserializationSchema(DecodableRecordDeserializationSchema<?>) - Method in interface co.decodable.sdk.pipeline.DecodableStreamSourceBuilder
Specifies the record deserialization schema to be used which supports both key and value parts of a record.
withRecordSerializationSchema(DecodableRecordSerializationSchema<?>) - Method in interface co.decodable.sdk.pipeline.DecodableStreamSinkBuilder
Specifies the key and value serialization schema to be used which supports both key and value parts of a record.
withSerializationSchema(SerializationSchema<T>) - Method in interface co.decodable.sdk.pipeline.DecodableStreamSinkBuilder
Deprecated.
Specifies the value only serialization schema to be used. Use DecodableStreamSinkBuilder.withRecordSerializationSchema(DecodableRecordSerializationSchema) instead.
withStartupMode(StartupMode) - Method in interface co.decodable.sdk.pipeline.DecodableStreamSourceBuilder
Specifies the start-up mode to use when reading from the stream.
withStreamId(String) - Method in interface co.decodable.sdk.pipeline.DecodableStreamSinkBuilder
Deprecated.
Specifies the id of the stream to write to. Use DecodableStreamSinkBuilder.withStreamName(String) instead.
withStreamId(String) - Method in interface co.decodable.sdk.pipeline.DecodableStreamSourceBuilder
Deprecated.
Specifies the id of the stream to read from. Use DecodableStreamSourceBuilder.withStreamName(String) instead.
withStreamName(String) - Method in interface co.decodable.sdk.pipeline.DecodableStreamSinkBuilder
Specifies the name of the stream to write to.
withStreamName(String) - Method in interface co.decodable.sdk.pipeline.DecodableStreamSourceBuilder
Specifies the name of the stream to read from.
withStreams(String, String...) - Method in class co.decodable.sdk.pipeline.testing.TestEnvironment.Builder
Specifies the names of the stream(s) which should be available via this test environment.
A B C D E F G H I K L N O P R S T U V W 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form