Search in sources :

Example 31 with EMDataSet

use of org.baderlab.csplugins.enrichmentmap.model.EMDataSet in project EnrichmentMapApp by BaderLab.

the class ControlPanelMediator method addNetworkView.

@SuppressWarnings("unchecked")
private void addNetworkView(CyNetworkView netView) {
    invokeOnEDT(() -> {
        EnrichmentMap map = emManager.getEnrichmentMap(netView.getModel().getSUID());
        // Is the new view an EnrichmentMap one?
        if (map != null) {
            EMViewControlPanel viewPanel = getControlPanel().addEnrichmentMapView(netView);
            if (viewPanel != null) {
                // Add listeners to the new panel's fields
                viewPanel.getQValueRadio().addActionListener(evt -> {
                    viewPanel.updateFilterPanel();
                    if (!updating)
                        filterNodesAndEdges(viewPanel, map);
                });
                viewPanel.getPValueRadio().addActionListener(evt -> {
                    viewPanel.updateFilterPanel();
                    if (!updating)
                        filterNodesAndEdges(viewPanel, map);
                });
                SliderBarPanel pvSliderPanel = viewPanel.getPValueSliderPanel();
                SliderBarPanel qvSliderPanel = viewPanel.getQValueSliderPanel();
                SliderBarPanel sSliderPanel = viewPanel.getSimilaritySliderPanel();
                if (pvSliderPanel != null)
                    pvSliderPanel.addChangeListener(evt -> {
                        if (!updating)
                            filterNodesAndEdges(viewPanel, map);
                    });
                if (qvSliderPanel != null)
                    qvSliderPanel.addChangeListener(evt -> {
                        if (!updating)
                            filterNodesAndEdges(viewPanel, map);
                    });
                if (sSliderPanel != null)
                    sSliderPanel.addChangeListener(evt -> {
                        if (!updating)
                            filterNodesAndEdges(viewPanel, map);
                    });
                viewPanel.getDataSetSelector().addPropertyChangeListener("checkedData", evt -> {
                    if (!updating) {
                        viewPanel.updateChartDataCombo();
                        filterNodesAndEdges(viewPanel, map);
                        ChartData data = (ChartData) viewPanel.getChartDataCombo().getSelectedItem();
                        Set<EMDataSet> oldDataSets = filterDataSets((Collection<AbstractDataSet>) evt.getOldValue());
                        Set<EMDataSet> newDataSets = filterDataSets((Collection<AbstractDataSet>) evt.getNewValue());
                        int oldSize = oldDataSets.size();
                        int newSize = newDataSets.size();
                        boolean updateStyle = data != null && data != ChartData.NONE && oldSize != newSize;
                        updateStyle = updateStyle || oldSize == 0 && newSize > 0;
                        updateStyle = updateStyle || oldSize > 0 && newSize == 0;
                        updateStyle = updateStyle || oldSize == 1 && newSize > 1;
                        updateStyle = updateStyle || oldSize > 1 && newSize == 1;
                        if (updateStyle)
                            updateVisualStyle(map, viewPanel);
                        else
                            netView.updateView();
                    }
                });
                viewPanel.getDataSetSelector().getAddButton().addActionListener(evt -> {
                    postAnalysisPanelMediatorProvider.get().showDialog(viewPanel, netView);
                });
                viewPanel.getDataSetSelector().getRemoveButton().addActionListener(evt -> {
                    removeSignatureDataSets(map, viewPanel);
                });
                viewPanel.getChartDataCombo().addItemListener(evt -> {
                    if (!updating && evt.getStateChange() == ItemEvent.SELECTED) {
                        updating = true;
                        try {
                            viewPanel.updateChartCombos();
                        } finally {
                            updating = false;
                        }
                        updateVisualStyle(map, viewPanel, true);
                    }
                });
                viewPanel.getChartTypeCombo().addItemListener(evt -> {
                    if (!updating && evt.getStateChange() == ItemEvent.SELECTED) {
                        updating = true;
                        try {
                            viewPanel.updateChartColorsCombo();
                            viewPanel.updateChartLabelsCheck();
                        } finally {
                            updating = false;
                        }
                        updateVisualStyle(map, viewPanel, true);
                    }
                });
                viewPanel.getChartColorsCombo().addItemListener(evt -> {
                    if (!updating && evt.getStateChange() == ItemEvent.SELECTED)
                        updateVisualStyle(map, viewPanel, true);
                });
                viewPanel.getShowChartLabelsCheck().addActionListener(evt -> {
                    if (!updating)
                        updateVisualStyle(map, viewPanel, true);
                });
                viewPanel.getPublicationReadyCheck().addActionListener(evt -> {
                    if (!updating)
                        updateVisualStyle(map, viewPanel);
                });
                viewPanel.getResetStyleButton().addActionListener(evt -> {
                    updateVisualStyle(map, viewPanel);
                });
                viewPanel.getSetEdgeWidthButton().addActionListener(evt -> {
                    showEdgeWidthDialog();
                });
                viewPanel.updateChartDataCombo();
            }
        }
    });
}
Also used : EMViewControlPanel(org.baderlab.csplugins.enrichmentmap.view.control.ControlPanel.EMViewControlPanel) ViewParams(org.baderlab.csplugins.enrichmentmap.view.control.io.ViewParams) ChartType(org.baderlab.csplugins.enrichmentmap.style.ChartType) EMViewControlPanel(org.baderlab.csplugins.enrichmentmap.view.control.ControlPanel.EMViewControlPanel) Inject(com.google.inject.Inject) AfterInjection(org.baderlab.csplugins.enrichmentmap.AfterInjection) SliderBarPanel(org.baderlab.csplugins.enrichmentmap.view.util.SliderBarPanel) CyCustomGraphics2(org.cytoscape.view.presentation.customgraphics.CyCustomGraphics2) JCheckBoxMenuItem(javax.swing.JCheckBoxMenuItem) CyNetwork(org.cytoscape.model.CyNetwork) Map(java.util.Map) SetCurrentNetworkViewEvent(org.cytoscape.application.events.SetCurrentNetworkViewEvent) LegendPanelMediator(org.baderlab.csplugins.enrichmentmap.view.legend.LegendPanelMediator) FinishStatus(org.cytoscape.work.FinishStatus) JComboBox(javax.swing.JComboBox) CyServiceRegistrar(org.cytoscape.service.util.CyServiceRegistrar) EDGE_DATASET_VALUE_COMPOUND(org.baderlab.csplugins.enrichmentmap.style.EMStyleBuilder.Columns.EDGE_DATASET_VALUE_COMPOUND) Timer(javax.swing.Timer) EMCreationParameters(org.baderlab.csplugins.enrichmentmap.model.EMCreationParameters) ChartData(org.baderlab.csplugins.enrichmentmap.style.ChartData) Columns(org.baderlab.csplugins.enrichmentmap.style.EMStyleBuilder.Columns) ItemEvent(java.awt.event.ItemEvent) EMStyleOptions(org.baderlab.csplugins.enrichmentmap.style.EMStyleOptions) NetworkViewAboutToBeDestroyedListener(org.cytoscape.view.model.events.NetworkViewAboutToBeDestroyedListener) Collection(java.util.Collection) SetCurrentNetworkViewListener(org.cytoscape.application.events.SetCurrentNetworkViewListener) Set(java.util.Set) CyNetworkManager(org.cytoscape.model.CyNetworkManager) FilterMode(org.baderlab.csplugins.enrichmentmap.task.FilterNodesEdgesTask.FilterMode) Collectors(java.util.stream.Collectors) NODE_GS_TYPE(org.baderlab.csplugins.enrichmentmap.style.EMStyleBuilder.Columns.NODE_GS_TYPE) ColorScheme(org.baderlab.csplugins.enrichmentmap.style.ColorScheme) AbstractDataSet(org.baderlab.csplugins.enrichmentmap.model.AbstractDataSet) ColumnDescriptor(org.baderlab.csplugins.enrichmentmap.style.ColumnDescriptor) List(java.util.List) EMDataSet(org.baderlab.csplugins.enrichmentmap.model.EMDataSet) CyApplicationManager(org.cytoscape.application.CyApplicationManager) CySwingApplication(org.cytoscape.application.swing.CySwingApplication) RemoveSignatureDataSetsTask(org.baderlab.csplugins.enrichmentmap.task.postanalysis.RemoveSignatureDataSetsTask) TaskObserver(org.cytoscape.work.TaskObserver) CyNetworkViewManager(org.cytoscape.view.model.CyNetworkViewManager) ApplyEMStyleTask(org.baderlab.csplugins.enrichmentmap.task.ApplyEMStyleTask) ObservableTask(org.cytoscape.work.ObservableTask) Singleton(com.google.inject.Singleton) ActionListener(java.awt.event.ActionListener) VisualStyle(org.cytoscape.view.vizmap.VisualStyle) EDGE_INTERACTION_VALUE_SIG(org.baderlab.csplugins.enrichmentmap.style.EMStyleBuilder.Columns.EDGE_INTERACTION_VALUE_SIG) CyNode(org.cytoscape.model.CyNode) EnrichmentMap(org.baderlab.csplugins.enrichmentmap.model.EnrichmentMap) NetworkViewAboutToBeDestroyedEvent(org.cytoscape.view.model.events.NetworkViewAboutToBeDestroyedEvent) HashMap(java.util.HashMap) Action(javax.swing.Action) TaskIterator(org.cytoscape.work.TaskIterator) HashSet(java.util.HashSet) FilterNodesEdgesTask(org.baderlab.csplugins.enrichmentmap.task.FilterNodesEdgesTask) CyRow(org.cytoscape.model.CyRow) JMenuItem(javax.swing.JMenuItem) PostAnalysisPanelMediator(org.baderlab.csplugins.enrichmentmap.view.postanalysis.PostAnalysisPanelMediator) ShowEnrichmentMapDialogAction(org.baderlab.csplugins.enrichmentmap.actions.ShowEnrichmentMapDialogAction) ChartOptions(org.baderlab.csplugins.enrichmentmap.style.ChartOptions) NetworkViewAddedListener(org.cytoscape.view.model.events.NetworkViewAddedListener) CyTable(org.cytoscape.model.CyTable) NetworkViewAddedEvent(org.cytoscape.view.model.events.NetworkViewAddedEvent) Properties(java.util.Properties) CyCustomGraphics2Factory(org.cytoscape.view.presentation.customgraphics.CyCustomGraphics2Factory) JPopupMenu(javax.swing.JPopupMenu) CyColumnIdentifier(org.cytoscape.view.presentation.property.values.CyColumnIdentifier) EnrichmentMapManager(org.baderlab.csplugins.enrichmentmap.model.EnrichmentMapManager) JOptionPane(javax.swing.JOptionPane) CutoffParam(org.baderlab.csplugins.enrichmentmap.view.control.io.ViewParams.CutoffParam) ActionEvent(java.awt.event.ActionEvent) CytoPanel(org.cytoscape.application.swing.CytoPanel) VisualMappingManager(org.cytoscape.view.vizmap.VisualMappingManager) DialogTaskManager(org.cytoscape.work.swing.DialogTaskManager) CytoPanelComponent(org.cytoscape.application.swing.CytoPanelComponent) Provider(com.google.inject.Provider) EdgeWidthDialog(org.baderlab.csplugins.enrichmentmap.view.postanalysis.EdgeWidthDialog) NODE_GS_TYPE_ENRICHMENT(org.baderlab.csplugins.enrichmentmap.style.EMStyleBuilder.Columns.NODE_GS_TYPE_ENRICHMENT) ForkJoinPool(java.util.concurrent.ForkJoinPool) ChartUtil(org.baderlab.csplugins.enrichmentmap.view.util.ChartUtil) ChartFactoryManager(org.baderlab.csplugins.enrichmentmap.style.ChartFactoryManager) CyNetworkView(org.cytoscape.view.model.CyNetworkView) CyColumnIdentifierFactory(org.cytoscape.view.presentation.property.values.CyColumnIdentifierFactory) EMSignatureDataSet(org.baderlab.csplugins.enrichmentmap.model.EMSignatureDataSet) CyEdge(org.cytoscape.model.CyEdge) WidthFunction(org.baderlab.csplugins.enrichmentmap.style.WidthFunction) Collections(java.util.Collections) SwingUtil.invokeOnEDT(org.baderlab.csplugins.enrichmentmap.view.util.SwingUtil.invokeOnEDT) ChartData(org.baderlab.csplugins.enrichmentmap.style.ChartData) AbstractDataSet(org.baderlab.csplugins.enrichmentmap.model.AbstractDataSet) EMDataSet(org.baderlab.csplugins.enrichmentmap.model.EMDataSet) EnrichmentMap(org.baderlab.csplugins.enrichmentmap.model.EnrichmentMap) SliderBarPanel(org.baderlab.csplugins.enrichmentmap.view.util.SliderBarPanel)

