Skip to content

Commit

Permalink
[FLINK-35401] Add Sqs Table API connector
Browse files Browse the repository at this point in the history
  • Loading branch information
vahmed-hamdy committed Aug 17, 2024
1 parent cc0b4d4 commit 5400e44
Show file tree
Hide file tree
Showing 6 changed files with 748 additions and 0 deletions.
22 changes: 22 additions & 0 deletions flink-connector-aws/flink-connector-sqs/pom.xml
Original file line number Diff line number Diff line change
Expand Up @@ -103,6 +103,28 @@ under the License.
<artifactId>jackson-datatype-jsr310</artifactId>
</dependency>

<!-- Table API dependencies-->
<dependency>
<groupId>org.apache.flink</groupId>
<artifactId>flink-table-common</artifactId>
<version>${flink.version}</version>
</dependency>

<dependency>
<groupId>org.apache.flink</groupId>
<artifactId>flink-table-runtime</artifactId>
<version>${flink.version}</version>
<scope>test</scope>
</dependency>

<dependency>
<groupId>org.apache.flink</groupId>
<artifactId>flink-table-common</artifactId>
<version>${flink.version}</version>
<scope>test</scope>
<type>test-jar</type>
</dependency>

<!-- ArchUnit test dependencies -->

<dependency>
Expand Down
Original file line number Diff line number Diff line change
@@ -0,0 +1,52 @@
/*
* Licensed to the Apache Software Foundation (ASF) under one or more
* contributor license agreements. See the NOTICE file distributed with
* this work for additional information regarding copyright ownership.
* The ASF licenses this file to You under the Apache License, Version 2.0
* (the "License"); you may not use this file except in compliance with
* the License. You may obtain a copy of the License at
*
* http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/

package org.apache.flink.connector.sqs.table;

import org.apache.flink.annotation.PublicEvolving;
import org.apache.flink.configuration.ConfigOption;
import org.apache.flink.configuration.ConfigOptions;

import java.util.Map;

/** Options for the SQS connector. */
@PublicEvolving
public class SqsConnectorOptions {
public static final ConfigOption<String> QUEUE_URL =
ConfigOptions.key("queue-url")
.stringType()
.noDefaultValue()
.withDescription("The URL of the SQS queue.");

public static final ConfigOption<String> AWS_REGION =
ConfigOptions.key("aws.region")
.stringType()
.noDefaultValue()
.withDescription("AWS region of used SQS queue.");

public static final ConfigOption<Map<String, String>> AWS_CONFIG_PROPERTIES =
ConfigOptions.key("aws")
.mapType()
.noDefaultValue()
.withDescription("AWS configuration properties.");

public static final ConfigOption<Boolean> FAIL_ON_ERROR =
ConfigOptions.key("sink.fail-on-error")
.booleanType()
.defaultValue(false)
.withDescription("Flag to trigger global failure on error.");
}
Original file line number Diff line number Diff line change
@@ -0,0 +1,261 @@
/*
* Licensed to the Apache Software Foundation (ASF) under one or more
* contributor license agreements. See the NOTICE file distributed with
* this work for additional information regarding copyright ownership.
* The ASF licenses this file to You under the Apache License, Version 2.0
* (the "License"); you may not use this file except in compliance with
* the License. You may obtain a copy of the License at
*
* http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/

package org.apache.flink.connector.sqs.table;

import org.apache.flink.annotation.Internal;
import org.apache.flink.api.common.serialization.SerializationSchema;
import org.apache.flink.connector.base.table.sink.AsyncDynamicTableSink;
import org.apache.flink.connector.base.table.sink.AsyncDynamicTableSinkBuilder;
import org.apache.flink.connector.sqs.sink.SqsSink;
import org.apache.flink.connector.sqs.sink.SqsSinkBuilder;
import org.apache.flink.connector.sqs.sink.SqsSinkElementConverter;
import org.apache.flink.table.connector.ChangelogMode;
import org.apache.flink.table.connector.format.EncodingFormat;
import org.apache.flink.table.connector.sink.DynamicTableSink;
import org.apache.flink.table.connector.sink.SinkV2Provider;
import org.apache.flink.table.data.RowData;
import org.apache.flink.table.types.DataType;

import software.amazon.awssdk.services.sqs.model.SendMessageBatchRequestEntry;

import javax.annotation.Nullable;

import java.util.Objects;
import java.util.Optional;
import java.util.Properties;

/** A {@link DynamicTableSink} for SQS. */
@Internal
public class SqsDynamicSink extends AsyncDynamicTableSink<SendMessageBatchRequestEntry> {

/** Consumed data type of the table. */
private final DataType consumedDataType;

/** Url of Sqs queue to write to. */
private final String sqsUrl;

/** Properties for the Sqs Aws Client. */
private final Properties sqsClientProps;

/** Encoding format to convert between row data and byte array. */
EncodingFormat<SerializationSchema<RowData>> encodingFormat;

/** Flag to determine whether to fail on error. */
private final Boolean failOnError;

protected SqsDynamicSink(
@Nullable Integer maxBatchSize,
@Nullable Integer maxInFlightRequests,
@Nullable Integer maxBufferedRequests,
@Nullable Long maxBufferSizeInBytes,
@Nullable Long maxTimeInBufferMS,
@Nullable Boolean failOnError,
@Nullable DataType consumedDataType,
EncodingFormat<SerializationSchema<RowData>> encodingFormat,
String sqsUrl,
@Nullable Properties sqsClientProps) {
super(
maxBatchSize,
maxInFlightRequests,
maxBufferedRequests,
maxBufferSizeInBytes,
maxTimeInBufferMS);
this.consumedDataType = consumedDataType;
this.sqsUrl = sqsUrl;
this.sqsClientProps = sqsClientProps;
this.failOnError = failOnError;
this.encodingFormat = encodingFormat;
}

@Override
public ChangelogMode getChangelogMode(ChangelogMode changelogMode) {
return encodingFormat.getChangelogMode();
}

@Override
public SinkRuntimeProvider getSinkRuntimeProvider(Context context) {
SqsSinkBuilder<RowData> builder = SqsSink.builder();
builder.setSqsUrl(sqsUrl);
Optional.ofNullable(sqsClientProps).ifPresent(builder::setSqsClientProperties);
builder.setSqsSinkElementConverter(
SqsSinkElementConverter.<RowData>builder()
.setSerializationSchema(
encodingFormat.createRuntimeEncoder(context, consumedDataType))
.build());
Optional.ofNullable(failOnError).ifPresent(builder::setFailOnError);
return SinkV2Provider.of(builder.build());
}

@Override
public DynamicTableSink copy() {
return new SqsDynamicSink(
maxBatchSize,
maxInFlightRequests,
maxBufferedRequests,
maxBufferSizeInBytes,
maxTimeInBufferMS,
failOnError,
consumedDataType,
encodingFormat,
sqsUrl,
sqsClientProps);
}

@Override
public boolean equals(Object o) {
if (this == o) {
return true;
}
if (o == null || getClass() != o.getClass()) {
return false;
}
SqsDynamicSink that = (SqsDynamicSink) o;
return super.equals(o)
&& failOnError == that.failOnError
&& Objects.equals(consumedDataType, that.consumedDataType)
&& Objects.equals(sqsUrl, that.sqsUrl)
&& Objects.equals(sqsClientProps, that.sqsClientProps)
&& Objects.equals(encodingFormat, that.encodingFormat);
}

@Override
public int hashCode() {
return Objects.hash(
super.hashCode(),
consumedDataType,
sqsUrl,
sqsClientProps,
encodingFormat,
failOnError);
}

@Override
public String asSummaryString() {
StringBuilder sb = new StringBuilder();
sb.append("SqsDynamicSink{");
sb.append("sqsUrl='").append(sqsUrl).append('\'');
sb.append(", consumedDataType=").append(consumedDataType);
sb.append(", encodingFormat=").append(encodingFormat);
sb.append(", failOnError=").append(failOnError);
Optional.ofNullable(sqsClientProps)
.ifPresent(
props ->
props.forEach(
(k, v) -> sb.append(", ").append(k).append("=").append(v)));
sb.append(", maxBatchSize=").append(maxBatchSize);
sb.append(", maxInFlightRequests=").append(maxInFlightRequests);
sb.append(", maxBufferedRequests=").append(maxBufferedRequests);
sb.append(", maxBufferSizeInBytes=").append(maxBufferSizeInBytes);
sb.append(", maxTimeInBufferMS=").append(maxTimeInBufferMS);
sb.append('}');
return sb.toString();
}

@Override
public String toString() {
return asSummaryString();
}

public static SqsQueueUrlConfigurator builder() {
return new SqsDynamicSinkBuilder();
}

/** Builder for {@link SqsDynamicSink}. */
@Internal
public static class SqsDynamicSinkBuilder
extends AsyncDynamicTableSinkBuilder<
SendMessageBatchRequestEntry, SqsDynamicSinkBuilder>
implements SqsQueueUrlConfigurator, SqsSinkEncodingFormatConfigurator {

private String sqsUrl;

private Properties sqsClientProps;

private EncodingFormat<SerializationSchema<RowData>> encodingFormat;

private Boolean failOnError;

private DataType consumedDataType;

@Override
public SqsSinkEncodingFormatConfigurator setSqsQueueUrl(String sqsUrl) {
this.sqsUrl = sqsUrl;
return this;
}

@Override
public SqsDynamicSinkBuilder setEncodingFormat(
EncodingFormat<SerializationSchema<RowData>> encodingFormat) {
this.encodingFormat = encodingFormat;
return this;
}

public SqsDynamicSinkBuilder setFailOnError(boolean failOnError) {
this.failOnError = failOnError;
return this;
}

public SqsDynamicSinkBuilder setSqsClientProperties(Properties sqsClientProps) {
this.sqsClientProps = sqsClientProps;
return this;
}

public SqsDynamicSinkBuilder setConsumedDataType(DataType consumedDataType) {
this.consumedDataType = consumedDataType;
return this;
}

@Override
public SqsDynamicSink build() {
return new SqsDynamicSink(
getMaxBatchSize(),
getMaxInFlightRequests(),
getMaxBufferedRequests(),
getMaxBufferSizeInBytes(),
getMaxTimeInBufferMS(),
failOnError,
consumedDataType,
encodingFormat,
sqsUrl,
sqsClientProps);
}
}

/** Configurator for the required Sqs queue url. */
@Internal
public interface SqsQueueUrlConfigurator {
/**
* Configures the Sqs queue url.
*
* @param sqsUrl the url of the Sqs queue
*/
SqsSinkEncodingFormatConfigurator setSqsQueueUrl(String sqsUrl);
}

/** Configurator for the required encoding format. */
@Internal
public interface SqsSinkEncodingFormatConfigurator {
/**
* Configures the encoding format.
*
* @param encodingFormat the encoding format
*/
SqsDynamicSinkBuilder setEncodingFormat(
EncodingFormat<SerializationSchema<RowData>> encodingFormat);
}
}
Loading

0 comments on commit 5400e44

Please sign in to comment.