org.sosy_lab.cpachecker.pcc.strategy.parallel.interleaved.PartialReachedSetIOCheckingOnlyInterleavedStrategy.java Source code

Java tutorial

Introduction

Here is the source code for org.sosy_lab.cpachecker.pcc.strategy.parallel.interleaved.PartialReachedSetIOCheckingOnlyInterleavedStrategy.java

Source

/*
 *  CPAchecker is a tool for configurable software verification.
 *  This file is part of CPAchecker.
 *
 *  Copyright (C) 2007-2014  Dirk Beyer
 *  All rights reserved.
 *
 *  Licensed 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.
 *
 *
 *  CPAchecker web page:
 *    http://cpachecker.sosy-lab.org
 */
package org.sosy_lab.cpachecker.pcc.strategy.parallel.interleaved;

import java.io.IOException;
import java.io.InputStream;
import java.io.ObjectInputStream;
import java.io.ObjectOutputStream;
import java.util.Collection;
import java.util.HashSet;
import java.util.List;
import java.util.Set;
import java.util.concurrent.Semaphore;
import java.util.concurrent.atomic.AtomicBoolean;
import java.util.logging.Level;
import java.util.zip.ZipInputStream;

import org.sosy_lab.common.Pair;
import org.sosy_lab.common.Triple;
import org.sosy_lab.common.configuration.Configuration;
import org.sosy_lab.common.configuration.InvalidConfigurationException;
import org.sosy_lab.common.log.LogManager;
import org.sosy_lab.cpachecker.cfa.model.CFANode;
import org.sosy_lab.cpachecker.core.ShutdownNotifier;
import org.sosy_lab.cpachecker.core.interfaces.AbstractState;
import org.sosy_lab.cpachecker.core.interfaces.Precision;
import org.sosy_lab.cpachecker.core.interfaces.pcc.PartitioningCheckingHelper;
import org.sosy_lab.cpachecker.core.reachedset.ReachedSet;
import org.sosy_lab.cpachecker.core.reachedset.UnmodifiableReachedSet;
import org.sosy_lab.cpachecker.cpa.PropertyChecker.PropertyCheckerCPA;
import org.sosy_lab.cpachecker.exceptions.CPAException;
import org.sosy_lab.cpachecker.pcc.strategy.AbstractStrategy;
import org.sosy_lab.cpachecker.pcc.strategy.partialcertificate.PartialReachedSetDirectedGraph;
import org.sosy_lab.cpachecker.pcc.strategy.partitioning.PartitionChecker;
import org.sosy_lab.cpachecker.pcc.strategy.partitioning.PartitioningIOHelper;

import com.google.common.collect.HashMultimap;
import com.google.common.collect.Multimap;
import com.google.common.collect.Sets;

public class PartialReachedSetIOCheckingOnlyInterleavedStrategy extends AbstractStrategy {

    private final PartitioningIOHelper ioHelper;
    private final PropertyCheckerCPA cpa;
    private final ShutdownNotifier shutdownNotifier;

    public PartialReachedSetIOCheckingOnlyInterleavedStrategy(final Configuration pConfig, final LogManager pLogger,
            final ShutdownNotifier pShutdownNotifier, final PropertyCheckerCPA pCpa)
            throws InvalidConfigurationException {
        super(pConfig, pLogger);
        ioHelper = new PartitioningIOHelper(pConfig, pLogger, pShutdownNotifier, pCpa);
        cpa = pCpa;
        shutdownNotifier = pShutdownNotifier;
        addPCCStatistic(ioHelper.getPartitioningStatistc());
    }

    @Override
    public void constructInternalProofRepresentation(UnmodifiableReachedSet pReached)
            throws InvalidConfigurationException, InterruptedException {
        throw new InvalidConfigurationException(
                "Interleaved proof reading and checking strategies do not  support internal PCC with result check algorithm");
    }