Example 32 with EMDataSet

use of org.baderlab.csplugins.enrichmentmap.model.EMDataSet in project EnrichmentMapApp by BaderLab.

the class HierarchicalClusterTask method cluster.

public Map<Integer, RankValue> cluster(TaskMonitor tm) {
    if (tm == null)
        tm = new NullTaskMonitor();
    tm.setTitle("Hierarchical Cluster");
    tm.setStatusMessage("Loading expression data");
    List<double[]> clusteringExpressionSet = new ArrayList<>(genes.size());
    ArrayList<Integer> labels = new ArrayList<>(genes.size());
    List<String> names = new ArrayList<>(genes.size());
    List<EMDataSet> dataSets = map.getDataSetList();
    final int expressionCount = getTotalExpressionCount(dataSets);
    for (int geneId : genes) {
        // values all default to 0.0
        double[] vals = new double[expressionCount];
        int valsIndex = 0;
        boolean found = false;
        String name = null;
        for (EMDataSet dataSet : dataSets) {
            GeneExpressionMatrix expressionSets = dataSet.getExpressionSets();
            int numConditions = expressionSets.getNumConditions() - 2;
            GeneExpression geneExpression = expressionSets.getExpressionMatrix().get(geneId);
            if (geneExpression != null) {
                found = true;
                name = geneExpression.getName();
                double[] expression = geneExpression.getExpression();
                System.arraycopy(expression, 0, vals, valsIndex, expression.length);
            }
            valsIndex += numConditions;
        }
        if (found) {
            clusteringExpressionSet.add(vals);
            labels.add(geneId);
            names.add(name);
        }
    }
    tm.setStatusMessage("Calculating Distance");
    DistanceMatrix distanceMatrix = new DistanceMatrix(genes.size());
    distanceMatrix.calcDistances(clusteringExpressionSet, distanceMetric);
    distanceMatrix.setLabels(labels);
    tm.setStatusMessage("Clustering");
    AvgLinkHierarchicalClustering clusterResult = new AvgLinkHierarchicalClustering(distanceMatrix);
    //check to see if there more than 1000 genes, if there are use eisen ordering otherwise use bar-joseph
    clusterResult.setOptimalLeafOrdering(genes.size() <= 1000);
    clusterResult.run();
    tm.setStatusMessage("Ranking");
    Map<Integer, RankValue> ranks = new HashMap<>();
    int[] order = clusterResult.getLeafOrder();
    for (int i = 0; i < order.length; i++) {
        Integer geneId = labels.get(order[i]);
        ranks.put(geneId, new RankValue(i + 1, null, false));
    }
    tm.setStatusMessage("");
    return ranks;
}
Also used : HashMap(java.util.HashMap) ArrayList(java.util.ArrayList) AvgLinkHierarchicalClustering(org.baderlab.csplugins.brainlib.AvgLinkHierarchicalClustering) RankValue(org.baderlab.csplugins.enrichmentmap.view.heatmap.table.RankValue) GeneExpressionMatrix(org.baderlab.csplugins.enrichmentmap.model.GeneExpressionMatrix) EMDataSet(org.baderlab.csplugins.enrichmentmap.model.EMDataSet) DistanceMatrix(org.baderlab.csplugins.brainlib.DistanceMatrix) GeneExpression(org.baderlab.csplugins.enrichmentmap.model.GeneExpression) NullTaskMonitor(org.baderlab.csplugins.enrichmentmap.util.NullTaskMonitor)

