All Downloads are FREE. Search and download functionalities are using the official Maven repository.

com.hazelcast.jet.kinesis.impl.source.KinesisSourcePMetaSupplier Maven / Gradle / Ivy

/*
 * Copyright 2021 Hazelcast Inc.
 *
 * Licensed under the Hazelcast Community License (the "License");
 * you may not use this file except in compliance with the License.
 * You may obtain a copy of the License at
 *
 * http://hazelcast.com/hazelcast-community-license
 *
 * Unless required by applicable law or agreed to in writing, software
 * distributed under the License is distributed on an "AS IS" BASIS,
 * WITHOUT WARRANTIES OF ANY KIND, either express or implied.
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */

package com.hazelcast.jet.kinesis.impl.source;

import com.hazelcast.cluster.Address;
import com.hazelcast.cluster.Member;
import com.hazelcast.jet.core.EventTimePolicy;
import com.hazelcast.jet.core.ProcessorMetaSupplier;
import com.hazelcast.jet.core.ProcessorSupplier;
import com.hazelcast.jet.kinesis.impl.AwsConfig;
import com.hazelcast.jet.retry.RetryStrategy;

import javax.annotation.Nonnull;
import java.util.HashMap;
import java.util.List;
import java.util.Map;
import java.util.function.Function;

import static java.util.stream.Collectors.joining;
import static java.util.stream.Collectors.toList;

public class KinesisSourcePMetaSupplier implements ProcessorMetaSupplier {

    private static final long serialVersionUID = 1L;

    @Nonnull
    private final AwsConfig awsConfig;
    @Nonnull
    private final String stream;
    @Nonnull
    private final RetryStrategy retryStrategy;
    @Nonnull
    private final InitialShardIterators initialShardIterators;
    @Nonnull
    private final EventTimePolicy> eventTimePolicy;

    private transient Map assignedHashRanges;

    public KinesisSourcePMetaSupplier(
            @Nonnull AwsConfig awsConfig,
            @Nonnull String stream,
            @Nonnull RetryStrategy retryStrategy,
            @Nonnull InitialShardIterators initialShardIterators,
            @Nonnull EventTimePolicy> eventTimePolicy
    ) {
        this.awsConfig = awsConfig;
        this.stream = stream;
        this.retryStrategy = retryStrategy;
        this.initialShardIterators = initialShardIterators;
        this.eventTimePolicy = eventTimePolicy;
    }

    @Override
    public void init(@Nonnull ProcessorMetaSupplier.Context context) {
        List
addresses = getMemberAddresses(context); assignedHashRanges = assignHashRangesToMembers(addresses); if (context.logger().isFineEnabled()) { context.logger().fine("Hash ranges assigned to members: \n\t" + assignedHashRanges.entrySet().stream().map(Object::toString).collect(joining("\n\t"))); } } @Nonnull @Override public Function get(@Nonnull List
addresses) { return address -> { HashRange assignedRange = assignedHashRanges.get(address); return new KinesisSourcePSupplier(awsConfig, stream, eventTimePolicy, assignedRange, retryStrategy, initialShardIterators); }; } @Nonnull private static List
getMemberAddresses(@Nonnull Context context) { return context .jetInstance().getCluster().getMembers().stream() .map(Member::getAddress) .collect(toList()); } /** * Divide the range of all possible hash key values into equally sized * chunks, as many as there are Jet members in the cluster and assign each * chunk to a member. */ @Nonnull private static Map assignHashRangesToMembers(List
addresses) { Map addressRanges = new HashMap<>(); for (int i = 0; i < addresses.size(); i++) { Address address = addresses.get(i); addressRanges.put(address, HashRange.DOMAIN.partition(i, addresses.size())); } return addressRanges; } }




© 2015 - 2025 Weber Informatics LLC | Privacy Policy