    @Override
    public boolean checkCertificate(ReachedSet pReachedSet) throws CPAException, InterruptedException {
        final AtomicBoolean checkResult = new AtomicBoolean(true);
        Semaphore partitionsAvailable = new Semaphore(0);

        Multimap<CFANode, AbstractState> partitionNodes = HashMultimap.create();
        Collection<AbstractState> inOtherPartition = new HashSet<>();
        Collection<AbstractState> certificate = Sets.newHashSetWithExpectedSize(ioHelper.getSavedReachedSetSize());

        AbstractState initialState = pReachedSet.popFromWaitlist();
        Precision initPrec = pReachedSet.getPrecision(initialState);

        logger.log(Level.INFO, "Create reading thread");
        Thread readingThread = new Thread(new PartitionReader(checkResult, partitionsAvailable));
        try {
            readingThread.start();

            PartitioningCheckingHelper checkInfo = new PartitioningCheckingHelper() {
                @Override
                public int getCurrentCertificateSize() {
                    return 0;
                }

                @Override
                public void abortCheckingPreparation() {
                    checkResult.set(false);
                }
            };
            PartitionChecker checker = new PartitionChecker(initPrec, cpa.getStopOperator(),
                    cpa.getTransferRelation(), ioHelper, checkInfo, shutdownNotifier, logger);

            for (int i = 0; i < ioHelper.getNumPartitions() && checkResult.get(); i++) {
                partitionsAvailable.acquire();

                if (!checkResult.get()) {
                    return false;
                }

                checker.checkPartition(i);
                checker.addCertificatePartsToCertificate(certificate);
                checker.clearPartitionElementsSavedForInspection();
            }

            if (!checkResult.get()) {
                return false;
            }

            checker.addPartitionElements(partitionNodes);
            checker.addElementsCheckedInOtherPartitions(inOtherPartition);

            logger.log(Level.INFO,
                    "Add initial state to elements for which it will be checked if they are covered by partition nodes of certificate.");
            inOtherPartition.add(initialState);

            logger.log(Level.INFO,
                    "Check if initial state and all nodes which should be contained in different partition are covered by certificate (partition node).");
            if (!PartitionChecker.areElementsCoveredByPartitionElement(inOtherPartition, partitionNodes,
                    cpa.getStopOperator(), initPrec)) {
                logger.log(Level.SEVERE,
                        "Initial state or a state which should be in other partition is not covered by certificate.");
                return false;
            }

            logger.log(Level.INFO, "Check property.");
            stats.getPropertyCheckingTimer().start();
            try {
                if (!cpa.getPropChecker().satisfiesProperty(certificate)) {
                    logger.log(Level.SEVERE, "Property violated");
                    return false;
                }
            } finally {
                stats.getPropertyCheckingTimer().stop();
            }
            return true;
        } finally {
            checkResult.set(false);
            readingThread.interrupt();
        }
    }

    @Override
    protected void writeProofToStream(final ObjectOutputStream pOut, final UnmodifiableReachedSet pReached)
            throws IOException, InvalidConfigurationException, InterruptedException {
        Pair<PartialReachedSetDirectedGraph, List<Set<Integer>>> partitioning = ioHelper
                .computePartialReachedSetAndPartition(pReached);

        ioHelper.writeMetadata(pOut, pReached.size(), partitioning.getSecond().size());
        for (Set<Integer> partition : partitioning.getSecond()) {
            ioHelper.writePartition(pOut, partition, partitioning.getFirst());
        }
    }

    @Override
    protected void readProofFromStream(final ObjectInputStream pIn)
            throws ClassNotFoundException, InvalidConfigurationException, IOException {
        ioHelper.readMetadata(pIn, true);
    }

    private class PartitionReader implements Runnable {

        private final AtomicBoolean checkResult;
        private final Semaphore mainSemaphore;

        public PartitionReader(final AtomicBoolean pCheckResult, final Semaphore pPartitionChecked) {
            checkResult = pCheckResult;
            mainSemaphore = pPartitionChecked;
        }

        @Override
        public void run() {
            Triple<InputStream, ZipInputStream, ObjectInputStream> streams = null;
            try {
                streams = openProofStream();
                ObjectInputStream o = streams.getThird();
                ioHelper.readMetadata(o, false);

                for (int i = 0; i < ioHelper.getNumPartitions() && checkResult.get(); i++) {
                    ioHelper.readPartition(o, stats);

                    if (shutdownNotifier.shouldShutdown()) {
                        abortPreparation();
                        break;
                    }
                    mainSemaphore.release();
                }
            } catch (IOException | ClassNotFoundException e) {
                logger.logUserException(Level.SEVERE, e, "Partition reading failed. Stop checking");
                abortPreparation();
            } catch (Exception e2) {
                logger.logException(Level.SEVERE, e2, "Unexpected failure during proof reading");
                abortPreparation();
            } finally {
                if (streams != null) {
                    try {
                        streams.getThird().close();
                        streams.getSecond().close();
                        streams.getFirst().close();
                    } catch (IOException e) {
                    }
                }
            }
        }

        private void abortPreparation() {
            checkResult.set(false);
            mainSemaphore.release();
        }

    }

}