Example 33 with EMDataSet

use of org.baderlab.csplugins.enrichmentmap.model.EMDataSet in project EnrichmentMapApp by BaderLab.

the class ComputeSimilarityTaskParallel method startComputeSimilarities.

private Map<SimilarityKey, GenesetSimilarity> startComputeSimilarities(TaskMonitor tm, ExecutorService executor, boolean distinct, boolean compound) {
    Set<String> names = map.getAllGeneSetOfInterestNames();
    Map<String, Set<Integer>> unionedGenesets = compound ? map.unionAllGeneSetsOfInterest() : null;
    DiscreteTaskMonitor taskMonitor = discreteTaskMonitor(tm, names.size());
    String edgeType = map.getParams().getEnrichmentEdgeType();
    Map<SimilarityKey, GenesetSimilarity> similarities = new ConcurrentHashMap<>();
    Collection<EMDataSet> dataSets = map.getDataSetList();
    for (final String geneset1Name : names) {
        // Compute similarities in batches, creating a Runnable for every similarity pair would create too many objects
        executor.execute(() -> {
            loop: for (final String geneset2Name : names) {
                if (Thread.interrupted())
                    break loop;
                if (geneset1Name.equalsIgnoreCase(geneset2Name))
                    //don't compare two identical gene sets
                    continue;
                if (distinct) {
                    for (EMDataSet dataset : dataSets) {
                        SimilarityKey key = new SimilarityKey(geneset1Name, geneset2Name, edgeType, dataset.getName());
                        if (!similarities.containsKey(key)) {
                            Map<String, GeneSet> genesets = dataset.getGeneSetsOfInterest().getGeneSets();
                            GeneSet geneset1 = genesets.get(geneset1Name);
                            GeneSet geneset2 = genesets.get(geneset2Name);
                            if (geneset1 != null && geneset2 != null) {
                                // returns null if the similarity coefficient doesn't pass the cutoff
                                GenesetSimilarity similarity = computeGenesetSimilarity(map.getParams(), geneset1Name, geneset2Name, geneset1.getGenes(), geneset2.getGenes(), dataset.getName());
                                if (similarity != null) {
                                    similarities.put(key, similarity);
                                }
                            }
                        }
                    }
                }
                if (compound) {
                    SimilarityKey key = new SimilarityKey(geneset1Name, geneset2Name, edgeType, null);
                    if (!similarities.containsKey(key)) {
                        Set<Integer> geneset1 = unionedGenesets.get(geneset1Name);
                        Set<Integer> geneset2 = unionedGenesets.get(geneset2Name);
                        // returns null if the similarity coefficient doesn't pass the cutoff
                        GenesetSimilarity similarity = computeGenesetSimilarity(map.getParams(), geneset1Name, geneset2Name, geneset1, geneset2, "compound");
                        if (similarity != null) {
                            similarities.put(key, similarity);
                        }
                    }
                }
            }
            taskMonitor.inc();
        });
    }
    return similarities;
}
Also used : DiscreteTaskMonitor(org.baderlab.csplugins.enrichmentmap.util.DiscreteTaskMonitor) GeneSet(org.baderlab.csplugins.enrichmentmap.model.GeneSet) Set(java.util.Set) EMDataSet(org.baderlab.csplugins.enrichmentmap.model.EMDataSet) SimilarityKey(org.baderlab.csplugins.enrichmentmap.model.SimilarityKey) EMDataSet(org.baderlab.csplugins.enrichmentmap.model.EMDataSet) GenesetSimilarity(org.baderlab.csplugins.enrichmentmap.model.GenesetSimilarity) ConcurrentHashMap(java.util.concurrent.ConcurrentHashMap) GeneSet(org.baderlab.csplugins.enrichmentmap.model.GeneSet) ConcurrentHashMap(java.util.concurrent.ConcurrentHashMap) EnrichmentMap(org.baderlab.csplugins.enrichmentmap.model.EnrichmentMap) Map(java.util.Map)

