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

org.apache.hyracks.control.cc.partitions.PartitionMatchMaker Maven / Gradle / Ivy

There is a newer version: 0.3.9
Show newest version
/*
 * 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.hyracks.control.cc.partitions;

import java.util.ArrayList;
import java.util.HashMap;
import java.util.Iterator;
import java.util.List;
import java.util.Map;
import java.util.Set;
import java.util.logging.Logger;

import org.apache.commons.lang3.tuple.Pair;

import org.apache.hyracks.api.dataflow.TaskAttemptId;
import org.apache.hyracks.api.partitions.PartitionId;
import org.apache.hyracks.control.common.job.PartitionDescriptor;
import org.apache.hyracks.control.common.job.PartitionRequest;
import org.apache.hyracks.control.common.job.PartitionState;

public class PartitionMatchMaker {
    private static final Logger LOGGER = Logger.getLogger(PartitionMatchMaker.class.getName());

    private final Map> partitionDescriptors;

    private final Map> partitionRequests;

    public PartitionMatchMaker() {
        partitionDescriptors = new HashMap>();
        partitionRequests = new HashMap>();
    }

    public List> registerPartitionDescriptor(
            PartitionDescriptor partitionDescriptor) {
        List> matches = new ArrayList>();
        PartitionId pid = partitionDescriptor.getPartitionId();
        boolean matched = false;
        List requests = partitionRequests.get(pid);
        if (requests != null) {
            Iterator i = requests.iterator();
            while (i.hasNext()) {
                PartitionRequest req = i.next();
                if (partitionDescriptor.getState().isAtLeast(req.getMinimumState())) {
                    matches.add(Pair. of(partitionDescriptor, req));
                    i.remove();
                    matched = true;
                    if (!partitionDescriptor.isReusable()) {
                        break;
                    }
                }
            }
            if (requests.isEmpty()) {
                partitionRequests.remove(pid);
            }
        }

        if (!matched) {
            List descriptors = partitionDescriptors.get(pid);
            if (descriptors == null) {
                descriptors = new ArrayList();
                partitionDescriptors.put(pid, descriptors);
            }
            descriptors.add(partitionDescriptor);
        }

        return matches;
    }

    public Pair matchPartitionRequest(PartitionRequest partitionRequest) {
        Pair match = null;

        PartitionId pid = partitionRequest.getPartitionId();

        List descriptors = partitionDescriptors.get(pid);
        if (descriptors != null) {
            Iterator i = descriptors.iterator();
            while (i.hasNext()) {
                PartitionDescriptor descriptor = i.next();
                if (descriptor.getState().isAtLeast(partitionRequest.getMinimumState())) {
                    match = Pair. of(descriptor, partitionRequest);
                    if (!descriptor.isReusable()) {
                        i.remove();
                    }
                    break;
                }
            }
            if (descriptors.isEmpty()) {
                partitionDescriptors.remove(pid);
            }
        }

        if (match == null) {
            List requests = partitionRequests.get(pid);
            if (requests == null) {
                requests = new ArrayList();
                partitionRequests.put(pid, requests);
            }
            requests.add(partitionRequest);
        }

        return match;
    }

    public PartitionState getMaximumAvailableState(PartitionId pid) {
        List descriptors = partitionDescriptors.get(pid);
        if (descriptors == null) {
            return null;
        }
        for (PartitionDescriptor descriptor : descriptors) {
            if (descriptor.getState() == PartitionState.COMMITTED) {
                return PartitionState.COMMITTED;
            }
        }
        return PartitionState.STARTED;
    }

    private interface IEntryFilter {
        public boolean matches(T o);
    }

    private static  void removeEntries(List list, IEntryFilter filter) {
        Iterator j = list.iterator();
        while (j.hasNext()) {
            T o = j.next();
            if (filter.matches(o)) {
                j.remove();
            }
        }
    }

    private static  void removeEntries(Map> map, IEntryFilter filter) {
        Iterator>> i = map.entrySet().iterator();
        while (i.hasNext()) {
            Map.Entry> e = i.next();
            List list = e.getValue();
            removeEntries(list, filter);
            if (list.isEmpty()) {
                i.remove();
            }
        }
    }

    public void notifyNodeFailures(final Set deadNodes) {
        removeEntries(partitionDescriptors, new IEntryFilter() {
            @Override
            public boolean matches(PartitionDescriptor o) {
                return deadNodes.contains(o.getNodeId());
            }
        });
        removeEntries(partitionRequests, new IEntryFilter() {
            @Override
            public boolean matches(PartitionRequest o) {
                return deadNodes.contains(o.getNodeId());
            }
        });
    }

    public void removeUncommittedPartitions(Set partitionIds, final Set taIds) {
        LOGGER.info("Removing uncommitted partitions: " + partitionIds);
        IEntryFilter filter = new IEntryFilter() {
            @Override
            public boolean matches(PartitionDescriptor o) {
                return o.getState() != PartitionState.COMMITTED && taIds.contains(o.getProducingTaskAttemptId());
            }
        };
        for (PartitionId pid : partitionIds) {
            List descriptors = partitionDescriptors.get(pid);
            if (descriptors != null) {
                removeEntries(descriptors, filter);
                if (descriptors.isEmpty()) {
                    partitionDescriptors.remove(pid);
                }
            }
        }
    }

    public void removePartitionRequests(Set partitionIds, final Set taIds) {
        LOGGER.info("Removing partition requests: " + partitionIds);
        IEntryFilter filter = new IEntryFilter() {
            @Override
            public boolean matches(PartitionRequest o) {
                return taIds.contains(o.getRequestingTaskAttemptId());
            }
        };
        for (PartitionId pid : partitionIds) {
            List requests = partitionRequests.get(pid);
            if (requests != null) {
                removeEntries(requests, filter);
                if (requests.isEmpty()) {
                    partitionRequests.remove(pid);
                }
            }
        }
    }
}




© 2015 - 2025 Weber Informatics LLC | Privacy Policy