From issues-return-171762-archive-asf-public=cust-asf.ponee.io@flink.apache.org Thu Jun 14 16:21:25 2018 Return-Path: X-Original-To: archive-asf-public@cust-asf.ponee.io Delivered-To: archive-asf-public@cust-asf.ponee.io Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by mx-eu-01.ponee.io (Postfix) with SMTP id 9FB3E180600 for ; Thu, 14 Jun 2018 16:21:24 +0200 (CEST) Received: (qmail 66376 invoked by uid 500); 14 Jun 2018 14:21:23 -0000 Mailing-List: contact issues-help@flink.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@flink.apache.org Delivered-To: mailing list issues@flink.apache.org Received: (qmail 66366 invoked by uid 99); 14 Jun 2018 14:21:23 -0000 Received: from git1-us-west.apache.org (HELO git1-us-west.apache.org) (140.211.11.23) by apache.org (qpsmtpd/0.29) with ESMTP; Thu, 14 Jun 2018 14:21:23 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 914D1E0FAF; Thu, 14 Jun 2018 14:21:23 +0000 (UTC) From: azagrebin To: issues@flink.apache.org Reply-To: issues@flink.apache.org References: In-Reply-To: Subject: [GitHub] flink pull request #6159: [FLINK-9487] Prepare InternalTimerHeap for asynchr... Content-Type: text/plain Message-Id: <20180614142123.914D1E0FAF@git1-us-west.apache.org> Date: Thu, 14 Jun 2018 14:21:23 +0000 (UTC) Github user azagrebin commented on a diff in the pull request: https://github.com/apache/flink/pull/6159#discussion_r195441098 --- Diff: flink-runtime/src/main/java/org/apache/flink/runtime/state/AbstractKeyGroupPartitionedSnapshot.java --- @@ -0,0 +1,76 @@ +/* + * 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.runtime.state; + +import org.apache.flink.core.memory.DataOutputView; + +import javax.annotation.Nonnull; + +import java.io.IOException; + + +/** + * Abstract base class for implementations of + * {@link org.apache.flink.runtime.state.StateSnapshot.KeyGroupPartitionedSnapshot} based on the result of a + * {@link AbstractKeyGroupPartitioner}. + * + * @param type of the written elements. + */ +public abstract class AbstractKeyGroupPartitionedSnapshot implements StateSnapshot.KeyGroupPartitionedSnapshot { + + /** The partitioning result to be written by key-group. */ + @Nonnull + private final AbstractKeyGroupPartitioner.PartitioningResult partitioningResult; + + public AbstractKeyGroupPartitionedSnapshot( + @Nonnull AbstractKeyGroupPartitioner.PartitioningResult partitioningResult) { + this.partitioningResult = partitioningResult; + } + + @Override + public void writeMappingsInKeyGroup(@Nonnull DataOutputView dov, int keyGroupId) throws IOException { + + final T[] groupedOut = partitioningResult.getPartitionedElements(); + + int startOffset = partitioningResult.getKeyGroupStartOffsetInclusive(keyGroupId); + int endOffset = partitioningResult.getKeyGroupEndOffsetExclusive(keyGroupId); + + // write number of mappings in key-group + dov.writeInt(endOffset - startOffset); + + // write mappings + for (int i = startOffset; i < endOffset; ++i) { + if(groupedOut[i] == null) { + throw new IllegalStateException(); + } + writeElement(groupedOut[i], dov); + groupedOut[i] = null; // free asap for GC + } + } + + /** + * This method defines how to write a single element to the output. + * + * @param element the element to be written. + * @param dov the output view to write the element. + * @throws IOException on write-related problems. + */ + protected abstract void writeElement(@Nonnull T element, @Nonnull DataOutputView dov) throws IOException; --- End diff -- `AbstractKeyGroupPartitionedSnapshot.writeElement` looks like strategy for `writeMappingsInKeyGroup`. It could be injected in constructor or `writeMappingsInKeyGroup` as lambda `ElementWriter` interface and eliminate inheritance abstractions. The partitioner could just output PartitionedSnapshot which would be partitioningResult + writeMappingsInKeyGroup. The result seems to have just one purpose to be written as keyed snapshot. ---