Example 34 with EMDataSet

use of org.baderlab.csplugins.enrichmentmap.model.EMDataSet in project EnrichmentMapApp by BaderLab.

the class CreateEMNetworkTask method createNodes.

private Map<String, CyNode> createNodes(CyNetwork network) {
    Map<String, CyNode> nodes = new HashMap<>();
    Map<String, Set<Integer>> geneSets = map.unionAllGeneSetsOfInterest();
    for (String genesetName : geneSets.keySet()) {
        CyNode node = network.addNode();
        nodes.put(genesetName, node);
        // Set common attributes
        CyRow row = network.getRow(node);
        row.set(CyNetwork.NAME, genesetName);
        Columns.NODE_FORMATTED_NAME.set(row, prefix, null, formatLabel(genesetName));
        // MKTODO why is this column needed?
        Columns.NODE_NAME.set(row, prefix, null, genesetName);
        Columns.NODE_GS_DESCR.set(row, prefix, null, map.findGeneSetDescription(genesetName));
        Columns.NODE_GS_TYPE.set(row, prefix, null, Columns.NODE_GS_TYPE_ENRICHMENT);
        Set<Integer> geneIds = geneSets.get(genesetName);
        List<String> genes = geneIds.stream().map(map::getGeneFromHashKey).collect(Collectors.toList());
        Columns.NODE_GENES.set(row, prefix, null, genes);
        Columns.NODE_GS_SIZE.set(row, prefix, null, genes.size());
        // Set attributes specific to each dataset
        for (EMDataSet ds : map.getDataSetList()) {
            if (ds.getGeneSetsOfInterest().getGeneSets().containsKey(genesetName))
                ds.addNodeSuid(node.getSUID());
            Map<String, EnrichmentResult> enrichmentResults = ds.getEnrichments().getEnrichments();
            EnrichmentResult result = enrichmentResults.get(genesetName);
            // if result is null it will fail both instanceof checks
            if (result instanceof GSEAResult)
                setGSEAResultNodeAttributes(row, ds.getName(), (GSEAResult) result);
            else if (result instanceof GenericResult)
                setGenericResultNodeAttributes(row, ds.getName(), (GenericResult) result);
        }
    }
    return nodes;
}
Also used : EnrichmentResult(org.baderlab.csplugins.enrichmentmap.model.EnrichmentResult) GSEAResult(org.baderlab.csplugins.enrichmentmap.model.GSEAResult) Set(java.util.Set) EMDataSet(org.baderlab.csplugins.enrichmentmap.model.EMDataSet) HashMap(java.util.HashMap) CyRow(org.cytoscape.model.CyRow) GenericResult(org.baderlab.csplugins.enrichmentmap.model.GenericResult) CyNode(org.cytoscape.model.CyNode) EMDataSet(org.baderlab.csplugins.enrichmentmap.model.EMDataSet)

Example 35 with EMDataSet

use of org.baderlab.csplugins.enrichmentmap.model.EMDataSet in project EnrichmentMapApp by BaderLab.

the class CreateDiseaseSignatureTaskFactory method createTaskIterator.

@Override
public TaskIterator createTaskIterator() {
    // Make sure that the minimum information is set in the current set of parameters
    EnrichmentMap map = emManager.getEnrichmentMap(netView.getModel().getSUID());
    StringBuilder errorBuilder = new StringBuilder();
    checkMinimalRequirements(errorBuilder, params);
    if (params.getRankTestParameters().getType().isMannWhitney() && map.getAllRanks().isEmpty())
        errorBuilder.append("Mann-Whitney requires ranks. \n");
    this.errors = errorBuilder.toString();
    if (errors.isEmpty()) {
        ControlPanelMediator controlPanelMediator = controlPanelMediatorProvider.get();
        EMStyleOptions options = controlPanelMediator.createStyleOptions(netView);
        CyCustomGraphics2<?> chart = controlPanelMediator.createChart(options);
        List<EMDataSet> dataSetList = getDataSets(map);
        TaskIterator tasks = new TaskIterator();
        tasks.append(signatureTaskFactory.create(params, map, dataSetList));
        tasks.append(applyStyleTaskFactory.create(options, chart, false));
        return tasks;
    } else {
        // MKTODO not entirely sure what to do in this case, just return an empty iterator I guess...
        return new TaskIterator(new AbstractTask() {

            @Override
            public void run(TaskMonitor taskMonitor) throws Exception {
                throw new RuntimeException(errors);
            }
        });
    }
}
Also used : EMStyleOptions(org.baderlab.csplugins.enrichmentmap.style.EMStyleOptions) AbstractTask(org.cytoscape.work.AbstractTask) EnrichmentMap(org.baderlab.csplugins.enrichmentmap.model.EnrichmentMap) ControlPanelMediator(org.baderlab.csplugins.enrichmentmap.view.control.ControlPanelMediator) TaskIterator(org.cytoscape.work.TaskIterator) TaskMonitor(org.cytoscape.work.TaskMonitor) EMDataSet(org.baderlab.csplugins.enrichmentmap.model.EMDataSet)

Aggregations

EMDataSet (org.baderlab.csplugins.enrichmentmap.model.EMDataSet)58 EnrichmentMap (org.baderlab.csplugins.enrichmentmap.model.EnrichmentMap)30 DataSetFiles (org.baderlab.csplugins.enrichmentmap.model.DataSetFiles)20 Test (org.junit.Test)19 Method (org.baderlab.csplugins.enrichmentmap.model.EMDataSet.Method)13 EnrichmentMapParameters (org.baderlab.csplugins.enrichmentmap.model.EnrichmentMapParameters)11 Map (java.util.Map)10 EMCreationParameters (org.baderlab.csplugins.enrichmentmap.model.EMCreationParameters)10 Set (java.util.Set)8 EnrichmentResult (org.baderlab.csplugins.enrichmentmap.model.EnrichmentResult)8 GeneSet (org.baderlab.csplugins.enrichmentmap.model.GeneSet)7 CyNode (org.cytoscape.model.CyNode)7 JPanel (javax.swing.JPanel)6 Inject (com.google.inject.Inject)5 Color (java.awt.Color)5 ArrayList (java.util.ArrayList)5 List (java.util.List)5 JLabel (javax.swing.JLabel)5 CyEdge (org.cytoscape.model.CyEdge)5 CyNetwork (org.cytoscape.model.CyNetwork)5