Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 

A

A_FOLLOWED_BY_INSERTION_BASE - Static variable in class org.broadinstitute.hellbender.utils.pileup.PileupElement
 
AB_FILTER - Static variable in class picard.vcf.filter.AlleleBalanceFilter
The filter string used for sites that fail the allele balance filter.
AbstractAlignmentMerger - Class in org.broadinstitute.hellbender.utils.read.mergealignment
Abstract class that coordinates the general task of taking in a set of alignment information, possibly in SAM format, possibly in other formats, and merging that with the set of all reads for which alignment was attempted, stored in an unmapped SAM file.
AbstractAlignmentMerger(File, File, File, boolean, boolean, boolean, SAMProgramRecord, List<String>, List<String>, Integer, Integer, List<SamPairUtil.PairOrientation>, SAMFileHeader.SortOrder, PrimaryAlignmentSelectionStrategy, boolean) - Constructor for class org.broadinstitute.hellbender.utils.read.mergealignment.AbstractAlignmentMerger
Constructor
AbstractAlignmentMerger - Class in picard.sam
Abstract class that coordinates the general task of taking in a set of alignment information, possibly in SAM format, possibly in other formats, and merging that with the set of all reads for which alignment was attempted, stored in an unmapped SAM file.
AbstractAlignmentMerger(File, File, File, boolean, boolean, boolean, SAMProgramRecord, List<String>, List<String>, Integer, Integer, List<SamPairUtil.PairOrientation>, SAMFileHeader.SortOrder, PrimaryAlignmentSelectionStrategy, boolean, boolean) - Constructor for class picard.sam.AbstractAlignmentMerger
constructor with a default setting for unmappingReadsStrategy.
AbstractAlignmentMerger(File, File, File, boolean, boolean, boolean, SAMProgramRecord, List<String>, List<String>, Integer, Integer, List<SamPairUtil.PairOrientation>, SAMFileHeader.SortOrder, PrimaryAlignmentSelectionStrategy, boolean, boolean, AbstractAlignmentMerger.UnmappingReadStrategy) - Constructor for class picard.sam.AbstractAlignmentMerger
Constructor
AbstractAlignmentMerger.UnmappingReadStrategy - Enum in picard.sam
 
AbstractConcordanceWalker - Class in org.broadinstitute.hellbender.engine
Base class for concordance walkers, which process one variant at a time from one or more sources of variants, with optional contextual information from a reference, sets of reads, and/or supplementary sources of Features.
AbstractConcordanceWalker() - Constructor for class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker
 
AbstractConcordanceWalker.TruthVersusEval - Class in org.broadinstitute.hellbender.engine
store a truth vc in case of a false negative, an eval vc in case of a false positive, or a concordance pair of truth and eval in case of a true positive.
AbstractIlluminaPositionFileReader - Class in picard.illumina.parser.readers
The position files of Illumina are nearly the same form: Pos files consist of text based tabbed x-y coordinate float pairs, locs files are binary x-y float pairs, clocs are compressed binary x-y float pairs.
AbstractIlluminaPositionFileReader(File) - Constructor for class picard.illumina.parser.readers.AbstractIlluminaPositionFileReader
 
AbstractIlluminaPositionFileReader(File, int, int) - Constructor for class picard.illumina.parser.readers.AbstractIlluminaPositionFileReader
Use this ctor if lane and tile are not discernible from file name.
AbstractIlluminaPositionFileReader.PositionInfo - Class in picard.illumina.parser.readers
 
AbstractInputParser - Class in picard.util
Class for parsing text files where each line consists of fields separated by whitespace.
AbstractInputParser() - Constructor for class picard.util.AbstractInputParser
 
AbstractLocatableCollection<METADATA extends LocatableMetadata,RECORD extends htsjdk.samtools.util.Locatable> - Class in org.broadinstitute.hellbender.tools.copynumber.formats.collections
Represents a sequence dictionary, an immutable, coordinate-sorted (with no overlaps allowed) collection of records that extend Locatable (although contigs are assumed to be non-null when writing to file), a set of mandatory column headers given by a TableColumnCollection, and lambdas for reading and writing records.
AbstractMarkDuplicatesCommandLineProgram - Class in org.broadinstitute.hellbender.utils.read.markduplicates
Abstract class that holds parameters and methods common to classes that perform duplicate detection and/or marking within SAM/BAM/CRAM files.
AbstractMarkDuplicatesCommandLineProgram() - Constructor for class org.broadinstitute.hellbender.utils.read.markduplicates.AbstractMarkDuplicatesCommandLineProgram
 
AbstractMarkDuplicatesCommandLineProgram - Class in picard.sam.markduplicates.util
Abstract class that holds parameters and methods common to classes that perform duplicate detection and/or marking within SAM/BAM files.
AbstractMarkDuplicatesCommandLineProgram() - Constructor for class picard.sam.markduplicates.util.AbstractMarkDuplicatesCommandLineProgram
 
AbstractMarkDuplicatesCommandLineProgram.SamHeaderAndIterator - Class in org.broadinstitute.hellbender.utils.read.markduplicates
Little class used to package up a header and an iterable/iterator.
AbstractMarkDuplicatesCommandLineProgram.SamHeaderAndIterator - Class in picard.sam.markduplicates.util
Little class used to package up a header and an iterable/iterator.
AbstractOpticalDuplicateFinderCommandLineProgram - Class in org.broadinstitute.hellbender.utils.read.markduplicates
Abstract class that holds parameters and methods common to classes that optical duplicate detection.
AbstractOpticalDuplicateFinderCommandLineProgram() - Constructor for class org.broadinstitute.hellbender.utils.read.markduplicates.AbstractOpticalDuplicateFinderCommandLineProgram
 
AbstractOpticalDuplicateFinderCommandLineProgram - Class in picard.sam.markduplicates.util
Abstract class that holds parameters and methods common to classes that optical duplicate detection.
AbstractOpticalDuplicateFinderCommandLineProgram() - Constructor for class picard.sam.markduplicates.util.AbstractOpticalDuplicateFinderCommandLineProgram
 
AbstractRecordCollection<METADATA extends Metadata,RECORD> - Class in org.broadinstitute.hellbender.tools.copynumber.formats.collections
Represents METADATA (which can be represented as a SAMFileHeader), an immutable collection of records, a set of mandatory column headers given by a TableColumnCollection, and lambdas for reading and writing records.
AbstractSampleLocatableCollection<RECORD extends htsjdk.samtools.util.Locatable> - Class in org.broadinstitute.hellbender.tools.copynumber.formats.collections
Represents a sample name, a sequence dictionary, an immutable, coordinate-sorted (with no overlaps allowed) collection of records that extend Locatable (although contigs are assumed to be non-null when writing to file), a set of mandatory column headers given by a TableColumnCollection, and lambdas for reading and writing records.
AbstractSampleRecordCollection<RECORD> - Class in org.broadinstitute.hellbender.tools.copynumber.formats.collections
Represents a sample name, an immutable collection of records, a set of mandatory column headers given by a TableColumnCollection, and lambdas for reading and writing records.
AbstractWgsMetricsCollector<T extends htsjdk.samtools.util.AbstractRecordAndOffset> - Class in picard.analysis
Class for collecting data on reference coverage, base qualities and excluded bases from one AbstractLocusInfo object for CollectWgsMetrics.
accept(int, int) - Method in interface org.broadinstitute.hellbender.utils.functional.IntBiConsumer
 
acceptRead(SAMRecord, ReferenceSequence) - Method in class picard.analysis.artifacts.CollectSequencingArtifactMetrics
 
acceptRead(SAMRecord, ReferenceSequence) - Method in class picard.analysis.CollectAlignmentSummaryMetrics
 
acceptRead(SAMRecord, ReferenceSequence) - Method in class picard.analysis.CollectBaseDistributionByCycle
 
acceptRead(SAMRecord, ReferenceSequence) - Method in class picard.analysis.CollectGcBiasMetrics
 
acceptRead(SAMRecord, ReferenceSequence) - Method in class picard.analysis.CollectInsertSizeMetrics
 
acceptRead(SAMRecord, ReferenceSequence) - Method in class picard.analysis.CollectQualityYieldMetrics
 
acceptRead(SAMRecord, ReferenceSequence) - Method in class picard.analysis.CollectRnaSeqMetrics
 
acceptRead(SAMRecord, ReferenceSequence) - Method in class picard.analysis.MeanQualityByCycle
 
acceptRead(SAMRecord, ReferenceSequence) - Method in class picard.analysis.QualityScoreDistribution
 
acceptRead(SAMRecord, ReferenceSequence) - Method in class picard.analysis.SinglePassSamProgram
Should be implemented by subclasses to accept SAMRecords one at a time.
acceptRecord(SAMRecord, ReferenceSequence) - Method in class org.broadinstitute.hellbender.metrics.MultiLevelCollector
Construct a argument of ARGTYPE using the given SAMRecord and ReferenceSequence then pass this value to all collectors that should include this record
acceptRecord(SAMRecord, ReferenceSequence) - Method in class org.broadinstitute.hellbender.metrics.MultiLevelReducibleCollector
Construct an argument of ARGTYPE using the given SAMRecord and ReferenceSequence, then pass this value to all collectors that should include this record
acceptRecord(InsertSizeMetricsCollectorArgs) - Method in class org.broadinstitute.hellbender.metrics.PerUnitInsertSizeMetricsCollector
 
acceptRecord(ARGTYPE) - Method in interface org.broadinstitute.hellbender.metrics.PerUnitMetricCollector
Add a SAMRecord (with ReferenceSequence and Read Group info) to the metric(s) being calculated)
acceptRecord(PerUnitExampleMultiMetricsCollectorArgs) - Method in class org.broadinstitute.hellbender.tools.examples.metrics.multi.PerUnitExampleMultiMetricsCollector
 
acceptRecord(SAMRecord, ReferenceSequence) - Method in class picard.analysis.AlignmentSummaryMetricsCollector
 
acceptRecord(SAMRecord, ReferenceSequence) - Method in class picard.analysis.CollectQualityYieldMetrics.QualityYieldMetricsCollector
 
acceptRecord(SAMRecord, ReferenceSequence) - Method in class picard.analysis.directed.InsertSizeMetricsCollector
 
acceptRecord(InsertSizeCollectorArgs) - Method in class picard.analysis.directed.InsertSizeMetricsCollector.PerUnitInsertSizeMetricsCollector
 
acceptRecord(SAMRecord) - Method in class picard.analysis.directed.RnaSeqMetricsCollector.PerUnitRnaSeqMetricsCollector
 
acceptRecord(SAMRecord) - Method in class picard.analysis.directed.TargetMetricsCollector.PerUnitTargetMetricCollector
Adds information about an individual SAMRecord to the statistics.
acceptRecord(GcBiasCollectorArgs) - Method in class picard.analysis.GcBiasMetricsCollector.PerUnitGcBiasMetricsCollector
 
acceptRecord(SAMRecord, ReferenceSequence) - Method in class picard.metrics.MultiLevelCollector
Construct a argument of ARGTYPE using the given SAMRecord and ReferenceSequence then pass this value to all collectors that should include this record
acceptRecord(ARGTYPE) - Method in interface picard.metrics.PerUnitMetricCollector
Add a SAMRecord (with ReferenceSequence and Read Group info) to the metric(s) being calculated)
accessibleTruthSites - Variable in class org.broadinstitute.hellbender.tools.walkers.vqsr.Tranche
 
accessionToTaxId - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTaxonomyDatabase
 
accumulate(VariantContext) - Method in class picard.vcf.CallingMetricAccumulator
Incorporates the provided variant's data into the metric analysis.
accumulate(VariantContext) - Method in class picard.vcf.GvcfMetricAccumulator
 
accumulate(VariantContext) - Method in interface picard.vcf.processor.VariantProcessor.Accumulator
 
AccumulateVariantCallingMetrics - Class in picard.vcf
Combines multiple Variant Calling Metrics files into a single file.
AccumulateVariantCallingMetrics() - Constructor for class picard.vcf.AccumulateVariantCallingMetrics
 
ACCUMULATION_LEVEL - Variable in class picard.analysis.GcBiasDetailMetrics
 
ACCUMULATION_LEVEL - Variable in class picard.analysis.GcBiasSummaryMetrics
 
accumulationLevels - Variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.MetricAccumulationLevelArgumentCollection
 
accumulators() - Method in interface picard.vcf.processor.VariantAccumulatorExecutor
Returns the VariantProcessor.Accumulators associated with this executor.
accumulators() - Method in class picard.vcf.processor.VariantAccumulatorExecutor.MultiThreadedChunkBased
 
ACCURACY - Variable in class picard.sam.DownsampleSam
 
ACTION - Variable in class picard.util.IntervalListTools
 
activateWriting() - Method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.OverhangFixingManager
Activates output writing for the Overhang Fixing Manager.
ACTIVE_CLASS_PADDING_HYBRID_MODE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineDenoisingModelArgumentCollection
 
activeProbThreshold - Variable in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
activeProbThreshold - Variable in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerSpark
 
activeProbThreshold - Variable in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark.ShardingArgumentCollection
 
activeProbThreshold - Variable in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfile
 
ActivityProfile - Class in org.broadinstitute.hellbender.utils.activityprofile
Class holding information about per-base activity scores for assembly region traversal
ActivityProfile(int, double, SAMFileHeader) - Constructor for class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfile
Create a new empty ActivityProfile
ActivityProfile(int, double, Set<SimpleInterval>, SAMFileHeader) - Constructor for class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfile
Create a empty ActivityProfile, restricting output to profiles overlapping intervals, if not null
activityProfileOut - Variable in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
If provided, this walker will write out its activity profile (per bp probabilities of being active) to this file in the IGV formatted TAB deliminated output: http://www.broadinstitute.org/software/igv/IGV Intended to make debugging the activity profile calculations easier
ActivityProfileState - Class in org.broadinstitute.hellbender.utils.activityprofile
Captures the probability that a specific locus in the genome represents an "active" site containing real variation.
ActivityProfileState(SimpleInterval, double) - Constructor for class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfileState
Create a new ActivityProfileState at loc with probability of being active of activeProb
ActivityProfileState(SimpleInterval, double, ActivityProfileState.Type, Number) - Constructor for class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfileState
Create a new ActivityProfileState at loc with probability of being active of activeProb that maintains some information about the result state and value The only state value in use is HIGH_QUALITY_SOFT_CLIPS, and here the value is interpreted as the number of bp affected by the soft clips.
ActivityProfileState.Type - Enum in org.broadinstitute.hellbender.utils.activityprofile
The type of the value returned by ActivityProfileState.getResultValue()
ADAMAX_BETA_1_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection
 
ADAMAX_BETA_2_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection
 
ADAPTER_SEQUENCE - Variable in class picard.analysis.CollectAlignmentSummaryMetrics
 
ADAPTER_TRUNCATION_LENGTH - Variable in class picard.illumina.MarkIlluminaAdapters
 
AdapterMarker - Class in picard.util
Store one or more AdapterPairs to use to mark adapter sequence of SAMRecords.
AdapterMarker(AdapterPair...) - Constructor for class picard.util.AdapterMarker
Truncates adapters to DEFAULT_ADAPTER_LENGTH
AdapterMarker(int, AdapterPair...) - Constructor for class picard.util.AdapterMarker
 
AdapterPair - Interface in org.broadinstitute.hellbender.utils.illumina
 
AdapterPair - Interface in picard.util
 
ADAPTERS - Variable in class picard.illumina.MarkIlluminaAdapters
 
ADAPTERS_TO_CHECK - Variable in class picard.illumina.IlluminaBasecallsToFastq
Deprecated.
ADAPTERS_TO_CHECK - Variable in class picard.illumina.IlluminaBasecallsToSam
 
adapterSequence - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
adapterTrimIlluminaPairedReads(SAMRecord, SAMRecord) - Method in class picard.util.AdapterMarker
 
adapterTrimIlluminaPairedReads(SAMRecord, SAMRecord, int, double) - Method in class picard.util.AdapterMarker
Overrides defaults for minMatchBases and maxErrorRate
adapterTrimIlluminaPairedReads(SAMRecord, SAMRecord, AdapterPair) - Static method in class picard.util.ClippingUtility
Deprecated.
Use the varargs version. This no longer returns a warning string..
adapterTrimIlluminaPairedReads(SAMRecord, SAMRecord, AdapterPair, int, double) - Static method in class picard.util.ClippingUtility
Deprecated.
Use the varargs version. This no longer returns a warning string..
adapterTrimIlluminaPairedReads(SAMRecord, SAMRecord, AdapterPair...) - Static method in class picard.util.ClippingUtility
Invokes adapterTrimIlluminaPairedReads with default less stringent parameters for a pair of reads.
adapterTrimIlluminaPairedReads(SAMRecord, SAMRecord, int, double, AdapterPair...) - Static method in class picard.util.ClippingUtility
Invokes adapterTrimIlluminaRead with explicit parameters for a pair of reads.
adapterTrimIlluminaSingleRead(SAMRecord) - Method in class picard.util.AdapterMarker
 
adapterTrimIlluminaSingleRead(SAMRecord, int, double) - Method in class picard.util.AdapterMarker
Overrides defaults for minMatchBases and maxErrorRate
adapterTrimIlluminaSingleRead(SAMRecord, AdapterPair) - Static method in class picard.util.ClippingUtility
Deprecated.
Use the varargs version. This no longer returns a warning string..
adapterTrimIlluminaSingleRead(SAMRecord, AdapterPair, int, double) - Static method in class picard.util.ClippingUtility
Deprecated.
Use the varargs version. This no longer returns a warning string..
adapterTrimIlluminaSingleRead(SAMRecord, AdapterPair...) - Static method in class picard.util.ClippingUtility
Invokes adapterTrimIlluminRead with default parameters for a single read.
adapterTrimIlluminaSingleRead(SAMRecord, int, double, AdapterPair...) - Static method in class picard.util.ClippingUtility
Invokes adapterTrimIlluminRead with explicit matching thresholds for a single read.
AdapterTrimTransformer - Class in org.broadinstitute.hellbender.transformers
Trims (hard clips) adapter sequences from read ends.
AdapterTrimTransformer(int, int, List<String>) - Constructor for class org.broadinstitute.hellbender.transformers.AdapterTrimTransformer
 
AdapterUtility - Class in picard.analysis
A utility class for matching reads to adapters.
AdapterUtility(List<String>) - Constructor for class picard.analysis.AdapterUtility
 
AdaptiveMetropolisSampler - Class in org.broadinstitute.hellbender.utils.mcmc
Metropolis MCMC sampler using an adaptive step size that increases / decreases in order to decrease / increase acceptance rate to some desired value.
AdaptiveMetropolisSampler(double, double, double, double, double, double) - Constructor for class org.broadinstitute.hellbender.utils.mcmc.AdaptiveMetropolisSampler
 
AdaptiveMetropolisSampler(double, double, double, double) - Constructor for class org.broadinstitute.hellbender.utils.mcmc.AdaptiveMetropolisSampler
 
add(GATKRead) - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
Add read to this region Read must have alignment start >= than the last read currently in this active region.
add(JavaSparkContext, JavaRDD<GATKRead>, ReferenceMultiSource, JavaRDD<GATKVariant>, List<String>, JoinStrategy, SAMSequenceDictionary, int, int) - Static method in class org.broadinstitute.hellbender.engine.spark.AddContextDataToReadSpark
Add context data (ReadContextData) to reads.
add(JavaSparkContext, List<SimpleInterval>, String, List<GATKVariant>, ReadFilter, ReferenceMultiSource) - Static method in class org.broadinstitute.hellbender.engine.spark.AddContextDataToReadSparkOptimized
Create shards with reads, variants, and reference bases, using default values for shard sizes and margin.
add(AnnotatedInterval) - Method in interface org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalWriter
Write one region to the file.
add(AnnotatedInterval) - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.SimpleAnnotatedIntervalWriter
Write one region to the file.
add(GATKRead) - Method in class org.broadinstitute.hellbender.tools.FlagStat.FlagStatus
 
add(PSPathogenTaxonScore) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenTaxonScore
 
add(T) - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchCollection
 
add(long) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LargeLongHopscotchSet
 
add(long) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongBloomFilter
 
add(long) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongHopscotchSet
 
add(long, int) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongHopscotchSet
 
add(byte[], byte[]) - Method in class org.broadinstitute.hellbender.tools.validation.CompareMatrix
 
add(CompareMatrix) - Method in class org.broadinstitute.hellbender.tools.validation.CompareMatrix
 
add(Haplotype) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResultSet
Adds a haplotype to the result set without indicating a generating assembly result.
add(Haplotype, AssemblyResult) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResultSet
Adds simultaneously a haplotype and the generating assembly-result.
add(BaseEdge) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseEdge
Add edge to this edge, updating isRef and multiplicity as appropriate isRef is simply the or of this and edge multiplicity is the sum
add(int, byte) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadErrorCorrector.CorrectionSet
Add a base to this correction set at a particular offset, measured from the start of the read
add(ActivityProfileState) - Method in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfile
Add the next ActivityProfileState to this profile.
add(int) - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
Add an integer value to the set.
add(Integer) - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
 
add(E) - Method in class org.broadinstitute.hellbender.utils.collections.IndexedSet
Adds a new element to the set.
add(T) - Method in class org.broadinstitute.hellbender.utils.CompressedDataList
 
add(T, int) - Method in class org.broadinstitute.hellbender.utils.CompressedDataList
 
add(CompressedDataList<T>) - Method in class org.broadinstitute.hellbender.utils.CompressedDataList
 
add(GenomeLoc) - Method in class org.broadinstitute.hellbender.utils.GenomeLocSortedSet
Adds a GenomeLoc to the collection, inserting at the correct sorted position into the set.
add(GenomeLoc, boolean) - Method in class org.broadinstitute.hellbender.utils.GenomeLocSortedSet
Adds a GenomeLoc to the collection, inserting at the correct sorted position into the set.
add(GATKRead) - Method in class org.broadinstitute.hellbender.utils.haplotype.HaplotypeBAMDestination
Write a read to the output specified by this destination.
add(GATKRead) - Method in class org.broadinstitute.hellbender.utils.haplotype.SAMFileDestination
Write a read to the output file specified by this destination.
add(Double) - Method in class org.broadinstitute.hellbender.utils.Histogram
Add a value to be stored in the histogram
add(Double, int) - Method in class org.broadinstitute.hellbender.utils.Histogram
Add multiple copies of the same value into the histogram to be stored in the histogram
add(Histogram) - Method in class org.broadinstitute.hellbender.utils.Histogram
Combine two histogram objects that have the same bin by adding the values to each bin
add(double) - Method in class org.broadinstitute.hellbender.utils.MathUtils.RunningAverage
 
add(Nucleotide) - Method in class org.broadinstitute.hellbender.utils.Nucleotide.Counter
Increases by 1 the count for a nucleotide.
add(byte) - Method in class org.broadinstitute.hellbender.utils.Nucleotide.Counter
Increases the nucleotide that corresponds to the input base own count by 1.
add(int, double, double, double, double, double, double, int) - Method in class org.broadinstitute.hellbender.utils.solver.SynchronizedUnivariateSolver
Add a solver jobDescription
add(int, double, double, double, double, double, int) - Method in class org.broadinstitute.hellbender.utils.solver.SynchronizedUnivariateSolver
Add a solver jobDescription using the default function accuracy SynchronizedUnivariateSolver.DEFAULT_FUNCTION_ACCURACY
add(String) - Method in class org.broadinstitute.hellbender.utils.test.ArgumentsBuilder
Add a string to the arguments list Strings are processed specially, they are reformatted to match the new unix style arguments
add(Object) - Method in class org.broadinstitute.hellbender.utils.test.ArgumentsBuilder
Add any object's string representation to the arguments list
add(VariantContext) - Method in class org.broadinstitute.hellbender.utils.variant.writers.GVCFWriter
Add a VariantContext to this writer for emission Requires that the VC have exactly one genotype
add(HaplotypeProbabilities) - Method in class picard.fingerprint.Fingerprint
 
add(PedFile.PedTrio) - Method in class picard.pedigree.PedFile
Adds a trio to the PedFile keyed by the individual id.
add(ReadEndsForMateCigar, SamRecordTrackingBuffer, DuplicationMetrics) - Method in class picard.sam.markduplicates.util.MarkQueue
Add a record to the mark queue.
add(ReadEndsForMateCigar) - Method in class picard.sam.markduplicates.util.PhysicalLocationForMateCigarSet
Adds the end to this set, if not already added based on physical location
ADD_MATE_CIGAR - Variable in class picard.sam.FixMateInformation
 
ADD_MATE_CIGAR - Variable in class picard.sam.MergeBamAlignment
 
ADD_OUTPUT_SAM_PROGRAM_RECORD - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
ADD_OUTPUT_VCF_COMMANDLINE - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
ADD_PG_TAG_TO_READS - Variable in class picard.sam.util.PGTagArgumentCollection
 
addAccession(String, long) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenReferenceTaxonProperties
 
addAll(Collection<GATKRead>) - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
Add all readsToAdd to this region
addAll(long[]) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LargeLongHopscotchSet
 
addAll(long[]) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongBloomFilter
 
addAll(long[]) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongHopscotchSet
 
addAll(int...) - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
Add a arbitrary number of integers to the set.
addAll(Collection<? extends Integer>) - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
 
addAll(int[], int, int) - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
Add all values within a range in an integer array.
addAll(CountSet) - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
Add all elements present in a int-set.
addAll(Collection<Number>) - Method in class org.broadinstitute.hellbender.utils.MathUtils.RunningAverage
 
addAll(byte[]) - Method in class org.broadinstitute.hellbender.utils.Nucleotide.Counter
Increase by one the count for a nucleotide for each occurrence of such in the input byte array base codes.
addAllLevelsToFile(MetricsFile<METRIC_TYPE, HISTOGRAM_KEY>) - Method in class org.broadinstitute.hellbender.metrics.MultiLevelCollector
Add all metrics to the given file in the following MetricAccumulationLevel order ALL_READS, SAMPLE, LIBRARY, READ_GROUP.
addAllLevelsToFile(MetricsFile<METRIC_TYPE, HISTOGRAM_KEY>) - Method in class org.broadinstitute.hellbender.metrics.MultiLevelReducibleCollector
Add all metrics to the given file in the following MetricAccumulationLevel order ALL_READS, SAMPLE, LIBRARY, READ_GROUP.
addAllLevelsToFile(MetricsFile<METRIC_TYPE, Histogram_KEY>) - Method in class picard.metrics.MultiLevelCollector
Add all metrics to the given file in the following MetricAccumulationLevel order ALL_READS, SAMPLE, LIBRARY, READ_GROUP.
addArg(String) - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
addArg(String, String) - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
addArgs(Object...) - Method in class org.broadinstitute.hellbender.utils.R.RScriptExecutor
Adds args to the end of the Rscript command line.
addArgs() - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
addArgument(String, String) - Method in class org.broadinstitute.hellbender.utils.test.ArgumentsBuilder
add an argument with a given value to this builder
addArgumentWithValueThatIncludesWhitespace(String, String) - Method in class org.broadinstitute.hellbender.utils.test.ArgumentsBuilder
Add an argument with a given value to this builder without splitting the value string into multiple arguments at whitespace.
addBAQTag(GATKRead, byte[]) - Static method in class org.broadinstitute.hellbender.utils.baq.BAQ
 
addBase(int) - Method in class picard.analysis.directed.TargetMetricsCollector.Coverage
Adds a single point of depth at the desired offset into the coverage array.
addBase(int, int) - Method in class picard.analysis.directed.TargetMetricsCollector.Coverage
Adds some depth at the desired offset into the coverage array.
addBaseQHistogram(MetricsFile<CollectWgsMetrics.WgsMetrics, Integer>) - Method in class picard.analysis.AbstractWgsMetricsCollector
 
addBases(ReferenceMultiSource, JavaRDD<GATKRead>) - Static method in class org.broadinstitute.hellbender.engine.spark.BroadcastJoinReadsWithRefBases
Joins each read of an RDD with that read's corresponding reference sequence.
addBases(ReferenceMultiSource, JavaPairRDD<GATKRead, T>) - Static method in class org.broadinstitute.hellbender.engine.spark.BroadcastJoinReadsWithRefBases
Joins each read of an RDD with key's corresponding reference sequence.
addBases(ReferenceMultiSource, JavaRDD<GATKRead>) - Static method in class org.broadinstitute.hellbender.engine.spark.ShuffleJoinReadsWithRefBases
Joins each read of an RDD with that read's corresponding reference sequence.
addBases(ReferenceMultiSource, JavaPairRDD<GATKRead, T>) - Static method in class org.broadinstitute.hellbender.engine.spark.ShuffleJoinReadsWithRefBases
Joins each read of an RDD with key's corresponding reference sequence.
addBooleanArgument(String, boolean) - Method in class org.broadinstitute.hellbender.utils.test.ArgumentsBuilder
add an argument with a boolean as its parameter
addChild(int) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTreeNode
 
addChromosomeCountsToHeader(Set<VCFHeaderLine>) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Add chromosome counts (AC, AN and AF) to the VCF header lines
addCigarElements(List<CigarElement>, int, int, int, CigarElement) - Static method in class org.broadinstitute.hellbender.utils.read.AlignmentUtils
Helper function for trimCigar that adds cigar elements (of total length X) of elt.op to dest for X bases that fall between start and end, where the last position of the base is pos.
addColumn(String, String) - Method in class org.broadinstitute.hellbender.utils.report.GATKReportTable
Add a column to the report and the format string used to display the data.
AddCommentsToBam - Class in picard.sam
A tool to add comments to a BAM file header.
AddCommentsToBam() - Constructor for class picard.sam.AddCommentsToBam
 
AddContextDataToReadSpark - Class in org.broadinstitute.hellbender.engine.spark
AddContextDataToRead pairs reference bases and overlapping variants with each GATKRead in the RDD input.
AddContextDataToReadSpark() - Constructor for class org.broadinstitute.hellbender.engine.spark.AddContextDataToReadSpark
 
AddContextDataToReadSparkOptimized - Class in org.broadinstitute.hellbender.engine.spark
 
AddContextDataToReadSparkOptimized() - Constructor for class org.broadinstitute.hellbender.engine.spark.AddContextDataToReadSparkOptimized
 
AddContextDataToReadSparkOptimized.SubdivideAndFillReadsIterator - Class in org.broadinstitute.hellbender.engine.spark
 
addCovariate(int, int, int, int) - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.ReadCovariates
Update the keys for mismatch, insertion, and deletion for the current covariate at read offset NOTE: no checks are performed on the number of covariates, for performance reasons.
addCoverageCounts(int, int, int[]) - Method in class picard.annotation.Gene.Transcript
 
addCustomBindings(DocWorkUnit) - Method in class org.broadinstitute.hellbender.utils.help.GATKHelpDocWorkUnitHandler
Add any custom freemarker bindings discovered via custom javadoc tags.
addData(ClipReads.ClippingData) - Method in class org.broadinstitute.hellbender.tools.ClipReads.ClippingData
 
addData(ClipReads.ClippingData) - Method in class org.broadinstitute.hellbender.tools.ClipReads.ReadClipperWithData
 
addData(ClusterData, PositionalData) - Method in class picard.illumina.parser.BaseIlluminaDataProvider
 
addData(ClusterData, PfData) - Method in class picard.illumina.parser.BaseIlluminaDataProvider
 
addData(ClusterData, BarcodeData) - Method in class picard.illumina.parser.BaseIlluminaDataProvider
 
addDescendentScore(double) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenTaxonScore
 
addEdge(Node, Node) - Method in class picard.util.GraphUtils.Graph
 
addEdges(V, V...) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Convenience function to add multiple edges to the graph
addEdges(Supplier<E>, V, V...) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Convenience function to add multiple edges to the graph
addExon(GencodeGtfExonFeature) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfTranscriptFeature
 
addExon(int, int) - Method in class picard.annotation.Gene.Transcript
 
addExpressions(Set<String>, List<FeatureInput<VariantContext>>, boolean) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotatorEngine
 
addFeatureInputsAfterInitialization(String, String, Class<? extends Feature>, int) - Method in class org.broadinstitute.hellbender.engine.GATKTool
A method to allow a user to inject data sources after initialization that were not specified as command-line arguments.
addFileArgument(String, File) - Method in class org.broadinstitute.hellbender.utils.test.ArgumentsBuilder
add an argument with a file as its parameter
addFilterToGenotype(String, String) - Static method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasUtils
Create an updated genotype string when trying to add a filter value.
addFirstOfPairOrFragment(SAMRecord) - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.HitsForInsert
 
addHaplotype(HaplotypeBlock) - Method in class picard.fingerprint.HaplotypeMap
Adds a HaplotypeBlock to the map and updates all the relevant caches/indices.
addHomRefSite(VariantContext, Genotype) - Method in class org.broadinstitute.hellbender.utils.variant.writers.GVCFWriter
Add hom-ref site from vc to this gVCF hom-ref state tracking, emitting any pending states if appropriate
addInfo(AbstractLocusInfo<T>, ReferenceSequence, boolean) - Method in class picard.analysis.AbstractWgsMetricsCollector
Accumulates the data from AbstractLocusInfo in inner structures
addInfo(AbstractLocusInfo<SamLocusIterator.RecordAndOffset>, ReferenceSequence, boolean) - Method in class picard.analysis.CollectWgsMetrics.WgsMetricsCollector
 
addInfo(AbstractLocusInfo<EdgingRecordAndOffset>, ReferenceSequence, boolean) - Method in class picard.analysis.FastWgsMetricsCollector
 
addInput(File) - Method in class org.broadinstitute.hellbender.utils.test.ArgumentsBuilder
addKmer(Kmer, int) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.KMerCounter
Add a kmer that occurred kmerCount times
addLeadingZeros() - Method in class picard.illumina.parser.fakers.BarcodeFileFaker
 
addLeadingZeros() - Method in class picard.illumina.parser.fakers.BciFileFaker
 
addLeadingZeros() - Method in class picard.illumina.parser.fakers.BclFileFaker
 
addLeadingZeros() - Method in class picard.illumina.parser.fakers.ClocsFileFaker
 
addLeadingZeros() - Method in class picard.illumina.parser.fakers.FileFaker
 
addLeadingZeros() - Method in class picard.illumina.parser.fakers.FilterFileFaker
 
addLeadingZeros() - Method in class picard.illumina.parser.fakers.LocsFileFaker
 
addLeadingZeros() - Method in class picard.illumina.parser.fakers.MultiTileBclFileFaker
 
addLeadingZeros() - Method in class picard.illumina.parser.fakers.MultiTileLocsFileFaker
 
addLeadingZeros() - Method in class picard.illumina.parser.fakers.PosFileFaker
 
addLibrary(RScriptLibrary) - Method in class org.broadinstitute.hellbender.utils.R.RScriptExecutor
 
addLocationInformation(String, PhysicalLocation) - Method in class picard.sam.util.ReadNameParser
Method used to extract tile/x/y from the read name and add it to the PhysicalLocationShort so that it can be used later to determine optical duplication
addMappedFragment(int, int, boolean, int) - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
addMappedFragment(int, int, boolean, int, boolean) - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
addMappedFragment(int, int, boolean, String, int) - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
addMappedFragment(int, int, boolean, String, String, int) - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
addMappedFragment(String, int, int, boolean, String, String, boolean, boolean, int) - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
addMappedPair(int, int, int, boolean, boolean, int) - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
addMappedPair(int, int, int, boolean, boolean, String, String, boolean, int) - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
addMappedPair(int, int, int, boolean, boolean, String, String, boolean, boolean, boolean, int) - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
addMatePair(int, int, int, boolean, boolean, boolean, boolean, String, String, boolean, boolean, boolean, boolean, boolean, int) - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
addMatePair(String, int, int, int, int, boolean, boolean, boolean, boolean, String, String, boolean, boolean, boolean, boolean, boolean, int, String) - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
addMatePair(String, int, int, int, boolean, boolean, boolean, boolean, String, String, boolean, boolean, boolean, boolean, boolean, int) - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
addMetricsByLibrary(String, GATKDuplicationMetrics) - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.LibraryIdGenerator
 
addMetricsByLibrary(String, DuplicationMetrics) - Method in class picard.sam.markduplicates.util.LibraryIdGenerator
 
addMetricsToFile(MetricsFile<InsertSizeMetrics, Integer>) - Method in class org.broadinstitute.hellbender.metrics.PerUnitInsertSizeMetricsCollector
 
addMetricsToFile(MetricsFile<BEAN, HKEY>) - Method in interface org.broadinstitute.hellbender.metrics.PerUnitMetricCollector
Any metrics collected will be added to the metric file provided.
addMetricsToFile(MetricsFile<ExampleMultiMetrics, Integer>) - Method in class org.broadinstitute.hellbender.tools.examples.metrics.multi.PerUnitExampleMultiMetricsCollector
 
addMetricsToFile(MetricsFile<CollectQualityYieldMetrics.QualityYieldMetrics, Integer>) - Method in class picard.analysis.CollectQualityYieldMetrics.QualityYieldMetricsCollector
 
addMetricsToFile(MetricsFile<InsertSizeMetrics, Integer>) - Method in class picard.analysis.directed.InsertSizeMetricsCollector.PerUnitInsertSizeMetricsCollector
 
addMetricsToFile(MetricsFile<RnaSeqMetrics, Integer>) - Method in class picard.analysis.directed.RnaSeqMetricsCollector.PerUnitRnaSeqMetricsCollector
 
addMetricsToFile(MetricsFile<METRIC_TYPE, Integer>) - Method in class picard.analysis.directed.TargetMetricsCollector.PerUnitTargetMetricCollector
 
addMetricsToFile(MetricsFile<GcBiasMetrics, Integer>) - Method in class picard.analysis.GcBiasMetricsCollector.PerUnitGcBiasMetricsCollector
 
addMetricsToFile(MetricsFile<BEAN, HKEY>) - Method in interface picard.metrics.PerUnitMetricCollector
Any metrics collected will be added to the metric file provided.
addMissingAlleles(Collection<A>, double) - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Add alleles that are missing in the read-likelihoods collection giving all reads a default likelihood value.
addMissingTruthAndMissingCallStates(double, long, GenotypeConcordanceCounts) - Static method in class picard.vcf.GenotypeConcordance
Method to add missing sites that are KNOWN to be HOM_REF in the case of the NIST truth data set.
addNode(int, String, int, long, String) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTree
Adds a node to the tree.
addNode(Node) - Method in class picard.util.GraphUtils.Graph
 
addNonReferenceAllele(A) - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Adds the non-reference allele to the read-likelihood collection setting each read likelihood to the second best found (or best one if only one allele has likelihood).
addObservation(GATKRead) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.KSWindowFinder
 
addObservation(int) - Method in class org.broadinstitute.hellbender.tools.spark.utils.IntHistogram
 
addObservations(int, long) - Method in class org.broadinstitute.hellbender.tools.spark.utils.IntHistogram
 
addObservations(IntHistogram) - Method in class org.broadinstitute.hellbender.tools.spark.utils.IntHistogram
 
addOp(ClippingOp) - Method in class org.broadinstitute.hellbender.utils.clipping.ReadClipper
Add clipping operation to the read.
AddOrReplaceReadGroups - Class in picard.sam
Assigns all the reads in a file to a single new read-group.
AddOrReplaceReadGroups() - Constructor for class picard.sam.AddOrReplaceReadGroups
 
addOrUpdateEdge(V, V, E) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Add edge between source -> target if none exists, or add e to an already existing one if present
addOutput(File) - Method in class org.broadinstitute.hellbender.utils.test.ArgumentsBuilder
add an output file argument using StandardArgumentDefinitions.OUTPUT_LONG_NAME
addOutputSAMProgramRecord - Variable in class org.broadinstitute.hellbender.engine.GATKTool
 
addOutputVCFCommandLine - Variable in class org.broadinstitute.hellbender.engine.GATKTool
 
addParameterSampler(V2, ParameterSampler<U, V2, S2, T2>, Class<U>) - Method in class org.broadinstitute.hellbender.utils.mcmc.ParameterizedModel.GibbsBuilder
Adds a ParameterSampler to the collection of parameter samplers using ParameterizedModel.GibbsBuilder.
addPileup(ReadPileup) - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.AllelePileupCounter
 
addPositionalArgument(String) - Method in class org.broadinstitute.hellbender.utils.test.ArgumentsBuilder
add a positional argument to this builder
addPrefetcher(int, SeekableByteChannel) - Static method in class org.broadinstitute.hellbender.utils.nio.SeekableByteChannelPrefetcher
Wraps the provided SeekableByteChannel within a SeekableByteChannelPrefetcher, using the provided buffer size
addRange(int, int) - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
Adds a range of integer values to the collection.
addRaw(String) - Method in class org.broadinstitute.hellbender.utils.test.ArgumentsBuilder
Add a string to the arguments list without processing the string itself.
addRead(GATKRead) - Method in class org.broadinstitute.hellbender.metrics.QualityYieldMetrics
 
addRead(GATKRead) - Method in class org.broadinstitute.hellbender.tools.examples.metrics.multi.ExampleMultiMetrics
Process a single read
addRead(GATKRead) - Method in class org.broadinstitute.hellbender.tools.examples.metrics.single.ExampleSingleMetrics
 
addRead(int, int, int, boolean) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.LibraryRawStatistics
 
addRead(String) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.MultiDeBruijnVertex
Add name information to this vertex for debugging This information will be captured as a list of strings, and displayed in DOT if this graph is written out to disk This functionality is only enabled when KEEP_TRACK_OF_READS is true
addRead(GATKRead) - Method in interface org.broadinstitute.hellbender.utils.read.GATKReadWriter
 
addRead(GATKRead) - Method in class org.broadinstitute.hellbender.utils.read.SAMFileGATKReadWriter
 
addReadData(ClusterData, int, BaseData) - Method in class picard.illumina.parser.BaseIlluminaDataProvider
 
addReadData(ClusterData, int, QualityData) - Method in class picard.illumina.parser.BaseIlluminaDataProvider
 
addReadData(ClusterData, int, CbclData) - Method in class picard.illumina.parser.BaseIlluminaDataProvider
 
addReadGroup(List<GATKRead>) - Method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.OverhangFixingManager
Add a family of split reads to the manager
addReadKmers(GATKRead) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadErrorCorrector
Main entry routine to add all kmers in a read to the read map counter
addReads(Map<String, List<GATKRead>>, double) - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Add more reads to the collection.
addReads(Map<String, List<GATKRead>>, double) - Method in class org.broadinstitute.hellbender.utils.genotyper.UnfilledReadsLikelihoods
 
addReadsToKmers(Collection<GATKRead>) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadErrorCorrector
Top-level entry point that adds a collection of reads to our kmer list.
addRecord(SAMRecord) - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
addReference(File) - Method in class org.broadinstitute.hellbender.utils.test.ArgumentsBuilder
add a reference file argument using StandardArgumentDefinitions.REFERENCE_LONG_NAME
addRegion(GenomeLoc) - Method in class org.broadinstitute.hellbender.utils.GenomeLocSortedSet
Adds a GenomeLoc to the collection, merging it if it overlaps another region.
addResults(MatchResults) - Method in class picard.fingerprint.FingerprintResults
 
addRow(Object...) - Method in class org.broadinstitute.hellbender.utils.report.GATKReport
This method provides an efficient way to populate a simplified GATK report.
addRow(GenotypeConcordanceStates.CallState, GenotypeConcordanceStates.ContingencyState[]...) - Method in class picard.vcf.GenotypeConcordanceScheme
Adds a row to the scheme
addRowID(String, boolean) - Method in class org.broadinstitute.hellbender.utils.report.GATKReportTable
Add a mapping from ID to the index of a new row added to the table.
addRowIDMapping(String, int) - Method in class org.broadinstitute.hellbender.utils.report.GATKReportTable
Add a mapping from ID to row index.
addRowIDMapping(Object, int, boolean) - Method in class org.broadinstitute.hellbender.utils.report.GATKReportTable
Add a mapping from ID to row index.
addSample(Sample) - Method in class org.broadinstitute.hellbender.utils.samples.SampleDB
Protected function to add a single sample to the database
addSamplesFromPedigreeFiles(List<File>) - Method in class org.broadinstitute.hellbender.utils.samples.SampleDBBuilder
 
addSamplesFromPedigreeStrings(List<String>) - Method in class org.broadinstitute.hellbender.utils.samples.SampleDBBuilder
 
addScoreNormalized(double) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenTaxonScore
 
addScript(Resource) - Method in class org.broadinstitute.hellbender.utils.R.RScriptExecutor
 
addScript(File) - Method in class org.broadinstitute.hellbender.utils.R.RScriptExecutor
 
addSecondOfPair(SAMRecord) - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.HitsForInsert
 
addSelenocysteine(GencodeGtfSelenocysteineFeature) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfTranscriptFeature
 
addSelfScore(double) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenTaxonScore
 
addSequence(String, byte[], boolean) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingGraph
Add all bases in sequence to this graph
addSequence(String, byte[], int, boolean) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingGraph
Add all bases in sequence to this graph
addSnp(Snp) - Method in class picard.fingerprint.HaplotypeBlock
Adds a SNP to the haplotype.
addSplicePosition(String, int, int) - Method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.OverhangFixingManager
Add a new observed split to the list to use
addSupplementalFirstOfPairOrFragment(SAMRecord) - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.HitsForInsert
 
addSupplementalSecondOfPair(SAMRecord) - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.HitsForInsert
 
addTable(String, String, int) - Method in class org.broadinstitute.hellbender.utils.report.GATKReport
Add a new, empty table to the report
addTable(String, String, int, GATKReportTable.Sorting) - Method in class org.broadinstitute.hellbender.utils.report.GATKReport
Add a new, empty table to the report
addTable(GATKReportTable) - Method in class org.broadinstitute.hellbender.utils.report.GATKReport
Adds a table, empty or populated, to the report
addTables(List<GATKReportTable>) - Method in class org.broadinstitute.hellbender.utils.report.GATKReport
 
addTag(SATagBuilder) - Method in class org.broadinstitute.hellbender.utils.SATagBuilder
Add a read encapsulated by another SATagBuilder to this tag, if the read is set to be primary, then it will be advanced to the front of the list, otherwise it will be placed at the back of the SA string.
addTag(GATKRead) - Method in class org.broadinstitute.hellbender.utils.SATagBuilder
Add a read to the SATag for the encapsulated read.
addToArrayInPlace(double[], double[]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
addToIntervalStrings(String) - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.IntervalArgumentCollection
Add an extra interval string to the intervals to include.
addToIntervalStrings(String) - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.OptionalIntervalArgumentCollection
 
addToIntervalStrings(String) - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.RequiredIntervalArgumentCollection
 
addToLogLikelihoods(Snp, List<Allele>, double[]) - Method in class picard.fingerprint.HaplotypeProbabilitiesFromGenotypeLikelihoods
Adds a base observation with the observed quality to the evidence for this haplotype based on the fact that the SNP is part of the haplotype.
addToMetricsFile(MetricsFile<CollectWgsMetrics.WgsMetrics, Integer>, boolean, CountingFilter, CountingFilter, CountingPairedFilter) - Method in class picard.analysis.AbstractWgsMetricsCollector
Adds collected metrics and depth histogram to file
addToMetricsFile(MetricsFile<CollectWgsMetrics.WgsMetrics, Integer>, boolean, CountingFilter, CountingFilter, CountingPairedFilter) - Method in class picard.analysis.CollectWgsMetricsWithNonZeroCoverage.WgsMetricsWithNonZeroCoverageCollector
 
addToMetricsFile(MetricsFile<CollectWgsMetrics.WgsMetrics, Integer>, boolean, CountingFilter, CountingFilter, CountingPairedFilter) - Method in interface picard.analysis.WgsMetricsProcessor
Adds result metric's data to input file
addToMetricsFile(MetricsFile<CollectWgsMetrics.WgsMetrics, Integer>, boolean, CountingFilter, CountingFilter, CountingPairedFilter) - Method in class picard.analysis.WgsMetricsProcessorImpl
Adds result metric's data to input file
addToProbs(Snp, byte, byte) - Method in class picard.fingerprint.HaplotypeProbabilitiesFromContaminatorSequence
Adds a base observation with the observed quality to the evidence for this haplotype based on the fact that the SNP is part of the haplotype.
addToProbs(Snp, byte, byte) - Method in class picard.fingerprint.HaplotypeProbabilitiesFromSequence
Adds a base observation with the observed quality to the evidence for this haplotype based on the fact that the SNP is part of the haplotype.
addTotalReads(int) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenTaxonScore
 
addTrainingSet(TrainingSet) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
 
addTranscript(GencodeGtfTranscriptFeature) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfGeneFeature
 
addTranscript(String, int, int, int, int, int) - Method in class picard.annotation.Gene
 
addUmiObservation(String, String) - Method in class picard.sam.markduplicates.UmiMetrics
Add an observation of a UMI to the metrics
addUmiObservationN() - Method in class picard.sam.markduplicates.UmiMetrics
Add an observation of a UMI containing at least one N to the metrics
addUnambiguousReads(int) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenTaxonScore
 
addUnmappedFragment(int, int) - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
addUnmappedFragment(int, String) - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
addUnmappedPair(int, int) - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
addUtr(GencodeGtfUTRFeature) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfTranscriptFeature
 
addVC(VariantContext) - Method in class org.broadinstitute.hellbender.utils.haplotype.EventMap
Add VariantContext vc to this map, merging events with the same start sites if necessary
addVC(VariantContext, boolean) - Method in class org.broadinstitute.hellbender.utils.haplotype.EventMap
Add VariantContext vc to this map
addVCF(File) - Method in class org.broadinstitute.hellbender.utils.test.ArgumentsBuilder
add a vcf file argument using StandardArgumentDefinitions.VARIANT_LONG_NAME
addVertices(V...) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Convenience function to add multiple vertices to the graph at once
addVertices(Collection<V>) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Convenience function to add multiple vertices to the graph at once
adjustQualsOfOverlappingPairedFragments(GATKRead, GATKRead) - Static method in class org.broadinstitute.hellbender.utils.fragments.FragmentUtils
Fix two overlapping reads from the same fragment by adjusting base qualities, if possible firstRead and secondRead must be part of the same fragment (though this isn't checked).
adjustQualsOfOverlappingPairedFragments(List<GATKRead>) - Static method in class org.broadinstitute.hellbender.utils.fragments.FragmentUtils
 
advance() - Method in class picard.util.AbstractInputParser
 
advanceBlock(GATKRead) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.KSWindowFinder
 
advanceFile() - Method in class picard.util.BasicInputParser
 
advanceToLocus(int, boolean) - Method in class org.broadinstitute.hellbender.utils.locusiterator.LocusIteratorByState
Move this LIBS until we are over position Will return null if cannot reach position (because we run out of data in the locus)
AF_PARAMETER_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
AF_PARAMETER_FILE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
AFCalculationResult - Class in org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc
Describes the results of the AFCalc Only the bare essentials are represented here, as all AFCalc models must return meaningful results for all of these fields.
AFCalculationResult(int[], List<Allele>, double[], double[], Map<Allele, Double>) - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculationResult
Create a results object capability of storing results for calls with up to maxAltAlleles
AFCalculator - Class in org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc
Generic interface for calculating the probability of alleles segregating given priors and genotype likelihoods
AFCalculator() - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculator
 
AFCalculatorImplementation - Enum in org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc
Enumeration of usable AF calculation, their constraints (i.e.
AFCalculatorProvider - Class in org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc
Instantiates Exact AF calculators given the required ploidy specs.
AFCalculatorProvider() - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculatorProvider
 
afCalculatorProvider - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
 
Affection - Enum in org.broadinstitute.hellbender.utils.samples
Categorical sample trait for association and analysis Samples can have unknown status, be affected or unaffected by the categorical trait, or they can be marked as actually having an other trait value (stored in an associated value in the Sample class)
afOfAllelesNotInGermlineResource - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
Population allele fraction assigned to alleles not found in germline resource.
AFPriorProvider - Class in org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc
Class that produces allele-frequency priors.
AFPriorProvider() - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFPriorProvider
 
afterExecute(Runnable, Throwable) - Method in class picard.util.ThreadPoolExecutorWithExceptions
 
afterFile - Variable in class org.broadinstitute.hellbender.tools.walkers.bqsr.AnalyzeCovariates
File containing the recalibration tables from the second pass.
afterFirstPass() - Method in class org.broadinstitute.hellbender.engine.TwoPassReadWalker
afterFirstPass() - Method in class org.broadinstitute.hellbender.engine.TwoPassVariantWalker
Process the data collected during the first pass.
afterFirstPass() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleTwoPassVariantWalker
 
afterFirstPass() - Method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.SplitNCigarReads
 
afterPipeline(JavaSparkContext) - Method in class org.broadinstitute.hellbender.engine.spark.SparkCommandLineProgram
Extend this method to run code after the pipeline returns.
aggregate(List<Integer>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.BaseQuality
 
aggregate(List<Integer>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.FragmentLength
 
aggregate(List<Integer>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.MappingQuality
 
aggregate(List<Integer>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.PerAlleleAnnotation
 
aggregate(List<Integer>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.ReadPosition
 
AggregatedSubHaplotypeFinder<F extends org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KBestSubHaplotypeFinder> - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs
K-best sub-haplotype finder that selects the best solutions out of a collection of sub-haplotype finders.
AggregatedSubHaplotypeFinder(Collection<F>) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.AggregatedSubHaplotypeFinder
Creates a new aggregated sub-haplotype finder given its sub-finders.
align(JavaRDD<GATKRead>, boolean) - Method in class org.broadinstitute.hellbender.tools.spark.bwa.BwaSparkEngine
Performs read alignment on a RDD.
align(Iterable<? extends T>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SingleSequenceReferenceAligner
 
align(List<? extends T>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SingleSequenceReferenceAligner
Aligns the input object returning a list of the outputs in the corresponding order.
align(List<? extends T>, BiFunction<? super T, ? super U, ? extends V>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SingleSequenceReferenceAligner
Composes a map of the aligned sequences.
align(byte[], byte[], SWParameters, SWOverhangStrategy) - Method in interface org.broadinstitute.hellbender.utils.smithwaterman.SmithWatermanAligner
perform a Smith-Waterman alignment of alt against ref
align(byte[], byte[], SWParameters, SWOverhangStrategy) - Method in class org.broadinstitute.hellbender.utils.smithwaterman.SmithWatermanIntelAligner
Aligns the alternate sequence to the reference sequence
align(byte[], byte[], SWParameters, SWOverhangStrategy) - Method in class org.broadinstitute.hellbender.utils.smithwaterman.SmithWatermanJavaAligner
Aligns the alternate sequence to the reference sequence
align(byte[], byte[], SWParameters, SWOverhangStrategy) - Method in class org.broadinstitute.hellbender.utils.smithwaterman.SWNativeAlignerWrapper
 
ALIGN_LENGTHS - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
ALIGNED_BAM - Variable in class picard.sam.MergeBamAlignment
 
ALIGNED_READS - Variable in class picard.analysis.GcBiasSummaryMetrics
The total number of aligned reads used to compute the gc bias metrics.
ALIGNED_READS_ONLY - Variable in class picard.analysis.CollectBaseDistributionByCycle
 
ALIGNED_READS_ONLY - Variable in class picard.analysis.MeanQualityByCycle
 
ALIGNED_READS_ONLY - Variable in class picard.analysis.QualityScoreDistribution
 
ALIGNED_READS_ONLY - Variable in class picard.sam.MergeBamAlignment
 
AlignedAssembly - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment
Holding necessary information about a local assembly for use in SV discovery.
AlignedAssembly(int, List<AlignedContig>) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignedAssembly
 
AlignedAssembly.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment
 
AlignedAssemblyOrExcuse - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
An assembly with its contigs aligned to reference, or a reason that there isn't an assembly.
AlignedAssemblyOrExcuse(int, String) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.AlignedAssemblyOrExcuse
 
AlignedAssemblyOrExcuse(int, FermiLiteAssembly, int, List<List<BwaMemAlignment>>) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.AlignedAssemblyOrExcuse
 
AlignedAssemblyOrExcuse.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
AlignedContig - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment
Locally assembled contig: its name its sequence as produced by the assembler (no reverse complement like in the SAM record if it maps to '-' strand), and its stripped-down alignment information.
AlignedContig(String, byte[], List<AlignmentInterval>) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignedContig
 
AlignedContig.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment
 
AlignedContigGenerator - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment
Loads various upstream assembly and alignment formats and turn into custom AlignedContig format in the discovery stage.
AlignedContigGenerator() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignedContigGenerator
 
alignedContigs - Variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignedAssembly
 
alignedInput - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
PathSeq will rapidly filter the reads if they are aligned to a host reference, thus reducing run time.
alignedReadsOnly - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectBaseDistributionByCycleSpark
 
alignedReadsOnly - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.MeanQualityByCycleSpark
 
alignedReadsOnly - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.QualityScoreDistributionSpark
 
ALIGNER_PROPER_PAIR_FLAGS - Variable in class picard.sam.MergeBamAlignment
 
alignerIndexImageFile - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
ALIGNMENT_ARTIFACT_FILTER_NAME - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
ALIGNMENT_LOW_READ_UNIQUENESS_THRESHOLD - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigAlignmentsConfigPicker
 
ALIGNMENT_LOW_REF_UNIQUENESS_THRESHOLD - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigAlignmentsConfigPicker
parameters to be passed to AssemblyContigAlignmentsConfigPicker.removeNonUniqueMappings(AssemblyContigWithFineTunedAlignments, int, int) for dropping alignments that offer either low reference or read uniqueness.
ALIGNMENT_STATUS - Variable in class picard.sam.ViewSam
 
alignmentAgreesWithHeader(SAMFileHeader, GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Check to ensure that the alignment makes sense based on the contents of the header.
AlignmentAgreesWithHeaderReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Filter out reads where the alignment does not match the contents of the header.
AlignmentAgreesWithHeaderReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.AlignmentAgreesWithHeaderReadFilter
 
AlignmentAgreesWithHeaderReadFilter(SAMFileHeader) - Constructor for class org.broadinstitute.hellbender.engine.filters.AlignmentAgreesWithHeaderReadFilter
 
AlignmentContext - Class in org.broadinstitute.hellbender.engine
Bundles together a pileup and a location.
AlignmentContext(Locatable, ReadPileup) - Constructor for class org.broadinstitute.hellbender.engine.AlignmentContext
 
AlignmentContext(Locatable, ReadPileup, boolean) - Constructor for class org.broadinstitute.hellbender.engine.AlignmentContext
 
AlignmentContext.ReadOrientation - Enum in org.broadinstitute.hellbender.engine
 
AlignmentContextIteratorBuilder - Class in org.broadinstitute.hellbender.utils.locusiterator
Create an iterator for traversing alignment contexts in a specified manner.
AlignmentContextIteratorBuilder() - Constructor for class org.broadinstitute.hellbender.utils.locusiterator.AlignmentContextIteratorBuilder
 
AlignmentInterval - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment
Each assembled contig should have at least one such accompanying structure, or 0 when it is unmapped.
AlignmentInterval(String) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
Compose an alignment interval instance from a SAM supplementary alignment formatted string.
AlignmentInterval(SAMRecord) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
 
AlignmentInterval(GATKRead) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
Constructs an alignment interval that reflects on the mapping properties of a GATKRead instance.
AlignmentInterval(BwaMemAlignment, List<String>, int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
 
AlignmentInterval(SimpleInterval, int, int, Cigar, boolean, int, int, int, ContigAlignmentsModifier.AlnModType) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
 
AlignmentInterval.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment
 
AlignmentStateMachine - Class in org.broadinstitute.hellbender.utils.locusiterator
Steps a single read along its alignment to the genome The logical model for generating extended events is as follows: the "record state" implements the traversal along the reference; thus stepForwardOnGenome() returns on every and only on actual reference bases.
AlignmentStateMachine(GATKRead) - Constructor for class org.broadinstitute.hellbender.utils.locusiterator.AlignmentStateMachine
 
AlignmentSummaryMetrics - Class in picard.analysis
High level metrics about the alignment of reads within a SAM file, produced by the CollectAlignmentSummaryMetrics program and usually stored in a file with the extension ".alignment_summary_metrics".
AlignmentSummaryMetrics() - Constructor for class picard.analysis.AlignmentSummaryMetrics
 
AlignmentSummaryMetrics.Category - Enum in picard.analysis
 
AlignmentSummaryMetricsCollector - Class in picard.analysis
 
AlignmentSummaryMetricsCollector(Set<MetricAccumulationLevel>, List<SAMReadGroupRecord>, boolean, List<String>, int, Set<SamPairUtil.PairOrientation>, boolean) - Constructor for class picard.analysis.AlignmentSummaryMetricsCollector
 
AlignmentUtils - Class in org.broadinstitute.hellbender.utils.read
 
AlignmentUtils.MismatchCount - Class in org.broadinstitute.hellbender.utils.read
 
alignPaired(JavaRDD<GATKRead>) - Method in class org.broadinstitute.hellbender.tools.spark.bwa.BwaSparkEngine
Performs pair-end alignment on a RDD.
alignUnpaired(JavaRDD<GATKRead>) - Method in class org.broadinstitute.hellbender.tools.spark.bwa.BwaSparkEngine
Performs single-end alignment on a RDD.
ALL_COVARIATES_REPORT_TABLE_TITLE - Static variable in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
 
ALL_GTS_FILTERED - Static variable in class picard.vcf.filter.FilterApplyingVariantIterator
Filter string that is used to filter a Variant when all variant genotypes are filtered out.
ALL_SITES_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.GenotypeGVCFs
 
allAlleles - Variable in class picard.vcf.GenotypeConcordance.Alleles
 
allele - Variable in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods.BestAllele
Null if there is no possible match (no allele?).
ALLELE_BALANCE_HET_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
ALLELE_BALANCE_HOM_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
ALLELE_BALANCE_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
ALLELE_EXTENSION - Static variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerGenotypingEngine
 
ALLELE_FRACTION_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
ALLELE_FRACTION_MODEL_PARAMETER_FILE_SUFFIX - Static variable in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
ALLELE_SPECIFIC_PREFIX - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
AlleleBalanceFilter - Class in picard.vcf.filter
Filters out a record if the allele balance for heterozygotes is out of a defined range across all samples.
AlleleBalanceFilter(double) - Constructor for class picard.vcf.filter.AlleleBalanceFilter
 
AlleleBiasedDownsamplingUtils - Class in org.broadinstitute.hellbender.utils.downsampling
The purpose of this set of utilities is to downsample a set of reads to remove contamination.
alleleCount() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeLikelihoodCalculator
Returns the total number of alleles for this genotype calculator.
alleleCountAt(int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeAlleleCounts
Returns the count of an allele in the genotype given is rank in the genotype (not the allele index itself).
alleleCountFor(int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeAlleleCounts
Returns the count of an allele in the genotype given it index.
alleleCountsByIndex(int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeAlleleCounts
Returns the allele counts for each allele index to maximum.
alleleCountsToIndex(int...) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeLikelihoodCalculator
Returns the likelihood index given the allele counts.
AlleleFractionKernelSegmenter - Class in org.broadinstitute.hellbender.tools.copynumber.segmentation
Segments alternate-allele-fraction data using kernel segmentation.
AlleleFractionKernelSegmenter(AllelicCountCollection) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.segmentation.AlleleFractionKernelSegmenter
 
AlleleFractionModeller - Class in org.broadinstitute.hellbender.tools.copynumber.models
Given segments and counts of alt and ref reads over a list of het sites, infers the minor-allele fraction of each segment.
AlleleFractionParameter - Enum in org.broadinstitute.hellbender.tools.copynumber.models
Enumerates the parameters for AlleleFractionState.
AlleleFractionPrior - Class in org.broadinstitute.hellbender.tools.copynumber.models
Represents priors for the allele-fraction model.
AlleleFractionPrior(double) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.models.AlleleFractionPrior
 
AlleleFractionSegment - Class in org.broadinstitute.hellbender.tools.copynumber.formats.records
 
AlleleFractionSegment(SimpleInterval, int) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.records.AlleleFractionSegment
 
AlleleFractionSegment(SimpleInterval, List<AllelicCount>) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.records.AlleleFractionSegment
 
AlleleFractionSegmentCollection - Class in org.broadinstitute.hellbender.tools.copynumber.formats.collections
Represents an allele-fraction segmentation.
AlleleFractionSegmentCollection(File) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.collections.AlleleFractionSegmentCollection
 
AlleleFractionSegmentCollection(SampleLocatableMetadata, List<AlleleFractionSegment>) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.collections.AlleleFractionSegmentCollection
 
alleleFractionsPosterior(RealMatrix, double[]) - Static method in class org.broadinstitute.hellbender.tools.walkers.mutect.SomaticLikelihoodsEngine
Given a likelihoods matrix, calculate the parameters of the Dirichlet posterior distribution on their allele fractions, which define a discrete distribution.
alleleFractionsPosterior(RealMatrix) - Static method in class org.broadinstitute.hellbender.tools.walkers.mutect.SomaticLikelihoodsEngine
 
AlleleFrequencyCalculator - Class in org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc
 
AlleleFrequencyCalculator(double, double, double, int) - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AlleleFrequencyCalculator
 
alleleIndexAt(int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeAlleleCounts
Returns the index of the allele from its rank in the genotype.
AlleleLikelihoodMatrixMapper<A extends htsjdk.variant.variantcontext.Allele> - Interface in org.broadinstitute.hellbender.tools.walkers.genotyper
Creates LikelihoodMatrix mappers to be used when working with a subset of the original alleles.
AlleleList<A extends htsjdk.variant.variantcontext.Allele> - Interface in org.broadinstitute.hellbender.utils.genotyper
Minimal interface for random access to a collection of Alleles.
AlleleList.ActualPermutation<A extends htsjdk.variant.variantcontext.Allele> - Class in org.broadinstitute.hellbender.utils.genotyper
 
AlleleList.NonPermutation<A extends htsjdk.variant.variantcontext.Allele> - Class in org.broadinstitute.hellbender.utils.genotyper
This is the identity permutation.
AlleleListPermutation<A extends htsjdk.variant.variantcontext.Allele> - Interface in org.broadinstitute.hellbender.utils.genotyper
Marks allele list permutation implementation classes.
AlleleMapper(VariantContext) - Constructor for class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils.AlleleMapper
 
AlleleMapper(Map<Allele, Allele>) - Constructor for class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils.AlleleMapper
 
AllelePileupCounter - Class in org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup
Useful when you know the interval and the alleles of interest ahead of the counting.
AllelePileupCounter(Allele, List<Allele>, int) - Constructor for class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.AllelePileupCounter
 
AllelePileupCounter(Allele, List<Allele>, int, ReadPileup) - Constructor for class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.AllelePileupCounter
See AllelePileupCounter.AllelePileupCounter(Allele, List, int), except this will immediately add the given pileup as well.
alleleRankFor(int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeAlleleCounts
Returns the rank of an allele in the genotype by its index.
alleles - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.StandardCallerArgumentCollection
When the caller is put into GENOTYPE_GIVEN_ALLELES mode it will genotype the samples using only the alleles provide in this rod binding
alleles() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.SubsettedLikelihoodMatrix
 
alleles() - Method in interface org.broadinstitute.hellbender.utils.genotyper.LikelihoodMatrix
List of alleles in the matrix sorted by their index in the collection.
alleles - Variable in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Allele list
alleles() - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Returns the samples in this read-likelihood collection.
Alleles(OrderedSet<String>, String, String, String, String) - Constructor for class picard.vcf.GenotypeConcordance.Alleles
 
AlleleSpecificAnnotationData<T> - Class in org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific
A class to encapsulate the raw data for allele-specific classes compatible with the ReducibleAnnotation interface
AlleleSpecificAnnotationData(List<Allele>, String) - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AlleleSpecificAnnotationData
 
alleleSpecificAnnotationEquals(VariantContext, VariantContext, String) - Static method in class org.broadinstitute.hellbender.utils.test.VariantContextTestUtils
 
allelesToIndex(int...) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeLikelihoodCalculator
Give a list of alleles, returns the likelihood array index.
AlleleSubsettingUtils - Class in org.broadinstitute.hellbender.tools.walkers.genotyper
Utilities class containing methods for restricting VariantContext and GenotypesContext objects to a reduced set of alleles, as well as for choosing the best set of alleles to keep and for cleaning up annotations and genotypes after subsetting.
AlleleSubsettingUtils - Class in picard.util
Utilities class containing methods for restricting VariantContext and GenotypesContext objects to a reduced set of alleles, as well as for choosing the best set of alleles to keep and for cleaning up annotations and genotypes after subsetting.
AlleleSubsettingUtils() - Constructor for class picard.util.AlleleSubsettingUtils
 
ALLELIC_COUNTS_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
ALLELIC_COUNTS_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.CopyNumberStandardArgument
 
ALLELIC_COUNTS_FILE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
ALLELIC_PON_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
ALLELIC_PON_FILE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
AllelicCount - Class in org.broadinstitute.hellbender.tools.copynumber.formats.records
Reference and alternate allele counts at a site specified by an interval.
AllelicCount(SimpleInterval, int, int, Nucleotide, Nucleotide) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.records.AllelicCount
Construct the allelic count object.
AllelicCount(SimpleInterval, int, int) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.records.AllelicCount
 
AllelicCountCollection - Class in org.broadinstitute.hellbender.tools.copynumber.formats.collections
Simple data structure to pass and read/write a List of AllelicCount objects.
AllelicCountCollection(File) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.collections.AllelicCountCollection
 
AllelicCountCollection(SampleLocatableMetadata, List<AllelicCount>) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.collections.AllelicCountCollection
 
AllelicCountCollector - Class in org.broadinstitute.hellbender.tools.copynumber.datacollection
Collects reference/alternate allele counts at specified sites.
AllelicCountCollector(SampleLocatableMetadata) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.datacollection.AllelicCountCollector
 
AllLocusIterator - Class in org.broadinstitute.hellbender.utils.iterators
A super-simplified/stripped-down/faster version of IntervalAlignmentContextIterator that takes a locus iterator and a *single* interval, and returns an AlignmentContext for every locus in the interval.
AllLocusIterator(SimpleInterval, Iterator<AlignmentContext>) - Constructor for class org.broadinstitute.hellbender.utils.iterators.AllLocusIterator
 
allMatch(double[], DoublePredicate) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Test whether all elements of a double[] array satisfy a double -> boolean predicate
allMatch(int[], IntPredicate) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Test whether all elements of an int[] array satisfy an int -> boolean predicate
ALLOSOMAL_CONTIG_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.PostprocessGermlineCNVCalls
 
ALLOW_ALL_READS - Static variable in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary
Static, stateless read filter instances
ALLOW_ALL_VARIANTS - Static variable in class org.broadinstitute.hellbender.engine.filters.VariantFilterLibrary
 
ALLOW_AND_IGNORE_EMPTY_LINES - Variable in class picard.sam.FastqToSam
 
ALLOW_CONTIG_LENGTH_DISCORDANCE - Variable in class picard.sam.ReorderSam
 
ALLOW_DUPLICATE_READS - Variable in class picard.fingerprint.CrosscheckFingerprints
 
ALLOW_HG19_GENCODE_B37_CONTIG_MATCHING_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorArgumentDefinitions
 
ALLOW_INCOMPLETE_DICT_CONCORDANCE - Variable in class picard.sam.ReorderSam
 
ALLOW_MISSING_FIELDS_IN_HEADER - Variable in class picard.vcf.LiftoverVcf
 
ALLOW_MISSING_UMIS - Variable in class picard.sam.markduplicates.UmiAwareMarkDuplicatesWithMateCigar
 
ALLOW_MULTIPLE_DOWNSAMPLING_DESPITE_WARNINGS - Variable in class picard.sam.PositionBasedDownsampleSam
 
AllowAllReadsReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.AllowAllReadsReadFilter
 
allowedShortFragmentOverhang - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
allowHg19ContigNamesWithB37 - Variable in class org.broadinstitute.hellbender.tools.funcotator.Funcotator
 
allowNonUniqueKmersInRef - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadThreadingAssemblerArgumentCollection
By default, the program does not allow processing of reference sections that contain non-unique kmers.
alnModType - Variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
when alnModType is not ContigAlignmentsModifier.AlnModType.NONE, fields "mapQual", "mismatches", "alnScore" should be viewed with care as they were either simply copied from the original alignment (e.g.
alnScore - Variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
Alignment score, AlignmentInterval.NO_AS if unknown or unspecified.
ALSO_IGNORE_DUPLICATES - Variable in class picard.analysis.CollectGcBiasMetrics
 
ALT - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
ALT_BASE - Variable in class picard.analysis.artifacts.ErrorSummaryMetrics
The alternative base (or it's complement).
ALT_BASE - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasDetailMetrics
The (upper-case) alternative base that is called as a result of DNA damage.
ALT_BASE - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasSummaryMetrics
The (upper-case) alternative base that is called as a result of DNA damage.
ALT_BASE - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterDetailMetrics
The (upper-case) alternative base that is called as a result of DNA damage.
ALT_BASE - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterSummaryMetrics
The (upper-case) alternative base that is called as a result of DNA damage.
ALT_COUNT - Variable in class picard.analysis.artifacts.ErrorSummaryMetrics
The number of alt bases observed.
ALT_NONOXO_BASES - Variable in class picard.analysis.CollectOxoGMetrics.CpcgMetrics
The count of observed A basecalls at C reference positions and T basecalls at G reference bases that are correlated to instrument read number in a way that rules out oxidation as the cause
ALT_OXO_BASES - Variable in class picard.analysis.CollectOxoGMetrics.CpcgMetrics
The count of observed A basecalls at C reference positions and T basecalls at G reference bases that are correlated to instrument read number in a way that is consistent with oxidative damage.
altAllele - Variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvType
 
altValues() - Static method in enum org.broadinstitute.hellbender.utils.artifacts.Transition
Like values(), but ignores the ref:ref "transitions".
altValues() - Static method in enum picard.analysis.artifacts.Transition
Like values(), but ignores the ref:ref "transitions".
AMBIGUOUS_FILTER_BASES_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ReadFilterArgumentDefinitions
 
AMBIGUOUS_FILTER_FRACTION_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ReadFilterArgumentDefinitions
 
AmbiguousBaseReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Filters out reads that have greater than the threshold number for unknown (N) bases.
AmbiguousBaseReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.AmbiguousBaseReadFilter
 
AmbiguousBaseReadFilter(int) - Constructor for class org.broadinstitute.hellbender.engine.filters.AmbiguousBaseReadFilter
 
AminoAcid - Enum in org.broadinstitute.hellbender.tools.funcotator
 
AMPLICON_INTERVALS - Variable in class picard.analysis.directed.CollectTargetedPcrMetrics
 
AMPLICON_TERRITORY - Variable in class picard.analysis.directed.TargetedPcrMetrics
The number of unique bases covered by the intervals of all amplicons in the amplicon set
ANALYSIS_DIR - Variable in class picard.fastq.BamToBfq
 
AnalyzeCovariates - Class in org.broadinstitute.hellbender.tools.walkers.bqsr
Evaluate and compare base quality score recalibration tables
AnalyzeCovariates() - Constructor for class org.broadinstitute.hellbender.tools.walkers.bqsr.AnalyzeCovariates
 
and(CountingReadFilter) - Method in class org.broadinstitute.hellbender.engine.filters.CountingReadFilter
Specialization of Predicate.and(Predicate) so that CountingReadFilter and'ed with other CountingReadFilter produce a CountingReadFilter
and(CountingVariantFilter) - Method in class org.broadinstitute.hellbender.engine.filters.CountingVariantFilter
Specialization of Predicate.and(Predicate) so that CountingVariantFilter and'ed with other CountingVariantFilter produce a CountingVariantFilter
and(ReadFilter) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilter
Specialization of Predicate.and(Predicate) so that ReadFilters anded with other ReadFilters produce a ReadFilter
and(VariantFilter) - Method in interface org.broadinstitute.hellbender.engine.filters.VariantFilter
 
andThen(ReadTransformer) - Method in interface org.broadinstitute.hellbender.transformers.ReadTransformer
 
annotate(ReferenceContext, VariantContext, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_InbreedingCoeff
 
annotate(ReferenceContext, VariantContext, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_QualByDepth
 
annotate(ReferenceContext, VariantContext, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RankSumTest
 
annotate(ReferenceContext, VariantContext, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RMSMappingQuality
 
annotate(ReferenceContext, VariantContext, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.ChromosomeCounts
 
annotate(ReferenceContext, VariantContext, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.Coverage
 
annotate(ReferenceContext, VariantContext, Genotype, GenotypeBuilder, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.DepthPerAlleleBySample
 
annotate(ReferenceContext, VariantContext, Genotype, GenotypeBuilder, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.DepthPerSampleHC
 
annotate(ReferenceContext, VariantContext, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.ExcessHet
 
annotate(ReferenceContext, VariantContext, Genotype, GenotypeBuilder, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.GenotypeAnnotation
Computes the annotation for the given genotype and the likelihoods per read.
annotate(ReferenceContext, VariantContext, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.GenotypeSummaries
 
annotate(ReferenceContext, VariantContext, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.InbreedingCoeff
 
annotate(ReferenceContext, VariantContext, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.InfoFieldAnnotation
Computes the annotation for the given variant and the likelihoods per read.
annotate(ReferenceContext, VariantContext, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.MappingQualityZero
 
annotate(ReferenceContext, VariantContext, Genotype, GenotypeBuilder, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.OxoGReadCounts
 
annotate(ReferenceContext, VariantContext, Genotype, GenotypeBuilder, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.PerAlleleAnnotation
Calculate annotations for each allele based on given VariantContext and likelihoods for a given genotype's sample and add the annotations to the GenotypeBuilder.
annotate(ReferenceContext, VariantContext, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.PossibleDeNovo
 
annotate(ReferenceContext, VariantContext, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.QualByDepth
 
annotate(ReferenceContext, VariantContext, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.RankSumTest
 
annotate(ReferenceContext, VariantContext, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.ReferenceBases
 
annotate(ReferenceContext, VariantContext, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.RMSMappingQuality
 
annotate(ReferenceContext, VariantContext, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.SampleList
 
annotate(ReferenceContext, VariantContext, Genotype, GenotypeBuilder, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.StrandArtifact
 
annotate(ReferenceContext, VariantContext, Genotype, GenotypeBuilder, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.StrandBiasBySample
 
annotate(ReferenceContext, VariantContext, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.StrandBiasTest
 
annotate(ReferenceContext, VariantContext, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.TandemRepeat
 
annotate(ReferenceContext, VariantContext, Genotype, GenotypeBuilder, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.UniqueAltReadCount
 
ANNOTATE_NUMBER_OF_ALLELES_DISCOVERED - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeCalculationArgumentCollection
Depending on the value of the --max_alternate_alleles argument, we may genotype only a fraction of the alleles being sent on for genotyping.
annotateAllSitesWithPLs - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.StandardCallerArgumentCollection
Advanced, experimental argument: if SNP likelihood model is specified, and if EMIT_ALL_SITES output mode is set, when we set this argument then we will also emit PLs at all sites.
annotateBreakpointBasedCallsWithImpreciseEvidenceLinks(List<VariantContext>, PairedStrandedIntervalTree<EvidenceTargetLink>, ReadMetadata, ReferenceMultiSource, StructuralVariationDiscoveryArgumentCollection.DiscoverVariantsFromContigsAlignmentsSparkArgumentCollection, Logger) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.AnnotatedVariantProducer
 
annotateContext(VariantContext, FeatureContext, ReferenceContext, ReadLikelihoods<Allele>, Predicate<VariantAnnotation>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotatorEngine
Annotates the given variant context - adds all annotations that satisfy the predicate.
ANNOTATED_INTERVAL_DEFAULT_CONFIG_RESOURCE - Static variable in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalCollection
 
ANNOTATED_INTERVALS_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.CopyNumberStandardArgument
 
AnnotatedInterval - Class in org.broadinstitute.hellbender.tools.copynumber.formats.records
Represents an interval with a set of annotations.
AnnotatedInterval(SimpleInterval, AnnotationSet) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.records.AnnotatedInterval
 
AnnotatedInterval - Class in org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval
Simple class that just has an interval and sorted name-value pairs.
AnnotatedInterval(SimpleInterval, SortedMap<String, String>) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedInterval
 
AnnotatedIntervalCodec - Class in org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval
Read AnnotatedIntervals from a xsv file (see XsvLocatableTableCodec.
AnnotatedIntervalCodec() - Constructor for class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalCodec
 
AnnotatedIntervalCodec(Path) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalCodec
 
AnnotatedIntervalCollection - Class in org.broadinstitute.hellbender.tools.copynumber.formats.collections
 
AnnotatedIntervalCollection(File) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.collections.AnnotatedIntervalCollection
 
AnnotatedIntervalCollection(LocatableMetadata, List<AnnotatedInterval>) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.collections.AnnotatedIntervalCollection
 
AnnotatedIntervalCollection - Class in org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval
Represents a collection of annotated intervals.
AnnotatedIntervalHeader - Class in org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval
 
AnnotatedIntervalHeader(String, String, String, List<String>, SAMFileHeader) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalHeader
 
AnnotatedIntervalUtils - Class in org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval
 
AnnotatedIntervalWriter - Interface in org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval
 
AnnotatedVariantProducer - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery
Given identified pair of breakpoints for a simple SV and its supportive evidence, i.e.
AnnotatedVariantProducer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.AnnotatedVariantProducer
 
AnnotateIntervals - Class in org.broadinstitute.hellbender.tools.copynumber
Annotates intervals with GC content.
AnnotateIntervals() - Constructor for class org.broadinstitute.hellbender.tools.copynumber.AnnotateIntervals
 
annotateOverlap(List<VariantContext>, String, VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantOverlapAnnotator
Add overlaps flag attributes to vcToAnnotate overlapTestVCs.getSource() => true if an overlapping variant context can be found in overlapTestVCs with vcToAnnotate Overlaps here means that the reference alleles are the same and at least one alt allele in vcToAnnotate is equals to one of the alt alleles in overlapTestVCs
annotateOverlaps(FeatureContext, VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantOverlapAnnotator
Add overlap attributes to vcToAnnotate against all overlaps in featureContext
AnnotatePairOrientation - Class in org.broadinstitute.hellbender.tools
 
AnnotatePairOrientation() - Constructor for class org.broadinstitute.hellbender.tools.AnnotatePairOrientation
 
annotateRawData(ReferenceContext, VariantContext, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_QualByDepth
Note: There is no raw annotation for AS_QualByDepth and thus this method does nothing.
annotateRawData(ReferenceContext, VariantContext, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RankSumTest
Generates an annotation by calling the client implementation of getElementForRead(GATKRead read) over each read given its best assigned allele and returns the value of the allele as a double.
annotateRawData(ReferenceContext, VariantContext, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RMSMappingQuality
 
annotateRawData(ReferenceContext, VariantContext, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_StrandBiasTest
Uses the ReadLikelihoods map to generate a 2x2 strand contingency table by counting the total read support for each allele in either the forward or reverse direction.
annotateRawData(ReferenceContext, VariantContext, ReadLikelihoods<Allele>) - Method in interface org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.ReducibleAnnotation
Generate the raw data necessary to calculate the annotation.
annotateRawData(ReferenceContext, VariantContext, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.RMSMappingQuality
Generate the raw data necessary to calculate the annotation.
annotateRsID(FeatureContext, VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantOverlapAnnotator
Update rsID in vcToAnnotate with rsIDs from dbSNP fetched from featureContext
annotateRsID(List<VariantContext>, VariantContext) - Static method in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantOverlapAnnotator
Update rsID of vcToAnnotate with rsID match found in vcsAtLoc, if one exists
annotateSingleVariant(VariantContext, GenotypeBuilder, ReadPileup, int) - Static method in class org.broadinstitute.hellbender.tools.walkers.annotator.OxoGReadCounts
Annotate the given variant context with the OxoG read count attributes, directly from the read pileup.
annotateVariantContextsWithFilterResults(double, SortedSet<Transition>, List<VariantContext>, Map<Transition, Double>) - Static method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasFilterer
Filter genotypes with orientation bias filter while trying to keep the false discovery rate for the sample below the threshold specified.
annotateVariantContextWithPreprocessingValues(VariantContext, SortedSet<Transition>, Map<Transition, Double>) - Static method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasFilterer
Adds the annotations that can be created for individual variants.
AnnotateVcfWithBamDepth - Class in org.broadinstitute.hellbender.tools.walkers.validation
Annotate every variant in a VCF with the depth at that locus in a bam.
AnnotateVcfWithBamDepth() - Constructor for class org.broadinstitute.hellbender.tools.walkers.validation.AnnotateVcfWithBamDepth
 
AnnotateVcfWithExpectedAlleleFraction - Class in org.broadinstitute.hellbender.tools.walkers.validation
Given mixing weights of different samples in a pooled bam, annotate a corresponding vcf containing individual sample genotypes.
AnnotateVcfWithExpectedAlleleFraction() - Constructor for class org.broadinstitute.hellbender.tools.walkers.validation.AnnotateVcfWithExpectedAlleleFraction
 
Annotation - Interface in org.broadinstitute.hellbender.tools.walkers.annotator
An annotation group is a set of annotation that have something in common and should be added at the same time.
ANNOTATION_DEFAULTS_DEFAULT_VALUE - Static variable in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorArgumentDefinitions
 
ANNOTATION_DEFAULTS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorArgumentDefinitions
 
ANNOTATION_GROUP_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
ANNOTATION_GROUP_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
ANNOTATION_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
ANNOTATION_OVERRIDES_DEFAULT_VALUE - Static variable in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorArgumentDefinitions
 
ANNOTATION_OVERRIDES_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorArgumentDefinitions
 
ANNOTATION_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
annotationDefaults - Variable in class org.broadinstitute.hellbender.tools.funcotator.Funcotator
 
annotationEngine - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
 
AnnotationException - Exception in picard.annotation
Exception thrown when loading gene annotations.
AnnotationException(String) - Constructor for exception picard.annotation.AnnotationException
 
AnnotationException(String, Throwable) - Constructor for exception picard.annotation.AnnotationException
 
annotationKeys - Variable in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
 
annotationOverrideMap - Variable in class org.broadinstitute.hellbender.tools.funcotator.DataSourceFuncotationFactory
Map of ANNOTATION_NAME -> OVERRIDE_VALUE.
annotationOverrides - Variable in class org.broadinstitute.hellbender.tools.funcotator.Funcotator
 
ANNOTATIONS_TO_EXCLUDE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
ANNOTATIONS_TO_EXCLUDE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
AnnotationSet - Class in org.broadinstitute.hellbender.tools.copynumber.formats.records
Represents a set of annotations for an interval.
AnnotationSet(double) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.records.AnnotationSet
 
annotationSource - Variable in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeatureBaseData
Keyword identifying the source of this feature.
AnnotationUtils - Class in org.broadinstitute.hellbender.tools.walkers.annotator
 
annotatorEngine - Variable in class org.broadinstitute.hellbender.tools.walkers.ReferenceConfidenceVariantContextMerger
 
anonymousOptionalFields - Variable in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeatureBaseData
Additional optional GTF fields.
ApacheSingularValueDecomposer - Class in org.broadinstitute.hellbender.utils.svd
Perform singular value decomposition (and pseudoinverse calculation) in pure Java, Commons Math.
ApacheSingularValueDecomposer() - Constructor for class org.broadinstitute.hellbender.utils.svd.ApacheSingularValueDecomposer
 
append(String) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Sets the next string value in the data-line that correspond to a column.
append(int) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Sets the next int value in the data-line that correspond to a column.
append(long) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Sets the next long value in the data-line that correspond to a column.
append(long...) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Sets the next long values in the data-line that correspond to next few columns.
append(double) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Sets the next double value in the data-line that correspond to a column.
append(int...) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Sets the next int values in the data-line that correspond to next few columns.
append(String...) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Sets the next string values in the data-line that correspond to next few columns.
append(double...) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Sets the next double values in the data-line that correspond to next few columns.
append(List<T>, T...) - Static method in class org.broadinstitute.hellbender.utils.Utils
Create a new list that contains the elements of left along with elements elts
appendBases(byte[]) - Method in class org.broadinstitute.hellbender.utils.reference.FastaReferenceWriter
Adds bases to current sequence from a byte array.
appendBases(byte[], int, int) - Method in class org.broadinstitute.hellbender.utils.reference.FastaReferenceWriter
Adds bases to current sequence from a range in a byte array.
appendSATagString(StringBuilder) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
Appends the SA string representation of this interval into a builder.
appendSequence(String, byte[]) - Method in class org.broadinstitute.hellbender.utils.reference.FastaReferenceWriter
Appends a new sequence to the output.
appendSequence(String, String, byte[]) - Method in class org.broadinstitute.hellbender.utils.reference.FastaReferenceWriter
Appends a new sequence to the output with or without a description.
appendSequence(String, String, int, byte[]) - Method in class org.broadinstitute.hellbender.utils.reference.FastaReferenceWriter
Appends a new sequence to the output with or without a description and an alternative number of bases-per-line.
apply(AbstractConcordanceWalker.TruthVersusEval, ReadsContext, ReferenceContext) - Method in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker
 
apply(AssemblyRegion, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
Process an individual AssemblyRegion.
apply(GATKRead) - Method in class org.broadinstitute.hellbender.engine.datasources.ReferenceWindowFunctions.FixedWindowFunction
 
apply(F, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.engine.FeatureWalker
Process an individual feature.
apply(SimpleInterval, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.engine.IntervalWalker
Process an individual interval.
apply(AlignmentContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.engine.LocusWalker
Process an individual AlignmentContext (with optional contextual information).
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.engine.MultiVariantWalkerGroupedOnStart
This method keeps track of all the variants it is passed and will feed all the variants that start at the same site to the reduce method.
apply(List<VariantContext>, ReferenceContext) - Method in class org.broadinstitute.hellbender.engine.MultiVariantWalkerGroupedOnStart
This method must be implemented by tool authors.
apply(GATKRead, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.engine.ReadWalker
Process an individual read (with optional contextual information).
apply(GATKRead, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.engine.TwoPassReadWalker
Not called by TwoPassReadWalker.
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.engine.TwoPassVariantWalker
Make final to hide it from subclasses
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.engine.VariantWalkerBase
Process an individual variant.
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.AnnotatePairOrientation
 
apply(GATKRead, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.ClipReads
 
apply(AlignmentContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.copynumber.CollectAllelicCounts
 
apply(GATKRead, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.copynumber.CollectReadCounts
 
apply(GATKRead, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.CountBases
 
apply(GATKRead, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.CountReads
 
apply(AssemblyRegion, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.examples.ExampleAssemblyRegionWalker
 
apply(BEDFeature, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.examples.ExampleFeatureWalker
 
apply(SimpleInterval, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.examples.ExampleIntervalWalker
 
apply(AlignmentContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.examples.ExampleLocusWalker
 
apply(GATKRead, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.examples.ExamplePostTraversalPythonExecutor
 
apply(GATKRead, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.examples.ExampleReadWalkerWithReference
 
apply(GATKRead, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.examples.ExampleReadWalkerWithVariants
 
apply(GATKRead, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.examples.ExampleStreamingPythonExecutor
 
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.examples.ExampleVariantWalker
 
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.exome.FilterByOrientationBias
Just adds the Pre Adapter Q annotation to the variant and creates a new variant.
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.FixCallSetSampleOrdering
 
apply(GATKRead, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.FixMisencodedBaseQualityReads
 
apply(GATKRead, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.FlagStat
 
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.funcotator.Funcotator
 
apply(GATKRead, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.LeftAlignIndels
 
apply(GATKRead, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.PrintReads
 
apply(Iterator<GATKRead>, SAMFileHeader) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBwaAligner
 
apply(Iterator<GATKRead>) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBwaFilter
 
apply(BreakpointEvidence) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidenceClusterer
 
apply(Tuple2<Integer, List<SVFastqUtils.FastqRead>>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.FermiLiteAssemblyHandler
This method creates an assembly with FermiLite, and uses the graph information returned by that assembler to stitch together valid paths through the contigs.
apply(Iterator<GATKRead>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.KmerCounter
 
apply(GATKRead) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.QNameFinder
 
apply(GATKRead) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.QNameIntervalFinder
 
apply(GATKRead) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.QNameKmerizer
 
apply(GATKRead) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.QNamesForKmersFinder
 
apply(GATKRead) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadClassifier
 
apply(T, U, V) - Method in interface org.broadinstitute.hellbender.tools.spark.sv.utils.SingleSequenceReferenceAligner.TriFunction
 
apply(JavaRDD<GATKRead>, Broadcast<RecalibrationReport>, SAMFileHeader, ApplyBQSRArgumentCollection) - Static method in class org.broadinstitute.hellbender.tools.spark.transforms.ApplyBQSRSparkFn
 
apply(JavaPairRDD<GATKRead, ReadContextData>, SAMFileHeader, SAMSequenceDictionary, RecalibrationArgumentCollection) - Static method in class org.broadinstitute.hellbender.tools.spark.transforms.BaseRecalibratorSparkFn
 
apply(Iterator<ContextShard>) - Method in class org.broadinstitute.hellbender.tools.spark.transforms.bqsr.BaseRecalibratorEngineSparkWrapper
 
apply(GATKRead, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.SplitReads
 
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotator
For each site of interest, annotate based on the requested annotation types
apply(GATKRead, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.bqsr.ApplyBQSR
 
apply(GATKRead, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.bqsr.BaseRecalibrator
For each read at this locus get the various covariate values and increment that location in the map based on whether or not the base matches the reference at this particular location
apply(List<VariantContext>, ReferenceContext) - Method in class org.broadinstitute.hellbender.tools.walkers.CombineGVCFs
 
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.contamination.GetPileupSummaries
 
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.CountVariants
 
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
 
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.GenotypeGVCFs
 
apply(AssemblyRegion, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCaller
 
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.FilterMutectCalls
 
apply(AssemblyRegion, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2
 
apply(AlignmentContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.qc.CheckPileup
 
apply(AlignmentContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.qc.Pileup
 
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.FilterAlignmentArtifacts
 
apply(GATKRead, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.RevertBaseQualityScores
 
apply(AlignmentContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.ASEReadCounter
 
apply(GATKRead, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.UnmarkDuplicates
 
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.validation.AnnotateVcfWithBamDepth
 
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.validation.AnnotateVcfWithExpectedAlleleFraction
 
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.validation.CalculateMixingFractions
 
apply(AbstractConcordanceWalker.TruthVersusEval, ReadsContext, ReferenceContext) - Method in class org.broadinstitute.hellbender.tools.walkers.validation.Concordance
 
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.validation.CountFalsePositives
 
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.validation.RemoveNearbyIndels
 
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.variantutils.CalculateGenotypePosteriors
 
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.variantutils.SelectVariants
 
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.variantutils.UpdateVCFSequenceDictionary
 
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.variantutils.ValidateVariants
 
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.variantutils.VariantsToTable
 
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.ApplyVQSR
 
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.CNNScoreVariants
 
apply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantRecalibrator
 
apply(GATKRead) - Method in class org.broadinstitute.hellbender.transformers.AdapterTrimTransformer
 
apply(GATKRead) - Method in class org.broadinstitute.hellbender.transformers.BaseQualityClipReadTransformer
Clip bases on the right end of the read from

argmax_x{ \sum{i = x + 1}^l (qTrimmingThreshold - qual).

apply(GATKRead) - Method in class org.broadinstitute.hellbender.transformers.BaseQualityReadTransformer
 
apply(GATKRead) - Method in class org.broadinstitute.hellbender.transformers.BQSRReadTransformer
Recalibrates the base qualities of a read
apply(GATKRead) - Method in class org.broadinstitute.hellbender.transformers.DUSTReadTransformer
 
apply(GATKRead) - Method in class org.broadinstitute.hellbender.transformers.MappingQualityReadTransformer
 
apply(GATKRead) - Method in class org.broadinstitute.hellbender.transformers.MisencodedBaseQualityReadTransformer
 
apply(GATKRead) - Method in class org.broadinstitute.hellbender.transformers.NDNCigarReadTransformer
 
apply(GATKRead) - Method in class org.broadinstitute.hellbender.transformers.SimpleRepeatMaskTransformer
 
apply(GATKRead) - Method in class org.broadinstitute.hellbender.transformers.StripMateNumberTransformer
 
apply(ClippingRepresentation, GATKRead) - Method in class org.broadinstitute.hellbender.utils.clipping.ClippingOp
Clips the bases in read according to this operation's start and stop.
apply(int, int) - Method in interface org.broadinstitute.hellbender.utils.functional.IntToDoubleBiFunction
 
apply(List<D>, List<T>, HMM<D, T, S>) - Static method in class org.broadinstitute.hellbender.utils.hmm.ForwardBackwardAlgorithm
Runs the forward-backward algorithm on a data-positions list pair given a type-compatible model.
apply(List<D>, List<T>, HMM<D, T, S>) - Static method in class org.broadinstitute.hellbender.utils.hmm.ViterbiAlgorithm
Calculates the most likely the hidden state sequence that explains the observed data given the corresponding sequence of observation positions.
apply(int) - Method in interface org.broadinstitute.hellbender.utils.MathUtils.IntToDoubleArrayFunction
 
apply(GATKRead) - Method in class org.broadinstitute.hellbender.utils.recalibration.BaseRecalibrationEngine.BQSRReferenceWindowFunction
 
apply(T) - Method in interface org.broadinstitute.hellbender.utils.SerializableFunction
 
APPLY_EAMSS_FILTER - Variable in class picard.illumina.IlluminaBasecallsToFastq
 
APPLY_EAMSS_FILTER - Variable in class picard.illumina.IlluminaBasecallsToSam
 
applyAlignment(String, byte[], byte[], String, BwaMemAlignment, List<String>, SAMFileHeader, boolean, boolean) - Static method in class org.broadinstitute.hellbender.utils.bwa.BwaMemAlignmentUtils
Builds a SAMRecord from unaligned read data and an alignment.
ApplyBQSR - Class in org.broadinstitute.hellbender.tools.walkers.bqsr
Apply base quality score recalibration
ApplyBQSR() - Constructor for class org.broadinstitute.hellbender.tools.walkers.bqsr.ApplyBQSR
 
applyBqsrArgs - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.BQSRPipelineSpark
command-line arguments to fine tune the apply BQSR step.
applyBqsrArgs - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.ReadsPipelineSpark
command-line arguments to fine tune the apply BQSR step.
ApplyBQSRArgumentCollection - Class in org.broadinstitute.hellbender.tools
The collection of all arguments needed for ApplyBQSR.
ApplyBQSRArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.ApplyBQSRArgumentCollection
 
ApplyBQSRSpark - Class in org.broadinstitute.hellbender.tools.spark
Apply base quality score recalibration with Spark.
ApplyBQSRSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.ApplyBQSRSpark
 
ApplyBQSRSparkFn - Class in org.broadinstitute.hellbender.tools.spark.transforms
 
ApplyBQSRSparkFn() - Constructor for class org.broadinstitute.hellbender.tools.spark.transforms.ApplyBQSRSparkFn
 
ApplyBQSRUniqueArgumentCollection - Class in org.broadinstitute.hellbender.tools
The collection of those arguments for ApplyBQSR that are not already defined in RecalibrationArgumentCollection.
ApplyBQSRUniqueArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.ApplyBQSRUniqueArgumentCollection
 
applyCigarToCigar(Cigar, Cigar) - Static method in class org.broadinstitute.hellbender.utils.read.AlignmentUtils
Generate a new Cigar that maps the operations of the first cigar through those in a second For example, if first is 5M and the second is 2M1I2M then the result is 2M1I2M.
applyFilter(Iterator<GATKRead>, BiPredicate<SVReadFilter, GATKRead>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.SVReadFilter
 
applyFilters(M2FiltersArgumentCollection, VariantContext, VariantContextBuilder) - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2FilteringEngine
 
applyMapFunc(Function<I, Iterator<O>>, Iterator<? extends I>) - Static method in class org.broadinstitute.hellbender.tools.spark.utils.FlatMapGluer
 
applyMapFunc(Function<I, Iterator<O>>, Iterator<? extends I>, I) - Static method in class org.broadinstitute.hellbender.tools.spark.utils.FlatMapGluer
 
applyToArray(double[], DoubleUnaryOperator) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
The following method implements Arrays.stream(array).map(func).toArray(), which is concise but performs poorly due to the overhead of creating a stream, especially with small arrays.
applyToArray(int[], IntToDoubleFunction) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
The following method implements Arrays.stream(array).map(func).toArray(), which is concise but performs poorly due to the overhead of creating a stream, especially with small arrays.
applyToArrayInPlace(double[], DoubleUnaryOperator) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
The following method implements Arrays.stream(array).map(func).toArray(), which is concise but performs poorly due to the overhead of creating a stream, especially with small arrays.
ApplyVQSR - Class in org.broadinstitute.hellbender.tools.walkers.vqsr
Apply a score cutoff to filter variants based on a recalibration table
ApplyVQSR() - Constructor for class org.broadinstitute.hellbender.tools.walkers.vqsr.ApplyVQSR
 
approximateLog10SumLog10(double[]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
approximateLog10SumLog10(double[], int) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
approximateLog10SumLog10(double, double, double) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
approximateLog10SumLog10(double, double) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
approximateLog10SumLog10(double[], int, int) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Calculate the approximate log10 sum of an array range.
areAlignmentsEqual() - Method in class org.broadinstitute.hellbender.utils.read.SamComparison
Returns true if the alignments are equal, false otherwise.
areEqual() - Method in class org.broadinstitute.hellbender.utils.read.SamComparison
 
areEqual() - Method in class picard.sam.CompareSAMs
 
areHeadersEqual() - Method in class org.broadinstitute.hellbender.utils.read.SamComparison
Returns true if the headers are equal, false otherwise.
areHistogramsEmpty() - Method in class picard.analysis.CollectWgsMetricsWithNonZeroCoverage.WgsMetricsWithNonZeroCoverageCollector
 
areVariantsAtSameLocusConcordant(VariantContext, VariantContext) - Method in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker
 
areVariantsAtSameLocusConcordant(VariantContext, VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.validation.Concordance
 
argmax(Function<Double, Double>, double, double, double) - Static method in class org.broadinstitute.hellbender.utils.OptimizationUtils
 
argmax(Function<Double, Double>, double, double, double, double, double, int) - Static method in class org.broadinstitute.hellbender.utils.OptimizationUtils
 
args - Variable in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
ARGUMENT_COLUMN_NAME - Static variable in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
 
ARGUMENT_REPORT_TABLE_TITLE - Static variable in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
 
ARGUMENT_VALUE_COLUMN_NAME - Static variable in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
 
ArgumentsBuilder - Class in org.broadinstitute.hellbender.utils.test
Builder for command line argument lists It will convert old style "Argument=Value" into new style "--Argument value" strings Use this only in test code.
ArgumentsBuilder() - Constructor for class org.broadinstitute.hellbender.utils.test.ArgumentsBuilder
 
ArgumentsBuilder(Object[]) - Constructor for class org.broadinstitute.hellbender.utils.test.ArgumentsBuilder
 
ARRAY_DIM - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.StrandBiasTest
 
ARRAY_SIZE - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.StrandBiasTest
 
arrayListCollector(int) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVUtils
Provides a stream collector that will collect items into an array list with a given initial capacity.
arrayMax(double[]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
arrayMin(int[]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
ARTIFACT_IN_NORMAL_FILTER_NAME - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
ARTIFACT_MODES_FULL_NAME - Static variable in class org.broadinstitute.hellbender.tools.exome.FilterByOrientationBias
 
ARTIFACT_MODES_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.exome.FilterByOrientationBias
 
ARTIFACT_NAME - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasSummaryMetrics
A "nickname" of this artifact, if it is a known error mode.
ARTIFACT_NAME - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterSummaryMetrics
A "nickname" of this artifact, if it is a known error mode.
ArtifactStatisticsScorer - Class in org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter
 
ArtifactStatisticsScorer() - Constructor for class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.ArtifactStatisticsScorer
 
ArtificialBAMBuilder - Class in org.broadinstitute.hellbender.utils.read
Easy to use creator of artificial BAM files for testing Allows us to make a stream of reads or an index BAM file with read having the following properties - coming from n samples - of fixed read length and aligned to the genome with M operator - having N reads per alignment start - skipping N bases between each alignment start - starting at a given alignment start
ArtificialBAMBuilder(int, int) - Constructor for class org.broadinstitute.hellbender.utils.read.ArtificialBAMBuilder
 
ArtificialBAMBuilder(SAMSequenceDictionary, int, int) - Constructor for class org.broadinstitute.hellbender.utils.read.ArtificialBAMBuilder
 
ArtificialReadIterator - Class in org.broadinstitute.hellbender.utils.read
this fake iterator allows us to look at how specific piles of reads are handled
ArtificialReadQueryIterator - Class in org.broadinstitute.hellbender.utils.read
 
ArtificialReadUtils - Class in org.broadinstitute.hellbender.utils.read
 
ArtificialReadUtils() - Constructor for class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
 
AS_BASE_QUAL_RANK_SUM_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
AS_BaseQualityRankSumTest - Class in org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific
Allele-specific rank Sum Test of REF versus ALT base quality scores
AS_BaseQualityRankSumTest() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_BaseQualityRankSumTest
 
AS_CULPRIT_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
AS_FILTER_STATUS_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
AS_FISHER_STRAND_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
AS_FisherStrand - Class in org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific
Allele-specific strand bias estimated using Fisher's Exact Test *
AS_FisherStrand() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_FisherStrand
 
AS_HETEROZYGOSITY_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
AS_INBREEDING_COEFFICIENT_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
AS_InbreedingCoeff - Class in org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific
Allele-specific likelihood-based test for the inbreeding among samples
AS_InbreedingCoeff() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_InbreedingCoeff
 
AS_InbreedingCoeff(Set<String>) - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_InbreedingCoeff
 
AS_MAP_QUAL_RANK_SUM_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
AS_MappingQualityRankSumTest - Class in org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific
Allele specific Rank Sum Test for mapping qualities of REF versus ALT reads
AS_MappingQualityRankSumTest() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_MappingQualityRankSumTest
 
AS_QUAL_BY_DEPTH_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
AS_QUAL_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
AS_QualByDepth - Class in org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific
Allele-specific call confidence normalized by depth of sample reads supporting the allele
AS_QualByDepth() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_QualByDepth
 
AS_RankSumTest - Class in org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific
Allele-specific implementation of rank sum test annotations
AS_RankSumTest() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RankSumTest
 
AS_RAW_BASE_QUAL_RANK_SUM_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
AS_RAW_MAP_QUAL_RANK_SUM_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
AS_RAW_READ_POS_RANK_SUM_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
AS_RAW_RMS_MAPPING_QUALITY_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
AS_READ_POS_RANK_SUM_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
AS_ReadPosRankSumTest - Class in org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific
Allele-specific Rank Sum Test for relative positioning of REF versus ALT allele within reads
AS_ReadPosRankSumTest() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_ReadPosRankSumTest
 
AS_RMS_MAPPING_QUALITY_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
AS_RMSMappingQuality - Class in org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific
Allele-specific Root Mean Square of the mapping quality of reads across all samples.
AS_RMSMappingQuality() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RMSMappingQuality
 
AS_SB_TABLE_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
AS_StandardAnnotation - Interface in org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific
This is a marker interface used to indicate which annotations are "Standard" and allele-specific.
AS_STRAND_ODDS_RATIO_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
AS_StrandBiasTest - Class in org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific
Allele-specific implementation of strand bias annotations
AS_StrandBiasTest() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_StrandBiasTest
 
AS_StrandOddsRatio - Class in org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific
Allele-specific strand bias estimated by the Symmetric Odds Ratio test
AS_StrandOddsRatio() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_StrandOddsRatio
 
AS_VQS_LOD_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
asAlleleList(List<T>) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeAlleleCounts
Composes a list with the alleles, possibly containing repeats i.e.
asDoubleArray(Collection<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.PerAlleleCollection
 
ASEReadCounter - Class in org.broadinstitute.hellbender.tools.walkers.rnaseq
Calculate read counts per allele for allele-specific expression analysis of RNAseq data
ASEReadCounter() - Constructor for class org.broadinstitute.hellbender.tools.walkers.rnaseq.ASEReadCounter
 
ASEReadCounter.CountPileupType - Enum in org.broadinstitute.hellbender.tools.walkers.rnaseq
 
ASEReadCounter.OUTPUT_FORMAT - Enum in org.broadinstitute.hellbender.tools.walkers.rnaseq
 
asList() - Method in class org.broadinstitute.hellbender.utils.collections.IndexedSet
Returns a list view of the elements in the set.
asList(int...) - Static method in class org.broadinstitute.hellbender.utils.Utils
Returns a List<Integer> representation of an primitive int array.
asList(double...) - Static method in class org.broadinstitute.hellbender.utils.Utils
Returns a List<Double> representation of an primitive double array.
asList() - Method in class picard.vcf.GenotypeConcordance.Alleles
 
asListOfAlleles() - Method in interface org.broadinstitute.hellbender.utils.genotyper.AlleleList
Returns a List unmodifiable view of this allele-list
asListOfSamples() - Method in interface org.broadinstitute.hellbender.utils.genotyper.SampleList
Returns a List unmodifiable view of a sample-list
AssembledEvidenceResults(ReadMetadata, List<SVInterval>, List<AlignedAssemblyOrExcuse>, List<EvidenceTargetLink>) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.FindBreakpointEvidenceSpark.AssembledEvidenceResults
 
assemblerArgs - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerArgumentCollection
 
assembleReads(AssemblyRegion, List<VariantContext>, AssemblyBasedCallerArgumentCollection, SAMFileHeader, SampleList, Logger, ReferenceSequenceFile, ReadThreadingAssembler, SmithWatermanAligner) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerUtils
High-level function that runs the assembler on the given region's reads, returning a data structure with the resulting information needed for further HC steps
assembliesSortOrder - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
ASSEMBLY_NAME_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
ASSEMBLY_PADDING_LONG_NAME - Static variable in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
ASSEMBLY_REGION_OUT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
AssemblyBasedCallerArgumentCollection - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
Set of arguments for Assembly Based Callers
AssemblyBasedCallerArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerArgumentCollection
 
AssemblyBasedCallerGenotypingEngine - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
Created by davidben on 12/21/16.
AssemblyBasedCallerGenotypingEngine(AssemblyBasedCallerArgumentCollection, SampleList, AFCalculatorProvider, boolean) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerGenotypingEngine
AssemblyBasedCallerGenotypingEngine.CalledHaplotypes - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
Carries the result of a call to #assignGenotypeLikelihoods
AssemblyBasedCallerUtils - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
Created by davidben on 9/8/16.
AssemblyBasedCallerUtils() - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerUtils
 
AssemblyContigAlignmentsConfigPicker - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment
A simple heuristic optimizer based on extensive manual review of alignments produced by the aligner (currently "bwa mem -x intractg") with the aim for picking a configuration that provides "optimal coverage" for the input assembly contig.
AssemblyContigAlignmentsConfigPicker() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigAlignmentsConfigPicker
 
AssemblyContigAlignmentsConfigPicker.GoodAndBadMappings - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment
After configuration scoring and picking, the original alignments can be classified as good and bad mappings: good: the ones used the picked configuration bad: unused alignments in the chosen configuration; these likely contain more noise than information they can be turned into string representation following the format as in AlignmentInterval.toPackedString() Note that a special case needs attention: if AssemblyContigAlignmentsConfigPicker.GoodAndBadMappings.getMayBeNullGoodMappingToNonCanonicalChromosome() returns non-null result, it is indicating an equally good--or better--non-chimeric mapping to a non-canonical chromosome exists, but to preserve the SV signal, we keep the chimeric alignments to canonical chromosomes and signal the situation to downstream units.
AssemblyContigWithFineTunedAlignments - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment
A wrapper around AlignedContig to represent mapped assembly contig whose alignments went through AssemblyContigAlignmentsConfigPicker and may represent SV breakpoints.
AssemblyContigWithFineTunedAlignments(AlignedContig) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments
 
AssemblyContigWithFineTunedAlignments(AlignedContig, List<String>, boolean, AlignmentInterval) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments
 
AssemblyContigWithFineTunedAlignments(AlignedContig, List<String>, boolean, String) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments
 
AssemblyContigWithFineTunedAlignments.AlignmentSignatureBasicType - Enum in org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment
 
AssemblyContigWithFineTunedAlignments.ReasonForAlignmentClassificationFailure - Enum in org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment
 
AssemblyContigWithFineTunedAlignments.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment
 
assemblyId - Variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignedAssembly
 
assemblyImpreciseEvidenceOverlapUncertainty - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.DiscoverVariantsFromContigsAlignmentsSparkArgumentCollection
 
AssemblyRegion - Class in org.broadinstitute.hellbender.engine
Region of the genome that gets assembled by the local assembly engine.
AssemblyRegion(SimpleInterval, List<ActivityProfileState>, boolean, int, SAMFileHeader) - Constructor for class org.broadinstitute.hellbender.engine.AssemblyRegion
Create a new AssemblyRegion containing no reads
AssemblyRegion(SimpleInterval, int, SAMFileHeader) - Constructor for class org.broadinstitute.hellbender.engine.AssemblyRegion
Simple interface to create an assembly region that isActive without any profile state
AssemblyRegionEvaluator - Interface in org.broadinstitute.hellbender.engine
Classes that implement this interface have the ability to evaluate how likely it is that a site is "active" (contains potential real variation).
assemblyRegionEvaluator() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
assemblyRegionEvaluator() - Method in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerSpark
 
assemblyRegionEvaluator() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleAssemblyRegionWalker
 
assemblyRegionEvaluator() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleAssemblyRegionWalkerSpark
 
assemblyRegionEvaluator() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCaller
 
assemblyRegionEvaluator() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2
 
AssemblyRegionIterator - Class in org.broadinstitute.hellbender.engine
Given a MultiIntervalShard of GATKRead, iterates over each AssemblyRegion within that shard, using the provided AssemblyRegionEvaluator to determine the boundaries between assembly regions.
AssemblyRegionIterator(MultiIntervalShard<GATKRead>, SAMFileHeader, ReferenceDataSource, FeatureManager, AssemblyRegionEvaluator, int, int, int, double, int, boolean) - Constructor for class org.broadinstitute.hellbender.engine.AssemblyRegionIterator
Constructs an AssemblyRegionIterator over a provided read shard
assemblyRegionOut - Variable in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
If provided, this walker will write out its assembly regions to this file in the IGV formatted TAB-delimited output: http://www.broadinstitute.org/software/igv/IGV Intended to make debugging the active region calculations easier
assemblyRegionPadding - Variable in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
assemblyRegionPadding - Variable in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerSpark
 
assemblyRegionPadding - Variable in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark.ShardingArgumentCollection
 
AssemblyRegionTrimmer - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
Helper component to manage active region trimming

It receives the user arguments that controls trimming and also performs the trimming region calculation.

AssemblyRegionTrimmer() - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmer
 
AssemblyRegionTrimmer.Result - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
Holds the result of trimming.
assemblyRegionTrimmerArgs - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerArgumentCollection
 
AssemblyRegionTrimmerArgumentCollection - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
 
AssemblyRegionTrimmerArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmerArgumentCollection
 
AssemblyRegionWalker - Class in org.broadinstitute.hellbender.engine
An AssemblyRegionWalker is a tool that processes an entire region of reads at a time, each marked as either "active" (containing possible variation) or "inactive" (not likely to contain actual variation).
AssemblyRegionWalker() - Constructor for class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
AssemblyRegionWalkerContext - Class in org.broadinstitute.hellbender.engine.spark
Encapsulates an AssemblyRegion with its ReferenceContext and FeatureContext.
AssemblyRegionWalkerContext(AssemblyRegion, ReferenceContext, FeatureContext) - Constructor for class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerContext
 
AssemblyRegionWalkerSpark - Class in org.broadinstitute.hellbender.engine.spark
A Spark version of AssemblyRegionWalker.
AssemblyRegionWalkerSpark() - Constructor for class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerSpark
 
assemblyRegionWithWellMappedReads(AssemblyRegion, int, SAMFileHeader) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerUtils
 
AssemblyResult - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
Result of assembling, with the resulting graph and status
AssemblyResult(AssemblyResult.Status, SeqGraph, ReadThreadingGraph) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResult
Create a new assembly result
AssemblyResult.Status - Enum in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
Status of the assembly result
AssemblyResultSet - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
Collection of read assembly using several kmerSizes.
AssemblyResultSet() - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResultSet
Constructs a new empty assembly result set.
assemblyToMappedSizeRatioGuess - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
assertAttributeNameIsLegal(String) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Check whether the given String represents a legal attribute name according to the SAM spec, and throw an exception if it doesn't.
assertBooleanPropertiesField(Properties, String, Path) - Static method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
Asserts that the given field is contained in the given props and is a boolean value.
assertCondition(Iterable<T>, Iterable<T>, BiConsumer<T, T>) - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest
 
assertConfigFilePropertiesAreValid(Properties, Path) - Method in enum org.broadinstitute.hellbender.tools.funcotator.FuncotatorArgumentDefinitions.DataSourceType
Asserts that the given properties and corresponding config file path are valid for this FuncotatorArgumentDefinitions.DataSourceType.
assertConfigPropertiesContainsKey(String, Properties, Path) - Static method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
Asserts that the given key is contained in the given configProperties.
assertContains(String, String) - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest
 
assertCRAMContents(Path) - Static method in class org.broadinstitute.hellbender.utils.test.SamAssertionUtils
Unconditionally validate/assert that the contents are CRAM
assertCRAMContentsIfCRAM(File) - Static method in class org.broadinstitute.hellbender.utils.test.SamAssertionUtils
Validate/assert that the contents are CRAM if the extension is .cram
assertCRAMContentsIfCRAM(Path) - Static method in class org.broadinstitute.hellbender.utils.test.SamAssertionUtils
Validate/assert that the contents are CRAM if the extension is .cram
assertEqualBamFiles(File, File, boolean, ValidationStringency) - Static method in class org.broadinstitute.hellbender.utils.test.SamAssertionUtils
Compares the two given bam files, optionally sorting them before comparison.
assertEqualBamFiles(File, File, File, boolean, ValidationStringency) - Static method in class org.broadinstitute.hellbender.utils.test.SamAssertionUtils
Compares the two given bam files, optionally sorting them before comparison.
assertEqualsDoubleArray(double[], double[], double) - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest
Checks whether two double array contain the same values or not.
assertEqualsDoubleSmart(Object, Double, double) - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest
 
assertEqualsDoubleSmart(double, double) - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest
 
assertEqualsDoubleSmart(double, double, double) - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest
 
assertEqualsDoubleSmart(double, double, double, String) - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest
 
assertEqualsLongArray(long[], long[]) - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest
Checks whether two long arrays contain the same values or not.
assertEqualsSet(Set<T>, Set<T>, String) - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest
 
assertEqualTextFiles(File, File) - Static method in class org.broadinstitute.hellbender.utils.test.IntegrationTestSpec
 
assertEqualTextFiles(File, File, String) - Static method in class org.broadinstitute.hellbender.utils.test.IntegrationTestSpec
Compares two text files and ignores all lines that start with the comment prefix.
assertEqualVariants(List<VariantContext>, List<VariantContext>) - Static method in class org.broadinstitute.hellbender.utils.test.VariantContextTestUtils
Validates that the given lists have variant context that correspond to the same variants in the same order.
assertFileIsReadable(Path) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
 
assertGenotypePosteriorsAttributeWasRemoved(VariantContext, VariantContext) - Static method in class org.broadinstitute.hellbender.utils.test.VariantContextTestUtils
 
assertGenotypesAreEqual(Genotype, Genotype) - Static method in class org.broadinstitute.hellbender.utils.test.VariantContextTestUtils
 
assertIntegerPropertiesField(Properties, String, Path) - Static method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
Asserts that the given field is contained in the given props and is an integer value.
assertMatchingFiles(List<File>, List<String>, boolean, ValidationStringency) - Static method in class org.broadinstitute.hellbender.utils.test.IntegrationTestSpec
 
assertMinimumQualities() - Method in class picard.illumina.parser.readers.BclQualityEvaluationStrategy
Reviews the qualities observed thus far and throws an exception if any are below the minimum quality threshold.
assertPairedMates(SAMRecord, SAMRecord) - Static method in class picard.sam.SamToFastq
 
assertPathFilePropertiesField(Properties, String, Path) - Static method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
Asserts that the given field is contained in the given props and is a file path.
assertProperFileStructure(File) - Method in class picard.illumina.parser.readers.BclReader
 
assertSamsEqual(File, File, ValidationStringency, File) - Static method in class org.broadinstitute.hellbender.utils.test.SamAssertionUtils
causes an exception if the given sam files aren't equal
assertSamsEqual(Path, Path, ValidationStringency, Path) - Static method in class org.broadinstitute.hellbender.utils.test.SamAssertionUtils
 
assertSamsEqual(File, File, ValidationStringency) - Static method in class org.broadinstitute.hellbender.utils.test.SamAssertionUtils
causes an exception if the given sam files aren't equal
assertSamsEqual(File, File, File) - Static method in class org.broadinstitute.hellbender.utils.test.SamAssertionUtils
causes an exception if the given sam files aren't equal
assertSamsEqual(Path, Path, Path) - Static method in class org.broadinstitute.hellbender.utils.test.SamAssertionUtils
 
assertSamsEqual(File, File) - Static method in class org.broadinstitute.hellbender.utils.test.SamAssertionUtils
causes an exception if the given sam files aren't equal
assertSamValid(File, ValidationStringency, File) - Static method in class org.broadinstitute.hellbender.utils.test.SamAssertionUtils
causes an exception if the given sam isn't valid
assertSamValid(File, ValidationStringency) - Static method in class org.broadinstitute.hellbender.utils.test.SamAssertionUtils
causes an exception if the given sam isn't valid
assertSamValid(File, File) - Static method in class org.broadinstitute.hellbender.utils.test.SamAssertionUtils
causes an exception if the given sam isn't valid
assertSamValid(File) - Static method in class org.broadinstitute.hellbender.utils.test.SamAssertionUtils
causes an exception if the given sam isn't valid the default ValidationStringency value for this method is LENIENT
assertSorted(Iterable<T>, Comparator<T>) - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest
assert that the iterable is sorted according to the comparator
assertSorted(Iterator<T>, Comparator<T>) - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest
assert that the iterator is sorted according to the comparator
assertSorted(SAMFileHeader.SortOrder) - Method in class picard.sam.markduplicates.MarkDuplicatesWithMateCigarIterator
Establishes that records returned by this iterator are expected to be in the specified sort order.
assertValidStrand(Strand) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Asserts that the given strand is non-null and is not equal to Strand.NONE.
assertVariantContextsAreEqual(VariantContext, VariantContext, List<String>) - Static method in class org.broadinstitute.hellbender.utils.test.VariantContextTestUtils
 
assertVariantContextsAreEqualAlleleOrderIndependent(VariantContext, VariantContext, List<String>, VCFHeader) - Static method in class org.broadinstitute.hellbender.utils.test.VariantContextTestUtils
Method which compares two variant contexts for equality regardless of different allele ordering.
assertVariantContextsHaveSameGenotypes(VariantContext, VariantContext) - Static method in class org.broadinstitute.hellbender.utils.test.VariantContextTestUtils
 
asSetOfSamples() - Method in interface org.broadinstitute.hellbender.utils.genotyper.SampleList
Returns a Set unmodifiable view of the sample-list
ASSIGNED_UMI_TAG - Variable in class picard.sam.markduplicates.UmiAwareMarkDuplicatesWithMateCigar
 
assignGenotypeLikelihoods(List<Haplotype>, ReadLikelihoods<Haplotype>, Map<String, List<GATKRead>>, byte[], SimpleInterval, SimpleInterval, FeatureContext, List<VariantContext>, boolean, int, SAMFileHeader) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerGenotypingEngine
Main entry point of class - given a particular set of haplotypes, samples and reference context, compute genotype likelihoods and assemble into a list of variant contexts and genomic events ready for calling The list of samples we're working with is obtained from the readLikelihoods
assignLocusFunctionForRange(int, LocusFunction[]) - Method in class picard.annotation.Gene.Transcript
Write into locusFunctions the function of each position from start to start + locusFunctions.length relative to this transcript.
ASSUME_SORT_ORDER - Variable in class picard.sam.markduplicates.util.AbstractMarkDuplicatesCommandLineProgram
 
ASSUME_SORT_ORDER_SHORT_NAME - Static variable in class picard.cmdline.StandardOptionDefinitions
 
ASSUME_SORTED - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectMultipleMetricsSpark
 
ASSUME_SORTED - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.AbstractMarkDuplicatesCommandLineProgram
 
ASSUME_SORTED - Variable in class picard.analysis.CollectMultipleMetrics
 
ASSUME_SORTED - Variable in class picard.analysis.CollectRrbsMetrics
 
ASSUME_SORTED - Variable in class picard.analysis.SinglePassSamProgram
 
ASSUME_SORTED - Variable in class picard.sam.FixMateInformation
 
ASSUME_SORTED - Variable in class picard.sam.markduplicates.util.AbstractMarkDuplicatesCommandLineProgram
Deprecated.
ASSUME_SORTED - Variable in class picard.sam.MergeSamFiles
 
ASSUME_SORTED_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
ASSUME_SORTED_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
ASSUME_SORTED_SHORT_NAME - Static variable in class picard.cmdline.StandardOptionDefinitions
 
asTag(BwaMemAlignment, List<String>) - Static method in class org.broadinstitute.hellbender.utils.bwa.BwaMemAlignmentUtils
Describes an alignment as a string for use in an SA tag, for example.
asVcf(ReferenceSequenceFile) - Method in class picard.fingerprint.HaplotypeMap
 
AsynchronousStreamWriterService<T> - Class in org.broadinstitute.hellbender.utils.runtime
A service that can be used to write to a stream using a thread background thread and an executor service.
AsynchronousStreamWriterService(ExecutorService, OutputStream, Function<T, ByteArrayOutputStream>) - Constructor for class org.broadinstitute.hellbender.utils.runtime.AsynchronousStreamWriterService
 
AsyncIterator<T> - Class in picard.util
Wrapper around a CloseableIterator that reads in a separate thread, for cases in which that might be efficient.
AsyncIterator(CloseableIterator<T>, int, String) - Constructor for class picard.util.AsyncIterator
 
AT_DROPOUT - Variable in class picard.analysis.directed.HsMetrics
A measure of how undercovered <= 50% GC regions are relative to the mean.
AT_DROPOUT - Variable in class picard.analysis.directed.TargetedPcrMetrics
A measure of how regions with low GC content (<= 50%), are undercovered relative to mean coverage.
AT_DROPOUT - Variable in class picard.analysis.directed.TargetMetrics
A measure of how undercovered <= 50% GC regions are relative to the mean.
AT_DROPOUT - Variable in class picard.analysis.GcBiasSummaryMetrics
Illumina-style AT dropout metric.
atEndOfCurrentCigar() - Method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Is the current position at the end of the current cigar? For example, if we are in element 3M, this function returns true if we are at offsetInCurrentCigar of 2, but not 0 or 1.
AtomicIterator<T> - Interface in picard.util
Describes
atomicIteratorOf(Iterable<E>) - Static method in class picard.util.Iterators
 
atomicIteratorOf(Iterator<E>) - Static method in class picard.util.Iterators
 
atStartOfCurrentCigar() - Method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Is the current position at the start of the current cigar? For example, if we are in element 3M, this function returns true if we are at offsetInCurrentCigar of 0, but not 1 or 2.
ATTEMPTED_LOCUS - Static variable in class picard.vcf.LiftoverVcf
Attribute used to store the position of the failed variant on the target contig prior to finding out that alleles do not match.
ATTRIBUTE_TO_CLEAR - Variable in class picard.sam.RevertSam
 
attributeMap - Variable in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.ReducibleAnnotationData
 
ATTRIBUTES_TO_REMOVE - Variable in class picard.sam.MergeBamAlignment
 
ATTRIBUTES_TO_RETAIN - Variable in class picard.sam.MergeBamAlignment
 
ATTRIBUTES_TO_REVERSE - Variable in class picard.sam.MergeBamAlignment
 
ATTRIBUTES_TO_REVERSE_COMPLEMENT - Variable in class picard.sam.MergeBamAlignment
 
AUTOSOMAL_REF_COPY_NUMBER_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.PostprocessGermlineCNVCalls
 
AVG_INTERVAL_DP_BY_SAMPLE_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
AVG_INTERVAL_DP_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
awaitCompletion() - Method in interface picard.vcf.processor.VariantAccumulatorExecutor
Blocks until the work is complete.
awaitCompletion() - Method in class picard.vcf.processor.VariantAccumulatorExecutor.MultiThreadedChunkBased
 

B

BAD_CYCLES - Variable in class picard.analysis.AlignmentSummaryMetrics
The number of instrument cycles in which 80% or more of base calls were no-calls.
BadInput(String, Throwable) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.BadInput
 
BadInput(String) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.BadInput
 
BadTempDir(String) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.BadTempDir
 
BadTempDir(String, Throwable) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.BadTempDir
 
BAIT_BIAS_DETAILS_EXT - Static variable in class picard.analysis.artifacts.SequencingArtifactMetrics
 
BAIT_BIAS_SUMMARY_EXT - Static variable in class picard.analysis.artifacts.SequencingArtifactMetrics
 
BAIT_DESIGN_EFFICIENCY - Variable in class picard.analysis.directed.HsMetrics
The ratio of TARGET_TERRITORY/BAIT_TERRITORY.
BAIT_INTERVALS - Variable in class picard.analysis.directed.CollectHsMetrics
 
BAIT_OFFSET - Variable in class picard.util.BaitDesigner
 
BAIT_SET - Variable in class picard.analysis.directed.HsMetrics
The name of the bait set used in the hybrid selection.
BAIT_SET_NAME - Variable in class picard.analysis.directed.CollectHsMetrics
 
BAIT_SIZE - Variable in class picard.util.BaitDesigner
 
BAIT_TERRITORY - Variable in class picard.analysis.directed.HsMetrics
The number of bases which are localized to one or more baits.
BaitBiasDetailMetrics() - Constructor for class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasDetailMetrics
 
BaitBiasSummaryMetrics() - Constructor for class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasSummaryMetrics
 
BaitDesigner - Class in picard.util
Designs baits for hybrid selection!
BaitDesigner() - Constructor for class picard.util.BaitDesigner
 
BaitDesigner.DesignStrategy - Enum in picard.util
Set of possible design strategies for bait design.
BAITS_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
BAITS_FILE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
BAM_MAGIC - Static variable in class org.broadinstitute.hellbender.utils.read.ReadUtils
BAM file magic value that starts every bam file
BAM_OUTPUT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerArgumentCollection
 
BAM_OUTPUT_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerArgumentCollection
 
BAM_PARTITION_SIZE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
 
BAM_PL_NAMES - Variable in enum org.broadinstitute.hellbender.utils.NGSPlatform
Array of the prefix names in a BAM file for each of the platforms.
BAM_SHARD_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.ConvertHeaderlessHadoopBamShardToBam
 
BAM_WITH_HEADER_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.ConvertHeaderlessHadoopBamShardToBam
 
BAM_WRITER_TYPE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerArgumentCollection
 
bamHeader - Static variable in class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSink.SparkBAMOutputFormat
 
bamHeader - Static variable in class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSink.SparkCRAMOutputFormat
 
BamIndexStats - Class in picard.sam
Command line program to print statistics from BAM index (.bai) file Statistics include count of aligned and unaligned reads for each reference sequence and a count of all records with no start coordinate.
BamIndexStats() - Constructor for class picard.sam.BamIndexStats
 
bamOutputPath - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerArgumentCollection
The assembled haplotypes and locally realigned reads will be written as BAM to this file if requested.
bamPartitionSplitSize - Variable in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
 
BamToBfq - Class in picard.fastq
Converts a BAM file into a BFQ (binary fastq formatted) file.
BamToBfq() - Constructor for class picard.fastq.BamToBfq
 
BamToBfqWriter - Class in picard.fastq
Class to take unmapped reads in BAM file format and create Maq binary fastq format file(s) -- one or two of them, depending on whether it's a paired-end read.
BamToBfqWriter(File, String, Integer, Integer, boolean, String, boolean, boolean, Integer) - Constructor for class picard.fastq.BamToBfqWriter
Constructor
BamToBfqWriter(File, String, boolean, String, boolean) - Constructor for class picard.fastq.BamToBfqWriter
Constructor
bamWriterType - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerArgumentCollection
The type of BAM output we want to see.
BandPassActivityProfile - Class in org.broadinstitute.hellbender.utils.activityprofile
A band pass filtering version of the activity profile Applies a band pass filter with a Gaussian kernel to the input state probabilities to smooth them out of an interval
BandPassActivityProfile(Set<SimpleInterval>, int, double, SAMFileHeader) - Constructor for class org.broadinstitute.hellbender.utils.activityprofile.BandPassActivityProfile
Create a new BandPassActivityProfile with default sigma and filter sizes
BandPassActivityProfile(Set<SimpleInterval>, int, double, int, double, SAMFileHeader) - Constructor for class org.broadinstitute.hellbender.utils.activityprofile.BandPassActivityProfile
sets adaptiveFilterSize to true
BandPassActivityProfile(Set<SimpleInterval>, int, double, int, double, boolean, SAMFileHeader) - Constructor for class org.broadinstitute.hellbender.utils.activityprofile.BandPassActivityProfile
Create an activity profile that implements a band pass filter on the states
BAQ - Class in org.broadinstitute.hellbender.utils.baq
 
BAQ() - Constructor for class org.broadinstitute.hellbender.utils.baq.BAQ
Use defaults for everything
BAQ(double) - Constructor for class org.broadinstitute.hellbender.utils.baq.BAQ
Use defaults for everything
BAQ(double, double, int, byte) - Constructor for class org.broadinstitute.hellbender.utils.baq.BAQ
Create a new HmmGlocal object with specified parameters
BAQ.BAQCalculationResult - Class in org.broadinstitute.hellbender.utils.baq
 
BAQ.CalculationMode - Enum in org.broadinstitute.hellbender.utils.baq
 
BAQ.QualityMode - Enum in org.broadinstitute.hellbender.utils.baq
these are features that only the walker can override
BAQ_TAG - Static variable in class org.broadinstitute.hellbender.utils.baq.BAQ
 
BAQCalculationResult(GATKRead, byte[]) - Constructor for class org.broadinstitute.hellbender.utils.baq.BAQ.BAQCalculationResult
 
BAQCalculationResult(byte[], byte[], byte[]) - Constructor for class org.broadinstitute.hellbender.utils.baq.BAQ.BAQCalculationResult
 
BAQGOP - Variable in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationArgumentCollection
 
baqRead(GATKRead, ReferenceDataSource, BAQ.CalculationMode, BAQ.QualityMode) - Method in class org.broadinstitute.hellbender.utils.baq.BAQ
Modifies read in place so that the base quality scores are capped by the BAQ calculation.
BARCODE - Variable in class picard.illumina.ExtractIlluminaBarcodes
 
BARCODE - Variable in class picard.illumina.ExtractIlluminaBarcodes.BarcodeMetric
The barcode (from the set of expected barcodes) for which the following metrics apply.
Barcode - Static variable in enum picard.illumina.parser.ReadType
 
barcode - Variable in class picard.sam.markduplicates.util.ReadEndsForMarkDuplicatesWithBarcodes
 
BARCODE_BQ - Variable in class picard.analysis.replicates.CollectIndependentReplicateMetrics
 
BARCODE_DELIMITER - Static variable in class picard.util.IlluminaUtil
 
BARCODE_FILE - Variable in class picard.illumina.ExtractIlluminaBarcodes
 
BARCODE_NAME - Variable in class picard.illumina.ExtractIlluminaBarcodes.BarcodeMetric
The barcode name.
BARCODE_NAME_COLUMN - Static variable in class picard.illumina.ExtractIlluminaBarcodes
Column header for the barcode name.
BARCODE_PARAMS - Variable in class picard.illumina.IlluminaBasecallsToSam
 
BARCODE_SEQUENCE_1_COLUMN - Static variable in class picard.illumina.ExtractIlluminaBarcodes
Column header for the first barcode sequence.
BARCODE_SEQUENCE_COLUMN - Static variable in class picard.illumina.ExtractIlluminaBarcodes
Column header for the first barcode sequence (preferred).
BARCODE_TAG - Variable in class picard.analysis.replicates.CollectIndependentReplicateMetrics
 
BARCODE_TAG - Variable in class picard.sam.markduplicates.EstimateLibraryComplexity
 
BARCODE_TAG - Variable in class picard.sam.markduplicates.MarkDuplicates
 
BARCODE_WITHOUT_DELIMITER - Variable in class picard.illumina.ExtractIlluminaBarcodes.BarcodeMetric
 
barcodeBytes - Variable in class picard.illumina.ExtractIlluminaBarcodes.BarcodeMetric
 
BarcodeFileFaker - Class in picard.illumina.parser.fakers
Created by jcarey on 3/13/14.
BarcodeFileFaker() - Constructor for class picard.illumina.parser.fakers.BarcodeFileFaker
 
BarcodeFileReader - Class in picard.illumina.parser.readers
Reads a single barcode file line by line and returns the barcode if there was a match or NULL otherwise.
BarcodeFileReader(File) - Constructor for class picard.illumina.parser.readers.BarcodeFileReader
 
BarcodeMatch() - Constructor for class picard.illumina.ExtractIlluminaBarcodes.PerTileBarcodeExtractor.BarcodeMatch
 
BarcodeMetric(String, String, String, String[]) - Constructor for class picard.illumina.ExtractIlluminaBarcodes.BarcodeMetric
 
BarcodeMetric() - Constructor for class picard.illumina.ExtractIlluminaBarcodes.BarcodeMetric
This ctor is necessary for when reading metrics from file
BARCODES_DIR - Variable in class picard.illumina.CollectIlluminaBasecallingMetrics
 
BARCODES_DIR - Variable in class picard.illumina.IlluminaBasecallsToFastq
 
BARCODES_DIR - Variable in class picard.illumina.IlluminaBasecallsToSam
 
barcodeSeqsToString(List<String>) - Static method in class picard.util.IlluminaUtil
Concatenates all the barcode sequences with BARCODE_DELIMITER
barcodeSeqsToString(String[]) - Static method in class picard.util.IlluminaUtil
Concatenates all the barcode sequences with BARCODE_DELIMITER
barcodeSeqsToString(byte[][]) - Static method in class picard.util.IlluminaUtil
Concatenates all the barcode sequences with BARCODE_DELIMITER
base - Variable in enum org.broadinstitute.hellbender.utils.BaseUtils.Base
 
base - Variable in enum picard.analysis.artifacts.Transition.Base
 
base - Variable in class picard.illumina.parser.ParameterizedFileUtil
If you think of the file system as a tree, this is the deepest directory(node) on the tree that still contains all of the files for this given type (e.g.
base1 - Variable in enum org.broadinstitute.hellbender.utils.genotyper.DiploidGenotype
 
base2 - Variable in enum org.broadinstitute.hellbender.utils.genotyper.DiploidGenotype
 
BASE_CHARS - Static variable in class org.broadinstitute.hellbender.utils.BaseUtils
 
BASE_COUNTS_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
BASE_QUAL_RANK_SUM_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
BASE_QUALITY_SCORE_THRESHOLD - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.LikelihoodEngineArgumentCollection
Bases with a quality below this threshold will reduced to the minimum usable qualiy score (6).
BASE_QUALITY_SCORE_THRESHOLD - Static variable in class org.broadinstitute.hellbender.utils.pairhmm.PairHMM
 
BaseBclReader - Class in picard.illumina.parser.readers
 
BaseBclReader.CycleData - Class in picard.illumina.parser.readers
 
BaseBclReader.TileData - Class in picard.illumina.parser.readers
 
BaseCallingProgramGroup - Class in picard.cmdline.programgroups
Tools that process sequencing machine data, e.g.
BaseCallingProgramGroup() - Constructor for class picard.cmdline.programgroups.BaseCallingProgramGroup
 
BASECALLS_DIR - Variable in class picard.illumina.CheckIlluminaDirectory
 
BASECALLS_DIR - Variable in class picard.illumina.CollectIlluminaBasecallingMetrics
 
BASECALLS_DIR - Variable in class picard.illumina.ExtractIlluminaBarcodes
 
BASECALLS_DIR - Variable in class picard.illumina.IlluminaBasecallsToFastq
 
BASECALLS_DIR - Variable in class picard.illumina.IlluminaBasecallsToSam
 
BASECALLS_DIR - Variable in class picard.illumina.quality.CollectHiSeqXPfFailMetrics
 
BaseDistributionByCycleMetrics - Class in org.broadinstitute.hellbender.metrics.analysis
 
BaseDistributionByCycleMetrics() - Constructor for class org.broadinstitute.hellbender.metrics.analysis.BaseDistributionByCycleMetrics
 
BaseDistributionByCycleMetrics - Class in picard.analysis
 
BaseDistributionByCycleMetrics() - Constructor for class picard.analysis.BaseDistributionByCycleMetrics
 
BaseEdge - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs
Simple edge class for connecting nodes in the graph.
BaseEdge(boolean, int) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseEdge
Create a new BaseEdge with weight multiplicity and, if isRef == true, indicates a path through the reference
BaseGraph<V extends BaseVertex,E extends BaseEdge> - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs
Common code for graphs used for local assembly.
BaseGraph(int, EdgeFactory<V, E>) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Construct a TestGraph with kmerSize
BaseIlluminaDataProvider - Class in picard.illumina.parser
Parse various formats and versions of Illumina Basecall files, and use them the to populate ClusterData objects.
BaseIlluminaDataProvider(int, OutputMapping) - Constructor for class picard.illumina.parser.BaseIlluminaDataProvider
 
baseIndexMap - Static variable in enum picard.analysis.artifacts.Transition
 
baseIndexToSimpleBase(int) - Static method in class org.broadinstitute.hellbender.utils.BaseUtils
Converts a base index to a simple base
BASELINE_COPY_NUMBER_FILE_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.gcnv.GermlineCNVNamingConstants
 
BASELINE_COPY_NUMBER_TABLE_COLUMN - Static variable in class org.broadinstitute.hellbender.tools.copynumber.gcnv.GermlineCNVNamingConstants
 
BaselineCopyNumberCollection - Class in org.broadinstitute.hellbender.tools.copynumber.formats.collections
Collection of baseline copy-number states.
BaselineCopyNumberCollection(File) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.collections.BaselineCopyNumberCollection
 
BaseQuality - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Median base quality of bases supporting each alt allele.
BaseQuality() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.BaseQuality
 
BaseQualityClipReadTransformer - Class in org.broadinstitute.hellbender.transformers
Clips reads on both ends using base quality scores
BaseQualityClipReadTransformer(int) - Constructor for class org.broadinstitute.hellbender.transformers.BaseQualityClipReadTransformer
 
BaseQualityRankSumTest - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Rank Sum Test of REF versus ALT base quality scores
BaseQualityRankSumTest() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.BaseQualityRankSumTest
 
BaseQualityReadTransformer - Class in org.broadinstitute.hellbender.transformers
 
BaseQualityReadTransformer() - Constructor for class org.broadinstitute.hellbender.transformers.BaseQualityReadTransformer
 
BaseQualityReadTransformer(int) - Constructor for class org.broadinstitute.hellbender.transformers.BaseQualityReadTransformer
 
baseQualTieBreaker - Static variable in class org.broadinstitute.hellbender.utils.pileup.ReadPileup
 
BaseRecalibrationEngine - Class in org.broadinstitute.hellbender.utils.recalibration
 
BaseRecalibrationEngine(RecalibrationArgumentCollection, SAMFileHeader) - Constructor for class org.broadinstitute.hellbender.utils.recalibration.BaseRecalibrationEngine
 
BaseRecalibrationEngine.BQSRReferenceWindowFunction - Class in org.broadinstitute.hellbender.utils.recalibration
Reference window function for BQSR.
baseRecalibrationKnownVariantPaths - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.BQSRPipelineSpark
 
baseRecalibrationKnownVariants - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.ReadsPipelineSpark
 
BaseRecalibrator - Class in org.broadinstitute.hellbender.tools.walkers.bqsr
First pass of the base quality score recalibration.
BaseRecalibrator() - Constructor for class org.broadinstitute.hellbender.tools.walkers.bqsr.BaseRecalibrator
 
BaseRecalibratorEngineSparkWrapper - Class in org.broadinstitute.hellbender.tools.spark.transforms.bqsr
A lightweight wrapper over BaseRecalibrationEngine to make it easier to use from Spark.
BaseRecalibratorEngineSparkWrapper(Broadcast<SAMFileHeader>, Broadcast<SAMSequenceDictionary>, RecalibrationArgumentCollection) - Constructor for class org.broadinstitute.hellbender.tools.spark.transforms.bqsr.BaseRecalibratorEngineSparkWrapper
Takes in reads + contextual data (overlapping reference bases and variants), spits out RecalibrationTables.
BaseRecalibratorSpark - Class in org.broadinstitute.hellbender.tools.spark
Spark version of the first pass of the base quality score recalibration.
BaseRecalibratorSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.BaseRecalibratorSpark
 
BaseRecalibratorSparkFn - Class in org.broadinstitute.hellbender.tools.spark.transforms
 
BaseRecalibratorSparkFn() - Constructor for class org.broadinstitute.hellbender.tools.spark.transforms.BaseRecalibratorSparkFn
 
BaseRecalibratorSparkSharded - Class in org.broadinstitute.hellbender.tools.spark
Experimental sharded spark implementation of the first pass of the base quality score recalibration.
BaseRecalibratorSparkSharded() - Constructor for class org.broadinstitute.hellbender.tools.spark.BaseRecalibratorSparkSharded
 
BASES - Static variable in class org.broadinstitute.hellbender.tools.copynumber.datacollection.AllelicCountCollector
 
bases() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KBestHaplotype
Returns the result haplotype bases.
bases() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.Kmer
Get the bases of this kmer.
BASES - Static variable in class org.broadinstitute.hellbender.utils.BaseUtils
 
bases(SimpleInterval) - Static method in class org.broadinstitute.hellbender.utils.test.FakeReferenceSource
bases returns some made up bases for an interval.
bases - Variable in class picard.illumina.parser.BclData
 
BASES_COMPARATOR - Static variable in class org.broadinstitute.hellbender.utils.BaseUtils
Lexicographical sorting of base arrays Comparator.
BASES_TO_WRITE - Variable in class picard.fastq.BamToBfq
 
basesAreEqual(byte, byte) - Static method in class org.broadinstitute.hellbender.utils.BaseUtils
 
basesAreRepeated(String, String, String, int) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
 
BaseTest - Class in org.broadinstitute.hellbender.utils.test
This is the base test class for all of our test cases.
BaseTest() - Constructor for class org.broadinstitute.hellbender.utils.test.BaseTest
 
BaseTest.TestDataProvider - Class in org.broadinstitute.hellbender.utils.test
Simple generic utility class to creating TestNG data providers: 1: inherit this class, as in private class SummarizeDifferenceTest extends TestDataProvider { public SummarizeDifferenceTest() { super(SummarizeDifferenceTest.class); } ...
BaseUtils - Class in org.broadinstitute.hellbender.utils
BaseUtils contains some basic utilities for manipulating nucleotides.
BaseUtils.Base - Enum in org.broadinstitute.hellbender.utils
 
BaseUtils.BaseSubstitutionType - Enum in org.broadinstitute.hellbender.utils
 
BaseVertex - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs
A graph vertex that holds some sequence information
BaseVertex(byte[]) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseVertex
Create a new sequence vertex with sequence This code doesn't copy sequence for efficiency reasons, so sequence must absolutely not be modified in any way after passing this sequence to the BaseVertex
BasicInputParser - Class in picard.util
TextFileParser which reads a single text file.
BasicInputParser(boolean, InputStream...) - Constructor for class picard.util.BasicInputParser
Constructor.
BasicInputParser(boolean, int, InputStream...) - Constructor for class picard.util.BasicInputParser
 
BasicInputParser(boolean, File...) - Constructor for class picard.util.BasicInputParser
Constructor.
BasicInputParser(boolean, int, File...) - Constructor for class picard.util.BasicInputParser
Constructor.
BasicSomaticShortMutationValidator - Class in org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup
 
BasicValidationResult - Class in org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup
 
BasicValidationResult(Locatable, int, boolean, boolean, double, int, int, int, int, Allele, Allele, String) - Constructor for class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.BasicValidationResult
 
batchSize - Variable in class org.broadinstitute.hellbender.tools.FixCallSetSampleOrdering
 
BATCHSIZE_ARG_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.genomicsdb.GenomicsDBImport
 
bayesianEstimateOfEmpiricalQuality(long, long, double) - Static method in class org.broadinstitute.hellbender.utils.recalibration.RecalDatum
 
BCF_FILE_EXTENSION - Static variable in class org.broadinstitute.hellbender.utils.variant.VcfUtils
 
bci - Variable in class picard.illumina.parser.MultiTileFileUtil
 
BciFileFaker - Class in picard.illumina.parser.fakers
Created by jcarey on 3/14/14.
BciFileFaker() - Constructor for class picard.illumina.parser.fakers.BciFileFaker
 
BclData - Class in picard.illumina.parser
A class that implements the IlluminaData interfaces provided by this parser One BclData object is returned to IlluminaDataProvider per cluster and each first level array in bases and qualities represents a single read in that cluster
BclData(int[]) - Constructor for class picard.illumina.parser.BclData
 
BclFileFaker - Class in picard.illumina.parser.fakers
 
BclFileFaker() - Constructor for class picard.illumina.parser.fakers.BclFileFaker
 
BclIndexReader - Class in picard.illumina.parser.readers
Annoyingly, there are two different files with extension .bci in NextSeq output.
BclIndexReader(File) - Constructor for class picard.illumina.parser.readers.BclIndexReader
 
BclQualityEvaluationStrategy - Class in picard.illumina.parser.readers
Describes a mechanism for revising and evaluating qualities read from a BCL file.
BclQualityEvaluationStrategy(int) - Constructor for class picard.illumina.parser.readers.BclQualityEvaluationStrategy
 
BclReader - Class in picard.illumina.parser.readers
BCL Files are base call and quality score binary files containing a (base,quality) pair for successive clusters.
BclReader(List<File>, int[], BclQualityEvaluationStrategy, boolean) - Constructor for class picard.illumina.parser.readers.BclReader
 
BclReader(File, BclQualityEvaluationStrategy, boolean) - Constructor for class picard.illumina.parser.readers.BclReader
 
BDGAlignmentRecordToGATKReadAdapter - Class in org.broadinstitute.hellbender.utils.read
Implementation of the GATKRead interface for the AlignmentRecord class.
BDGAlignmentRecordToGATKReadAdapter(AlignmentRecord, SAMFileHeader) - Constructor for class org.broadinstitute.hellbender.utils.read.BDGAlignmentRecordToGATKReadAdapter
 
BedToIntervalList - Class in picard.util
 
BedToIntervalList() - Constructor for class picard.util.BedToIntervalList
 
beforeExecute(Thread, Runnable) - Method in class picard.util.ThreadPoolExecutorWithExceptions
 
beforeFile - Variable in class org.broadinstitute.hellbender.tools.walkers.bqsr.AnalyzeCovariates
File containing the recalibration tables from the first pass.
BEGIN_FIT_FILE_TAG - Static variable in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
beginOfShard(int, int) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
first offset in this shard (1-based).
bestAlleles() - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Returns the collection of best allele estimates for the reads based on the read-likelihoods.
bestAlleles(String) - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Returns the collection of best allele estimates for one sample's reads based on the read-likelihoods.
BestEndMapqPrimaryAlignmentStrategy - Class in org.broadinstitute.hellbender.utils.read.mergealignment
For an aligner that aligns each end independently, select the alignment for each end with the best MAPQ, and make that the primary.
BestEndMapqPrimaryAlignmentStrategy() - Constructor for class org.broadinstitute.hellbender.utils.read.mergealignment.BestEndMapqPrimaryAlignmentStrategy
 
BestEndMapqPrimaryAlignmentStrategy - Class in picard.sam
For an aligner that aligns each end independently, select the alignment for each end with the best MAPQ, and make that the primary.
BestEndMapqPrimaryAlignmentStrategy() - Constructor for class picard.sam.BestEndMapqPrimaryAlignmentStrategy
 
BestMapqPrimaryAlignmentSelectionStrategy - Class in org.broadinstitute.hellbender.utils.read.mergealignment
This strategy was designed for TopHat output, but could be of general utility.
BestMapqPrimaryAlignmentSelectionStrategy() - Constructor for class org.broadinstitute.hellbender.utils.read.mergealignment.BestMapqPrimaryAlignmentSelectionStrategy
 
BestMapqPrimaryAlignmentSelectionStrategy - Class in picard.sam
This strategy was designed for TopHat output, but could be of general utility.
BestMapqPrimaryAlignmentSelectionStrategy() - Constructor for class picard.sam.BestMapqPrimaryAlignmentSelectionStrategy
 
bestValue(int, int, AFCalculatorImplementation) - Static method in enum org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculatorImplementation
Returns the best (fastest) model give the required ploidy and alternative allele count.
BetaBinomialDistribution - Class in org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup
Beta-binomial using the Apache Math3 Framework.
BetaBinomialDistribution(RandomGenerator, double, double, int) - Constructor for class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.BetaBinomialDistribution
 
BIAS_P - Static variable in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasFilterer
mode of binomial distribution of pair orientation for the artifact alt reads.
bigShardSize - Static variable in class org.broadinstitute.hellbender.engine.spark.AddContextDataToReadSparkOptimized
 
BIN_LENGTH_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.PreprocessIntervals
 
BINARY_TAG_NAME - Variable in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationArgumentCollection
The tag name for the binary tag covariate (if using it)
binomialCoefficient(int, int) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Calculates the binomial coefficient.
binomialProbability(int, int, double) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Computes a binomial probability.
biSiteHeterogeneityRate - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
biSiteHomogeneityRate - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
BLACK_LISTED_LANES_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ReadFilterArgumentDefinitions
 
blackList - Variable in class org.broadinstitute.hellbender.engine.filters.ReadGroupBlackListReadFilter
 
blackListedLanes - Variable in class org.broadinstitute.hellbender.engine.filters.PlatformUnitReadFilter
 
BLOCK_SIZE - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.evidence.KSWindowFinder
 
BLOCK_SIZE - Variable in class picard.sam.markduplicates.MarkDuplicatesWithMateCigar
 
BLOOM_FILTER_EXTENSION - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerUtils
 
BLOOM_FILTER_FALSE_POSITIVE_P_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildKmers
 
BLOOM_FILTER_FALSE_POSITIVE_P_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildKmers
 
bloomFpp - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildKmers
Note that the provided argument is used as an upper limit on the probability, and the actual false positive probability may be less.
BND_MATEID_STR - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
boundQual(int) - Static method in class org.broadinstitute.hellbender.utils.QualityUtils
Return a quality score that bounds qual by MAX_SAM_QUAL_SCORE and 1
boundQual(int, byte) - Static method in class org.broadinstitute.hellbender.utils.QualityUtils
Return a quality score that bounds qual by maxQual and 1 WARNING -- because this function takes a byte for maxQual, you must be careful in converting integers to byte.
BP_RES_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.CombineGVCFs
 
bq - Variable in class org.broadinstitute.hellbender.utils.baq.BAQ.BAQCalculationResult
 
BQSR_BASE_DELETION_QUALITIES - Static variable in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
BQSR_BASE_INSERTION_QUALITIES - Static variable in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
BQSR_RECAL_FILE - Variable in class org.broadinstitute.hellbender.tools.walkers.bqsr.AnalyzeCovariates
Enables recalibration of base qualities, intended primarily for use with BaseRecalibrator and ApplyBQSR (see Best Practices workflow documentation).
BQSR_RECAL_FILE - Variable in class org.broadinstitute.hellbender.tools.walkers.bqsr.ApplyBQSR
This argument is required for recalibration of base qualities.
BQSR_REFERENCE_WINDOW_FUNCTION - Static variable in class org.broadinstitute.hellbender.utils.recalibration.BaseRecalibrationEngine
 
BQSR_TABLE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
BQSR_TABLE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
bqsrArgs - Variable in class org.broadinstitute.hellbender.tools.walkers.bqsr.ApplyBQSR
Command-line arguments to fine tune the recalibration.
BQSRPipelineSpark - Class in org.broadinstitute.hellbender.tools.spark.pipelines
The full BQSR pipeline in one tool to run on Spark.
BQSRPipelineSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.pipelines.BQSRPipelineSpark
 
BQSRReadTransformer - Class in org.broadinstitute.hellbender.transformers
 
BQSRReadTransformer(SAMFileHeader, File, ApplyBQSRArgumentCollection) - Constructor for class org.broadinstitute.hellbender.transformers.BQSRReadTransformer
Constructor using a GATK Report file
BQSRReadTransformer(SAMFileHeader, RecalibrationReport, ApplyBQSRArgumentCollection) - Constructor for class org.broadinstitute.hellbender.transformers.BQSRReadTransformer
Constructor using a RecalibrationReport
BQSRReferenceWindowFunction() - Constructor for class org.broadinstitute.hellbender.utils.recalibration.BaseRecalibrationEngine.BQSRReferenceWindowFunction
 
BREAK_BANDS_AT_MULTIPLES_OF - Variable in class picard.util.IntervalListTools
 
BREAK_BANDS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.CombineGVCFs
 
BREAKEND_STR - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
BreakEndVariantType - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery
 
BreakEndVariantType.InvSuspectBND - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery
Breakend variant type for inversion suspects: those with novel adjacency between two reference locations on the same chromosome but the novel adjacency brings them together in a strand-switch fashion.
BreakEndVariantType.TransLocBND - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery
Generic variant type for suspected "translocations", including what could be a breakpoint for a dispersed duplication or an inter-chromosome novel adjacency.
BreakpointComplications - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.inference
A helper struct for annotating complications that make the locations represented by its associated NovelAdjacencyAndAltHaplotype a little ambiguous.
BreakpointComplications() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications
 
BreakpointComplications(Kryo, Input) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications
 
BreakpointComplications.IntraChrStrandSwitchBreakpointComplications - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.inference
For novel adjacency between reference locations that are on the same chromosome, and with a strand switch.
BreakpointComplications.IntraChrStrandSwitchBreakpointComplications.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.inference
 
BreakpointComplications.SmallDuplicationWithImpreciseDupRangeBreakpointComplications - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.inference
This is for dealing with case when the duplicated range could NOT be inferred exactly, but only from a simple optimization scheme.
BreakpointComplications.SmallDuplicationWithImpreciseDupRangeBreakpointComplications.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.inference
 
BreakpointComplications.SmallDuplicationWithPreciseDupRangeBreakpointComplications - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.inference
 
BreakpointComplications.SmallDuplicationWithPreciseDupRangeBreakpointComplications.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.inference
 
BreakpointDensityFilter - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
A class that acts as a filter for breakpoint evidence.
BreakpointDensityFilter(Iterator<BreakpointEvidence>, ReadMetadata, int, int, PartitionCrossingChecker, int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointDensityFilter
 
BreakpointEvidence - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
Various types of read anomalies that provide evidence of genomic breakpoints.
BreakpointEvidence(SVInterval, int, boolean) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence
 
BreakpointEvidence(Kryo, Input) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence
 
BreakpointEvidence.DiscordantReadPairEvidence - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
BreakpointEvidence.ExternalEvidence - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
BreakpointEvidence.ExternalEvidence.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
BreakpointEvidence.InterContigPair - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
BreakpointEvidence.InterContigPair.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
BreakpointEvidence.LargeIndel - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
BreakpointEvidence.LargeIndel.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
BreakpointEvidence.MateUnmapped - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
BreakpointEvidence.MateUnmapped.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
BreakpointEvidence.OutiesPair - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
BreakpointEvidence.OutiesPair.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
BreakpointEvidence.ReadEvidence - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
BreakpointEvidence.ReadEvidence.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
BreakpointEvidence.SameStrandPair - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
BreakpointEvidence.SameStrandPair.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
BreakpointEvidence.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
BreakpointEvidence.SplitRead - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
BreakpointEvidence.SplitRead.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
BreakpointEvidence.TemplateSizeAnomaly - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
BreakpointEvidence.TemplateSizeAnomaly.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
BreakpointEvidence.WeirdTemplateSize - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
BreakpointEvidence.WeirdTemplateSize.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
BreakpointEvidenceClusterer - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
A class to examine a stream of BreakpointEvidence, and group it into Intervals.
BreakpointEvidenceClusterer(int, PartitionCrossingChecker) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidenceClusterer
 
broadcastCNVCalls(JavaSparkContext, SAMFileHeader, String) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryPipelineSpark
 
BroadcastJoinReadsWithRefBases - Class in org.broadinstitute.hellbender.engine.spark
Joins an RDD of GATKReads to reference data using a broadcast strategy.
BroadcastJoinReadsWithRefBases() - Constructor for class org.broadinstitute.hellbender.engine.spark.BroadcastJoinReadsWithRefBases
 
BroadcastJoinReadsWithVariants - Class in org.broadinstitute.hellbender.engine.spark
Joins an RDD of GATKReads to variant data using a broadcast strategy.
BucketUtils - Class in org.broadinstitute.hellbender.utils.gcs
Utilities for dealing with google buckets.
BUFFER_SIZE - Variable in class picard.util.FifoBuffer
 
bufferSize() - Method in class picard.illumina.parser.fakers.BarcodeFileFaker
 
bufferSize() - Method in class picard.illumina.parser.fakers.BciFileFaker
 
bufferSize() - Method in class picard.illumina.parser.fakers.BclFileFaker
 
bufferSize() - Method in class picard.illumina.parser.fakers.ClocsFileFaker
 
bufferSize() - Method in class picard.illumina.parser.fakers.FileFaker
 
bufferSize() - Method in class picard.illumina.parser.fakers.FilterFileFaker
 
bufferSize() - Method in class picard.illumina.parser.fakers.LocsFileFaker
 
bufferSize() - Method in class picard.illumina.parser.fakers.MultiTileBclFileFaker
 
bufferSize() - Method in class picard.illumina.parser.fakers.MultiTileLocsFileFaker
 
bufferSize() - Method in class picard.illumina.parser.fakers.PosFileFaker
 
bufferStream - Variable in class org.broadinstitute.hellbender.utils.runtime.CapturedStreamOutput
The byte stream to capture content or null if no output string content was requested.
build() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
 
build(Iterator<GATKRead>, SAMFileHeader, List<SimpleInterval>, SAMSequenceDictionary, boolean) - Method in class org.broadinstitute.hellbender.utils.locusiterator.AlignmentContextIteratorBuilder
Have this builder return an instance of the iterator as specified by the caller.
build() - Method in class org.broadinstitute.hellbender.utils.mcmc.ParameterizedModel.GibbsBuilder
Builds the ParameterizedModel as specified via ParameterizedModel.GibbsBuilder.
build() - Method in interface picard.vcf.processor.VariantProcessor.AccumulatorGenerator
 
build() - Method in class picard.vcf.processor.VariantProcessor.Builder
 
buildAccessionToTaxIdMap(Map<Integer, PSPathogenReferenceTaxonProperties>, PSTree, int) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBuildReferenceTaxonomyUtils
Create reference_name-to-taxid map (just an inversion on taxIdToProperties)
BuildBamIndex - Class in picard.sam
Command line program to generate a BAM index (.bai) file from a BAM (.bam) file
BuildBamIndex() - Constructor for class picard.sam.BuildBamIndex
 
buildContigIDToNameArray(Map<String, Integer>) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata
 
buildContigNameToIDMap(SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata
 
buildEventMapsForHaplotypes(List<Haplotype>, byte[], Locatable, boolean, int) - Static method in class org.broadinstitute.hellbender.utils.haplotype.EventMap
Build event maps for each haplotype, returning the sorted set of all of the starting positions of all events across all haplotypes
buildGraphIfNecessary() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingGraph
Build the read threaded assembly graph if it hasn't already been constructed from the sequences that have been added to the graph.
buildGroupToLibMap(SAMFileHeader) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata
 
buildMetadata(StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection, SAMFileHeader, JavaRDD<GATKRead>, SVReadFilter, Logger) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.FindBreakpointEvidenceSpark
 
buildPriors(int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFPriorProvider
Given a total ploidy construct the allele prior probabilities array.
buildPriors(int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.CustomAFPriorProvider
 
buildPriors(int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.HeterozygosityAFPriorProvider
 
buildTaxonomicTree(Map<Integer, PSPathogenReferenceTaxonProperties>) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBuildReferenceTaxonomyUtils
Returns a PSTree representing a reduced taxonomic tree containing only taxa present in the reference
bumpCount() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.KmerAndCount
 
bumpCount(int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.KmerAndCount
 
bunny - Static variable in class org.broadinstitute.hellbender.utils.logging.BunnyLog
 
BunnyLog - Class in org.broadinstitute.hellbender.utils.logging
The "bunny" log format: =[**]= START =[**]= STEPEND =[**]= END The functions here create an id for you and keep track of it, and format the various strings, sending it to a logger if you provided one.
BunnyLog() - Constructor for class org.broadinstitute.hellbender.utils.logging.BunnyLog
 
BunnyLog(Logger) - Constructor for class org.broadinstitute.hellbender.utils.logging.BunnyLog
 
BWA_MEM_INDEX_IMAGE_FULL_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.bwa.BwaArgumentCollection
 
BWA_MEM_INDEX_IMAGE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.bwa.BwaArgumentCollection
 
BwaAndMarkDuplicatesPipelineSpark - Class in org.broadinstitute.hellbender.tools.spark.pipelines
Runs BWA and MarkDuplicates on Spark.
BwaAndMarkDuplicatesPipelineSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.pipelines.BwaAndMarkDuplicatesPipelineSpark
 
bwaArgs - Variable in class org.broadinstitute.hellbender.tools.spark.bwa.BwaSpark
 
bwaArgs - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBwaSpark
 
bwaArgs - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqPipelineSpark
 
bwaArgs - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.BwaAndMarkDuplicatesPipelineSpark
 
bwaArgs - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.ReadsPipelineSpark
 
BwaArgumentCollection - Class in org.broadinstitute.hellbender.tools.spark.bwa
A collection of the arguments that are used for BWA.
BwaArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.spark.bwa.BwaArgumentCollection
 
bwaImage - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBwaArgumentCollection
 
BwaMemAlignmentUtils - Class in org.broadinstitute.hellbender.utils.bwa
Utils to move data from a BwaMemAlignment into a GATKRead, or into a SAM tag.
BwaMemAlignmentUtils() - Constructor for class org.broadinstitute.hellbender.utils.bwa.BwaMemAlignmentUtils
 
BwaMemIndexCache - Class in org.broadinstitute.hellbender.utils.bwa
Manage a global collection of BwaMemIndex instances.
BwaMemIndexCache() - Constructor for class org.broadinstitute.hellbender.utils.bwa.BwaMemIndexCache
 
bwaMemIndexImage - Variable in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.RealignmentArgumentCollection
BWA-mem index image created by BwaMemIndexImageCreator
BwaMemIndexImageCreator - Class in org.broadinstitute.hellbender.tools
Create a BWA-MEM index image file for use with GATK BWA tools
BwaMemIndexImageCreator() - Constructor for class org.broadinstitute.hellbender.tools.BwaMemIndexImageCreator
 
BwaSpark - Class in org.broadinstitute.hellbender.tools.spark.bwa
 
BwaSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.bwa.BwaSpark
 
BwaSparkEngine - Class in org.broadinstitute.hellbender.tools.spark.bwa
The BwaSparkEngine provides a simple interface for transforming a JavaRDD in which the reads are paired and unaligned, into a JavaRDD of aligned reads, and does so lazily.
BwaSparkEngine(JavaSparkContext, String, String, SAMFileHeader, SAMSequenceDictionary) - Constructor for class org.broadinstitute.hellbender.tools.spark.bwa.BwaSparkEngine
 
bwaThreads - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBwaArgumentCollection
 
bwaThreads - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
byHundredMegabaseChunks(List<File>) - Static method in class picard.vcf.processor.VariantIteratorProducer
Produces a chunking with segments of size 100 megabases (or less if a contig boundary is reached).
byHundredMegabaseChunksWithOnTheFlyFilteringByInterval(List<File>, IntervalList) - Static method in class picard.vcf.processor.VariantIteratorProducer
Produces a chunking with segments of size 100 megabases (or less if a contig boundary is reached), that also performs on-the-fly filtering of VariantContext
ByIntervalListVariantContextIterator - Class in picard.vcf
Takes a VCFFileReader and an IntervalList and provides a single iterator over all variants in all the intervals.
ByIntervalListVariantContextIterator(VCFFileReader, IntervalList) - Constructor for class picard.vcf.ByIntervalListVariantContextIterator
 
ByteArrayIterator - Class in org.broadinstitute.hellbender.utils.iterators
Trivial adapter class allowing a primitive byte[] array to be accessed using the java.util.Iterator interface
ByteArrayIterator(byte[]) - Constructor for class org.broadinstitute.hellbender.utils.iterators.ByteArrayIterator
 
ByteArrayIterator(byte[], int, int) - Constructor for class org.broadinstitute.hellbender.utils.iterators.ByteArrayIterator
Iterates through this array, starting at index 'firstIndex' and going until (but not including) index 'stopIndex'.
byteArrayToString(byte[][], String) - Static method in class picard.util.IlluminaUtil
Concatenates all the barcode sequences with BARCODE_DELIMITER
bytesRead - Variable in class org.broadinstitute.hellbender.utils.nio.SeekableByteChannelPrefetcher
 
bytesReturned - Variable in class org.broadinstitute.hellbender.utils.nio.SeekableByteChannelPrefetcher
 
BYTEWISE_REVERSE_COMPLEMENT - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmer
 
byWholeContigSubdividingWithWidth(long) - Static method in class picard.vcf.processor.VcfFileSegmentGenerator
 

C

C_FOLLOWED_BY_INSERTION_BASE - Static variable in class org.broadinstitute.hellbender.utils.pileup.PileupElement
 
C_QUALITY_THRESHOLD - Variable in class picard.analysis.CollectRrbsMetrics
 
C_REF_ALT_BASES - Variable in class picard.analysis.CollectOxoGMetrics.CpcgMetrics
The number of alt (A/T) basecalls observed at sites where the genome reference == C.
C_REF_OXO_ERROR_RATE - Variable in class picard.analysis.CollectOxoGMetrics.CpcgMetrics
The rate at which C>A and G>T substitutions are observed at C reference sites above the expected rate if there were no bias between sites with a C reference base vs.
C_REF_OXO_Q - Variable in class picard.analysis.CollectOxoGMetrics.CpcgMetrics
C_REF_OXO_ERROR_RATE expressed as a phred-scaled quality score.
C_REF_REF_BASES - Variable in class picard.analysis.CollectOxoGMetrics.CpcgMetrics
The number of ref basecalls observed at sites where the genome reference == C.
CACHE_LOOKAHEAD - Static variable in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker
 
CachingIndexedFastaSequenceFile - Class in org.broadinstitute.hellbender.utils.fasta
A caching version of the IndexedFastaSequenceFile that avoids going to disk as often as the raw indexer.
CachingIndexedFastaSequenceFile(Path, FastaSequenceIndex, long, boolean, boolean) - Constructor for class org.broadinstitute.hellbender.utils.fasta.CachingIndexedFastaSequenceFile
Same as general constructor but allows one to override the default cacheSize
CachingIndexedFastaSequenceFile(Path, long, boolean, boolean) - Constructor for class org.broadinstitute.hellbender.utils.fasta.CachingIndexedFastaSequenceFile
Open the given indexed fasta sequence file.
CachingIndexedFastaSequenceFile(Path, FastaSequenceIndex, long) - Constructor for class org.broadinstitute.hellbender.utils.fasta.CachingIndexedFastaSequenceFile
Same as general constructor but allows one to override the default cacheSize By default, this CachingIndexedFastaReader converts all incoming bases to upper case
CachingIndexedFastaSequenceFile(Path) - Constructor for class org.broadinstitute.hellbender.utils.fasta.CachingIndexedFastaSequenceFile
Open the given indexed fasta sequence file.
CachingIndexedFastaSequenceFile(Path, boolean) - Constructor for class org.broadinstitute.hellbender.utils.fasta.CachingIndexedFastaSequenceFile
Open the given indexed fasta sequence file.
CachingIndexedFastaSequenceFile(Path, long) - Constructor for class org.broadinstitute.hellbender.utils.fasta.CachingIndexedFastaSequenceFile
Open the given indexed fasta sequence file.
calcAlignmentByteArrayOffset(Cigar, PileupElement, int, int) - Static method in class org.broadinstitute.hellbender.utils.read.AlignmentUtils
 
calcAlignmentByteArrayOffset(Cigar, int, boolean, int, int) - Static method in class org.broadinstitute.hellbender.utils.read.AlignmentUtils
Calculate the index into the read's bases of the beginning of the encompassing cigar element for a given cigar and offset
calcBAQFromHMM(GATKRead, ReferenceDataSource) - Method in class org.broadinstitute.hellbender.utils.baq.BAQ
 
calcBAQFromHMM(byte[], byte[], byte[], int, int) - Method in class org.broadinstitute.hellbender.utils.baq.BAQ
 
calcBAQFromHMM(GATKRead, byte[], int) - Method in class org.broadinstitute.hellbender.utils.baq.BAQ
 
calcBAQFromTag(GATKRead, boolean, boolean) - Static method in class org.broadinstitute.hellbender.utils.baq.BAQ
Returns a new qual array for read that includes the BAQ adjustment.
calcBAQFromTag(GATKRead, int, boolean) - Static method in class org.broadinstitute.hellbender.utils.baq.BAQ
Returns the BAQ adjusted quality score for this read at this offset.
calcEfficiency() - Method in class org.broadinstitute.hellbender.utils.fasta.CachingIndexedFastaSequenceFile
Returns the efficiency (% of hits of all queries) of this object
calcEpsilon(byte, byte, byte) - Method in class org.broadinstitute.hellbender.utils.baq.BAQ
 
calcFirstBaseMatchingReferenceInCigar(Cigar, int) - Static method in class org.broadinstitute.hellbender.utils.read.AlignmentUtils
Get the offset (base 0) of the first reference aligned base in Cigar that occurs after readStartByBaseOfCigar base of the cigar The main purpose of this routine is to find a good start position for a read given it's cigar.
calcGenotypeLikelihoodsOfRefVsAny(int, ReadPileup, byte, byte, MathUtils.RunningAverage) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReferenceConfidenceModel
Calculate the genotype likelihoods for the sample in pileup for being hom-ref contrasted with being ref vs.
calcMD5(String) - Static method in class org.broadinstitute.hellbender.utils.Utils
 
calcMD5(byte[]) - Static method in class org.broadinstitute.hellbender.utils.Utils
Calculate the md5 for bytes, and return the result as a 32 character string
CalcMetadataSpark - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
(Internal) Collects read metrics relevant to structural variant discovery
CalcMetadataSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.CalcMetadataSpark
 
calcNumDifferentBases(Cigar, byte[], byte[]) - Static method in class org.broadinstitute.hellbender.utils.read.AlignmentUtils
Get the number of bases at which refSeq and readSeq differ, given their alignment
calcNumHighQualitySoftClips(GATKRead, byte) - Static method in class org.broadinstitute.hellbender.utils.read.AlignmentUtils
Calculate the number of bases that are soft clipped in read with quality score greater than threshold Handles the case where the cigar is null (i.e., the read is unmapped), returning 0
CALCULATE_TUMOR_AWARE_RESULTS - Variable in class picard.fingerprint.CrosscheckFingerprints
 
calculateAllGcs(byte[], int, int) - Static method in class picard.analysis.GcBiasUtils
 
calculateAnnotationFromGTfield(GenotypesContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_StrandBiasTest
 
calculateAnnotationFromGTfield(GenotypesContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.FisherStrand
 
calculateAnnotationFromGTfield(GenotypesContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.StrandBiasTest
 
calculateAnnotationFromGTfield(GenotypesContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.StrandOddsRatio
 
calculateAnnotationFromLikelihoods(ReadLikelihoods<Allele>, VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_FisherStrand
 
calculateAnnotationFromLikelihoods(ReadLikelihoods<Allele>, VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_StrandOddsRatio
 
calculateAnnotationFromLikelihoods(ReadLikelihoods<Allele>, VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.FisherStrand
 
calculateAnnotationFromLikelihoods(ReadLikelihoods<Allele>, VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.StrandBiasTest
 
calculateAnnotationFromLikelihoods(ReadLikelihoods<Allele>, VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.StrandOddsRatio
 
calculateAnnotationFromStratifiedContexts(Map<String, List<PileupElement>>, VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_StrandBiasTest
 
calculateAnnotationFromStratifiedContexts(Map<String, List<PileupElement>>, VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.FisherStrand
 
calculateAnnotationFromStratifiedContexts(Map<String, List<PileupElement>>, VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.StrandBiasTest
 
calculateAnnotationFromStratifiedContexts(Map<String, List<PileupElement>>, VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.StrandOddsRatio
 
calculateArtifactPValue(int, int, double) - Static method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.ArtifactStatisticsScorer
p-value for being an artifact
calculateBaseDistributionByCycle(JavaRDD<GATKRead>) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectBaseDistributionByCycleSpark
Computes the MeanQualityByCycle.
calculateBasicValidationResult(Genotype, Allele, ReadPileup, int, int, int, SimpleInterval, String) - Static method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.BasicSomaticShortMutationValidator
Perform basic somatic pileup validation and return a result instance.
calculateCigar(byte[], SmithWatermanAligner) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.Path
Calculate the cigar elements for this path against the reference sequence
calculateCigar(byte[], byte[], SmithWatermanAligner) - Static method in class org.broadinstitute.hellbender.utils.read.CigarUtils
Calculate the cigar elements for this path against the reference sequence
CalculateContamination - Class in org.broadinstitute.hellbender.tools.walkers.contamination
Calculates the fraction of reads coming from cross-sample contamination, given results from GetPileupSummaries.
CalculateContamination() - Constructor for class org.broadinstitute.hellbender.tools.walkers.contamination.CalculateContamination
 
calculateDerivedFields() - Method in class picard.analysis.artifacts.ErrorSummaryMetrics
 
calculateDerivedFields() - Method in class picard.analysis.CollectWgsMetrics.WgsMetrics
 
calculateDerivedFields() - Method in class picard.analysis.MergeableMetricBase
placeholder method that will calculate the derived fields from the other ones.
calculateDerivedFields() - Method in class picard.analysis.replicates.IndependentReplicateMetric
 
calculateDerivedFields() - Method in class picard.illumina.quality.CollectHiSeqXPfFailMetrics.PFFailSummaryMetric
 
calculateDerivedFields() - Method in class picard.sam.DuplicationMetrics
Fills in the ESTIMATED_LIBRARY_SIZE based on the paired read data examined where possible and the PERCENT_DUPLICATION.
calculateDerivedFields() - Method in class picard.sam.markduplicates.UmiMetrics
 
calculateDerivedFields() - Method in class picard.vcf.CollectVariantCallingMetrics.VariantCallingDetailMetrics
 
calculateDerivedFields() - Method in class picard.vcf.CollectVariantCallingMetrics.VariantCallingSummaryMetrics
 
calculateDerivedFields() - Method in class picard.vcf.MendelianViolations.MendelianViolationMetrics
 
calculateDerivedMetrics() - Method in class picard.sam.DuplicationMetrics
Deprecated.
calculateDerivedStatistics() - Method in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasDetailMetrics
Calculate the error rate given the raw counts.
calculateDerivedStatistics() - Method in class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterDetailMetrics
Calculate the error rate given the raw counts.
calculateFileMD5(File) - Static method in class org.broadinstitute.hellbender.utils.Utils
Calculates the MD5 for the specified file and returns it as a String Warning: this loads the whole file into memory, so it's not suitable for large files.
calculateFractionalErrorArray(int[], byte[]) - Static method in class org.broadinstitute.hellbender.utils.recalibration.BaseRecalibrationEngine
 
calculateFromDerivedFields() - Method in class picard.vcf.CollectVariantCallingMetrics.VariantCallingDetailMetrics
 
calculateFromDerivedFields(long) - Method in class picard.vcf.CollectVariantCallingMetrics.VariantCallingSummaryMetrics
 
calculateGc(byte[], int, int, GcBiasUtils.CalculateGcState) - Static method in class picard.analysis.GcBiasUtils
 
calculateGcContent(Allele, Allele, ReferenceContext, int) - Static method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationFactory
Calculates the fraction of Guanine and Cytosine bases in a window of a given size around a variant.
calculateGenotypeConcordance(GenotypeConcordanceScheme, boolean) - Method in class picard.vcf.GenotypeConcordanceCounts
Genotype Concordance is the number of times the truth and call states match exactly / all truth and call combinations made If the GA4GH scheme is being used, any MISSING sites in truth OR call will not be included in the discordance calculations.
CalculateGenotypePosteriors - Class in org.broadinstitute.hellbender.tools.walkers.variantutils
Calculate genotype posterior probabilities given family and/or known population genotypes
CalculateGenotypePosteriors() - Constructor for class org.broadinstitute.hellbender.tools.walkers.variantutils.CalculateGenotypePosteriors
 
calculateGenotypeQualityFromPLs(Genotype) - Static method in class org.broadinstitute.hellbender.utils.GATKProtectedVariantContextUtils
Instead of using the GQ value, it re-calculates the quality from the PL so that it does not need to be bounded by an artificial maximum such as the standard GQ = 99.
calculateGenotypes(VariantContext, GenotypeLikelihoodsCalculationModel, SAMFileHeader) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
Completes a variant context with genotype calls and associated annotations given the genotype likelihoods and the model that need to be applied.
calculateGenotypes(FeatureContext, ReferenceContext, AlignmentContext, Map<String, AlignmentContext>, VariantContext, GenotypeLikelihoodsCalculationModel, boolean, ReadLikelihoods<Allele>, SAMFileHeader) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
Main entry function to calculate genotypes of a given VC with corresponding GL's that is shared across genotypers (namely UG and HC).
calculateGermlineProbabilities(double[], double[], double[], Optional<double[]>, double) - Static method in class org.broadinstitute.hellbender.tools.walkers.mutect.GermlineProbabilityCalculator
 
calculateGLsForThisEvent(ReadLikelihoods<Allele>, VariantContext, List<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerGenotypingEngine
For a particular event described in inputVC, form PL vector for each sample by looking into allele read map and filling likelihood matrix for each allele
calculateGQFromPLs(int[]) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Calculate the Genotype Quality (GQ) by subtracting the smallest Phred-scaled likelihoods (PL) from the second smallest.
calculateHighestPosteriorDensityAndDecilesSummary(List<Double>, double, JavaSparkContext) - Static method in class org.broadinstitute.hellbender.utils.mcmc.PosteriorSummaryUtils
Given a list of posterior samples, returns a PosteriorSummary with central tendency given by the posterior mode (which is estimated using mllib kernel density estimation in KernelDensity, see PosteriorSummaryUtils.calculatePosteriorMode(List, JavaSparkContext)), lower/upper credible-interval bounds given by the (1-alpha) highest-posterior-density interval (i.e., the narrowest interval that contains (1-alpha) of the samples), and deciles.
calculateHighestPosteriorDensitySummary(List<Double>, double, JavaSparkContext) - Static method in class org.broadinstitute.hellbender.utils.mcmc.PosteriorSummaryUtils
Given a list of posterior samples, returns a PosteriorSummary with central tendency given by the posterior mode (which is estimated using mllib kernel density estimation in KernelDensity, see PosteriorSummaryUtils.calculatePosteriorMode(List, JavaSparkContext)) and lower/upper credible-interval bounds given by the (1-alpha) highest-posterior-density interval (i.e., the narrowest interval that contains (1-alpha) of the samples).
calculateIC(VariantContext, Allele) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_InbreedingCoeff
 
calculateIsSNPOrIndel(GATKRead, ReferenceDataSource, int[], int[], int[]) - Static method in class org.broadinstitute.hellbender.utils.recalibration.BaseRecalibrationEngine
Locates all SNP and indel events, storing them in the provided snp, isIns, and isDel arrays, and returns the total number of SNP/indel events.
calculateKnownSites(GATKRead, Iterable<? extends Locatable>) - Method in class org.broadinstitute.hellbender.utils.recalibration.BaseRecalibrationEngine
 
calculateLikelihoods(AlleleList<A>, GenotypingData<A>) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.IndependentSampleGenotypesModel
 
calculateLogChainPriorProbability(List<T>) - Method in interface org.broadinstitute.hellbender.utils.hmm.HMM
Calculates the expected log probability of the HMM chain with respect to prior state probabilities: \log(\pi_i) \pi_i + \sum_{t=1}^{T-1} \log(T_{t, t+1}^{i, j}) \pi_i \pi_j where \pi_i is the prior probability of state i, and T_{t, t+1}^{i, j} is the transition matrix from position and state (t, i) to (t+1, j).
calculateMatchResults(Fingerprint, Fingerprint, double, double) - Static method in class picard.fingerprint.FingerprintChecker
 
calculateMatchResults(Fingerprint, Fingerprint, double, double, boolean, boolean) - Static method in class picard.fingerprint.FingerprintChecker
Compares two fingerprints and calculates a MatchResults object which contains detailed information about the match (or mismatch) between fingerprints including the LOD score for whether or not the two are likely from the same sample.
calculateMatchResults(Fingerprint, Fingerprint) - Static method in class picard.fingerprint.FingerprintChecker
Compares two fingerprints and calculates a MatchResults object which contains detailed information about the match (or mismatch) between fingerprints including the LOD score for whether or not the two are likely from the same sample.
calculateMaxAltRatio(ReadPileup, Allele, int) - Static method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.PowerCalculationUtils
Calculate the fraction of non-ref reads in the given pileup.
calculateMeanQualityByCycle(JavaRDD<GATKRead>) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.MeanQualityByCycleSpark
Computes the MeanQualityByCycle.
calculateMinCountForSignal(int, double) - Static method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.PowerCalculationUtils
 
CalculateMixingFractions - Class in org.broadinstitute.hellbender.tools.walkers.validation
Given a VCF of known variants from multiple samples, calculate how much each sample contributes to a pooled BAM.
CalculateMixingFractions() - Constructor for class org.broadinstitute.hellbender.tools.walkers.validation.CalculateMixingFractions
 
calculateMostLikelyAlleles(VariantContext, int, int) - Static method in class org.broadinstitute.hellbender.tools.walkers.genotyper.AlleleSubsettingUtils
Returns the new set of alleles to use based on a likelihood score: alleles' scores are the sum of their counts in sample genotypes, weighted by the confidence in the genotype calls.
calculateNonRefGenotypeConcordance(GenotypeConcordanceScheme, boolean) - Method in class picard.vcf.GenotypeConcordanceCounts
Non Ref Genotype Concordance is the number of times the truth and call states match exactly for *vars only* / all truth and call *var* combinations made If the GA4GH scheme is being used, any MISSING sites in truth OR call will not be included in the discordance calculations.
calculateOneSidedU(double[], double[], MannWhitneyU.TestType) - Method in class org.broadinstitute.hellbender.utils.MannWhitneyU
Calculates the rank-sum test statisic U (sometimes W) from two sets of input data for a one-sided test with an int indicating which group is the dominator.
calculatePathMD5(Path) - Static method in class org.broadinstitute.hellbender.utils.Utils
Calculates the MD5 for the specified file and returns it as a String Warning: this loads the whole file into memory, so it's not suitable for large files.
calculatePosteriorGLs(VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.variantutils.FamilyLikelihoods
Computes phred-scaled genotype posteriors given the data in the given variant context and family priors given by this object.
calculatePosteriorMode(List<Double>, JavaSparkContext) - Static method in class org.broadinstitute.hellbender.utils.mcmc.PosteriorSummaryUtils
Given a list of posterior samples, returns an estimate of the posterior mode (using mllib kernel density estimation in KernelDensity and BrentOptimizer).
calculatePosteriorProbs(VariantContext, List<VariantContext>, int, PosteriorProbabilitiesUtils.PosteriorProbabilitiesOptions) - Static method in class org.broadinstitute.hellbender.tools.walkers.variantutils.PosteriorProbabilitiesUtils
Calculates phred-scaled posterior probabilities for genotypes given the data and allele frequency priors.
calculatePosteriorProbs(List<double[]>, double[], int, boolean) - Static method in class org.broadinstitute.hellbender.tools.walkers.variantutils.PosteriorProbabilitiesUtils
Given genotype likelihoods and known allele counts, calculate the posterior probabilities over the genotype states
calculatePower(int, int, int, int) - Static method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.PowerCalculationUtils
Calculate the power to validate the mutation with given alt and total counts.
calculateRank(double[], double[]) - Method in class org.broadinstitute.hellbender.utils.MannWhitneyU
 
calculateRankSum(Map<Allele, CompressedDataList<Integer>>, Allele) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RankSumTest
 
calculateRawData(VariantContext, ReadLikelihoods<Allele>, ReducibleAnnotationData) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RMSMappingQuality
 
calculateRawData(VariantContext, ReadLikelihoods<Allele>, ReducibleAnnotationData) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.RMSMappingQuality
 
CalculateReadGroupChecksum - Class in picard.sam
 
CalculateReadGroupChecksum() - Constructor for class picard.sam.CalculateReadGroupChecksum
 
calculateReducedData(AlleleSpecificAnnotationData<List<Integer>>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_FisherStrand
 
calculateReducedData(Map<Allele, Histogram>, Allele) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RankSumTest
 
calculateReducedData(AlleleSpecificAnnotationData<List<Integer>>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_StrandBiasTest
Method which determines how the Strand Bias read direction allele data must be combined into a final annotation Must be overridden by client methods.
calculateReducedData(AlleleSpecificAnnotationData<List<Integer>>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_StrandOddsRatio
 
calculateRefConfidence(Haplotype, Collection<Haplotype>, SimpleInterval, AssemblyRegion, ReadLikelihoods<Haplotype>, PloidyModel, List<VariantContext>) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReferenceConfidenceModel
 
calculateRefConfidence(Haplotype, Collection<Haplotype>, SimpleInterval, AssemblyRegion, ReadLikelihoods<Haplotype>, PloidyModel, List<VariantContext>, boolean, List<VariantContext>) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReferenceConfidenceModel
Calculate the reference confidence for a single sample given the its read data Returns a list of variant contexts, one for each position in the activeRegion.getLoc(), each containing detailed information about the certainty that the sample is hom-ref for each base in the region.
calculateRefWindowsByGc(int, File, int) - Static method in class picard.analysis.GcBiasUtils
 
calculateRoiHistogram() - Method in class picard.sam.DuplicationMetrics
Calculates a histogram using the estimateRoi method to estimate the effective yield doing x sequencing for x=1..10.
calculateRunningMetric(List<VariantDatum>) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.TrancheManager.SelectionMetric
 
calculateRunningMetric(List<VariantDatum>) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.TrancheManager.TruthSensitivityMetric
 
calculateSingleSampleRefVsAnyActiveStateProfileValue(double[]) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
Calculates the active state profile value for a single sample.
calculateSOR(int[][]) - Static method in class org.broadinstitute.hellbender.tools.walkers.annotator.StrandOddsRatio
Computes the SOR value of a table after augmentation.
calculateSortOrder(double[]) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
Get a list of indices which give the ascending sort order of the data array
calculateSuppressionFactorFromPreAdapterQ(double, double, double) - Static method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.ArtifactStatisticsScorer
Reduces the number of artifacts to cut based on the preAdapterQ score.
calculateSuppressionFactorFromPreAdapterQ(double) - Static method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.ArtifactStatisticsScorer
See calculateSuppressionFactorFromPreAdapterQ Configured to behave exactly like the CGA Matlab OxoG filter in Firehose.
calculateTwoSidedU(double[], double[]) - Method in class org.broadinstitute.hellbender.utils.MannWhitneyU
Calculates the two-sided rank-sum test statisic U (sometimes W) from two sets of input data.
calculateU1andU2(double[], double[]) - Method in class org.broadinstitute.hellbender.utils.MannWhitneyU
Rank both groups together and return a TestStatistic object that includes U1, U2 and number of ties for sigma
calculateUnfilteredNonRefGenotypeCount(List<VariantContext>, String) - Static method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasUtils
 
calculateVCDepth(VariantContext) - Static method in class org.broadinstitute.hellbender.tools.walkers.ReferenceConfidenceVariantContextMerger
lookup the depth from the VC DP field or calculate by summing the depths of the genotypes
calculateWordCount(byte[]) - Method in class picard.util.AbstractInputParser
Calculates the number of delimiter-separated "words" in a line and sets the value of wordCount
calculateWorstPerformingAnnotation(List<VariantDatum>, GaussianMixtureModel, GaussianMixtureModel) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantRecalibratorEngine
 
calculateZ(double, int, int, double, MannWhitneyU.TestType) - Method in class org.broadinstitute.hellbender.utils.MannWhitneyU
Calculates the Z score (i.e.
call(GATKRead) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.ContainsKmerReadFilterSpark
 
call(GATKRead) - Method in class org.broadinstitute.hellbender.tools.spark.utils.ReadFilterSparkifier
 
call(GATKRead) - Method in class org.broadinstitute.hellbender.tools.spark.utils.ReadTransformerSparkifier
 
call() - Method in enum org.broadinstitute.hellbender.utils.artifacts.Transition
 
call() - Method in class org.broadinstitute.hellbender.utils.runtime.ProcessControllerBase.OutputCapture
Runs the capture.
call() - Method in enum picard.analysis.artifacts.Transition
Gets the call for the transition.
CALL_SAMPLE - Variable in class picard.vcf.GenotypeConcordance
 
CALL_SAMPLE - Variable in class picard.vcf.GenotypeConcordanceContingencyMetrics
The name of the 'call' sample
CALL_SAMPLE - Variable in class picard.vcf.GenotypeConcordanceDetailMetrics
The name of the 'call' sample
CALL_SAMPLE - Variable in class picard.vcf.GenotypeConcordanceSummaryMetrics
The name of the 'call' sample
CALL_STATE - Variable in class picard.vcf.GenotypeConcordanceDetailMetrics
The state of the 'call' sample (i.e.
CALL_VCF - Variable in class picard.vcf.GenotypeConcordance
 
callableEvents - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmer.Result
Holds the collection of callable events within the variant trimming region.
callableRegion - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmer.Result
Holds variant-containing callable region.
callableSpan - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmer.Result
Holds the smaller range that contain all relevant callable variants in the input active region (not considering the extension).
callAllele1 - Variable in class picard.vcf.GenotypeConcordance.Alleles
 
callAllele2 - Variable in class picard.vcf.GenotypeConcordance.Alleles
 
callAlleles() - Method in class picard.vcf.GenotypeConcordance.Alleles
 
CallCopyRatioSegments - Class in org.broadinstitute.hellbender.tools.copynumber
Calls copy-ratio segments as amplified, deleted, or copy-number neutral.
CallCopyRatioSegments() - Constructor for class org.broadinstitute.hellbender.tools.copynumber.CallCopyRatioSegments
 
CalledCopyRatioSegment - Class in org.broadinstitute.hellbender.tools.copynumber.formats.records
 
CalledCopyRatioSegment(CopyRatioSegment, CalledCopyRatioSegment.Call) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.records.CalledCopyRatioSegment
 
CalledCopyRatioSegment.Call - Enum in org.broadinstitute.hellbender.tools.copynumber.formats.records
 
CalledCopyRatioSegmentCollection - Class in org.broadinstitute.hellbender.tools.copynumber.formats.collections
 
CalledCopyRatioSegmentCollection(File) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.collections.CalledCopyRatioSegmentCollection
 
CalledCopyRatioSegmentCollection(SampleLocatableMetadata, List<CalledCopyRatioSegment>) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.collections.CalledCopyRatioSegmentCollection
 
CalledHaplotypes(List<VariantContext>, Set<Haplotype>) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerGenotypingEngine.CalledHaplotypes
 
CALLER_EXTERNAL_ADMIXING_RATE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection
 
CALLER_INTERNAL_ADMIXING_RATE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection
 
CALLER_UPDATE_CONVERGENCE_THRESHOLD_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection
 
callImpreciseDeletionFromEvidenceLinks(PairedStrandedIntervalTree<EvidenceTargetLink>, ReadMetadata, ReferenceMultiSource, int, int, Logger) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.ImpreciseVariantDetector
 
CALLING_COPY_RATIO_Z_SCORE_THRESHOLD_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.CallCopyRatioSegments
 
CallingMetricAccumulator - Class in picard.vcf
Collects variants and generates metrics about them.
CallingMetricAccumulator(DbSnpBitSetUtil.DbSnpBitSets) - Constructor for class picard.vcf.CallingMetricAccumulator
 
CallingMetricAccumulator.Result - Class in picard.vcf
 
callMutations(ReadLikelihoods<Haplotype>, AssemblyResultSet, ReferenceContext, SimpleInterval, FeatureContext, List<VariantContext>, SAMFileHeader) - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.SomaticGenotypingEngine
Main entry point of class - given a particular set of haplotypes, samples and reference context, compute genotype likelihoods and assemble into a list of variant contexts and genomic events ready for calling The list of samples we're working with is obtained from the readLikelihoods
callRegion(AssemblyRegion, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerEngine
Generate variant calls for an assembly region
callRegion(AssemblyRegion, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2Engine
 
CALLS_PATH_SUFFIX - Static variable in class org.broadinstitute.hellbender.tools.copynumber.DetermineGermlineContigPloidy
 
CALLS_PATH_SUFFIX - Static variable in class org.broadinstitute.hellbender.tools.copynumber.GermlineCNVCaller
 
CALLS_SHARD_PATH_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.PostprocessGermlineCNVCalls
 
callsAtTruthSites - Variable in class org.broadinstitute.hellbender.tools.walkers.vqsr.Tranche
 
callSourceString() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
What string to use as source of variant-context generated by this genotyper-engine.
callSourceString() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.MinimalGenotypingEngine
 
callSourceString() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerGenotypingEngine
 
callSourceString() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.SomaticGenotypingEngine
 
callState - Variable in class picard.vcf.GenotypeConcordanceStates.TruthAndCallStates
 
callVariantsWithHaplotypeCaller(JavaSparkContext, JavaRDD<GATKRead>, SAMFileHeader, ReferenceMultiSource, List<SimpleInterval>, HaplotypeCallerArgumentCollection, HaplotypeCallerSpark.ShardingArgumentCollection, VariantAnnotatorEngine) - Static method in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark
Call Variants using HaplotypeCaller on Spark and return an RDD of VariantContext This may be called from any spark pipeline in order to call variants from an RDD of GATKRead
callVariantsWithHaplotypeCallerAndWriteOutput(JavaSparkContext, JavaRDD<GATKRead>, SAMFileHeader, ReferenceMultiSource, List<SimpleInterval>, HaplotypeCallerArgumentCollection, HaplotypeCallerSpark.ShardingArgumentCollection, int, String, Collection<Annotation>) - Static method in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark
Call Variants using HaplotypeCaller on Spark and write out a VCF file.
canDecode(String) - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalCodec
 
canDecode(String) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfCodec
 
canDecode(String) - Method in class org.broadinstitute.hellbender.utils.codecs.ProgressReportingDelegatingCodec
 
canDecode(String) - Method in class org.broadinstitute.hellbender.utils.codecs.sampileup.SAMPileupCodec
Only files with SAMPileupCodec.SAM_PILEUP_FILE_EXTENSIONS could be parsed
canDecode(String) - Method in class org.broadinstitute.hellbender.utils.codecs.table.TableCodec
 
canDecode(String) - Method in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvLocatableTableCodec
 
canDecodeMinusExtensionChecks(String) - Method in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvLocatableTableCodec
Minus checking the file extension, can this class decode the given path.
canMakeInstances(Class<?>) - Static method in class org.broadinstitute.hellbender.utils.ClassUtils
Returns true iff we can make instances of this class.
canMerge(MergeableMetricBase) - Method in class picard.analysis.MergeableMetricBase
checks if this instance can be merged with another Other must have all the fields that this instance has, and the fields that are annotated as MergeByAssertEquals must contain the same value
CANNOT_COMPUTE_ADAPTOR_BOUNDARY - Static variable in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
CannotExecuteScript(String, String) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.CannotExecuteScript
 
CannotHandleGzippedRef() - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.CannotHandleGzippedRef
 
canonical(int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmer
 
canonical(int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerLong
Returns a SVKmerLong that is a canonical representation of this one.
canonical(int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerShort
Returns a SVKmerShort that is a canonical representation of this one.
canonicalizeAndMask(SVKmerShort, int, SVKmerShort) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerCollection
Definition for the order of canonicalization and masking
canonicalStream(CharSequence, int, int, SVKmer) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVDUSTFilteredKmerizer
 
canonicalStream(byte[], int, int, SVKmer) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVDUSTFilteredKmerizer
 
canonicalStream(byte[], int, SVKmer) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerizer
 
canReadFile(File...) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
Checks that one or more user provided files are in fact regular (i.e.
canSkip() - Method in enum picard.sam.RevertOriginalBaseQualitiesAndAddMateCigar.CanSkipSamFile
 
canSkipSAMFile(File, int, boolean, File) - Static method in class picard.sam.RevertOriginalBaseQualitiesAndAddMateCigar
Checks if we can skip the SAM/BAM file when reverting origin base qualities and adding mate cigars.
capacity() - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchCollection
maximum number of elements that can be held without resizing.
capacity() - Method in class org.broadinstitute.hellbender.tools.spark.utils.LargeLongHopscotchSet
 
capacity() - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongHopscotchSet
maximum number of elements that can be held without resizing.
capBaseByBAQ(byte, byte, int, int) - Method in class org.broadinstitute.hellbender.utils.baq.BAQ
 
CAPTURE_ASSEMBLY_FAILURE_BAM_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerArgumentCollection
 
captureAssemblyFailureBAM - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerArgumentCollection
 
CapturedStreamOutput - Class in org.broadinstitute.hellbender.utils.runtime
Stream output captured from a stream.
CapturedStreamOutput(OutputStreamSettings, InputStream, PrintStream) - Constructor for class org.broadinstitute.hellbender.utils.runtime.CapturedStreamOutput
 
CapturedStreamOutputSnapshot - Class in org.broadinstitute.hellbender.utils.runtime
Stream output captured from a streaming stream.
CapturedStreamOutputSnapshot(OutputStreamSettings, InputStream, PrintStream) - Constructor for class org.broadinstitute.hellbender.utils.runtime.CapturedStreamOutputSnapshot
 
captureStderr(Runnable) - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest
captures System.err while runnable is executing
captureStdout(Runnable) - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest
captures System.out while runnable is executing
Casava18ReadNameEncoder - Class in picard.fastq
A read name encoder conforming to the standard described by Illumina Casava 1.8.
Casava18ReadNameEncoder(String, String, String) - Constructor for class picard.fastq.Casava18ReadNameEncoder
 
CASE_SAMPLE_CALLING_PYTHON_SCRIPT - Static variable in class org.broadinstitute.hellbender.tools.copynumber.GermlineCNVCaller
 
CATEGORY - Variable in class picard.analysis.AlignmentSummaryMetrics
One of either UNPAIRED (for a fragment run), FIRST_OF_PAIR when metrics are for only the first read in a paired run, SECOND_OF_PAIR when the metrics are for only the second read in a paired run or PAIR when the metrics are aggregated for both first and second reads in a pair.
CATEGORY - Variable in class picard.analysis.CollectWgsMetricsWithNonZeroCoverage.WgsMetricsWithNonZeroCoverage
One of either WHOLE_GENOME or NON_ZERO_REGIONS
CbclData - Class in picard.illumina.parser
This class provides that data structure for cbcls.
CbclData(int[], int) - Constructor for class picard.illumina.parser.CbclData
 
CbclReader - Class in picard.illumina.parser.readers
------------------------------------- CBCL Header ----------------------------------- Bytes 0 - 1 Version number, current version is 1 unsigned 16 bits little endian integer Bytes 2 - 5 Header size unsigned 32 bits little endian integer Byte 6 Number of bits per basecall unsigned Byte 7 Number of bits per q-score unsigned
CbclReader(List<File>, Map<Integer, File>, int[], int, List<AbstractIlluminaPositionFileReader.PositionInfo>, int[], boolean) - Constructor for class picard.illumina.parser.readers.CbclReader
 
cd - Variable in class org.broadinstitute.hellbender.utils.baq.BAQ
 
CDF(IntHistogram) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.IntHistogram.CDF
 
CHAIN - Variable in class picard.util.LiftOverIntervalList
 
CHAIN - Variable in class picard.vcf.LiftoverVcf
 
changeReads(Map<GATKRead, GATKRead>) - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
 
changeReads(Map<GATKRead, GATKRead>) - Method in class org.broadinstitute.hellbender.utils.genotyper.UnfilledReadsLikelihoods
 
ChannelAsSeekableStream - Class in org.broadinstitute.hellbender.utils.nio
A SeekableByteChannel in SeekableStream clothes.
ChannelAsSeekableStream(SeekableByteChannel) - Constructor for class org.broadinstitute.hellbender.utils.nio.ChannelAsSeekableStream
 
ChannelAsSeekableStream(SeekableByteChannel, String) - Constructor for class org.broadinstitute.hellbender.utils.nio.ChannelAsSeekableStream
 
charAt(int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerizer.ASCIICharSequence
 
CHART_OUTPUT - Variable in class picard.analysis.CollectBaseDistributionByCycle
 
CHART_OUTPUT - Variable in class picard.analysis.CollectGcBiasMetrics
 
CHART_OUTPUT - Variable in class picard.analysis.CollectRnaSeqMetrics
 
CHART_OUTPUT - Variable in class picard.analysis.CollectWgsMetricsWithNonZeroCoverage
 
CHART_OUTPUT - Variable in class picard.analysis.MeanQualityByCycle
 
CHART_OUTPUT - Variable in class picard.analysis.QualityScoreDistribution
 
chartOutput - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectBaseDistributionByCycleSpark
 
chartOutput - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.MeanQualityByCycleSpark
 
chartOutput - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.QualityScoreDistributionSpark
 
CHECK_FIRST_N_RECORDS - Variable in class picard.vcf.FixVcfHeader
 
checkAndClearHeaderSequences(SAMFileHeader, PSFilterArgumentCollection, Logger) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSUtils
Returns a deep copy of the input header with an empty sequence dictionary, and logs warnings if the input may be aligned but --isHostAligned was not set to true (or vice versa).
checkAndCreate(Path) - Static method in class org.broadinstitute.hellbender.utils.fasta.CachingIndexedFastaSequenceFile
Create reference data source from fasta file, after performing several preliminary checks on the file.
checkAndCreate(Path, boolean) - Static method in class org.broadinstitute.hellbender.utils.fasta.CachingIndexedFastaSequenceFile
Create reference data source from fasta file, after performing several preliminary checks on the file.
checkCigarAndConvertTerminalInsertionToSoftClip(Cigar) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SvCigarUtils
Checks the input CIGAR for assumption that operator 'D' is not immediately adjacent to clipping operators.
checkCommand(String[]) - Method in class org.broadinstitute.hellbender.utils.runtime.ProcessSettings
 
checkError() - Method in class org.broadinstitute.hellbender.utils.variant.writers.GVCFWriter
 
CheckFingerprint - Class in picard.fingerprint
Checks the sample identity of the sequence/genotype data in the provided file (SAM/BAM or VCF) against a set of known genotypes in the supplied genotype file (in VCF format).
CheckFingerprint() - Constructor for class picard.fingerprint.CheckFingerprint
 
checkFingerprints(List<Path>, List<Path>, String, boolean) - Method in class picard.fingerprint.FingerprintChecker
Top level method to take a set of one or more SAM files and one or more Genotype files and compare each read group in each SAM file to each set of fingerprint genotypes.
checkFingerprintsFromPaths(List<Path>, List<Path>, String, String) - Method in class picard.fingerprint.FingerprintChecker
Top level method to take a set of one or more observed genotype (VCF) files and one or more expected genotype (VCF) files and compare one or more sample in the observed genotype file with one or more in the expected file and generate results for each set.
checkForDuplicatesAndReturnSet(Collection<E>, String) - Static method in class org.broadinstitute.hellbender.utils.Utils
Checks that the collection does not contain a duplicate value (throws an IllegalArgumentException if it does).
checkHasTrainingSet() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
 
checkHasTruthSet() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
 
checkHistograms(List<BreakpointEvidence>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.KSWindowFinder
Used in production to gather evidence derived from K-S calculation on windows.
CheckIlluminaDirectory - Class in picard.illumina
Program to check a lane of an Illumina output directory.
CheckIlluminaDirectory() - Constructor for class picard.illumina.CheckIlluminaDirectory
 
checkIndexVersionAndModificationTime(File, File, Index) - Static method in class org.broadinstitute.hellbender.utils.IndexUtils
 
checkMandatoryColumns(TableColumnCollection, TableColumnCollection, Function<String, RuntimeException>) - Static method in class org.broadinstitute.hellbender.utils.tsv.TableUtils
Checks if all mandatory columns are present in a TableColumnCollection.
checkNames(Object[], Function<String, RuntimeException>) - Static method in class org.broadinstitute.hellbender.utils.tsv.TableColumnCollection
Checks that a column name, as objects, array is valid.
checkNames(String[], Function<String, RuntimeException>) - Static method in class org.broadinstitute.hellbender.utils.tsv.TableColumnCollection
Checks that a column name array is valid.
checkOutOfBounds(int) - Method in class picard.analysis.CounterManager
Method checks that new locus position is not out of bounds of Counter arrays and there is enough space in them to hold information on at least one more read of length CounterManager.readLength.
checkOutputSpecs(JobContext) - Method in class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSink.SparkBAMOutputFormat
 
checkOutputSpecs(JobContext) - Method in class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSink.SparkCRAMOutputFormat
 
checkOutputSpecs(JobContext) - Method in class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSink.SparkSAMOutputFormat
 
checkOutputSpecs(JobContext) - Method in class org.broadinstitute.hellbender.engine.spark.datasources.VariantsSparkSink.SparkVCFOutputFormat
 
CheckPileup - Class in org.broadinstitute.hellbender.tools.walkers.qc
Compare GATK's internal pileup to a reference Samtools pileup
CheckPileup() - Constructor for class org.broadinstitute.hellbender.tools.walkers.qc.CheckPileup
 
checkPythonEnvironmentForPackage(String) - Static method in class org.broadinstitute.hellbender.utils.python.PythonScriptExecutor
 
checkSettings(InputStreamSettings) - Method in class org.broadinstitute.hellbender.utils.runtime.ProcessSettings
 
checkSettings(OutputStreamSettings) - Method in class org.broadinstitute.hellbender.utils.runtime.ProcessSettings
 
checkStructure() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTree
Because of the piecemeal way we allow the tree to be constructed, we can end up with invalid tree structures.
CheckTerminatorBlock - Class in picard.sam
Simple class to check the terminator block of a SAM file.
CheckTerminatorBlock() - Constructor for class picard.sam.CheckTerminatorBlock
 
checkTileCount() - Method in class picard.illumina.parser.ParameterizedFileUtil
 
checkTileCount() - Method in class picard.illumina.parser.PerTileOrPerRunFileUtil
 
checkVariationClass(VariantContext, VariantContext) - Static method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
 
checkVariationClass(VariantContext, VariantRecalibratorArgumentCollection.Mode) - Static method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
 
checkVariationClass(VariantContext, Allele, VariantRecalibratorArgumentCollection.Mode) - Static method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
 
CHIMERA_KB_MIN - Variable in class picard.analysis.CollectJumpingLibraryMetrics
 
ChimeraUtil - Class in picard.analysis
 
ChimeraUtil() - Constructor for class picard.analysis.ChimeraUtil
 
CHIMERIC_ALIGNMENTS_HIGHMQ_THRESHOLD - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.DiscoverVariantsFromContigsAlignmentsSparkArgumentCollection
 
CHIMERIC_PAIRS - Variable in class picard.analysis.JumpingLibraryMetrics
The number of pairs where either (a) the ends fall on different chromosomes or (b) the insert size is greater than the maximum of 100000 or 2 times the mode of the insert size for outward-facing pairs.
chooseAlleleForRead(PileupElement, Allele, List<Allele>, int) - Static method in class org.broadinstitute.hellbender.utils.GATKProtectedVariantContextUtils
Given a set of alleles (reference and alternate), choose the allele that is the best match for the given read (and offset)
CHR10_B36 - Static variable in class org.broadinstitute.hellbender.utils.SequenceDictionaryUtils
 
CHR10_B37 - Static variable in class org.broadinstitute.hellbender.utils.SequenceDictionaryUtils
 
CHR10_HG18 - Static variable in class org.broadinstitute.hellbender.utils.SequenceDictionaryUtils
 
CHR10_HG19 - Static variable in class org.broadinstitute.hellbender.utils.SequenceDictionaryUtils
 
CHR1_B36 - Static variable in class org.broadinstitute.hellbender.utils.SequenceDictionaryUtils
 
CHR1_B37 - Static variable in class org.broadinstitute.hellbender.utils.SequenceDictionaryUtils
 
CHR1_HG18 - Static variable in class org.broadinstitute.hellbender.utils.SequenceDictionaryUtils
 
CHR1_HG19 - Static variable in class org.broadinstitute.hellbender.utils.SequenceDictionaryUtils
 
CHR2_B36 - Static variable in class org.broadinstitute.hellbender.utils.SequenceDictionaryUtils
 
CHR2_B37 - Static variable in class org.broadinstitute.hellbender.utils.SequenceDictionaryUtils
 
CHR2_HG18 - Static variable in class org.broadinstitute.hellbender.utils.SequenceDictionaryUtils
 
CHR2_HG19 - Static variable in class org.broadinstitute.hellbender.utils.SequenceDictionaryUtils
 
CHROM - Variable in class picard.analysis.FingerprintingDetailMetrics
The chromosome on which the SNP resides.
ChromosomeCounts - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Counts and frequency of alleles in called genotypes
ChromosomeCounts() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.ChromosomeCounts
 
CHUNK_INDEX_PATH_SUFFIX - Static variable in class org.broadinstitute.hellbender.tools.copynumber.utils.HDF5Utils
 
CIEND - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
CIGAR_CONTAINS_NO_N_OPERATOR - Static variable in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary
 
cigarAlong5to3DirectionOfContig - Variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
 
cigarAlongReference() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
Returns the cigar of this alignment interval along the reference.
CigarContainsNoNOperator() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.CigarContainsNoNOperator
 
cigarHasZeroSizeElement(Cigar) - Static method in class org.broadinstitute.hellbender.utils.read.AlignmentUtils
Does one of the elements in cigar have a 0 length?
CigarUtils - Class in org.broadinstitute.hellbender.utils.read
 
CIPOS - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
CircularByteBuffer - Class in picard.util
Implementation of a circular byte buffer that uses a large byte[] internally and supports basic read/write operations from/to other byte[]s passed as arguments.
CircularByteBuffer(int) - Constructor for class picard.util.CircularByteBuffer
Constructs a buffer capable of holding the given number of bytes.
CLASS_COHERENCE_LENGTH_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineCallingArgumentCollection
 
ClassFinder - Class in picard.cmdline
Utility class that can scan for classes in the classpath and find all the ones annotated with a particular annotation.
ClassFinder() - Constructor for class picard.cmdline.ClassFinder
 
ClassFinder(ClassLoader) - Constructor for class picard.cmdline.ClassFinder
 
ClassFinder(File) - Constructor for class picard.cmdline.ClassFinder
 
CLASSIFICATION - Variable in class picard.illumina.quality.CollectHiSeqXPfFailMetrics.PFFailDetailedMetric
The classification of this read: {EMPTY, POLYCLONAL, MISALIGNED, UNKNOWN} (See PFFailSummaryMetric for explanation regarding the possible classification.)
classifyVariants(Optional<VariantContext>, String, Optional<VariantContext>, String, int, int, boolean) - Static method in class picard.vcf.GenotypeConcordance
 
classifyVariants(Optional<VariantContext>, String, Optional<VariantContext>, String, Optional<GenotypeConcordanceCounts>, Optional<GenotypeConcordanceCounts>, int, int, boolean) - Static method in class picard.vcf.GenotypeConcordance
Attempts to determine the concordance state given the truth and all variant context and optionally increments the genotype concordance count for the given variant type (SNP or INDEL).
ClassUtils - Class in org.broadinstitute.hellbender.utils
Utilities for dealing with reflection.
cleanerMaxCopyNumber - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
cleanerMaxIntervals - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
cleanerMinKmerCount - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
cleanNonRefPaths() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Remove edges that are connected before the reference source and after the reference sink Also removes all vertices that are orphaned by this process
CleanSam - Class in picard.sam
 
CleanSam() - Constructor for class picard.sam.CleanSam
 
CleanSamTester - Class in org.broadinstitute.hellbender.utils.test.testers
This class is the extension of the SamFileTester to test CleanSam with SAM files generated on the fly.
CleanSamTester(String, int, int) - Constructor for class org.broadinstitute.hellbender.utils.test.testers.CleanSamTester
 
cleanUpCigar(Cigar) - Static method in class org.broadinstitute.hellbender.utils.read.AlignmentUtils
Clean up the incoming cigar Removes elements with zero size Clips away beginning deletion operators
cleanUpSymbolicUnassembledEvents(List<Haplotype>) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerGenotypingEngine
Removes symbolic events from list of haplotypes
clear() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree
Remove all entries.
clear() - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchCollection
 
clear() - Method in class org.broadinstitute.hellbender.tools.spark.utils.IntHistogram
 
clear() - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongBloomFilter
 
clear() - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongHopscotchSet
 
clear() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.KMerCounter
Remove all current counts, resetting the counter to an empty state
clear() - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
 
clear() - Method in class org.broadinstitute.hellbender.utils.collections.IndexedSet
Removes all elements in the set.
clear() - Method in class org.broadinstitute.hellbender.utils.Nucleotide.Counter
Reset all the counts to 0.
clear() - Method in class org.broadinstitute.hellbender.utils.SATagBuilder
Clears all SA tag units from the SATagBuilder as they exist.
clear() - Method in class picard.analysis.CounterManager
Clears all inner Counter arrays
clear() - Method in class picard.illumina.parser.readers.CbclReader
 
CLEAR_DT - Variable in class picard.sam.markduplicates.MarkDuplicates
 
clearAttribute(String) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Clear an individual attribute on the read.
clearAttribute(String) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
clearAttributes() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Clear all attributes on the read.
clearAttributes() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
clearItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.Downsampler
Empty the downsampler of all finalized/pending items
clearItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.FractionalDownsampler
 
clearItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.LevelingDownsampler
 
clearItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.MutectDownsampler
 
clearItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.PassThroughDownsampler
 
clearItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.PositionalDownsampler
 
clearItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.ReservoirDownsampler
Clear the data structures used to hold information
clearReads() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
Clear all of the reads currently in this region
CLIP_ADAPTERS - Variable in class picard.fastq.BamToBfq
 
CLIP_ADAPTERS - Variable in class picard.sam.MergeBamAlignment
 
CLIP_OVERLAPPING_READS - Variable in class picard.analysis.directed.CollectTargetedMetrics
 
CLIP_OVERLAPPING_READS - Variable in class picard.sam.MergeBamAlignment
 
CLIP_REPRESENTATION_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.ClipReads
 
CLIP_REPRESENTATION_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.ClipReads
 
CLIP_SEQUENCE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.ClipReads
 
CLIP_SEQUENCE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.ClipReads
 
CLIP_SEQUENCES_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.ClipReads
 
CLIP_SEQUENCES_FILE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.ClipReads
 
clipAlignmentInterval(AlignmentInterval, int, boolean) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.ContigAlignmentsModifier
Given clipLengthOnRead to be clipped from an aligned contig's AlignmentInterval input, return a modified AlignmentInterval with the requested number of bases clipped away and ref span recomputed.
clipByReferenceCoordinates(int, int, ClippingRepresentation, boolean) - Method in class org.broadinstitute.hellbender.utils.clipping.ReadClipper
Generic functionality to clip a read, used internally by hardClipByReferenceCoordinatesLeftTail and hardClipByReferenceCoordinatesRightTail.
clipForOverlappingReads(SAMRecord, SAMRecord) - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.AbstractAlignmentMerger
Checks to see whether the ends of the reads overlap and soft clips reads them if necessary.
clipForOverlappingReads(SAMRecord, SAMRecord) - Static method in class picard.sam.AbstractAlignmentMerger
Checks to see whether the ends of the reads overlap and soft clips reads them if necessary.
clipLowQualEnds(GATKRead, byte, ClippingRepresentation) - Static method in class org.broadinstitute.hellbender.utils.clipping.ReadClipper
 
CLIPPING_ACTION - Variable in class picard.sam.SamToFastq
 
CLIPPING_ATTRIBUTE - Variable in class picard.sam.SamToFastq
 
CLIPPING_GOAL_NOT_REACHED - Static variable in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
CLIPPING_MIN_LENGTH - Variable in class picard.sam.SamToFastq
 
CLIPPING_RANK_SUM_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
ClippingData(List<ClipReads.SeqToClip>) - Constructor for class org.broadinstitute.hellbender.tools.ClipReads.ClippingData
 
ClippingOp - Class in org.broadinstitute.hellbender.utils.clipping
Represents a clip on a read.
ClippingOp(int, int) - Constructor for class org.broadinstitute.hellbender.utils.clipping.ClippingOp
 
ClippingRankSumTest - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Rank Sum Test for hard-clipped bases on REF versus ALT reads
ClippingRankSumTest() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.ClippingRankSumTest
 
ClippingRepresentation - Enum in org.broadinstitute.hellbender.utils.clipping
How should we represent a clipped bases in a read?
ClippingUtility - Class in picard.util
Utilities to clip the adapter sequence from a SAMRecord read
ClippingUtility() - Constructor for class picard.util.ClippingUtility
 
clipRead(ClippingRepresentation) - Method in class org.broadinstitute.hellbender.utils.clipping.ReadClipper
Clips a read according to ops and the chosen algorithm.
ClipReads - Class in org.broadinstitute.hellbender.tools
Read clipping based on quality, position or sequence matching.
ClipReads() - Constructor for class org.broadinstitute.hellbender.tools.ClipReads
 
ClipReads.ClippingData - Class in org.broadinstitute.hellbender.tools
 
ClipReads.ReadClipperWithData - Class in org.broadinstitute.hellbender.tools
 
ClocsFileFaker - Class in picard.illumina.parser.fakers
 
ClocsFileFaker() - Constructor for class picard.illumina.parser.fakers.ClocsFileFaker
 
ClocsFileReader - Class in picard.illumina.parser.readers
The clocs file format is one of 3 Illumina formats(pos, locs, and clocs) that stores position data exclusively.
ClocsFileReader(File) - Constructor for class picard.illumina.parser.readers.ClocsFileReader
 
clone() - Method in class htsjdk.samtools.SAMRecordSparkCodec
 
clone() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
 
clone() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.SeqGraph
 
clone() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingGraph
 
clone() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.TestingReadThreadingGraph
 
clone() - Method in class org.broadinstitute.hellbender.utils.MathUtils.RunningAverage
 
clone() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEndsForMarkDuplicatesCodec
For an explanation of why codecs must implement clone(), see the HTSJDK documentation for SortingCollection.Codec.
clone() - Method in class picard.sam.markduplicates.util.ReadEndsForMarkDuplicates
 
clone() - Method in class picard.sam.markduplicates.util.ReadEndsForMarkDuplicatesCodec
 
clone() - Method in class picard.sam.markduplicates.util.ReadEndsForMarkDuplicatesWithBarcodes
 
clone() - Method in class picard.sam.markduplicates.util.ReadEndsForMarkDuplicatesWithBarcodesCodec
 
clone() - Method in class picard.sam.markduplicates.util.RepresentativeReadIndexerCodec
 
cloneSAMFileHeader(SAMFileHeader) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
HACK: This is used to make a copy of a header.
cloneSAMRecord(SAMRecord) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
HACK: This is used to make a copy of a read.
close() - Method in class org.broadinstitute.hellbender.engine.FeatureDataSource
Permanently close this data source, invalidating any open iteration over it, and making it invalid for future iterations and queries.
close() - Method in class org.broadinstitute.hellbender.engine.FeatureManager
Permanently closes this manager by closing all backing data sources
close() - Method in class org.broadinstitute.hellbender.engine.MultiVariantDataSource
Permanently close this data source, invalidating any open iteration over it, and making it invalid for future iterations and queries.
close() - Method in class org.broadinstitute.hellbender.engine.ReadsDataSource
Shut down this data source permanently, closing all iterations and readers.
close() - Method in interface org.broadinstitute.hellbender.engine.ReferenceDataSource
Permanently close this data source.
close() - Method in class org.broadinstitute.hellbender.engine.ReferenceFileSource
Permanently close this data source
close() - Method in class org.broadinstitute.hellbender.engine.ReferenceMemorySource
no-op (nothing's open)
close() - Method in interface org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalWriter
attempt to close the file
close() - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.SimpleAnnotatedIntervalWriter
attempt to close the file
close() - Method in class org.broadinstitute.hellbender.tools.funcotator.DataSourceFuncotationFactory
Perform cleanup tasks for this DataSourceFuncotationFactory.
close() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.cosmic.CosmicFuncotationFactory
 
close() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationFactory
 
close() - Method in class org.broadinstitute.hellbender.tools.funcotator.mafOutput.MafOutputRenderer
 
close() - Method in class org.broadinstitute.hellbender.tools.funcotator.OutputRenderer
Close the OutputRenderer.
close() - Method in class org.broadinstitute.hellbender.tools.funcotator.vcfOutput.VcfOutputRenderer
 
close() - Method in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark.ReferenceMultiSourceAdapter
 
close() - Method in class org.broadinstitute.hellbender.tools.spark.bwa.BwaSparkEngine
 
close() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterEmptyLogger
 
close() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterFileLogger
 
close() - Method in interface org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterLogger
 
close() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSScoreFileLogger
 
close() - Method in interface org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSScoreLogger
 
close() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBwaAlignerSpark
 
close() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilter
After doFilter(), this should be run after a Spark action (e.g.
close() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPairedUnpairedSplitterSpark
Call only after Spark is done with all closures involving the paired/unpaired RDDs, i.e.
close() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SingleSequenceReferenceAligner
 
close() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.PairHMMLikelihoodCalculationEngine
 
close() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.RandomLikelihoodCalculationEngine
 
close() - Method in interface org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadLikelihoodCalculationEngine
This method must be called when the client is done with likelihood calculations.
close(LineIterator) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfCodec
 
close() - Method in class org.broadinstitute.hellbender.utils.codecs.LineIteratorReader
 
close(B) - Method in class org.broadinstitute.hellbender.utils.codecs.ProgressReportingDelegatingCodec
 
close() - Method in class org.broadinstitute.hellbender.utils.haplotype.HaplotypeBAMWriter
Close any output resource associated with this writer.
close() - Method in class org.broadinstitute.hellbender.utils.iterators.SamReaderQueryingIterator
 
close() - Method in class org.broadinstitute.hellbender.utils.nio.ChannelAsSeekableStream
 
close() - Method in class org.broadinstitute.hellbender.utils.nio.PathLineIterator
 
close() - Method in class org.broadinstitute.hellbender.utils.nio.SeekableByteChannelPrefetcher
Closes this channel.
close() - Method in class org.broadinstitute.hellbender.utils.pairhmm.PairHMM
Called at the end of the program to close files, print profiling information etc
close() - Method in class org.broadinstitute.hellbender.utils.pairhmm.VectorLoglessPairHMM
 
close() - Method in class org.broadinstitute.hellbender.utils.read.ArtificialReadIterator
 
close() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.AbstractMarkDuplicatesCommandLineProgram.SamHeaderAndIterator
 
close() - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.AbstractAlignmentMerger
 
close() - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.MultiHitAlignedReadIterator
 
close() - Method in class org.broadinstitute.hellbender.utils.read.SAMFileGATKReadWriter
 
close() - Method in class org.broadinstitute.hellbender.utils.reference.FastaReferenceWriter
Closes this writer flushing all remaining writing operation input the output resources.
close() - Method in interface org.broadinstitute.hellbender.utils.smithwaterman.SmithWatermanAligner
Implementations may optionally implement close in order to release any resources that they are holding.
close() - Method in class org.broadinstitute.hellbender.utils.smithwaterman.SmithWatermanIntelAligner
Close the aligner
close() - Method in class org.broadinstitute.hellbender.utils.smithwaterman.SmithWatermanJavaAligner
 
close() - Method in class org.broadinstitute.hellbender.utils.smithwaterman.SWNativeAlignerWrapper
Report total compute time and close aligner
close() - Method in class org.broadinstitute.hellbender.utils.test.XorWrapper
 
close() - Method in class org.broadinstitute.hellbender.utils.text.XReadLines
 
close() - Method in class org.broadinstitute.hellbender.utils.tsv.TableReader
 
close() - Method in class org.broadinstitute.hellbender.utils.tsv.TableWriter
 
close() - Method in class org.broadinstitute.hellbender.utils.variant.writers.GVCFWriter
Close this GVCF writer.
close() - Method in class picard.illumina.parser.BaseIlluminaDataProvider
 
close() - Method in class picard.illumina.parser.IlluminaDataProvider
 
close() - Method in class picard.illumina.parser.MultiTileFilterParser
 
close() - Method in class picard.illumina.parser.MultiTileLocsParser
 
close() - Method in class picard.illumina.parser.NewIlluminaDataProvider
 
close() - Method in class picard.illumina.parser.PerTileParser
 
close() - Method in class picard.illumina.parser.readers.BarcodeFileReader
 
close() - Method in class picard.illumina.parser.readers.BclReader
 
close() - Method in class picard.illumina.parser.readers.CbclReader
 
close() - Method in class picard.illumina.parser.readers.ClocsFileReader
 
close() - Method in class picard.illumina.parser.readers.LocsFileReader
 
close() - Method in class picard.illumina.parser.readers.PosFileReader
 
close() - Method in class picard.sam.AbstractAlignmentMerger
 
close() - Method in class picard.sam.markduplicates.MarkDuplicatesWithMateCigarIterator
 
close() - Method in class picard.util.AbstractInputParser
Closes this stream and releases any system resources associated with it.
close() - Method in class picard.util.AsyncIterator
Stops the thread and then calls synchronouslyClose() to allow implementation to do any one time clean up.
close() - Method in class picard.util.BasicInputParser
Closes the underlying stream
close() - Method in class picard.util.CircularByteBuffer
Signals that the buffer is closed and no further writes will occur.
close() - Method in class picard.util.DelimitedTextFileWithHeaderIterator
 
close() - Method in class picard.util.TabbedTextFileWithHeaderParser
Release all resources associated with the parser.
close() - Method in class picard.vcf.filter.FilterApplyingVariantIterator
 
close() - Method in class picard.vcf.processor.util.PredicateFilterDecoratingClosableIterator
 
close() - Method in class picard.vcf.processor.VariantIteratorProducer
Closes any latent file handles that may have been opened by calls to VariantIteratorProducer.iterators().
closeAllDistributedInstances(JavaSparkContext) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.ContainsKmerReadFilterSpark
Closes kmer library on all executors
closeAllDistributedInstances(JavaSparkContext) - Static method in class org.broadinstitute.hellbender.utils.bwa.BwaMemIndexCache
Closes all instances in all the VMs involved in the spark context provided.
closeInstance(String) - Static method in class org.broadinstitute.hellbender.utils.bwa.BwaMemIndexCache
Closes an index instance in the cache given its index file name.
closeInstance(BwaMemIndex) - Static method in class org.broadinstitute.hellbender.utils.bwa.BwaMemIndexCache
Closes an index instance.
closeInstances() - Static method in class org.broadinstitute.hellbender.utils.bwa.BwaMemIndexCache
Closes all instances in the VM.
closeKmerLib() - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.ContainsKmerReadFilter
 
closeTool() - Method in class org.broadinstitute.hellbender.engine.GATKTool
This method is called by the GATK framework at the end of the GATKTool.doWork() template method.
closeTool() - Method in class org.broadinstitute.hellbender.tools.AnnotatePairOrientation
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.ClipReads
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleAssemblyRegionWalker
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleFeatureWalker
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleIntervalWalker
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleLocusWalker
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.examples.ExamplePostTraversalPythonExecutor
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleReadWalkerWithReference
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleReadWalkerWithVariants
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleStreamingPythonExecutor
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleTwoPassVariantWalker
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleVariantWalker
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.exome.FilterByOrientationBias
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.FixCallSetSampleOrdering
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.FixMisencodedBaseQualityReads
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.funcotator.Funcotator
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.LeftAlignIndels
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.PrintReads
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.SplitReads
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotator
Make sure that the writer is closed upon completing the tool.
closeTool() - Method in class org.broadinstitute.hellbender.tools.walkers.bqsr.ApplyBQSR
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.walkers.CombineGVCFs
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.walkers.GenotypeGVCFs
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCaller
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.FilterMutectCalls
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.walkers.qc.CheckPileup
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.walkers.qc.Pileup
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.FilterAlignmentArtifacts
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.walkers.RevertBaseQualityScores
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.ASEReadCounter
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.SplitNCigarReads
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.walkers.UnmarkDuplicates
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.AnnotateVcfWithBamDepth
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.AnnotateVcfWithExpectedAlleleFraction
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.RemoveNearbyIndels
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.walkers.variantutils.CalculateGenotypePosteriors
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.walkers.variantutils.SelectVariants
Close out the new variants file.
closeTool() - Method in class org.broadinstitute.hellbender.tools.walkers.variantutils.UpdateVCFSequenceDictionary
Close out the new variants file.
closeTool() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.ApplyVQSR
 
closeTool() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantRecalibrator
 
closeWriter() - Method in class picard.sam.FixMateInformation
 
CLOUD_INDEX_PREFETCH_BUFFER_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
CLOUD_INDEX_PREFETCH_BUFFER_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
CLOUD_PREFETCH_BUFFER_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
CLOUD_PREFETCH_BUFFER_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
cloudIndexPrefetchBuffer - Variable in class org.broadinstitute.hellbender.engine.GATKTool
 
cloudIndexPrefetchBuffer() - Method in interface org.broadinstitute.hellbender.utils.config.GATKConfig
 
cloudPrefetchBuffer - Variable in class org.broadinstitute.hellbender.engine.GATKTool
 
cloudPrefetchBuffer - Variable in class org.broadinstitute.hellbender.tools.GatherVcfsCloud
 
cloudPrefetchBuffer() - Method in interface org.broadinstitute.hellbender.utils.config.GATKConfig
 
cluster(Iterator<BreakpointEvidence>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.EvidenceTargetLinkClusterer
 
CLUSTER - Variable in class picard.fingerprint.ClusteredCrosscheckMetric
The cluster identifier to which the two groups within this metric (CrosscheckMetric.LEFT_GROUP_VALUE and CrosscheckMetric.RIGHT_GROUP_VALUE) belong.
cluster() - Method in class picard.util.GraphUtils.Graph
returns the cluster map of connected components
CLUSTER_DENSITY - Variable in class picard.illumina.IlluminaLaneMetrics
The number of clusters per unit area on the this lane expressed in units of [cluster / mm^2].
CLUSTER_SIZE - Variable in class picard.fingerprint.ClusteredCrosscheckMetric
The number of different groups that are assigned to this cluster.
CLUSTER_SIZE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
 
CLUSTER_WINDOW_SIZE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
 
ClusterCrosscheckMetrics - Class in picard.fingerprint
Summary
ClusterCrosscheckMetrics() - Constructor for class picard.fingerprint.ClusterCrosscheckMetrics
 
ClusterData - Class in picard.illumina.parser
Store the information from Illumina files for a single cluster with one or more reads.
ClusterData(ReadData...) - Constructor for class picard.illumina.parser.ClusterData
Used for testing, reads is set directly with no copying to the input array
ClusterData(ReadType[]) - Constructor for class picard.illumina.parser.ClusterData
Creates a ClusterData with one read for each type provided
ClusterDataToSamConverter - Class in picard.illumina
Takes ClusterData provided by an IlluminaDataProvider into one or two SAMRecords, as appropriate, and optionally marking adapter sequence.
ClusterDataToSamConverter(String, String, ReadStructure, List<AdapterPair>) - Constructor for class picard.illumina.ClusterDataToSamConverter
Constructor
CLUSTERED_EVENTS_FILTER_NAME - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
CLUSTERED_SNP_FILTER_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
 
ClusteredCrosscheckMetric - Class in picard.fingerprint
A metric class to hold the result of ClusterCrosscheckMetrics fingerprints.
ClusteredCrosscheckMetric() - Constructor for class picard.fingerprint.ClusteredCrosscheckMetric
 
ClusteredCrosscheckMetric(CrosscheckMetric) - Constructor for class picard.fingerprint.ClusteredCrosscheckMetric
 
clusterSize - Variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
Works together with the --cluster-window-size argument.
clusterWindow - Variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
Works together with the --cluster-size argument.
CNN_1D_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
CNN_2D_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
CNNScoreVariants - Class in org.broadinstitute.hellbender.tools.walkers.vqsr
Annotate a VCF with scores from a Convolutional Neural Network (CNN).
CNNScoreVariants() - Constructor for class org.broadinstitute.hellbender.tools.walkers.vqsr.CNNScoreVariants
 
CNNVariantTrain - Class in org.broadinstitute.hellbender.tools.walkers.vqsr
Train a Convolutional Neural Network (CNN) for filtering variants.
CNNVariantTrain() - Constructor for class org.broadinstitute.hellbender.tools.walkers.vqsr.CNNVariantTrain
 
CNNVariantWriteTensors - Class in org.broadinstitute.hellbender.tools.walkers.vqsr
Write variant tensors for training a Convolutional Neural Network (CNN) for filtering variants.
CNNVariantWriteTensors() - Constructor for class org.broadinstitute.hellbender.tools.walkers.vqsr.CNNVariantWriteTensors
 
CNV_COHERENCE_LENGTH_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineCallingArgumentCollection
 
cnvCallsFile - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.DiscoverVariantsFromContigsAlignmentsSparkArgumentCollection
 
CNVInputReader - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
CNVInputReader() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.CNVInputReader
 
code() - Method in enum picard.sam.markduplicates.MarkDuplicates.DuplicateType
 
codec_packages() - Method in interface org.broadinstitute.hellbender.utils.config.GATKConfig
 
CODING_BASES - Variable in class picard.analysis.RnaSeqMetrics
Number of bases in primary alignments that align to a non-UTR coding base for some gene, and not ribosomal sequence.
codingEnd - Variable in class picard.annotation.Gene.Transcript
 
codingStart - Variable in class picard.annotation.Gene.Transcript
 
COHORT_DENOISING_CALLING_PYTHON_SCRIPT - Static variable in class org.broadinstitute.hellbender.tools.copynumber.GermlineCNVCaller
 
CollectAlignmentRefArgCollection() - Constructor for class picard.analysis.CollectAlignmentSummaryMetrics.CollectAlignmentRefArgCollection
 
CollectAlignmentSummaryMetrics - Class in picard.analysis
A command line tool to read a BAM file and produce standard alignment metrics that would be applicable to any alignment.
CollectAlignmentSummaryMetrics() - Constructor for class picard.analysis.CollectAlignmentSummaryMetrics
 
CollectAlignmentSummaryMetrics.CollectAlignmentRefArgCollection - Class in picard.analysis
 
CollectAllelicCounts - Class in org.broadinstitute.hellbender.tools.copynumber
Collects reference and alternate allele counts at specified sites.
CollectAllelicCounts() - Constructor for class org.broadinstitute.hellbender.tools.copynumber.CollectAllelicCounts
 
collectAtLocus(Nucleotide, ReadPileup, Locatable, int) - Method in class org.broadinstitute.hellbender.tools.copynumber.datacollection.AllelicCountCollector
Add counts to this class for a specific locus.
CollectBaseDistributionByCycle - Class in picard.analysis
 
CollectBaseDistributionByCycle() - Constructor for class picard.analysis.CollectBaseDistributionByCycle
 
CollectBaseDistributionByCycleSpark - Class in org.broadinstitute.hellbender.tools.spark.pipelines.metrics
Collects base distribution per cycle in SAM/BAM/CRAM file(s).
CollectBaseDistributionByCycleSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectBaseDistributionByCycleSpark
 
CollectGcBiasMetrics - Class in picard.analysis
Tool to collect information about GC bias in the reads in a given BAM file.
CollectGcBiasMetrics() - Constructor for class picard.analysis.CollectGcBiasMetrics
 
CollectHiSeqXPfFailMetrics - Class in picard.illumina.quality
Collect metrics regarding the reason for reads (sequenced by HiSeqX) not passing the Illumina PF Filter.
CollectHiSeqXPfFailMetrics() - Constructor for class picard.illumina.quality.CollectHiSeqXPfFailMetrics
 
CollectHiSeqXPfFailMetrics.PFFailDetailedMetric - Class in picard.illumina.quality
a metric class for describing FP failing reads from an Illumina HiSeqX lane *
CollectHiSeqXPfFailMetrics.PFFailSummaryMetric - Class in picard.illumina.quality
Metrics produced by the GetHiSeqXPFFailMetrics program.
CollectHiSeqXPfFailMetrics.ReadClassifier - Class in picard.illumina.quality
 
CollectHiSeqXPfFailMetrics.ReadClassifier.PfFailReason - Enum in picard.illumina.quality
 
CollectHsMetrics - Class in picard.analysis.directed
This tool takes a SAM/BAM file input and collects metrics that are specific for sequence datasets generated through hybrid-selection.
CollectHsMetrics() - Constructor for class picard.analysis.directed.CollectHsMetrics
 
CollectIlluminaBasecallingMetrics - Class in picard.illumina
A Command line tool to collect Illumina Basecalling metrics for a sequencing run Requires a Lane and an input file of Barcodes to expect.
CollectIlluminaBasecallingMetrics() - Constructor for class picard.illumina.CollectIlluminaBasecallingMetrics
 
CollectIlluminaLaneMetrics - Class in picard.illumina
CollectIlluminaLaneMetrics() - Constructor for class picard.illumina.CollectIlluminaLaneMetrics
 
CollectIlluminaLaneMetrics.IlluminaLaneMetricsCollector - Class in picard.illumina
Utility for collating Tile records from the Illumina TileMetrics file into lane-level and phasing-level metrics.
CollectIndependentReplicateMetrics - Class in picard.analysis.replicates
A CLP that, given a BAM and a VCF with genotypes of the same sample, estimates the rate of independent replication of reads within the bam.
CollectIndependentReplicateMetrics() - Constructor for class picard.analysis.replicates.CollectIndependentReplicateMetrics
 
CollectInsertSizeMetrics - Class in picard.analysis
Command line program to read non-duplicate insert sizes, create a Histogram and report distribution statistics.
CollectInsertSizeMetrics() - Constructor for class picard.analysis.CollectInsertSizeMetrics
 
CollectInsertSizeMetricsSpark - Class in org.broadinstitute.hellbender.tools.spark.pipelines.metrics
Collects insert size distribution information in alignment data.
CollectInsertSizeMetricsSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectInsertSizeMetricsSpark
 
CollectJumpingLibraryMetrics - Class in picard.analysis
Command-line program to compute metrics about outward-facing pairs, inward-facing pairs, and chimeras in a jumping library.
CollectJumpingLibraryMetrics() - Constructor for class picard.analysis.CollectJumpingLibraryMetrics
 
collectLaneMetrics(File, File, String, MetricsFile<MetricBase, Comparable<?>>, MetricsFile<MetricBase, Comparable<?>>, ReadStructure, String, ValidationStringency, boolean) - Static method in class picard.illumina.CollectIlluminaLaneMetrics.IlluminaLaneMetricsCollector
Parses the tile data from the basecall directory and writes to both the lane and phasing metrics files
collectMetrics(JavaRDD<GATKRead>, SAMFileHeader) - Method in class org.broadinstitute.hellbender.tools.examples.metrics.multi.ExampleCollectMultiMetricsSpark
Execute the actual metrics collection.
collectMetrics(JavaRDD<GATKRead>, SAMFileHeader) - Method in class org.broadinstitute.hellbender.tools.examples.metrics.multi.ExampleMultiMetricsCollectorSpark
Do he actual Metrics collection.
collectMetrics(JavaRDD<GATKRead>, SAMFileHeader) - Method in class org.broadinstitute.hellbender.tools.examples.metrics.single.ExampleCollectSingleMetricsSpark
Execute the actual metrics collection.
collectMetrics(JavaRDD<GATKRead>, SAMFileHeader) - Method in class org.broadinstitute.hellbender.tools.examples.metrics.single.ExampleSingleMetricsCollectorSpark
Do the actual metrics collection on the provided RDD.
collectMetrics(JavaRDD<GATKRead>, SAMFileHeader) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectInsertSizeMetricsSpark
 
collectMetrics(JavaRDD<GATKRead>, SAMFileHeader) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectQualityYieldMetricsSpark
 
collectMetrics(JavaRDD<GATKRead>, SAMFileHeader) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.InsertSizeMetricsCollectorSpark
 
collectMetrics(JavaRDD<GATKRead>, SAMFileHeader) - Method in interface org.broadinstitute.hellbender.tools.spark.pipelines.metrics.MetricsCollectorSpark
Do the actual metrics collection on the provided RDD.
collectMetrics(JavaRDD<GATKRead>, SAMFileHeader) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.MetricsCollectorSparkTool
 
collectMetrics(JavaRDD<GATKRead>, SAMFileHeader) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.QualityYieldMetricsCollectorSpark
Do the actual metrics collection on the provided RDD.
CollectMultipleMetrics - Class in picard.analysis
Class that is designed to instantiate and execute multiple metrics programs that extend SinglePassSamProgram while making only a single pass through the SAM file and supplying each program with the records as it goes.
CollectMultipleMetrics() - Constructor for class picard.analysis.CollectMultipleMetrics
 
CollectMultipleMetrics.Program - Enum in picard.analysis
 
CollectMultipleMetrics.ProgramInterface - Interface in picard.analysis
 
CollectMultipleMetricsSpark - Class in org.broadinstitute.hellbender.tools.spark.pipelines.metrics
Runs multiple metrics collection modules for a given alignment file.
CollectMultipleMetricsSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectMultipleMetricsSpark
 
CollectMultipleMetricsSpark.SparkCollectorProvider - Interface in org.broadinstitute.hellbender.tools.spark.pipelines.metrics
 
CollectMultipleMetricsSpark.SparkCollectors - Enum in org.broadinstitute.hellbender.tools.spark.pipelines.metrics
 
CollectOxoGMetrics - Class in picard.analysis
Class for trying to quantify the CpCG->CpCA error rate.
CollectOxoGMetrics() - Constructor for class picard.analysis.CollectOxoGMetrics
 
CollectOxoGMetrics.CpcgMetrics - Class in picard.analysis
Metrics class for outputs.
CollectQualityYieldMetrics - Class in picard.analysis
Command line program to calibrate quality yield metrics
CollectQualityYieldMetrics() - Constructor for class picard.analysis.CollectQualityYieldMetrics
 
CollectQualityYieldMetrics.QualityYieldMetrics - Class in picard.analysis
A set of metrics used to describe the general quality of a BAM file
CollectQualityYieldMetrics.QualityYieldMetricsCollector - Class in picard.analysis
 
CollectQualityYieldMetricsSpark - Class in org.broadinstitute.hellbender.tools.spark.pipelines.metrics
Collects quality yield metrics in SAM/BAM/CRAM file(s).
CollectQualityYieldMetricsSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectQualityYieldMetricsSpark
 
CollectRawWgsMetrics - Class in picard.analysis
Computes a number of metrics that are useful for evaluating coverage and performance of whole genome sequencing experiments, same implementation as CollectWgsMetrics, with different defaults: lacks baseQ and mappingQ filters and has much higher coverage cap.
CollectRawWgsMetrics() - Constructor for class picard.analysis.CollectRawWgsMetrics
 
CollectRawWgsMetrics.RawWgsMetrics - Class in picard.analysis
 
CollectReadCounts - Class in org.broadinstitute.hellbender.tools.copynumber
Collects read counts at specified intervals.
CollectReadCounts() - Constructor for class org.broadinstitute.hellbender.tools.copynumber.CollectReadCounts
 
CollectRnaSeqMetrics - Class in picard.analysis
 
CollectRnaSeqMetrics() - Constructor for class picard.analysis.CollectRnaSeqMetrics
 
CollectRrbsMetrics - Class in picard.analysis
Calculates and reports QC metrics for RRBS data based on the methylation status at individual C/G bases as well as CpG sites across all reads in the input BAM/SAM file.
CollectRrbsMetrics() - Constructor for class picard.analysis.CollectRrbsMetrics
 
CollectRrbsMetrics.CollectRrbsMetricsReferenceArgumentCollection - Class in picard.analysis
 
CollectRrbsMetricsReferenceArgumentCollection() - Constructor for class picard.analysis.CollectRrbsMetrics.CollectRrbsMetricsReferenceArgumentCollection
 
CollectSequencingArtifactMetrics - Class in picard.analysis.artifacts
Quantify substitution errors caused by mismatched base pairings during various stages of sample / library prep.
CollectSequencingArtifactMetrics() - Constructor for class picard.analysis.artifacts.CollectSequencingArtifactMetrics
 
CollectTargetedMetrics<METRIC extends MultilevelMetrics,COLLECTOR extends TargetMetricsCollector<METRIC>> - Class in picard.analysis.directed
Both CollectTargetedPCRMetrics and CollectHsSelection share virtually identical program structures except for the name of their targeting mechanisms (e.g.
CollectTargetedMetrics() - Constructor for class picard.analysis.directed.CollectTargetedMetrics
 
CollectTargetedPcrMetrics - Class in picard.analysis.directed
This tool calculates a set of PCR-related metrics from an aligned SAM or BAM file containing targeted sequencing data.
CollectTargetedPcrMetrics() - Constructor for class picard.analysis.directed.CollectTargetedPcrMetrics
 
CollectVariantCallingMetrics - Class in picard.vcf
Collects summary and per-sample metrics about variant calls in a VCF file.
CollectVariantCallingMetrics() - Constructor for class picard.vcf.CollectVariantCallingMetrics
 
CollectVariantCallingMetrics.VariantCallingDetailMetrics - Class in picard.vcf
A collection of metrics relating to snps and indels within a variant-calling file (VCF) for a given sample.
CollectVariantCallingMetrics.VariantCallingSummaryMetrics - Class in picard.vcf
A collection of metrics relating to snps and indels within a variant-calling file (VCF).
CollectWgsMetrics - Class in picard.analysis
Computes a number of metrics that are useful for evaluating coverage and performance of whole genome sequencing experiments.
CollectWgsMetrics() - Constructor for class picard.analysis.CollectWgsMetrics
 
CollectWgsMetrics.CollectWgsMetricsIntervalArgumentCollection - Class in picard.analysis
 
CollectWgsMetrics.WgsMetrics - Class in picard.analysis
Metrics for evaluating the performance of whole genome sequencing experiments.
CollectWgsMetrics.WgsMetricsCollector - Class in picard.analysis
 
CollectWgsMetricsIntervalArgumentCollection() - Constructor for class picard.analysis.CollectWgsMetrics.CollectWgsMetricsIntervalArgumentCollection
 
CollectWgsMetricsWithNonZeroCoverage - Class in picard.analysis
 
CollectWgsMetricsWithNonZeroCoverage() - Constructor for class picard.analysis.CollectWgsMetricsWithNonZeroCoverage
 
CollectWgsMetricsWithNonZeroCoverage.WgsMetricsWithNonZeroCoverage - Class in picard.analysis
Metrics for evaluating the performance of whole genome sequencing experiments.
CollectWgsMetricsWithNonZeroCoverage.WgsMetricsWithNonZeroCoverage.Category - Enum in picard.analysis
 
CollectWgsMetricsWithNonZeroCoverage.WgsMetricsWithNonZeroCoverageCollector - Class in picard.analysis
 
COLOR_STATUS - Static variable in class picard.cmdline.CommandLineDefaults
Implementation note, this is duplicate code stolen from HTSJDK's Default.java /** Decides if we want to write colors to the terminal.
COLUMN_SEPARATOR - Static variable in class org.broadinstitute.hellbender.utils.tsv.TableUtils
Column separator .
COLUMN_SEPARATOR_STRING - Static variable in class org.broadinstitute.hellbender.utils.tsv.TableUtils
Column separator as an string.
columnCount() - Method in class org.broadinstitute.hellbender.utils.codecs.table.TableFeature
Gets the number of columns in the feature.
columnCount() - Method in class org.broadinstitute.hellbender.utils.tsv.TableColumnCollection
Returns the number of columns.
columnLabels() - Method in class picard.util.DelimitedTextFileWithHeaderIterator
 
columnLabels() - Method in class picard.util.TabbedTextFileWithHeaderParser
 
columnLabelsList() - Method in class picard.util.TabbedTextFileWithHeaderParser
 
columnMeans(RealMatrix) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Calculates the mean per column from a matrix.
COLUMNS - Static variable in enum org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasFilterSummaryTableColumn
 
COLUMNS - Static variable in enum org.broadinstitute.hellbender.utils.mcmc.ParameterTableColumn
 
columns() - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Returns the column collection for this data-line instance.
columns() - Method in class org.broadinstitute.hellbender.utils.tsv.TableReader
Returns the column collection for this reader.
COLUMNS_OF_INTEREST_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.utils.CombineSegmentBreakpoints
 
columnStdDevs(RealMatrix) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Calculates the standard deviation per column from a matrix.
columnSums(RealMatrix) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Return an array with column sums in each entry
combine(InsertSizeMetricsCollector, InsertSizeMetricsCollector) - Method in class org.broadinstitute.hellbender.metrics.InsertSizeMetricsCollector
Combine two InsertSizeMetricsCollector objects and return a single InsertSizeMetricsCollector object representing the combined results.
combine(MultiLevelReducibleCollector<METRIC_TYPE, HISTOGRAM_KEY, ARGTYPE, UNIT_COLLECTOR>) - Method in class org.broadinstitute.hellbender.metrics.MultiLevelReducibleCollector
Combine a source MultiLevelReducibleCollector object into this MultiLevelReducibleCollector.
combine(PerUnitInsertSizeMetricsCollector) - Method in class org.broadinstitute.hellbender.metrics.PerUnitInsertSizeMetricsCollector
Combine this PerUnitInsertSizeMetricsCollector with sourceCollector and return a combined PerUnitInsertSizeMetricsCollector.
combine(QualityYieldMetrics) - Method in class org.broadinstitute.hellbender.metrics.QualityYieldMetrics
 
combine(ExampleMultiMetrics) - Method in class org.broadinstitute.hellbender.tools.examples.metrics.multi.ExampleMultiMetrics
Combines two ExampleMultiMetrics objects
combine(ExampleMultiMetricsCollector, ExampleMultiMetricsCollector) - Static method in class org.broadinstitute.hellbender.tools.examples.metrics.multi.ExampleMultiMetricsCollector
Combine two ExampleMultiMetricsCollector objects and return a single ExampleMultiMetricsCollector object representing the combined results.
combine(PerUnitExampleMultiMetricsCollector) - Method in class org.broadinstitute.hellbender.tools.examples.metrics.multi.PerUnitExampleMultiMetricsCollector
Combine this PerUnitExampleMultiMetricsCollector with sourceCollector and return a combined PerUnitExampleMultiMetricsCollector.
combine(ExampleSingleMetrics) - Method in class org.broadinstitute.hellbender.tools.examples.metrics.single.ExampleSingleMetrics
 
combine(RecalDatum) - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalDatum
Add in all of the data from other into this object, updating the reported quality from the expected error rate implied by the two reported qualities
combine(RecalibrationReport) - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationReport
Combines two recalibration reports by adding all observations and errors Note: This method DOES NOT recalculate the empirical qualities and quantized qualities.
combine(RecalibrationTables) - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationTables
Merge all of the tables from toMerge into into this set of tables
combineAdjacentCigarElements(Cigar) - Static method in class org.broadinstitute.hellbender.utils.read.CigarUtils
Combines equal adjacent elements of a Cigar object
combineAndSortBreakpoints(List<T>, List<T>, SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Combine the breakpoints of multiple intervals and return a list of locatables based on the updated breakpoints.
combineAnnotations(List<Allele>, Map<String, List<?>>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotatorEngine
Combine (raw) data for reducible annotations (those that use raw data in gVCFs) Mutates annotationMap by removing the annotations that were combined Additionally, will combine other annotations by parsing them as numbers and reducing them down to the
combineAttributeMap(ReducibleAnnotationData<Histogram>, ReducibleAnnotationData<Histogram>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RankSumTest
 
combineAttributeMap(ReducibleAnnotationData<Double>, ReducibleAnnotationData<Double>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RMSMappingQuality
 
combineAttributeMap(ReducibleAnnotationData<List<Integer>>, ReducibleAnnotationData<List<Integer>>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_StrandBiasTest
 
combineAttributeMap(ReducibleAnnotationData<Double>, ReducibleAnnotationData<Double>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.RMSMappingQuality
 
CombineGVCFs - Class in org.broadinstitute.hellbender.tools.walkers
Combine per-sample gVCF files produced by HaplotypeCaller into a multi-sample gVCF file
CombineGVCFs() - Constructor for class org.broadinstitute.hellbender.tools.walkers.CombineGVCFs
 
combineRawData(List<Allele>, List<ReducibleAnnotationData<?>>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_QualByDepth
Note there is no raw annotation data for AS_QualByDepth and thus data cannot be combined
combineRawData(List<Allele>, List<ReducibleAnnotationData<?>>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RankSumTest
Parses expected raw data strings per-allele, which are in the form of run length encoded histograms and combines them by summing the counts for each histogram bin, producing a new set histograms for each output allele.
combineRawData(List<Allele>, List<ReducibleAnnotationData<?>>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RMSMappingQuality
For AS_RMSMappingQuality annotations, the annotations will simply consist of a list of the total value for every allele computed by parsing all of the individual AS_RMSMappingQuality Raw Key values as doubles and totaling them.
combineRawData(List<Allele>, List<ReducibleAnnotationData<?>>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_StrandBiasTest
Method which combines the per allele contingency tables from the underlying variant contexts by totaling supported values for both forward and reverse data and outputting it as a new contingency table.
combineRawData(List<Allele>, List<ReducibleAnnotationData<?>>) - Method in interface org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.ReducibleAnnotation
Combine raw data, typically during the merging of raw data contained in multiple gVCFs as in CombineGVCFs and the preliminary merge for GenotypeGVCFs
combineRawData(List<Allele>, List<ReducibleAnnotationData<?>>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.RMSMappingQuality
 
CombineSegmentBreakpoints - Class in org.broadinstitute.hellbender.tools.copynumber.utils
 
CombineSegmentBreakpoints() - Constructor for class org.broadinstitute.hellbender.tools.copynumber.utils.CombineSegmentBreakpoints
 
combineTables(NestedIntegerArray<RecalDatum>, NestedIntegerArray<RecalDatum>) - Static method in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
Combines the recalibration data for table1 and table2 into table1 Note that table1 is the destination, so it is modified
combineUnit(PerUnitInsertSizeMetricsCollector, PerUnitInsertSizeMetricsCollector) - Method in class org.broadinstitute.hellbender.metrics.InsertSizeMetricsCollector
Combine two PerUnitInsertSizeMetricsCollector objects and return a single PerUnitInsertSizeMetricsCollector object representing the combined results.
combineUnit(UNIT_COLLECTOR, UNIT_COLLECTOR) - Method in class org.broadinstitute.hellbender.metrics.MultiLevelReducibleCollector
Combined two UNIT_COLLECTOR objects into a single object representing the combined collectors.
combineUnit(PerUnitExampleMultiMetricsCollector, PerUnitExampleMultiMetricsCollector) - Method in class org.broadinstitute.hellbender.tools.examples.metrics.multi.ExampleMultiMetricsCollector
Combine two PerUnitExampleMultiMetricsCollector objects and return a single PerUnitExampleMultiMetricsCollector object representing the combined results.
combiningResultsBy(VariantProcessor.ResultMerger<R>) - Method in class picard.vcf.processor.VariantProcessor.Builder
 
CommandLineDefaults - Class in picard.cmdline
Embodies defaults for global values that affect how the Picard Command Line operates.
CommandLineDefaults() - Constructor for class picard.cmdline.CommandLineDefaults
 
CommandLineProgram - Class in org.broadinstitute.hellbender.cmdline
Abstract class to facilitate writing command-line programs.
CommandLineProgram() - Constructor for class org.broadinstitute.hellbender.cmdline.CommandLineProgram
 
CommandLineProgram - Class in picard.cmdline
Abstract class to facilitate writing command-line programs.
CommandLineProgram() - Constructor for class picard.cmdline.CommandLineProgram
 
CommandLineProgramTester - Interface in org.broadinstitute.hellbender.utils.test
Utility interface for CommandLine Program testing.
CommandLineSyntaxTranslater - Class in picard.cmdline
Class for handling translation of Picard-style command line argument syntax to POSIX-style argument syntax; used for running tests written with Picard style syntax against the Barclay command line parser.
CommandLineSyntaxTranslater() - Constructor for class picard.cmdline.CommandLineSyntaxTranslater
 
COMMENT - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.AbstractMarkDuplicatesCommandLineProgram
 
COMMENT - Variable in class picard.sam.AddCommentsToBam
 
COMMENT - Variable in class picard.sam.FastqToSam
 
COMMENT - Variable in class picard.sam.markduplicates.util.AbstractMarkDuplicatesCommandLineProgram
 
COMMENT - Variable in class picard.sam.MergeSamFiles
 
COMMENT - Variable in class picard.util.IntervalListTools
 
COMMENT_DELIMITER - Static variable in class org.broadinstitute.hellbender.utils.codecs.table.TableCodec
 
COMMENT_PREFIX - Static variable in class org.broadinstitute.hellbender.utils.tsv.TableUtils
Comment line prefix string "#".
COMMENT_START - Static variable in class org.broadinstitute.hellbender.engine.filters.ReadGroupBlackListReadFilter
 
COMMENT_STRING - Static variable in class org.broadinstitute.hellbender.tools.walkers.vqsr.Tranche
 
commonMaximumPrefixLength(List<byte[]>) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.GraphUtils
Compute the maximum shared prefix length of list of bytes.
commonMaximumSuffixLength(List<byte[]>, int) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.GraphUtils
Compute the maximum shared suffix length of list of bytes.
CommonSuffixSplitter - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs
Split a collection of middle nodes in a graph into their shared prefix and suffix values This code performs the following transformation.
commonToString() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
A human-digestable representation of the read.
compactifyNeighboringSoftClippings(List<CigarElement>) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SvCigarUtils
Compactify two neighboring soft clippings, one of which was converted from an insertion operation.
compare(PairedEnds, PairedEnds) - Method in class org.broadinstitute.hellbender.tools.spark.transforms.markduplicates.MarkDuplicatesSparkUtils.PairedEndsCoordinateComparator
 
compare(T, T) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.Tranche.TrancheComparator
 
compare(TruthSensitivityTranche, TruthSensitivityTranche) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.Tranche.TrancheTruthSensitivityComparator
 
compare(SAMRecord, SAMRecord) - Method in class org.broadinstitute.hellbender.utils.read.HeaderlessSAMRecordCoordinateComparator
 
compare(GATKRead, GATKRead) - Method in class org.broadinstitute.hellbender.utils.read.ReadCoordinateComparator
 
compare(GATKRead, GATKRead) - Method in class org.broadinstitute.hellbender.utils.read.ReadQueryNameComparator
 
compare(int, int) - Static method in class picard.util.MathUtil
 
COMPARE_STRINGS_NULLS_FIRST - Static variable in class org.broadinstitute.hellbender.utils.Utils
Comparator for strings that sorts null first;
CompareBaseQualities - Class in org.broadinstitute.hellbender.tools.validation
Compares the base qualities of two SAM/BAM/CRAM files.
CompareBaseQualities() - Constructor for class org.broadinstitute.hellbender.tools.validation.CompareBaseQualities
 
compareContigs(GenomeLoc) - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
conpare this genomeLoc's contig to another genome loc
compareContigs(Locatable, Locatable, SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Determines the relative contig ordering of first and second using the provided sequence dictionary
compareCoordinates(PairedEnds, PairedEnds) - Static method in class org.broadinstitute.hellbender.tools.spark.transforms.markduplicates.MarkDuplicatesSparkUtils.PairedEndsCoordinateComparator
 
compareCoordinates(GATKRead, GATKRead, SAMFileHeader) - Static method in class org.broadinstitute.hellbender.utils.read.ReadCoordinateComparator
 
compareDictionaries(SAMSequenceDictionary, SAMSequenceDictionary, boolean) - Static method in class org.broadinstitute.hellbender.utils.SequenceDictionaryUtils
Workhorse routine that takes two dictionaries and returns their compatibility.
compareDoubles(double, double) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Compares double values for equality (within 1e-6), or inequality.
compareDoubles(double, double, double) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Compares double values for equality (within epsilon), or inequality.
CompareDuplicatesSpark - Class in org.broadinstitute.hellbender.tools.spark.validation
Determine if two potentially identical BAMs have the same duplicate reads.
CompareDuplicatesSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.validation.CompareDuplicatesSpark
 
compareLocatables(Locatable, Locatable, SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Compare two locations using a SAMSequenceDictionary sequence ordering
CompareMatrix - Class in org.broadinstitute.hellbender.tools.validation
CompareMatrix contains a square matrix of linear dimension QualityUtils.MAX_SAM_QUAL_SCORE.
CompareMatrix(byte[]) - Constructor for class org.broadinstitute.hellbender.tools.validation.CompareMatrix
 
CompareMetrics - Class in picard.analysis
Compare two metrics files.
CompareMetrics() - Constructor for class picard.analysis.CompareMetrics
 
compareReadNames(GATKRead, GATKRead) - Method in class org.broadinstitute.hellbender.utils.read.ReadQueryNameComparator
compare read names lexicographically without any additional tie breakers
compareReportArguments(RecalibrationArgumentCollection, String, String) - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationArgumentCollection
Returns a map with the arguments that differ between this an another RecalibrationArgumentCollection instance.
CompareSAMs - Class in picard.sam
Rudimentary SAM comparer.
CompareSAMs() - Constructor for class picard.sam.CompareSAMs
 
compareTo(IntegerCopyNumberState) - Method in class org.broadinstitute.hellbender.tools.copynumber.gcnv.IntegerCopyNumberState
 
compareTo(SVInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVInterval
 
compareTo(SVKmerLong) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerLong
SVKmerLong comparison is consistent with equals.
compareTo(SVKmerShort) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerShort
SVKmerShort comparison is consistent with equals.
compareTo(SVLocation) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVLocation
 
compareTo(GenotypeAlleleCounts) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeAlleleCounts
Compares to genotypes.
compareTo(KBestHaplotype) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KBestHaplotype
Compares k-best haplotypes based on the score where the one with larger score comes first (descending orther).
compareTo(VQSLODTranche) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VQSLODTranche
 
compareTo(GencodeGtfFeature) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
Comparable interface implementation for GencodeGtfFeature.
compareTo(GenomeLoc) - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
 
compareTo(DocWorkUnit) - Method in class org.broadinstitute.hellbender.utils.help.GATKDocWorkUnit
Sort in order of the name of this WorkUnit
compareTo(PrimaryAlignmentKey) - Method in class org.broadinstitute.hellbender.utils.read.PrimaryAlignmentKey
 
compareTo(QualQuantizer.QualInterval) - Method in class org.broadinstitute.hellbender.utils.recalibration.QualQuantizer.QualInterval
 
compareTo(Sample) - Method in class org.broadinstitute.hellbender.utils.samples.Sample
 
compareTo(SequencingArtifactMetrics.BaitBiasDetailMetrics) - Method in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasDetailMetrics
 
compareTo(SequencingArtifactMetrics.PreAdapterDetailMetrics) - Method in class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterDetailMetrics
 
compareTo(Gene) - Method in class picard.annotation.Gene
 
compareTo(HaplotypeBlock) - Method in class picard.fingerprint.HaplotypeBlock
 
compareTo(MatchResults) - Method in class picard.fingerprint.MatchResults
Provides a natural sort so that better matches (by LOD) sort earlier.
compareTo(Snp) - Method in class picard.fingerprint.Snp
 
compareTo(GenotypeConcordanceStates.TruthAndCallStates) - Method in class picard.vcf.GenotypeConcordanceStates.TruthAndCallStates
 
complement() - Method in enum org.broadinstitute.hellbender.utils.artifacts.Transition
Return the complementary transition.
complement() - Method in enum picard.analysis.artifacts.Transition
Return the complementary transition.
ComplexityPartitioner - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
A Spark Partitioner that puts tasks with greater complexities into earlier partitions.
ComplexityPartitioner(int[]) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.ComplexityPartitioner
 
compose(ReadTransformer) - Method in interface org.broadinstitute.hellbender.transformers.ReadTransformer
 
composeAlleleFrequencyPriorProvider(int, double, List<Double>) - Static method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
Function that fills vector with allele frequency priors.
composeCallAttributes(boolean, VariantContext, AlignmentContext, Map<String, AlignmentContext>, FeatureContext, ReferenceContext, List<Integer>, boolean, AFCalculationResult, List<Allele>, GenotypesContext, GenotypeLikelihoodsCalculationModel, ReadLikelihoods<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
 
composeGivenAllelesVariantContextFromRod(FeatureContext, Locatable, boolean, boolean, Logger, FeatureInput<VariantContext>) - Static method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingGivenAllelesUtils
Composes the given allele variant-context providing information about the rods and reference location.
composeGivenHaplotypes(Haplotype, List<VariantContext>, GenomeLoc) - Static method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingGivenAllelesUtils
Create the list of artificial GGA-mode haplotypes by injecting each of the provided alternate alleles into the reference haplotype
composeHaplotypeBasedOnReference(int, int, ReferenceMultiSource) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVContext
Composes the haplotype that corresponds to an allele based on the reference sequence.
composeLine(ConcordanceSummaryRecord, DataLine) - Method in class org.broadinstitute.hellbender.tools.walkers.validation.ConcordanceSummaryRecord.Writer
 
composeLine(Map.Entry<T, PosteriorSummary>, DataLine) - Method in class org.broadinstitute.hellbender.utils.mcmc.ParameterWriter
 
composeLine(R, DataLine) - Method in class org.broadinstitute.hellbender.utils.tsv.TableWriter
Composes the data-line to write into the output to represent a given record
composeVariantContextHeader(Set<VCFHeaderLine>) - Method in class org.broadinstitute.hellbender.tools.copynumber.gcnv.GermlineCNVIntervalVariantComposer
 
composeVariantContextHeader(Set<VCFHeaderLine>) - Method in class org.broadinstitute.hellbender.tools.copynumber.gcnv.GermlineCNVSegmentVariantComposer
 
COMPRESS_OUTPUTS - Variable in class picard.illumina.ExtractIlluminaBarcodes
 
COMPRESS_OUTPUTS - Variable in class picard.illumina.IlluminaBasecallsToFastq
 
COMPRESS_OUTPUTS_PER_RG - Variable in class picard.sam.SamToFastq
 
COMPRESS_OUTPUTS_PER_TAG_GROUP - Variable in class picard.sam.SamToFastqWithTags
 
CompressedDataList<T> - Class in org.broadinstitute.hellbender.utils
A class to represent data as a list of pairs.
CompressedDataList() - Constructor for class org.broadinstitute.hellbender.utils.CompressedDataList
 
COMPRESSION_LEVEL - Variable in class org.broadinstitute.hellbender.cmdline.PicardCommandLineProgram
 
COMPRESSION_LEVEL - Variable in class picard.cmdline.CommandLineProgram
 
comps - Variable in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotator
If a call overlaps with a record from the provided comp track, the INFO field will be annotated as such in the output with the track name (e.g.
comps - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerArgumentCollection
If a call overlaps with a record from the provided comp track, the INFO field will be annotated as such in the output with the track name (e.g.
COMPUTE_SLOD - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.UnifiedArgumentCollection
Note that calculating the SLOD increases the runtime by an appreciable amount.
computeAlleleFrequencyPriors(int, double[], double, List<Double>) - Static method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
Function that fills vector with allele frequency priors.
computeAssociatedDistOnRead(Cigar, int, int, boolean) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SvCigarUtils
Computes the corresponding distance needs to be walked on the read, given the Cigar and distance walked on the reference.
computeAssociatedDistOnRef(Cigar, int, int) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SvCigarUtils
Computes the corresponding distance needs to be walked on the reference, given the Cigar and distance walked on the read.
computeCovariates(GATKRead, SAMFileHeader, StandardCovariateList, boolean, CovariateKeyCache) - Static method in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
Computes all requested covariates for every offset in the given read by calling covariate.getValues(..).
computeCovariates(GATKRead, SAMFileHeader, StandardCovariateList, ReadCovariates, boolean) - Static method in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
Computes all requested covariates for every offset in the given read by calling covariate.getValues(..).
computeDerivedMetrics() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterMetrics
Computes number of reads filtered at each step and total final reads.
computeDiploidGenotypeCounts(VariantContext, GenotypesContext, boolean) - Static method in class org.broadinstitute.hellbender.utils.GenotypeUtils
Returns a triple of ref/het/hom genotype "counts".
computeForwardClipping(List<Allele>) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Clip out any unnecessary bases off the front of the alleles The VCF spec represents alleles as block substitutions, replacing AC with A for a 1 bp deletion of the C.
computeIndelBQSRTables - Variable in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationArgumentCollection
 
computeLog10Likelihoods(LikelihoodMatrix<Haplotype>, List<GATKRead>, Map<GATKRead, byte[]>) - Method in class org.broadinstitute.hellbender.utils.pairhmm.PairHMM
Given a list of reads and haplotypes, for every read compute the total probability of said read arising from each haplotype given base substitution, insertion, and deletion probabilities.
computeLog10Likelihoods(LikelihoodMatrix<Haplotype>, List<GATKRead>, Map<GATKRead, byte[]>) - Method in class org.broadinstitute.hellbender.utils.pairhmm.VectorLoglessPairHMM
Given a list of reads and haplotypes, for every read compute the total probability of said read arising from each haplotype given base substitution, insertion, and deletion probabilities.
computeLog10PNonRef(VariantContext, int, double[], StateTracker) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculator
Actually carry out the log10PNonRef calculation on vc, storing results in results
computeLog10PNonRef(VariantContext, int, double[], StateTracker) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AlleleFrequencyCalculator
 
computeLog10PNonRef(VariantContext, int, double[], StateTracker) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.GeneralPloidyExactAFCalculator
 
computeLog10PNonRef(VariantContext, int, double[], StateTracker) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.IndependentAllelesDiploidExactAFCalculator
 
computeLog10PNonRef(VariantContext, int, double[], StateTracker) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.ReferenceDiploidExactAFCalculator
 
computeMaxAcceptableAlleleCount(int, int) - Static method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeLikelihoodCalculators
Compute the maximally acceptable allele count (ref allele included) given the maximally acceptable genotype count.
computeReadLikelihoods(AssemblyResultSet, SampleList, Map<String, List<GATKRead>>) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.PairHMMLikelihoodCalculationEngine
 
computeReadLikelihoods(AssemblyResultSet, SampleList, Map<String, List<GATKRead>>) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.RandomLikelihoodCalculationEngine
 
computeReadLikelihoods(AssemblyResultSet, SampleList, Map<String, List<GATKRead>>) - Method in interface org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadLikelihoodCalculationEngine
Calculates the likelihood of reads across many samples evaluated against haplotypes resulting from the active region assembly process.
computeReverseClipping(List<Allele>, byte[]) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
 
computeTaxScores(Iterator<PSPathogenAlignmentHit>, PSTaxonomyDatabase, boolean) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScorer
Computes abundance scores and returns key-values of taxonomic id and scores
CON_ALT_BASES - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterDetailMetrics
The number of REF_BASE:ALT_BASE alignments having a read number and orientation that refutes the presence of this artifact.
CON_REF_BASES - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterDetailMetrics
The number of REF_BASE:REF_BASE alignments having a read number and orientation that refutes the presence of this artifact.
concat(GATKReport) - Method in class org.broadinstitute.hellbender.utils.report.GATKReport
This is the main function is charge of gathering the reports.
concat(GATKReportTable) - Method in class org.broadinstitute.hellbender.utils.report.GATKReportTable
Concatenates the rows from the table to this one
concat(byte[]...) - Static method in class org.broadinstitute.hellbender.utils.Utils
Concatenates byte arrays
concatenateLists(List<T>, List<T>) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVUtils
Concatenate two lists.
concatIterators(Iterator<Iterator<T>>) - Static method in class org.broadinstitute.hellbender.tools.spark.utils.FlatMapGluer
 
concatIterators(Iterator<? extends Iterable<T>>) - Static method in class org.broadinstitute.hellbender.utils.Utils
Concatenates a series of Iterators (all of the same type) into a single Iterator.
Concordance - Class in org.broadinstitute.hellbender.tools.walkers.validation
Evaluate site-level concordance of an input VCF against a truth VCF.
Concordance() - Constructor for class org.broadinstitute.hellbender.tools.walkers.validation.Concordance
 
ConcordanceState - Enum in org.broadinstitute.hellbender.tools.walkers.validation
Created by davidben on 3/2/17.
ConcordanceSummaryRecord - Class in org.broadinstitute.hellbender.tools.walkers.validation
Created by tsato on 2/8/17.
ConcordanceSummaryRecord(VariantContext.Type, long, long, long) - Constructor for class org.broadinstitute.hellbender.tools.walkers.validation.ConcordanceSummaryRecord
 
ConcordanceSummaryRecord.Reader - Class in org.broadinstitute.hellbender.tools.walkers.validation
 
ConcordanceSummaryRecord.Writer - Class in org.broadinstitute.hellbender.tools.walkers.validation
 
CONCRETE_TYPES - Static variable in enum org.broadinstitute.hellbender.tools.walkers.variantutils.ValidateVariants.ValidationType
Unmodifiable set of concrete validation types.
ConcurrentAFCalculatorProvider - Class in org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc
Produces independent AF calculators per thread.
ConcurrentAFCalculatorProvider() - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.ConcurrentAFCalculatorProvider
Create a new concurrent af-calculator provider instance.
confidence - Variable in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods.BestAllele
Confidence that the read actually was generated under that likelihood.
CONFIDENCE_REGION_LONG_NAME - Static variable in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker
 
CONFIDENCE_REGION_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker
 
confidentlyCalled(double, double) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
Checks whether a variant site seems confidently called base on user threshold that the score provided by the exact model.
CONFIG_FILE_CONTIG_COLUMN_KEY - Static variable in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvLocatableTableCodec
 
CONFIG_FILE_DATA_SOURCE_NAME_KEY - Static variable in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvLocatableTableCodec
 
CONFIG_FILE_DELIMITER_KEY - Static variable in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvLocatableTableCodec
 
CONFIG_FILE_END_COLUMN_KEY - Static variable in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvLocatableTableCodec
 
CONFIG_FILE_FIELD_NAME_CONTIG_COLUMN - Static variable in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
 
CONFIG_FILE_FIELD_NAME_END_COLUMN - Static variable in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
 
CONFIG_FILE_FIELD_NAME_GENCODE_FASTA_PATH - Static variable in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
 
CONFIG_FILE_FIELD_NAME_NAME - Static variable in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
 
CONFIG_FILE_FIELD_NAME_ORIGIN_LOCATION - Static variable in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
 
CONFIG_FILE_FIELD_NAME_PREPROCESSING_SCRIPT - Static variable in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
 
CONFIG_FILE_FIELD_NAME_SRC_FILE - Static variable in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
 
CONFIG_FILE_FIELD_NAME_START_COLUMN - Static variable in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
 
CONFIG_FILE_FIELD_NAME_TYPE - Static variable in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
 
CONFIG_FILE_FIELD_NAME_VERSION - Static variable in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
 
CONFIG_FILE_FIELD_NAME_XSV_DELIMITER - Static variable in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
 
CONFIG_FILE_FIELD_NAME_XSV_KEY - Static variable in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
 
CONFIG_FILE_FIELD_NAME_XSV_KEY_COLUMN - Static variable in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
 
CONFIG_FILE_FIELD_NAME_XSV_PERMISSIVE_COLS - Static variable in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
 
CONFIG_FILE_START_COLUMN_KEY - Static variable in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvLocatableTableCodec
 
CONFIG_FILE_VARIABLE_CLASS_PATH - Static variable in interface org.broadinstitute.hellbender.utils.config.GATKConfig
Name of the configuration file variable to be used in the Config.Sources annotation for GATKConfig as a place to find the configuration file corresponding to this interface.
CONFIG_FILE_VARIABLE_FILE_NAME - Static variable in interface org.broadinstitute.hellbender.utils.config.GATKConfig
Name of the configuration file variable to be used in the Config.Sources annotation for GATKConfig as a place to find the configuration file corresponding to this interface.
ConfigFactory - Class in org.broadinstitute.hellbender.utils.config
A singleton class to act as a user interface for loading configuration files from org.aeonbits.owner.
configuration - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
 
cons(T, List<T>) - Static method in class org.broadinstitute.hellbender.utils.Utils
 
consensusMode - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadThreadingAssemblerArgumentCollection
This argument is specifically intended for 1000G consensus analysis mode.
CONSOLIDATE_ARG_NAME - Static variable in class org.broadinstitute.hellbender.tools.genomicsdb.GenomicsDBImport
 
consolidateCigar(Cigar) - Static method in class org.broadinstitute.hellbender.utils.read.AlignmentUtils
Need a well-formed, consolidated Cigar string so that the left aligning code works properly.
constantsAreInitialized - Variable in class org.broadinstitute.hellbender.utils.pairhmm.PairHMM
 
constructHaplotypeMapping(List<VariantContext>, Set<Haplotype>) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerGenotypingEngine
Construct the mapping from alternate allele to the set of haplotypes that contain that allele
constructPhaseGroups(List<VariantContext>, Map<VariantContext, Pair<Integer, String>>, int) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerGenotypingEngine
Assemble the phase groups together and update the original calls accordingly
constructPhaseSetMapping(List<VariantContext>, Map<VariantContext, Set<Haplotype>>, int, Map<VariantContext, Pair<Integer, String>>) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerGenotypingEngine
Construct the mapping from call (variant context) to phase set ID
constructStaticQuantizedMapping(List<Integer>, boolean) - Static method in class org.broadinstitute.hellbender.transformers.BQSRReadTransformer
Constructs an array that maps particular quantized values to a rounded value in staticQuantizedQuals Rounding is done in probability space.
consumeCachedReads() - Method in class org.broadinstitute.hellbender.utils.iterators.ReadCachingIterator
 
consumeFinalizedItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.Downsampler
Return (and *remove*) all items that have survived downsampling and are waiting to be retrieved.
consumeFinalizedItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.FractionalDownsampler
 
consumeFinalizedItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.LevelingDownsampler
 
consumeFinalizedItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.MutectDownsampler
 
consumeFinalizedItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.PassThroughDownsampler
Note that this list is a linked list and so doesn't support fast random access
consumeFinalizedItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.PositionalDownsampler
 
consumeFinalizedItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.ReservoirDownsampler
 
containedInRegionToIgnore(SVInterval, SVIntervalTree<SVInterval>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.SVReadFilter
 
contains(SVKmerShort) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerBloomFilter
Input should not be canonicalized/masked
contains(SVKmerShort) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerSet
Input should not be canonicalized/masked
contains(PairedStrandedIntervals) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.PairedStrandedIntervalTree
 
contains(Object) - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchCollection
 
contains(long) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LargeLongHopscotchSet
 
contains(long) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongBloomFilter
 
contains(long) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongHopscotchSet
 
contains(long, int) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongHopscotchSet
 
contains(Locatable) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
Checks if other is contained within this GencodeGtfFeature.
contains(int) - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
Checks whether a integer value is included in the set.
contains(Object) - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
 
contains(Object) - Method in class org.broadinstitute.hellbender.utils.collections.IndexedSet
 
contains(Locatable) - Method in class org.broadinstitute.hellbender.utils.SimpleInterval
Determines whether this interval contains the entire region represented by other (in other words, whether it covers it).
contains(String) - Method in class org.broadinstitute.hellbender.utils.tsv.TableColumnCollection
Check whether there is such a column by name.
contains(Snp) - Method in class picard.fingerprint.HaplotypeBlock
Returns true if the SNP is contained within the haplotype block, false otherwise.
containsAll(long[]) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LargeLongHopscotchSet
 
containsAll(long[]) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongBloomFilter
 
containsAll(long[]) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongHopscotchSet
 
containsAll(Collection<?>) - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
 
containsAll(String...) - Method in class org.broadinstitute.hellbender.utils.tsv.TableColumnCollection
Checks whether columns contain all the names in an array.
containsAll(Iterable<String>) - Method in class org.broadinstitute.hellbender.utils.tsv.TableColumnCollection
Checks whether columns contain all the names in an array.
containsAllele(int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeAlleleCounts
Checks whether this genotype contain at least one call on a particular allele index.
containsAllele(A) - Method in interface org.broadinstitute.hellbender.utils.genotyper.AlleleList
Returns true if this AlleleList contains the specified allele and false otherwise.
containsAllVertices(Collection<? extends V>) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Checks whether the graph contains all the vertices in a collection.
containsExactly(String...) - Method in class org.broadinstitute.hellbender.utils.tsv.TableColumnCollection
Checks whether columns contain all the names in an array and no other.
containsGapOfEqualOrLargerSize(int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
 
containsIndelLargerOrSmallerThan(VariantContext, int, int) - Static method in class org.broadinstitute.hellbender.tools.walkers.variantutils.SelectVariants
 
ContainsKmerReadFilter - Class in org.broadinstitute.hellbender.tools.spark.pathseq
Keep reads that do NOT contain one or more kmers from a set of SVKmerShorts
ContainsKmerReadFilter(String, int) - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.ContainsKmerReadFilter
 
ContainsKmerReadFilterSpark - Class in org.broadinstitute.hellbender.tools.spark.pathseq
Wrapper for ContainsKmerReadFilter to avoid serializing the kmer filter in Spark
ContainsKmerReadFilterSpark(String, int) - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.ContainsKmerReadFilterSpark
 
containsNoNull(Collection<?>, String) - Static method in class org.broadinstitute.hellbender.utils.Utils
Checks that the collection does not contain a null value (throws an IllegalArgumentException if it does).
containsNOperator(Cigar) - Static method in class org.broadinstitute.hellbender.utils.read.CigarUtils
Returns whether the cigar has any N operators.
containsNOperator(List<CigarElement>) - Static method in class org.broadinstitute.hellbender.utils.read.CigarUtils
Returns whether the list has any N operators.
containsOnRead(AlignmentInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
 
containsOnRef(AlignmentInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
 
containsP(GenomeLoc) - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
 
containsVertex(T) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.Path
Does this path contain the given vertex?
contamination - Variable in class picard.fingerprint.HaplotypeProbabilitiesFromContaminatorSequence
 
CONTAMINATION - Variable in class picard.fingerprint.IdentifyContaminant
 
CONTAMINATION_FILTER_NAME - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
CONTAMINATION_FRACTION - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.StandardCallerArgumentCollection
If this fraction is greater is than zero, the caller will aggressively attempt to remove contamination through biased down-sampling of reads.
CONTAMINATION_FRACTION_FILE - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.StandardCallerArgumentCollection
This argument specifies a file with two columns "sample" and "contamination" specifying the contamination level for those samples.
CONTAMINATION_TABLE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
contaminationDownsampling(Map<String, Double>) - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Downsamples reads based on contamination fractions making sure that all alleles are affected proportionally.
contaminationDownsampling(Map<String, Double>) - Method in class org.broadinstitute.hellbender.utils.genotyper.UnfilledReadsLikelihoods
 
ContaminationRecord - Class in org.broadinstitute.hellbender.tools.walkers.contamination
Created by David Benjamin on 2/13/17.
ContaminationRecord(String, double, double) - Constructor for class org.broadinstitute.hellbender.tools.walkers.contamination.ContaminationRecord
 
ContaminationRecord.Level - Enum in org.broadinstitute.hellbender.tools.walkers.contamination
 
contaminationTable - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
CONTEXT - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasDetailMetrics
The sequence context to which the analysis is constrained.
CONTEXT - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterDetailMetrics
The sequence context to which the analysis is constrained.
CONTEXT - Variable in class picard.analysis.CollectOxoGMetrics.CpcgMetrics
The sequence context being reported on.
CONTEXT_SIZE - Variable in class picard.analysis.artifacts.CollectSequencingArtifactMetrics
 
CONTEXT_SIZE - Variable in class picard.analysis.CollectOxoGMetrics
 
ContextCovariate - Class in org.broadinstitute.hellbender.utils.recalibration.covariates
 
ContextCovariate(RecalibrationArgumentCollection) - Constructor for class org.broadinstitute.hellbender.utils.recalibration.covariates.ContextCovariate
 
contextFromKey(int) - Static method in class org.broadinstitute.hellbender.utils.recalibration.covariates.ContextCovariate
Converts a key into the dna string representation.
contextMatchesLoc(VariantContext, Locatable) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
 
CONTEXTS - Variable in class picard.analysis.CollectOxoGMetrics
 
CONTEXTS_TO_PRINT - Variable in class picard.analysis.artifacts.CollectSequencingArtifactMetrics
 
ContextShard - Class in org.broadinstitute.hellbender.engine
Immutable storage class.
ContextShard(SimpleInterval) - Constructor for class org.broadinstitute.hellbender.engine.ContextShard
 
CONTIG - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
contig() - Method in class picard.vcf.processor.VcfFileSegment
 
CONTIG_COL_COMMENT - Static variable in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalCodec
 
CONTIG_ID_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
CONTIG_LENGTH_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
CONTIG_NAMES - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
CONTIG_PLOIDY_CALLS_DIRECTORY_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.GermlineCNVCaller
 
CONTIG_PLOIDY_CALLS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.PostprocessGermlineCNVCalls
 
CONTIG_PLOIDY_PRIORS_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.DetermineGermlineContigPloidy
 
CONTIG_SEPARATOR - Static variable in class org.broadinstitute.hellbender.utils.SimpleInterval
 
ContigAlignmentsModifier - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment
 
ContigAlignmentsModifier() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.ContigAlignmentsModifier
 
ContigAlignmentsModifier.AlnModType - Enum in org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment
 
ContigAlignmentsModifier.AlnModType.ModTypeString - Enum in org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment
 
contigIndex - Variable in class org.broadinstitute.hellbender.utils.GenomeLoc
the basic components of a genome loc, its contig index, start and stop position, and (optionally) the contig name
contigIndex - Variable in class org.broadinstitute.hellbender.utils.read.ArtificialReadQueryIterator
 
contigIsInDictionary(String) - Method in class org.broadinstitute.hellbender.utils.GenomeLocParser
Determines whether the given contig is valid with respect to the sequence dictionary already installed in the GenomeLoc.
contigLength - Variable in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfile
A cached value of the regionStartLoc contig length, to make calls to getCurrentContigLength efficient
contigName - Variable in class org.broadinstitute.hellbender.utils.GenomeLoc
 
contigsAligner(String, byte[], Function<? super T, String>, Function<? super T, byte[]>) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SingleSequenceReferenceAligner
Composes a contig aligner from an arbitrary input type given contig name and base sequence generation functions.
contiguousP(GenomeLoc) - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
 
CONTINGENCY_METRICS_FILE_EXTENSION - Static variable in class picard.vcf.GenotypeConcordance
 
CONTINGENCY_STATE_HEADER_LINE - Static variable in class picard.vcf.GenotypeConcordance
 
CONTINGENCY_STATE_TAG - Static variable in class picard.vcf.GenotypeConcordance
 
CONTINGENCY_VALUES - Variable in class picard.vcf.GenotypeConcordanceDetailMetrics
The list of contingency table values (TP, TN, FP, FN) that are deduced from the truth/call state comparison, given the reference.
continueAfterAnError - Variable in class org.broadinstitute.hellbender.tools.walkers.qc.CheckPileup
By default the program will quit if it encounters an error (such as missing truth data for a given position).
controllerId - Variable in class org.broadinstitute.hellbender.utils.runtime.ProcessControllerBase
 
CONVERGENCE_SNR_AVERAGING_WINDOW_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection
 
CONVERGENCE_SNR_COUNTDOWN_WINDOW_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection
 
CONVERGENCE_SNR_TRIGGER_THRESHOLD_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection
 
CONVERGENCE_THRESHOLD - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.SomaticLikelihoodsEngine
 
convert(Method, String) - Method in class org.broadinstitute.hellbender.utils.config.CustomBooleanConverter
 
convert(GATKRead, SAMFileHeader) - Static method in class org.broadinstitute.hellbender.utils.read.GATKReadToBDGAlignmentRecordConverter
 
convert(GATKRead, SAMFileHeader, SequenceDictionary, RecordGroupDictionary) - Static method in class org.broadinstitute.hellbender.utils.read.GATKReadToBDGAlignmentRecordConverter
 
convert(SAMRecord, SequenceDictionary, RecordGroupDictionary) - Static method in class org.broadinstitute.hellbender.utils.read.GATKReadToBDGAlignmentRecordConverter
 
convertB37ContigToHg19Contig(String) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Converts a given B37 style contig name to the equivalent in hg19.
convertClusterToOutputRecord(ClusterData) - Method in class picard.illumina.ClusterDataToSamConverter
Creates the SAMRecord for each read in the cluster
CONVERTED_SITES - Variable in class picard.analysis.RrbsCpgDetailMetrics
Number of times this CpG site was converted (TG for + strand, CA for - strand)
convertGenomeLocsToSimpleIntervals(List<GenomeLoc>) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Convert a List of intervals in GenomeLoc format into a List of intervals in SimpleInterval format.
ConvertHeaderlessHadoopBamShardToBam - Class in org.broadinstitute.hellbender.tools
This is a troubleshooting utility that converts a headerless BAM shard (e.g., a part-r-00000.bam, part-r-00001.bam, etc.), produced by a Spark tool with --sharded-output set to true, into a readable BAM file by adding a header and a BGZF terminator.
ConvertHeaderlessHadoopBamShardToBam() - Constructor for class org.broadinstitute.hellbender.tools.ConvertHeaderlessHadoopBamShardToBam
 
convertHeaderlessHadoopBamShardToBam(File, SAMFileHeader, File) - Static method in class org.broadinstitute.hellbender.utils.spark.SparkUtils
Converts a headerless Hadoop bam shard (eg., a part0000, part0001, etc.
convertInsToSoftClipFromOneEnd(List<CigarElement>, boolean) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SvCigarUtils
Actually convert terminal 'I' to 'S' and in case there's an 'S' comes before 'I', compactify the two neighboring 'S' operations into one.
convertIUPACtoN(byte[], boolean, boolean) - Static method in class org.broadinstitute.hellbender.utils.BaseUtils
 
convertMetric(TargetMetrics) - Method in class picard.analysis.directed.HsMetricCollector
 
convertMetric(TargetMetrics) - Method in class picard.analysis.directed.TargetedPcrMetricsCollector
 
convertMetric(TargetMetrics) - Method in class picard.analysis.directed.TargetMetricsCollector
 
convertRealMatrixToSparkRowMatrix(JavaSparkContext, RealMatrix, int) - Static method in class org.broadinstitute.hellbender.utils.spark.SparkConverter
Create a distributed matrix given an Apache Commons RealMatrix.
ConvertSequencingArtifactToOxoG - Class in picard.analysis.artifacts
 
ConvertSequencingArtifactToOxoG() - Constructor for class picard.analysis.artifacts.ConvertSequencingArtifactToOxoG
 
convertSimpleIntervalToQueryInterval(SimpleInterval, SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Converts an interval in SimpleInterval format into an htsjdk QueryInterval.
convertSolexaQualityAscii_1_1_ToPhredBinary(byte[]) - Static method in class picard.util.IlluminaUtil
Converts from Solexa ASCII to Phred binary in place.
convertSparkMatrixToRealMatrix(Matrix) - Static method in class org.broadinstitute.hellbender.utils.spark.SparkConverter
Convert a local (not distributed) Spark Matrix to an Apache Commons matrix.
convertSparkRowMatrixToRealMatrix(RowMatrix, int) - Static method in class org.broadinstitute.hellbender.utils.spark.SparkConverter
Create an Apache Commons RealMatrix from a Spark RowMatrix.
convertToBDGAlignmentRecord() - Method in class org.broadinstitute.hellbender.utils.read.BDGAlignmentRecordToGATKReadAdapter
 
convertToSAMRecord(SAMFileHeader) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Convert this read into a SAMRecord.
convertToSAMRecord(SAMFileHeader) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
coordinateByHitIndex() - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.HitsForInsert
Some alignment strategies expect to receive alignments for ends that are coordinated by hit index (HI) tag.
copy() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTreeNode
 
copy() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseEdge
Create a new copy of this BaseEdge
copy() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.MultiSampleEdge
 
copy() - Method in class org.broadinstitute.hellbender.utils.mcmc.ParameterizedState
 
copy() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Return a copy of this read.
copy() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.GATKDuplicationMetrics
 
copy() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
copy(ExtractIlluminaBarcodes.BarcodeMetric) - Static method in class picard.illumina.ExtractIlluminaBarcodes.BarcodeMetric
Creates a copy of metric initialized with only non-accumulated and non-calculated values set
COPY_NUMBER_FORMAT - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
COPY_NUMBER_POSTERIOR_EXPECTATION_MODE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineDenoisingModelArgumentCollection
 
COPY_NUMBER_POSTERIOR_FILE_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.gcnv.GermlineCNVNamingConstants
 
COPY_NUMBER_QUALITY_FORMAT - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
COPY_NUMBER_SEGMENTS_FILE_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.gcnv.GermlineCNVNamingConstants
 
COPY_NUMBER_TABLE_COLUMN_PREFIX - Static variable in class org.broadinstitute.hellbender.tools.copynumber.gcnv.GermlineCNVNamingConstants
 
COPY_OF_QD_KEY_NAME - Static variable in class org.broadinstitute.hellbender.tools.examples.ExampleTwoPassVariantWalker
 
COPY_RATIO_MODEL_PARAMETER_FILE_SUFFIX - Static variable in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
COPY_RATIO_SEGMENTS_FOR_CALLER_FILE_SUFFIX - Static variable in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
copyAlleleCounts(int[], int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeAlleleCounts
Copies the sorted allele counts into an array.
copyAlleleLikelihoods(int, double[], int) - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.SubsettedLikelihoodMatrix
 
copyAlleleLikelihoods(int, double[], int) - Method in interface org.broadinstitute.hellbender.utils.genotyper.LikelihoodMatrix
Copies the likelihood of all the reads for a given allele into an array from a particular offset.
copyFile(String, String) - Static method in class org.broadinstitute.hellbender.utils.gcs.BucketUtils
Copies a file.
copyFromBaseClass(T, S) - Static method in class picard.util.ReflectionUtil
 
CopyNumberArgumentValidationUtils - Class in org.broadinstitute.hellbender.tools.copynumber.arguments
 
CopyNumberFormatsUtils - Class in org.broadinstitute.hellbender.tools.copynumber.formats
 
CopyNumberPosteriorDistribution - Class in org.broadinstitute.hellbender.tools.copynumber.formats.records
A record containing the integer copy-number posterior distribution for a single interval.
CopyNumberPosteriorDistribution(Map<IntegerCopyNumberState, Double>) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.records.CopyNumberPosteriorDistribution
Constructor for storing copy number posterior distribution given a mapping between copy number states and their respective probabilities in log scale
CopyNumberPosteriorDistributionCollection - Class in org.broadinstitute.hellbender.tools.copynumber.formats.collections
Collection of integer copy-number posteriors.
CopyNumberPosteriorDistributionCollection(File) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.collections.CopyNumberPosteriorDistributionCollection
 
CopyNumberProgramGroup - Class in org.broadinstitute.hellbender.cmdline.programgroups
Tools that analyze read coverage to detect copy number variants
CopyNumberProgramGroup() - Constructor for class org.broadinstitute.hellbender.cmdline.programgroups.CopyNumberProgramGroup
 
CopyNumberStandardArgument - Class in org.broadinstitute.hellbender.tools.copynumber.arguments
 
CopyNumberStandardArgument() - Constructor for class org.broadinstitute.hellbender.tools.copynumber.arguments.CopyNumberStandardArgument
 
CopyRatio - Class in org.broadinstitute.hellbender.tools.copynumber.formats.records
 
CopyRatio(SimpleInterval, double) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.records.CopyRatio
 
CopyRatioCollection - Class in org.broadinstitute.hellbender.tools.copynumber.formats.collections
 
CopyRatioCollection(File) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.collections.CopyRatioCollection
 
CopyRatioCollection(SampleLocatableMetadata, List<CopyRatio>) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.collections.CopyRatioCollection
 
CopyRatioKernelSegmenter - Class in org.broadinstitute.hellbender.tools.copynumber.segmentation
Segments copy-ratio data using kernel segmentation.
CopyRatioKernelSegmenter(CopyRatioCollection) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.segmentation.CopyRatioKernelSegmenter
 
CopyRatioModeller - Class in org.broadinstitute.hellbender.tools.copynumber.models
Represents a segmented model for copy ratio fit to denoised log2 copy-ratio data.
CopyRatioParameter - Enum in org.broadinstitute.hellbender.tools.copynumber.models
Enumerates the parameters for CopyRatioState.
CopyRatioSegment - Class in org.broadinstitute.hellbender.tools.copynumber.formats.records
 
CopyRatioSegment(SimpleInterval, int, double) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.records.CopyRatioSegment
 
CopyRatioSegment(SimpleInterval, List<CopyRatio>) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.records.CopyRatioSegment
 
CopyRatioSegmentCollection - Class in org.broadinstitute.hellbender.tools.copynumber.formats.collections
 
CopyRatioSegmentCollection(File) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.collections.CopyRatioSegmentCollection
 
CopyRatioSegmentCollection(SampleLocatableMetadata, List<CopyRatioSegment>) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.collections.CopyRatioSegmentCollection
 
copyStandardCallerArgsFrom(StandardCallerArgumentCollection) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.StandardCallerArgumentCollection
Copies the values from other into this StandardCallerArgumentCollection
copyTo(int[], int) - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
Copy the content of the set into an array.
copyTo(int[]) - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
Copy the content of the set into an array.
copyWithNewPriors(double[]) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculationResult
Return a new AFCalcResult with a new prior probability
CORRECT_STRAND_READS - Variable in class picard.analysis.RnaSeqMetrics
Number of aligned reads that are mapped to the correct strand.
correctGCBias(RealMatrix, double[]) - Static method in class org.broadinstitute.hellbender.tools.copynumber.denoising.GCBiasCorrector
Corrects GC bias of read counts in place.
CorrectionSet(int) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadErrorCorrector.CorrectionSet
Main class constructor.
correctReads(Collection<GATKRead>) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadErrorCorrector
Correct a collection of reads based on stored k-mer counts
correspondingInterval() - Method in class picard.vcf.processor.VcfFileSegment
 
CosmicFuncotationFactory - Class in org.broadinstitute.hellbender.tools.funcotator.dataSources.cosmic
Factory for creating Funcotations by handling a SQLite database containing information from COSMIC.
CosmicFuncotationFactory(Path) - Constructor for class org.broadinstitute.hellbender.tools.funcotator.dataSources.cosmic.CosmicFuncotationFactory
 
CosmicFuncotationFactory(Path, LinkedHashMap<String, String>, String) - Constructor for class org.broadinstitute.hellbender.tools.funcotator.dataSources.cosmic.CosmicFuncotationFactory
 
CouldNotCreateOutputFile(File, String, Exception) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.CouldNotCreateOutputFile
 
CouldNotCreateOutputFile(File, String) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.CouldNotCreateOutputFile
 
CouldNotCreateOutputFile(String, String, Exception) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.CouldNotCreateOutputFile
 
CouldNotCreateOutputFile(File, Exception) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.CouldNotCreateOutputFile
 
CouldNotCreateOutputFile(String, Exception) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.CouldNotCreateOutputFile
 
CouldNotIndexFile(File, Exception) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.CouldNotIndexFile
 
CouldNotReadInputFile(String, Exception) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.CouldNotReadInputFile
 
CouldNotReadInputFile(File) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.CouldNotReadInputFile
 
CouldNotReadInputFile(Path) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.CouldNotReadInputFile
 
CouldNotReadInputFile(File, String) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.CouldNotReadInputFile
 
CouldNotReadInputFile(Path, String) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.CouldNotReadInputFile
 
CouldNotReadInputFile(Path, String, Throwable) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.CouldNotReadInputFile
 
CouldNotReadInputFile(String, String) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.CouldNotReadInputFile
 
CouldNotReadInputFile(File, String, Exception) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.CouldNotReadInputFile
 
CouldNotReadInputFile(File, Exception) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.CouldNotReadInputFile
 
CouldNotReadInputFile(Path, Exception) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.CouldNotReadInputFile
 
CouldNotReadInputFile(String) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.CouldNotReadInputFile
 
COUNT - Variable in class picard.vcf.GenotypeConcordanceDetailMetrics
The number of events of type TRUTH_STATE and CALL_STATE for the EVENT_TYPE and SAMPLEs
COUNT_PANEL_OF_NORMALS_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.CopyNumberStandardArgument
 
COUNT_UNPAIRED - Variable in class picard.analysis.CollectWgsMetrics
 
countAlignedBases(Cigar) - Static method in class org.broadinstitute.hellbender.utils.read.CigarUtils
 
CountBases - Class in org.broadinstitute.hellbender.tools
Calculate and print to the standard output the overall number of bases in a SAM/BAM/CRAM file
CountBases() - Constructor for class org.broadinstitute.hellbender.tools.CountBases
 
CountBasesSpark - Class in org.broadinstitute.hellbender.tools.spark.pipelines
Calculate the overall number of bases SAM/BAM/CRAM file
CountBasesSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.pipelines.CountBasesSpark
 
countBooleanOccurrences(boolean, boolean[]) - Static method in class org.broadinstitute.hellbender.utils.Utils
Returns the number of occurrences of a boolean element in a boolean array.
countCallsAtTruth(List<VariantDatum>, double) - Static method in class org.broadinstitute.hellbender.tools.walkers.vqsr.TrancheManager
 
Counter() - Constructor for class org.broadinstitute.hellbender.utils.Nucleotide.Counter
Creates a new counter with all counts set to 0.
counter - Variable in class picard.analysis.AbstractWgsMetricsCollector
The number of processed genomic bases
CounterManager - Class in picard.analysis
Class for managing a list of Counters of integer, provides methods to access data from Counters with respect to an offset.
CounterManager(int, int) - Constructor for class picard.analysis.CounterManager
Constructor creates new CounterManager without any Counters, counters are added to CounterManager via newCounter() method
CounterManager.Counter - Class in picard.analysis
Class represents an integer array with methods to increment and get the values from it with respect to offset of outer CounterManager.
CountFalsePositives - Class in org.broadinstitute.hellbender.tools.walkers.validation
Count variants which were not filtered in a VCF.
CountFalsePositives() - Constructor for class org.broadinstitute.hellbender.tools.walkers.validation.CountFalsePositives
 
countFamilyViolations(SampleDB, Set<String>, VariantContext) - Method in class org.broadinstitute.hellbender.utils.samples.MendelianViolation
 
CountingDuplicateFilter - Class in picard.filter
Counting filter that discards reads that have been marked as duplicates.
CountingDuplicateFilter() - Constructor for class picard.filter.CountingDuplicateFilter
 
CountingFilter - Class in picard.filter
A SamRecordFilter that counts the number of bases in the reads which it filters out.
CountingFilter() - Constructor for class picard.filter.CountingFilter
 
CountingMapQFilter - Class in picard.filter
Counting filter that discards reads below a configurable mapping quality threshold.
CountingMapQFilter(int) - Constructor for class picard.filter.CountingMapQFilter
 
CountingPairedFilter - Class in picard.filter
Counting filter that discards reads that are unpaired in sequencing and paired reads whose mates are not mapped.
CountingPairedFilter() - Constructor for class picard.filter.CountingPairedFilter
 
CountingReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Wrapper/adapter for ReadFilter that counts the number of reads filtered, and provides a filter count summary.
CountingReadFilter(ReadFilter) - Constructor for class org.broadinstitute.hellbender.engine.filters.CountingReadFilter
 
CountingReadFilter.CountingAndReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Private class for Counting AND filters
CountingVariantFilter - Class in org.broadinstitute.hellbender.engine.filters
Wrapper/adapter for VariantFilter that counts the number of variants filtered, and provides a filter count summary.
CountingVariantFilter(VariantFilter) - Constructor for class org.broadinstitute.hellbender.engine.filters.CountingVariantFilter
 
CountingVariantFilter.CountingAndVariantFilter - Class in org.broadinstitute.hellbender.engine.filters
Private class for Counting AND filters
countLeftClippedBases(Cigar) - Static method in class org.broadinstitute.hellbender.utils.read.CigarUtils
Total number of bases clipped on the left/head side of the cigar.
countLeftHardClippedBases(Cigar) - Static method in class org.broadinstitute.hellbender.utils.read.CigarUtils
Returns the number of based hard-clipped to the left/head of the cigar.
CountReads - Class in org.broadinstitute.hellbender.tools
Calculate and print to the standard output the overall number of reads in a SAM/BAM/CRAM file
CountReads() - Constructor for class org.broadinstitute.hellbender.tools.CountReads
 
CountReadsSpark - Class in org.broadinstitute.hellbender.tools.spark.pipelines
Calculate the overall number of reads in a SAM/BAM file
CountReadsSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.pipelines.CountReadsSpark
 
countRefBasesBasedOnCigar(GATKRead, int, int) - Static method in class org.broadinstitute.hellbender.utils.read.CigarUtils
Compute the number of reference bases between the start (inclusive) and end (exclusive) cigar elements.
countRightClippedBases(Cigar) - Static method in class org.broadinstitute.hellbender.utils.read.CigarUtils
Total number of bases clipped (soft or hard) on the right/tail side of the cigar.
countRightHardClippedBases(Cigar) - Static method in class org.broadinstitute.hellbender.utils.read.CigarUtils
Returns the number of based hard-clipped to the right/tail of the cigar.
CountSet - Class in org.broadinstitute.hellbender.utils.collections
Efficient implementation for a small set of integer primitive values.
CountSet(int) - Constructor for class org.broadinstitute.hellbender.utils.collections.CountSet
Creates a new set indicating the expected maximum number of elements it will contain.
countType - Variable in class org.broadinstitute.hellbender.tools.walkers.rnaseq.ASEReadCounter
These options modify how the tool deals with overlapping read pairs.
countUnclippedReadBases(Cigar) - Static method in class org.broadinstitute.hellbender.utils.read.CigarUtils
Returns the length of the original read considering all clippings based on this cigar.
CountVariants - Class in org.broadinstitute.hellbender.tools.walkers
Count variant records in a VCF file, regardless of filter status.
CountVariants() - Constructor for class org.broadinstitute.hellbender.tools.walkers.CountVariants
 
CountVariantsSpark - Class in org.broadinstitute.hellbender.tools.spark.pipelines
 
CountVariantsSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.pipelines.CountVariantsSpark
 
Covariate - Interface in org.broadinstitute.hellbender.utils.recalibration.covariates
The Covariate interface.
COVARIATE_NAME_COLUMN_NAME - Static variable in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
 
COVARIATE_VALUE_COLUMN_NAME - Static variable in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
 
CovariateKeyCache - Class in org.broadinstitute.hellbender.utils.recalibration.covariates
 
CovariateKeyCache() - Constructor for class org.broadinstitute.hellbender.utils.recalibration.covariates.CovariateKeyCache
 
covariateNames() - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.StandardCovariateList
Return a human-readable string representing the used covariates
Coverage - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Total depth of coverage per sample and over all samples.
Coverage() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.Coverage
 
Coverage(Interval, int) - Constructor for class picard.analysis.directed.TargetMetricsCollector.Coverage
Constructs a new coverage object for the provided mapping with the desired padding either side.
COVERAGE_CAP - Variable in class picard.analysis.CollectWgsMetrics
 
COVERAGE_CAP - Variable in class picard.analysis.directed.CollectTargetedMetrics
 
CoverageAnalysisProgramGroup - Class in org.broadinstitute.hellbender.cmdline.programgroups
Tools that count coverage, e.g.
CoverageAnalysisProgramGroup() - Constructor for class org.broadinstitute.hellbender.cmdline.programgroups.CoverageAnalysisProgramGroup
 
coverageCap - Variable in class picard.analysis.AbstractWgsMetricsCollector
Positions with coverage exceeding this value are treated as if they had coverage at this value
coverageCap - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The maximum depth/coverage to consider.
CoveragePerContig - Class in org.broadinstitute.hellbender.tools.copynumber.formats.records
Represents total coverage over each contig in an ordered set associated with a named sample.
CoveragePerContig(String, LinkedHashMap<String, Integer>) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.records.CoveragePerContig
 
CoveragePerContigCollection - Class in org.broadinstitute.hellbender.tools.copynumber.formats.collections
Represents a sequence dictionary and total coverage over each contig in an ordered set associated with a cohort of named samples.
CoveragePerContigCollection(LocatableMetadata, List<CoveragePerContig>, List<String>) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.collections.CoveragePerContigCollection
 
coveredSize() - Method in class org.broadinstitute.hellbender.utils.GenomeLocSortedSet
Return the size, in bp, of the genomic regions by all of the regions in this set
CpcgMetrics() - Constructor for class picard.analysis.CollectOxoGMetrics.CpcgMetrics
 
CPG_BASES_CONVERTED - Variable in class picard.analysis.RrbsSummaryMetrics
Number of CpG sites that were converted (TG for +, CA for -)
CPG_BASES_SEEN - Variable in class picard.analysis.RrbsSummaryMetrics
Number of CpG sites encountered
CPX_EVENT_ALT_ARRANGEMENTS - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
CPX_SV_REF_SEGMENTS - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
CPX_SV_SYB_ALT_ALLELE_STR - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
CpxVariantInterpreter - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.inference
This deals with the special case where a contig has multiple (> 2) alignments and seemingly has the complete alt haplotype assembled.
CpxVariantInterpreter() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.CpxVariantInterpreter
 
CpxVariantReInterpreterSpark - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.inference
(Internal) Tries to extract simple variants from a provided GATK-SV CPX.vcf
CpxVariantReInterpreterSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.CpxVariantReInterpreterSpark
 
create(File, String, SAMSequenceDictionary, RealMatrix, List<String>, List<SimpleInterval>, double[], double, double, double, double, boolean, double, int, int, JavaSparkContext) - Static method in class org.broadinstitute.hellbender.tools.copynumber.denoising.HDF5SVDReadCountPanelOfNormals
Create the panel of normals and write it to an HDF5 file.
create(List<AnnotatedInterval>, SAMFileHeader, List<String>) - Static method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalCollection
Create a collection from components.
create(Path, Path, Set<String>) - Static method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalCollection
Create a collection based on the contents of an input file and a given config file.
create(Path, Set<String>) - Static method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalCollection
Same as AnnotatedIntervalCollection.create(Path, Path, Set) , but uses the default annotated interval config file in the GATK.
create(String[]) - Static method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfCDSFeature
 
create(GencodeGtfFeatureBaseData) - Static method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfCDSFeature
 
create(String[]) - Static method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfExonFeature
 
create(GencodeGtfFeatureBaseData) - Static method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfExonFeature
 
create(GencodeGtfFeatureBaseData) - Static method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
Create the appropriate GencodeGtfFeature object based on the given baseData
create(String) - Static method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
Create a GencodeGtfFeature based on a line from a Gencode GTF File.
create(String[]) - Static method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
Create a GencodeGtfFeature based on a line from a Gencode GTF File.
create(GencodeGtfFeatureBaseData) - Method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.FeatureType
Create a GencodeGtfFeature of this type given baseData
create(String[]) - Method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.FeatureType
Create a GencodeGtfFeature of this type given gtfFields
create(String[]) - Static method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfGeneFeature
 
create(GencodeGtfFeatureBaseData) - Static method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfGeneFeature
 
create(String[]) - Static method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfSelenocysteineFeature
 
create(GencodeGtfFeatureBaseData) - Static method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfSelenocysteineFeature
 
create(String[]) - Static method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfStartCodonFeature
 
create(GencodeGtfFeatureBaseData) - Static method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfStartCodonFeature
 
create(String[]) - Static method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfStopCodonFeature
 
create(GencodeGtfFeatureBaseData) - Static method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfStopCodonFeature
 
create(String[]) - Static method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfTranscriptFeature
 
create(GencodeGtfFeatureBaseData) - Static method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfTranscriptFeature
 
create(String[]) - Static method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfUTRFeature
 
create(GencodeGtfFeatureBaseData) - Static method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfUTRFeature
 
create(Class<? extends T>, Map<?, ?>...) - Method in class org.broadinstitute.hellbender.utils.config.ConfigFactory
Wrapper around ConfigFactory.create(Class, Map[]) which will ensure that path variables specified in Config.Sources annotations are resolved prior to creation.
create(ReadPileup) - Static method in class org.broadinstitute.hellbender.utils.fragments.FragmentCollection
Create a FragmentCollection containing PileupElements from the ReadBackedPileup rbp
create(List<GATKRead>) - Static method in class org.broadinstitute.hellbender.utils.fragments.FragmentCollection
Create a FragmentCollection containing SAMRecords from a list of reads
create(HaplotypeBAMWriter.WriterType, Path, boolean, boolean, SAMFileHeader) - Static method in class org.broadinstitute.hellbender.utils.haplotype.HaplotypeBAMWriter
Create a new HaplotypeBAMWriter of type "type" for writing SAMRecords to an output file
create(HaplotypeBAMWriter.WriterType, HaplotypeBAMDestination) - Static method in class org.broadinstitute.hellbender.utils.haplotype.HaplotypeBAMWriter
Create a new HaplotypeBAMWriter of type "type" for writing SAMRecords to and output destination
create(HaplotypeBAMDestination) - Method in enum org.broadinstitute.hellbender.utils.haplotype.HaplotypeBAMWriter.WriterType
Create an instance of the HaplotypeBAMWriter corresponding to this type.
CREATE_BAI_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.CreateHadoopBamSplittingIndex
 
CREATE_INDEX - Variable in class org.broadinstitute.hellbender.cmdline.PicardCommandLineProgram
 
CREATE_INDEX - Variable in class picard.cmdline.CommandLineProgram
 
CREATE_MD5_FILE - Variable in class org.broadinstitute.hellbender.cmdline.PicardCommandLineProgram
 
CREATE_MD5_FILE - Variable in class picard.cmdline.CommandLineProgram
 
CREATE_OUTPUT_BAM_INDEX_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
CREATE_OUTPUT_BAM_INDEX_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
CREATE_OUTPUT_BAM_MD5_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
CREATE_OUTPUT_BAM_MD5_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
CREATE_OUTPUT_VARIANT_INDEX_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
CREATE_OUTPUT_VARIANT_INDEX_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
CREATE_OUTPUT_VARIANT_MD5_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
CREATE_OUTPUT_VARIANT_MD5_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
createAlleleMapper(List<VariantContext>, VariantContext, int, List<Haplotype>) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerGenotypingEngine
 
createAlleleMapping(Allele, VariantContext, Collection<Allele>) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Create an allele mapping for the given context where its reference allele must (potentially) be extended to the given allele The refAllele is the longest reference allele seen at this start site.
createAminoAcidSequence(String) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Creates an amino acid sequence from a given coding sequence.
createAminoAcidSequence(String, boolean) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Creates an amino acid sequence from a given coding sequence.
createAndSetHeader(int) - Method in class org.broadinstitute.hellbender.utils.read.ArtificialBAMBuilder
 
createArtificialRead(SAMFileHeader, String, int, int, int) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
Create an artificial GATKRead based on the parameters.
createArtificialRead(SAMFileHeader, String, int, int, byte[], byte[]) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
Create an artificial GATKRead based on the parameters.
createArtificialRead(SAMFileHeader, String, String, int, byte[], byte[]) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
Create an artificial GATKRead based on the parameters.
createArtificialRead(SAMFileHeader, String, int, int, byte[], byte[], String) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
Create an artificial GATKRead based on the parameters
createArtificialRead(SAMFileHeader, String, String, int, byte[], byte[], String) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
Create an artificial GATKRead based on the parameters
createArtificialRead(SAMFileHeader, byte[], byte[], String) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
Create an artificial GATKRead with the following default parameters : header: numberOfChromosomes = 1 startingChromosome = 1 chromosomeSize = 1000000 read: name = "default_read" refIndex = 0 alignmentStart = 10000
createArtificialRead(byte[], byte[], String) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
 
createArtificialRead(SAMFileHeader, String) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
 
createArtificialRead(SAMFileHeader, Cigar) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
 
createArtificialRead(Cigar) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
 
createArtificialRead(Cigar, String) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
 
createArtificialRead(String) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
 
createArtificialSamHeader(int, int, int) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
Creates an artificial sam header, matching the parameters, chromosomes which will be labeled chr1, chr2, etc
createArtificialSamHeader() - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
Creates an artificial sam header with standard test parameters
createArtificialSamHeader(SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
Creates an artificial sam header based on the sequence dictionary dict
createArtificialSamHeaderWithGroups(int, int, int, int) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
Creates an artificial sam header, matching the parameters, chromosomes which will be labeled chr1, chr2, etc It also adds read groups.
createArtificialSamHeaderWithReadGroup(SAMReadGroupRecord) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
 
createArtificialSAMRecord(SAMFileHeader, String, int, int, int) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
Create an artificial SAMRecord based on the parameters.
createArtificialSAMRecord(SAMFileHeader, String, int, int, byte[], byte[]) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
Create an artificial SAMRecord based on the parameters.
createArtificialSAMRecord(SAMFileHeader, String, int, int, byte[], byte[], String) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
Create an artificial SAMRecord based on the parameters
createArtificialSAMRecord(SAMFileHeader, byte[], byte[], String) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
Create an artificial SAMRecord with the following default parameters : header: numberOfChromosomes = 1 startingChromosome = 1 chromosomeSize = 1000000 read: name = "default_read" refIndex = 0 alignmentStart = 10000
createArtificialSAMRecord(byte[], byte[], String) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
 
createArtificialSAMRecord(SAMFileHeader, Cigar, String) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
 
createArtificialSAMRecord(SAMFileHeader, Cigar) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
 
createArtificialSAMRecord(Cigar) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
 
createArtificialUnmappedRead(SAMFileHeader, byte[], byte[]) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
 
createArtificialUnmappedReadWithAssignedPosition(SAMFileHeader, String, int, byte[], byte[]) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
 
createBai - Variable in class org.broadinstitute.hellbender.tools.spark.CreateHadoopBamSplittingIndex
 
createBamWriter(AssemblyBasedCallerArgumentCollection, boolean, boolean, SAMFileHeader) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerUtils
 
createBracketedSymbAlleleString(String) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SimpleSVType
 
createCollector(String, Set<MetricAccumulationLevel>, List<Header>, SAMFileHeader) - Method in interface org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectMultipleMetricsSpark.SparkCollectorProvider
For each collector type, provide a type-safe, collector-specific method that creates and populates an instance of the collector's input argument class; creates an instance of the collector; initializes the collector with the arguments, and returns the initialized collector.
createCommonSAMWriter(File, File, SAMFileHeader, boolean, boolean, boolean) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Create a common SAMFileWriter for use with GATK tools.
createCommonSAMWriter(Path, File, SAMFileHeader, boolean, boolean, boolean) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Create a common SAMFileWriter for use with GATK tools.
createCommonSAMWriterFromFactory(SAMFileWriterFactory, File, File, SAMFileHeader, boolean) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Create a common SAMFileWriter from a factory for use with GATK tools.
createCommonSAMWriterFromFactory(SAMFileWriterFactory, Path, File, SAMFileHeader, boolean, OpenOption...) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Create a common SAMFileWriter from a factory for use with GATK tools.
createCosmicDataSource(Path, Properties, LinkedHashMap<String, String>) - Static method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
Create a CosmicFuncotationFactory from filesystem resources and field overrides.
createDataSourceFuncotationFactoriesForDataSources(Map<Path, Properties>, LinkedHashMap<String, String>, TranscriptSelectionMode, Set<String>) - Static method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
Create a List of DataSourceFuncotationFactory based on meta data on the data sources, overrides, and transcript reporting priority information.
createDefaultFuncotationsOnVariant(VariantContext, ReferenceContext) - Method in class org.broadinstitute.hellbender.tools.funcotator.DataSourceFuncotationFactory
Creates a List of Funcotation for the given variant and referenceContext.
createDefaultFuncotationsOnVariant(VariantContext, ReferenceContext) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.cosmic.CosmicFuncotationFactory
 
createDefaultFuncotationsOnVariant(VariantContext, ReferenceContext) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationFactory
 
createDefaultFuncotationsOnVariant(VariantContext, ReferenceContext) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.vcf.VcfFuncotationFactory
 
createDefaultFuncotationsOnVariant(VariantContext, ReferenceContext) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv.LocatableXsvFuncotationFactory
 
createDefaultFuncotationsOnVariant(VariantContext, ReferenceContext) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv.SimpleKeyXsvFuncotationFactory
 
createDiploidGenotype(byte, byte) - Static method in enum org.broadinstitute.hellbender.utils.genotyper.DiploidGenotype
create a diploid genotype, given 2 chars which may not necessarily be ordered correctly
createDiploidGenotype(int, int) - Static method in enum org.broadinstitute.hellbender.utils.genotyper.DiploidGenotype
create a diploid genotype, given 2 base indexes which may not necessarily be ordered correctly
createDirectory(String) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
Creates a directory, in local FS, HDFS, or Google buckets to write individual files in.
createDownsampler() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
createDownsampler() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2
 
createDummyStratifiedReadMap(Haplotype, SampleList, AssemblyRegion) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerEngine
Create a context that maps each read to the reference haplotype with log10 L of 0
createEmptyHistogram() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.LibraryStatistics
 
createEmptyHistogram() - Method in class org.broadinstitute.hellbender.tools.spark.utils.IntHistogram.CDF
 
createEvenlySpacedPoints(double, double, int) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Create a set number of points, linearly spaced, between a minimum and maximum.
createFIFO() - Method in class org.broadinstitute.hellbender.utils.runtime.StreamingProcessController
Create a temporary FIFO suitable for sending output to the remote process.
createFile(String) - Static method in class org.broadinstitute.hellbender.utils.gcs.BucketUtils
Open a binary file for writing regardless of whether it's on GCS, HDFS or local disk.
createFilterListWithAppend(VariantContext, String) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Create a string with existing filters plus the one to append
createFuncotations(VariantContext, ReferenceContext, Map<String, List<Feature>>) - Method in class org.broadinstitute.hellbender.tools.funcotator.DataSourceFuncotationFactory
Creates a List of Funcotation for the given variant, referenceContext, and featureContext.
createFuncotations(VariantContext, ReferenceContext, Map<String, List<Feature>>, List<GencodeFuncotation>) - Method in class org.broadinstitute.hellbender.tools.funcotator.DataSourceFuncotationFactory
Creates a List of Funcotation for the given variant, referenceContext, featureContext, and gencodeFuncotations.
createFuncotationsOnVariant(VariantContext, ReferenceContext, List<Feature>) - Method in class org.broadinstitute.hellbender.tools.funcotator.DataSourceFuncotationFactory
Creates a List of Funcotation for the given variant, referenceContext, and featureContext.
createFuncotationsOnVariant(VariantContext, ReferenceContext, List<Feature>, List<GencodeFuncotation>) - Method in class org.broadinstitute.hellbender.tools.funcotator.DataSourceFuncotationFactory
Creates a List of Funcotation for the given variant, referenceContext, featureContext, and gencodeFuncotations.
createFuncotationsOnVariant(VariantContext, ReferenceContext, List<Feature>) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.cosmic.CosmicFuncotationFactory
 
createFuncotationsOnVariant(VariantContext, ReferenceContext, List<Feature>, List<GencodeFuncotation>) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.cosmic.CosmicFuncotationFactory
 
createFuncotationsOnVariant(VariantContext, ReferenceContext, List<Feature>) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationFactory
 
createFuncotationsOnVariant(VariantContext, ReferenceContext, List<Feature>, List<GencodeFuncotation>) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationFactory
 
createFuncotationsOnVariant(VariantContext, ReferenceContext, List<Feature>) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.vcf.VcfFuncotationFactory
 
createFuncotationsOnVariant(VariantContext, ReferenceContext, List<Feature>, List<GencodeFuncotation>) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.vcf.VcfFuncotationFactory
 
createFuncotationsOnVariant(VariantContext, ReferenceContext, List<Feature>) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv.LocatableXsvFuncotationFactory
 
createFuncotationsOnVariant(VariantContext, ReferenceContext, List<Feature>, List<GencodeFuncotation>) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv.LocatableXsvFuncotationFactory
 
createFuncotationsOnVariant(VariantContext, ReferenceContext, List<Feature>) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv.SimpleKeyXsvFuncotationFactory
 
createFuncotationsOnVariant(VariantContext, ReferenceContext, List<Feature>, List<GencodeFuncotation>) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv.SimpleKeyXsvFuncotationFactory
 
createGATKReport() - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationReport
Creates the recalibration report.
createGencodeDataSource(Path, Properties, LinkedHashMap<String, String>, TranscriptSelectionMode, Set<String>) - Static method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
Create a GencodeFuncotationFactory from filesystem resources and field overrides.
createGenomeLoc(String, int, int) - Method in class org.broadinstitute.hellbender.utils.GenomeLocParser
 
createGenomeLoc(String, int, int, boolean) - Method in class org.broadinstitute.hellbender.utils.GenomeLocParser
 
createGenomeLoc(String, int, int, int) - Method in class org.broadinstitute.hellbender.utils.GenomeLocParser
 
createGenomeLoc(String, int, int, int, boolean) - Method in class org.broadinstitute.hellbender.utils.GenomeLocParser
Create a GenomeLoc on contig, starting at start and ending (inclusive) at stop.
createGenomeLoc(String, int) - Method in class org.broadinstitute.hellbender.utils.GenomeLocParser
Create a new GenomeLoc, on contig, including the single position pos.
createGenomeLoc(GATKRead) - Method in class org.broadinstitute.hellbender.utils.GenomeLocParser
 
createGenomeLoc(Feature) - Method in class org.broadinstitute.hellbender.utils.GenomeLocParser
Creates a GenomeLoc from a Tribble feature
createGenomeLoc(Locatable) - Method in class org.broadinstitute.hellbender.utils.GenomeLocParser
Creates a GenomeLoc from a Locatable.
createGenomeLocAtStart(GenomeLoc, int) - Method in class org.broadinstitute.hellbender.utils.GenomeLocParser
Creates a loc to the left (starting at the loc start + 1) of maxBasePairs size.
createGenomeLocAtStop(GenomeLoc, int) - Method in class org.broadinstitute.hellbender.utils.GenomeLocParser
Creates a loc to the right (starting at the loc stop + 1) of maxBasePairs size.
createGenomeLocOnContig(String, int, int) - Method in class org.broadinstitute.hellbender.utils.GenomeLocParser
 
createGenomeLocOnContig(String, int, int, int) - Method in class org.broadinstitute.hellbender.utils.GenomeLocParser
Create a new genome loc, bounding start and stop by the start and end of contig This function will return null if start and stop cannot be adjusted in any reasonable way to be on the contig.
createGSONWorkUnit(DocWorkUnit, List<Map<String, String>>, List<Map<String, String>>) - Method in class org.broadinstitute.hellbender.utils.help.GATKHelpDoclet
Create a GSONWorkUnit-derived object that holds our custom data.
CreateHadoopBamSplittingIndex - Class in org.broadinstitute.hellbender.tools.spark
Create a Hadoop BAM splitting index and optionally a BAM index from a BAM file.
CreateHadoopBamSplittingIndex() - Constructor for class org.broadinstitute.hellbender.tools.spark.CreateHadoopBamSplittingIndex
 
createHeaderForWriter(Path, List<String>, SAMFileHeader) - Static method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalCodec
Create an annotated interval header based on a config file (for locatable field names only) and a list of annotations (the rest of the fields).
createHeaderForWriter(List<String>, SAMFileHeader) - Static method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalCodec
See AnnotatedIntervalCodec.createHeaderForWriter(Path, List, SAMFileHeader) This will use the default headers for annotated regions.
createHeaderlessSamBackedRead(String, String, int, int) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
Creates an artificial GATKRead backed by a SAMRecord with no header.
createHomGenotype(byte) - Static method in enum org.broadinstitute.hellbender.utils.genotyper.DiploidGenotype
create a diploid genotype, given a character to make into a hom genotype
createIdenticalArtificialReads(int, SAMFileHeader, String, int, int, int) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
Create a collection of identical artificial reads based on the parameters.
createIndex - Variable in class org.broadinstitute.hellbender.tools.GatherVcfsCloud
 
createInstanceForPlugin(Class<?>) - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKAnnotationPluginDescriptor
Return an instance of the specified pluggable class.
createInstanceForPlugin(Class<?>) - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKReadFilterPluginDescriptor
 
createLibraryStatistics(long) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.LibraryRawStatistics
 
createLikelihoodCalculationEngine(LikelihoodEngineArgumentCollection) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerUtils
Instantiates the appropriate likelihood calculation engine.
createLocatableXsvDataSource(Path, Properties, LinkedHashMap<String, String>) - Static method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
Create a LocatableXsvFuncotationFactory from filesystem resources and field overrides.
createNewCigarsIfMapsOffEndOfReference(SAMRecord) - Static method in class org.broadinstitute.hellbender.utils.read.mergealignment.AbstractAlignmentMerger
Soft-clip an alignment that hangs off the end of its reference sequence.
createNewCigarsIfMapsOffEndOfReference(SAMRecord) - Static method in class picard.sam.AbstractAlignmentMerger
Soft-clip an alignment that hangs off the end of its reference sequence.
createNextRead() - Method in class org.broadinstitute.hellbender.utils.read.ArtificialReadIterator
 
createNonIndelPileupElement(int, Allele, int) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
See ArtificialReadUtils.createSplicedInsertionPileupElement(int, htsjdk.variant.variantcontext.Allele, int), except that this method returns a pileup element containing base-by-base replacement.
createOptimalCoverageAlignmentSetsForContigs(JavaRDD<GATKRead>, SAMFileHeader, Set<String>, Double, Logger) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigAlignmentsConfigPicker
Filters an input of SAM file containing alignments of a single-ended long read that aims at providing an "optimal coverage" of the assembly contig, based on an heuristic scoring scheme AssemblyContigAlignmentsConfigPicker.computeScoreOfConfiguration(List, Set, int).
createOutputBamIndex - Variable in class org.broadinstitute.hellbender.engine.GATKTool
 
createOutputBamIndex() - Method in interface org.broadinstitute.hellbender.utils.config.GATKConfig
 
createOutputBamMD5 - Variable in class org.broadinstitute.hellbender.engine.GATKTool
 
createOutputVariantIndex - Variable in class org.broadinstitute.hellbender.engine.GATKTool
 
createOutputVariantMD5 - Variable in class org.broadinstitute.hellbender.engine.GATKTool
 
createOverEntireContig(String) - Method in class org.broadinstitute.hellbender.utils.GenomeLocParser
Creates a GenomeLoc than spans the entire contig.
createOverlapMap(List<T>, List<U>, SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Creates a map of which locatables (keys) overlap the other list of locatables (vals) Input lists will be sorted sorted by the input dictionary.
createPaddedGenomeLoc(GenomeLoc, int) - Method in class org.broadinstitute.hellbender.utils.GenomeLocParser
Creates a loc padded in both directions by maxBasePairs size (if possible).
createPair(SAMFileHeader, String, int, int, int, boolean, boolean) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
 
createPair(SAMFileHeader, String, int, int, int, int, boolean, boolean) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
 
createPileupForReadAndGenomeLoc(GATKRead, Locatable) - Static method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Create a pileup element for read at a particular spot on the genome.
createPileupForReadAndOffset(GATKRead, int) - Static method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Create a pileup element for read at offset.
createProvider() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.ConcurrentAFCalculatorProvider
 
createRandomRead(SAMFileHeader, int) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
 
createRandomRead(int) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
 
createRandomRead(SAMFileHeader, int, boolean) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
 
createRandomRead(int, boolean) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
 
createRandomReadBases(int, boolean) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
Create random read qualities
createRandomReadQuals(int) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
Create random read qualities
createReadAlignedToRef(GATKRead, Haplotype, Haplotype, int, boolean, SmithWatermanAligner) - Static method in class org.broadinstitute.hellbender.utils.read.AlignmentUtils
Aligns reads the haplotype, and then projects this alignment of read -> hap onto the reference via the alignment of haplotype (via its getCigar) method.
CreateReadCountPanelOfNormals - Class in org.broadinstitute.hellbender.tools.copynumber
Creates a panel of normals (PoN) for read-count denoising given the read counts for samples in the panel.
CreateReadCountPanelOfNormals() - Constructor for class org.broadinstitute.hellbender.tools.copynumber.CreateReadCountPanelOfNormals
 
createReadThreadingAssembler(AssemblyBasedCallerArgumentCollection) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerUtils
 
createRecalibrationGATKReport(GATKReportTable, QuantizationInfo, RecalibrationTables, StandardCovariateList) - Static method in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
Creates a consolidated GATK report, first generating report tables.
createRecalibrationGATKReport(GATKReportTable, GATKReportTable, List<GATKReportTable>) - Static method in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
Creates a consolidated GATK report from the tables.
createRecalibrationReport(GATKReportTable, GATKReportTable, List<GATKReportTable>) - Static method in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
Creates a consolidated RecalibrationReport report from the tables.
createRecord(DataLine) - Method in class org.broadinstitute.hellbender.tools.walkers.validation.ConcordanceSummaryRecord.Reader
 
createRecord(DataLine) - Method in class org.broadinstitute.hellbender.utils.mcmc.ParameterReader
 
createRecord(DataLine) - Method in class org.broadinstitute.hellbender.utils.tsv.TableReader
Transforms a data-line column values into a record.
createReferenceHaplotype(AssemblyRegion, SimpleInterval, ReferenceSequenceFile) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerUtils
Helper function to create the reference haplotype out of the active region and a padded loc
createReferenceHaplotype(AssemblyRegion, byte[], SimpleInterval) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReferenceConfidenceModel
Create a reference haplotype for an active region
createReferenceReader(String) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerUtils
 
createReverseComplementTransitions(Collection<Transition>) - Static method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasUtils
Create new Transitions that are complements of the given collection.
createSamBackedRead(String, int, int) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
Creates an artificial GATKRead backed by a SAMRecord.
createSamBackedRead(String, String, int, int) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
Creates an artificial GATKRead backed by a SAMRecord.
createSamFileHeader() - Method in class picard.sam.FastqToSam
Creates a simple header with the values provided on the command line.
createSamFileWriter(SAMFileHeader) - Method in class picard.sam.FixMateInformation
 
createSampleToGenotypeVariantContextSortedMap(List<String>, Collection<VariantContext>) - Static method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasFilterer
Creates a map that includes the artifact mode complements.
createSAMWriter(File, File, SAMFileHeader, boolean) - Method in class org.broadinstitute.hellbender.cmdline.PicardCommandLineProgram
Create a common SAMFileWriter for use with Picard tools.
createSAMWriter(File, boolean) - Method in class org.broadinstitute.hellbender.engine.GATKTool
 
createSAMWriter(Path, boolean) - Method in class org.broadinstitute.hellbender.engine.GATKTool
 
createSATags(List<BwaMemAlignment>, List<String>) - Static method in class org.broadinstitute.hellbender.utils.bwa.BwaMemAlignmentUtils
Produces an SA tag for each primary line and supplemental alignment as a map from alignment to tag value.
CreateSeqDictReferenceArgumentCollection() - Constructor for class picard.sam.CreateSequenceDictionary.CreateSeqDictReferenceArgumentCollection
 
CreateSequenceDictionary - Class in picard.sam
Create a SAM/BAM file from a fasta containing reference sequence.
CreateSequenceDictionary() - Constructor for class picard.sam.CreateSequenceDictionary
 
CreateSequenceDictionary.CreateSeqDictReferenceArgumentCollection - Class in picard.sam
 
createSequenceDictionaryFromFeatureIndex(File) - Static method in class org.broadinstitute.hellbender.utils.IndexUtils
get the sequence dictionary contig list that is in the index or null if there is no index or no contigs Note: the dictionary returned will not have the contig lengths filled in SAMSequenceRecord.UNKNOWN_SEQUENCE_LENGTH is used.
createSetFromList(GenomeLocParser, List<GenomeLoc>) - Static method in class org.broadinstitute.hellbender.utils.GenomeLocSortedSet
Create a sorted genome location set from a list of GenomeLocs.
createSetFromSequenceDictionary(SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.utils.GenomeLocSortedSet
create a list of genomic locations, given a reference sequence
createSimpleXsvDataSource(Path, Properties, LinkedHashMap<String, String>) - Static method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
Create a SimpleKeyXsvFuncotationFactory from filesystem resources and field overrides.
createSnpAndIndelBitSets(File, SAMSequenceDictionary) - Static method in class picard.util.DbSnpBitSetUtil
Factory method to create both a SNP bitmask and an indel bitmask in a single pass of the VCF.
createSnpAndIndelBitSets(File, SAMSequenceDictionary, IntervalList) - Static method in class picard.util.DbSnpBitSetUtil
Factory method to create both a SNP bitmask and an indel bitmask in a single pass of the VCF.
createSnpAndIndelBitSets(File, SAMSequenceDictionary, IntervalList, Optional<Log>) - Static method in class picard.util.DbSnpBitSetUtil
Factory method to create both a SNP bitmask and an indel bitmask in a single pass of the VCF.
CreateSomaticPanelOfNormals - Class in org.broadinstitute.hellbender.tools.walkers.mutect
Create a panel of normals (PoN) containing germline and artifactual sites for use with Mutect2.
CreateSomaticPanelOfNormals() - Constructor for class org.broadinstitute.hellbender.tools.walkers.mutect.CreateSomaticPanelOfNormals
 
CreateSomaticPanelOfNormals.DuplicateSampleStrategy - Enum in org.broadinstitute.hellbender.tools.walkers.mutect
 
createSplicedDeletionPileupElement(int, Allele, int) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
See ArtificialReadUtils.createSplicedInsertionPileupElement(int, htsjdk.variant.variantcontext.Allele, int), except that this method returns a pileup element containing the specified deletion.
createSplicedInsertionPileupElement(int, Allele, int) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
Create a pileupElement with the given insertion added to the bases.
createSpliceSiteCodonChange(int, int, int, int, Strand, int) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Gets a codon change string for a splice site.
createSVD(RealMatrix) - Method in class org.broadinstitute.hellbender.utils.svd.ApacheSingularValueDecomposer
Create a SVD instance using Apache Commons Math.
createSVD(RealMatrix) - Method in class org.broadinstitute.hellbender.utils.svd.OjAlgoSingularValueDecomposer
Create a SVD instance using ojAlgo.
createSVD(RealMatrix) - Method in interface org.broadinstitute.hellbender.utils.svd.SingularValueDecomposer
 
createSVD(RealMatrix) - Method in class org.broadinstitute.hellbender.utils.svd.SparkSingularValueDecomposer
Create a SVD of the given matrix using the given Java Spark Context.
createSVD(RealMatrix) - Static method in class org.broadinstitute.hellbender.utils.svd.SVDFactory
Create a SVD instance using Apache Commons Math.
createSVD(RealMatrix, JavaSparkContext) - Static method in class org.broadinstitute.hellbender.utils.svd.SVDFactory
Create a SVD instance using a spark context.
createTempDir(String) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
Creates a temp directory with the given prefix.
createTempDir(String) - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest
Creates an empty temp directory which will be deleted on exit after tests are complete
createTempFile(String, String) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
Creates a temp file that will be deleted on exit This will also mark the corresponding Tribble/Tabix/BAM indices matching the temp file for deletion.
createTempFile(String, String) - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest
Creates a temp file that will be deleted on exit after tests are complete.
createTempFileInDirectory(String, String, File) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
Creates a temp file in a target directory that will be deleted on exit This will also mark the corresponding Tribble/Tabix/BAM indices matching the temp file for deletion.
createTempGenomicsDB(File, Locatable) - Static method in class org.broadinstitute.hellbender.utils.test.GenomicsDBTestUtils
Create a temporary GenomicsDB containing a single interval of data from a set of gvcfs this database will be deleted on jvm shutdown automatically
createTempGenomicsDB(List<File>, Locatable) - Static method in class org.broadinstitute.hellbender.utils.test.GenomicsDBTestUtils
Create a temporary GenomicsDB containing a single interval of data from a set of gvcfs this database will be deleted on jvm shutdown automatically
createThreadSafeProvider(StandardCallerArgumentCollection) - Static method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.FixedAFCalculatorProvider
Creates a fixed AF calculator provider that is thread safe.
createTransitionMatrix(int) - Static method in class org.broadinstitute.hellbender.utils.pairhmm.PairHMMModel
Creates a transition probability matrix large enough to work with sequences of a particular length.
createUniqueArtificialRead(Cigar) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
Makes a new read with a name that is unique (so that it will return false to equals(otherRead)
createUniqueArtificialRead(String) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
Makes a new read with a name that is unique (so that it will return false to equals(otherRead)
createUniqueArtificialSAMRecord(Cigar) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
Makes a new read with a name that is unique (so that it will return false to equals(otherRead)
createVariantContextWriter(Configuration, OutputStream) - Method in class org.broadinstitute.hellbender.engine.spark.datasources.VariantsSparkSink.GvcfKeyIgnoringVCFRecordWriter
 
createVcfDataSource(Path, Properties, LinkedHashMap<String, String>, TranscriptSelectionMode, Set<String>) - Static method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
Create a VcfFuncotationFactory from filesystem resources and field overrides.
createVCFHeader(VCFHeader, String, List<String>) - Static method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasFilterer
Ingest the current VCF header and update it with the information necessary for the Orientation Bias filter to run.
createVCFWriter(File) - Method in class org.broadinstitute.hellbender.engine.GATKTool
Creates a VariantContextWriter whose outputFile type is determined by the outFile's extension, using the best available sequence dictionary for this tool, and default index, leniency and md5 generation settings.
createVCFWriter(File, SAMSequenceDictionary, boolean, Options...) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Creates a VariantContextWriter whose outputFile type is based on the extension of the output file name.
createVCSetFromFingerprint(Fingerprint, ReferenceSequenceFile, String) - Static method in class picard.fingerprint.FingerprintUtils
A utility function that takes a fingerprint and returns a VariantContextSet with variants representing the haplotypes in the fingerprint
createWorkUnit(DocumentedFeature, ClassDoc, Class<?>) - Method in class org.broadinstitute.hellbender.utils.help.GATKHelpDoclet
 
createWorkUnit(DocumentedFeature, ClassDoc, Class<?>) - Method in class picard.util.help.PicardHelpDoclet
 
CROSSCHECK_BY - Variable in class picard.fingerprint.CrosscheckFingerprints
 
CROSSCHECK_LIBRARIES - Variable in class picard.fingerprint.CrosscheckReadGroupFingerprints
Deprecated.
 
CROSSCHECK_MODE - Variable in class picard.fingerprint.CrosscheckFingerprints
 
CROSSCHECK_SAMPLES - Variable in class picard.fingerprint.CrosscheckReadGroupFingerprints
Deprecated.
 
CrosscheckFingerprints - Class in picard.fingerprint
Checks that all data in the set of input files appear to come from the same individual.
CrosscheckFingerprints() - Constructor for class picard.fingerprint.CrosscheckFingerprints
 
CrosscheckMetric - Class in picard.fingerprint
A class to hold the result of crosschecking fingerprints.
CrosscheckMetric() - Constructor for class picard.fingerprint.CrosscheckMetric
 
CrosscheckMetric.DataType - Enum in picard.fingerprint
 
CrosscheckMetric.FingerprintResult - Enum in picard.fingerprint
 
CrosscheckReadGroupFingerprints - Class in picard.fingerprint
Deprecated.
6/6/2017 Use CrosscheckFingerprints instead.
CrosscheckReadGroupFingerprints() - Constructor for class picard.fingerprint.CrosscheckReadGroupFingerprints
Deprecated.
 
crossContigsToIgnoreFile - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
This is a path to a text file of contig names (one per line) that will be ignored when looking for inter-contig pairs.
csvFile - Variable in class org.broadinstitute.hellbender.tools.walkers.bqsr.AnalyzeCovariates
Output csv file name.
CsvInputParser - Class in picard.util
 
CsvInputParser(boolean, InputStream...) - Constructor for class picard.util.CsvInputParser
Constructor
CsvInputParser(boolean, File...) - Constructor for class picard.util.CsvInputParser
Constructor
csvPrinter(File, StandardCovariateList) - Static method in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
Returns a csv output printer.
CTG_GOOD_NONCANONICAL_MAPPING - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
CULPRIT_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
cumulativeProbability(int) - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.BetaBinomialDistribution
 
curContig - Variable in class org.broadinstitute.hellbender.tools.spark.sv.evidence.KSWindowFinder
 
curEnd - Variable in class org.broadinstitute.hellbender.tools.spark.sv.evidence.KSWindowFinder
 
CURRENT_MINIMUM_DATA_SOURCE_VERSION - Static variable in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
The minimum version of the data sources required for funcotator to run.
currentChromo - Variable in class org.broadinstitute.hellbender.utils.read.ArtificialReadIterator
 
currentInterval - Variable in class org.broadinstitute.hellbender.utils.iterators.IntervalLocusIterator
 
currentRead - Variable in class org.broadinstitute.hellbender.utils.read.ArtificialReadIterator
 
CUSHION_FOR_INDELS - Static variable in class org.broadinstitute.hellbender.utils.recalibration.covariates.CycleCovariate
 
CUSTOM_AMPLICON_SET - Variable in class picard.analysis.directed.TargetedPcrMetrics
The name of the amplicon set used in this metrics collection run
CUSTOM_AMPLICON_SET_NAME - Variable in class picard.analysis.directed.CollectTargetedPcrMetrics
 
CustomAFPriorProvider - Class in org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc
Custom priors provided as an array.
CustomAFPriorProvider(List<Double>) - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.CustomAFPriorProvider
 
CustomBooleanConverter - Class in org.broadinstitute.hellbender.utils.config
Converts a given string into a Boolean after trimming whitespace from that string.
CustomBooleanConverter() - Constructor for class org.broadinstitute.hellbender.utils.config.CustomBooleanConverter
 
customCommandLineValidation() - Method in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
Put any custom command-line validation in an override of this method.
customCommandLineValidation() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.CNNScoreVariants
 
customCommandLineValidation() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.AbstractOpticalDuplicateFinderCommandLineProgram
 
customCommandLineValidation() - Method in class picard.analysis.artifacts.CollectSequencingArtifactMetrics
 
customCommandLineValidation() - Method in class picard.analysis.CollectInsertSizeMetrics
Put any custom command-line validation in an override of this method.
customCommandLineValidation() - Method in class picard.analysis.CollectMultipleMetrics
 
customCommandLineValidation() - Method in class picard.analysis.CollectOxoGMetrics
 
customCommandLineValidation() - Method in class picard.analysis.CollectRnaSeqMetrics
 
customCommandLineValidation() - Method in class picard.analysis.CollectRrbsMetrics
 
customCommandLineValidation() - Method in class picard.analysis.directed.CollectTargetedMetrics
 
customCommandLineValidation() - Method in class picard.cmdline.CommandLineProgram
Put any custom command-line validation in an override of this method.
customCommandLineValidation() - Method in class picard.fastq.BamToBfq
 
customCommandLineValidation() - Method in class picard.fingerprint.CheckFingerprint
 
customCommandLineValidation() - Method in class picard.fingerprint.CrosscheckFingerprints
 
customCommandLineValidation() - Method in class picard.fingerprint.CrosscheckReadGroupFingerprints
Deprecated.
 
customCommandLineValidation() - Method in class picard.illumina.CheckIlluminaDirectory
 
customCommandLineValidation() - Method in class picard.illumina.ExtractIlluminaBarcodes
Validate that POSITION >= 1, and that all BARCODEs are the same length and unique
customCommandLineValidation() - Method in class picard.illumina.IlluminaBasecallsToFastq
 
customCommandLineValidation() - Method in class picard.illumina.IlluminaBasecallsToSam
Put any custom command-line validation in an override of this method.
customCommandLineValidation() - Method in class picard.illumina.MarkIlluminaAdapters
 
customCommandLineValidation() - Method in class picard.illumina.quality.CollectHiSeqXPfFailMetrics
 
customCommandLineValidation() - Method in class picard.sam.AddOrReplaceReadGroups
 
customCommandLineValidation() - Method in class picard.sam.CreateSequenceDictionary
Use reference filename to create URI to go into header if URI was not passed on cmd line.
customCommandLineValidation() - Method in class picard.sam.DownsampleSam
 
customCommandLineValidation() - Method in class picard.sam.FastqToSam
 
customCommandLineValidation() - Method in class picard.sam.FilterSamReads
 
customCommandLineValidation() - Method in class picard.sam.markduplicates.EstimateLibraryComplexity
 
customCommandLineValidation() - Method in class picard.sam.markduplicates.util.AbstractOpticalDuplicateFinderCommandLineProgram
 
customCommandLineValidation() - Method in class picard.sam.MergeBamAlignment
Put any custom command-line validation in an override of this method.
customCommandLineValidation() - Method in class picard.sam.MergeSamFiles
 
customCommandLineValidation() - Method in class picard.sam.PositionBasedDownsampleSam
 
customCommandLineValidation() - Method in class picard.sam.RevertSam
Enforce that output ordering is queryname when sanitization is turned on since it requires a queryname sort.
customCommandLineValidation() - Method in class picard.sam.SamToFastq
Put any custom command-line validation in an override of this method.
customCommandLineValidation() - Method in class picard.sam.SamToFastqWithTags
 
customCommandLineValidation() - Method in class picard.sam.SplitSamByNumberOfReads
 
customCommandLineValidation() - Method in class picard.sam.ValidateSamFile
 
customCommandLineValidation() - Method in class picard.sam.ViewSam
 
customCommandLineValidation() - Method in class picard.util.BaitDesigner
 
customCommandLineValidation() - Method in class picard.util.IntervalListTools
 
customCommandLineValidation() - Method in class picard.vcf.FixVcfHeader
 
customCommandLineValidation() - Method in class picard.vcf.GenotypeConcordance
 
customCommandLineValidation() - Method in class picard.vcf.MendelianViolations.FindMendelianViolations
Validates that the sex chromosomes don't overlap and parses the pseudo-autosomal regions into usable objects to ensure their parsability
CUTOFF_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.AnnotatePairOrientation
 
CUTOFF_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
CUTOFF_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.AnnotatePairOrientation
 
cutToShards(Iterable<SimpleInterval>, int) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Splits the given input intervals into shards of at most the requested size.
CYCLE - Variable in class org.broadinstitute.hellbender.metrics.analysis.BaseDistributionByCycleMetrics
 
CYCLE - Variable in class picard.analysis.BaseDistributionByCycleMetrics
 
cycle - Variable in class picard.illumina.parser.readers.EmpiricalPhasingMetricsOutReader.IlluminaPhasingMetrics
 
CYCLE_CONTAINING_TILE_METRICS - Static variable in class picard.illumina.parser.TileMetricsUtil
The cycle directory that contain the tile metrics output.
CYCLE_SUBDIRECTORY_PATTERN - Static variable in class picard.illumina.parser.IlluminaFileUtil
 
CycleCovariate - Class in org.broadinstitute.hellbender.utils.recalibration.covariates
The Cycle covariate.
CycleCovariate(RecalibrationArgumentCollection) - Constructor for class org.broadinstitute.hellbender.utils.recalibration.covariates.CycleCovariate
 
cycleFromKey(int) - Static method in class org.broadinstitute.hellbender.utils.recalibration.covariates.CycleCovariate
Decodes the cycle number from the key.
cycleKey(int, GATKRead, boolean, int) - Static method in class org.broadinstitute.hellbender.utils.recalibration.covariates.CycleCovariate
Computes the encoded value of CycleCovariate's key for the given position at the read.
CYCLES_TO_TRIM_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.ClipReads
 
CYCLES_TO_TRIM_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.ClipReads
 

D

data - Variable in class org.broadinstitute.hellbender.utils.collections.NestedIntegerArray
 
data() - Method in interface org.broadinstitute.hellbender.utils.hmm.ForwardBackwardAlgorithm.Result
Returns the data passed to the forward-backward algorithm.
DATA_SOURCES_BUCKET_PATH - Static variable in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
 
DATA_SOURCES_FTP_PATH - Static variable in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
 
DATA_SOURCES_PATH_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorArgumentDefinitions
 
DATA_TYPE - Variable in class picard.fingerprint.CrosscheckMetric
 
DATA_TYPES - Variable in class picard.illumina.CheckIlluminaDirectory
 
DATA_TYPES_NO_BARCODE - Static variable in class picard.illumina.IlluminaBasecallsConverter
 
DataCollection - Interface in org.broadinstitute.hellbender.utils.mcmc
Interface for tagging any class that represents a collection of datasets required to update posterior samples for Markov-Chain Monte Carlo sampling using samplers implementing the ParameterSampler interface.
dataFile - Variable in class picard.illumina.parser.MultiTileFileUtil
 
DataLine - Class in org.broadinstitute.hellbender.utils.tsv
Table data-line string array wrapper.
DataLine(long, TableColumnCollection, Function<String, RuntimeException>) - Constructor for class org.broadinstitute.hellbender.utils.tsv.DataLine
Creates a new data-line instance.
DataLine(TableColumnCollection, Function<String, RuntimeException>) - Constructor for class org.broadinstitute.hellbender.utils.tsv.DataLine
Creates a new data-line instance with no line-number.
datasourceComparator(DataSourceFuncotationFactory, DataSourceFuncotationFactory) - Static method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
Sort by putting gencode datasources first and then non-gencode in alphabetical order.
dataSourceDirectories - Variable in class org.broadinstitute.hellbender.tools.funcotator.Funcotator
 
dataSourceFactories - Variable in class org.broadinstitute.hellbender.tools.funcotator.OutputRenderer
List of the DataSourceFuncotationFactory objects that are being used in this run of Funcotator.
DataSourceFuncotationFactory - Class in org.broadinstitute.hellbender.tools.funcotator
An abstract class to allow for the creation of a Funcotation for a given data source.
DataSourceFuncotationFactory() - Constructor for class org.broadinstitute.hellbender.tools.funcotator.DataSourceFuncotationFactory
 
DataSourceUtils - Class in org.broadinstitute.hellbender.tools.funcotator.dataSources
Utilities for reading / working with / manipulating Data Sources.
datumValue(VariantDatum) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.TrancheManager.SelectionMetric
 
datumValue(VariantDatum) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.TrancheManager.TruthSensitivityMetric
 
DB_SNP - Variable in class picard.analysis.artifacts.CollectSequencingArtifactMetrics
 
DB_SNP - Variable in class picard.analysis.CollectMultipleMetrics
 
DB_SNP - Variable in class picard.analysis.CollectOxoGMetrics
 
dbsnp - Variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.DbsnpArgumentCollection
A dbSNP VCF file.
dbsnp - Variable in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotator
The rsIDs from this file are used to populate the ID column of the output.
dbsnp - Variable in class org.broadinstitute.hellbender.tools.walkers.CombineGVCFs
The rsIDs from this file are used to populate the ID column of the output.
dbsnp - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerArgumentCollection
rsIDs from this file are used to populate the ID column of the output.
DBSNP - Variable in class picard.vcf.CollectVariantCallingMetrics
 
DBSNP_INS_DEL_RATIO - Variable in class picard.vcf.CollectVariantCallingMetrics.VariantCallingSummaryMetrics
The Insertion/Deletion ratio of the indel calls made at dbSNP sites
DBSNP_TITV - Variable in class picard.vcf.CollectVariantCallingMetrics.VariantCallingSummaryMetrics
The Transition/Transversion ratio of the passing bi-allelic SNP calls made at dbSNP sites
DbsnpArgumentCollection - Class in org.broadinstitute.hellbender.cmdline.argumentcollections
 
DbsnpArgumentCollection() - Constructor for class org.broadinstitute.hellbender.cmdline.argumentcollections.DbsnpArgumentCollection
 
DbSnpBitSets() - Constructor for class org.broadinstitute.hellbender.utils.variant.DbSnpBitSetUtil.DbSnpBitSets
 
DbSnpBitSets() - Constructor for class picard.util.DbSnpBitSetUtil.DbSnpBitSets
 
DbSnpBitSetUtil - Class in org.broadinstitute.hellbender.utils.variant
Utility class to use with DbSnp files to determine is a locus is a dbSnp site.
DbSnpBitSetUtil(File, SAMSequenceDictionary) - Constructor for class org.broadinstitute.hellbender.utils.variant.DbSnpBitSetUtil
Constructor that creates a bit set with bits set to true for all variant types.
DbSnpBitSetUtil(File, SAMSequenceDictionary, Collection<DbSnpVariantType>) - Constructor for class org.broadinstitute.hellbender.utils.variant.DbSnpBitSetUtil
Constructor.
DbSnpBitSetUtil - Class in picard.util
Utility class to use with DbSnp files to determine is a locus is a dbSnp site.
DbSnpBitSetUtil(File, SAMSequenceDictionary) - Constructor for class picard.util.DbSnpBitSetUtil
Constructor that creates a bit set with bits set to true for all variant types.
DbSnpBitSetUtil(File, SAMSequenceDictionary, Collection<VariantType>) - Constructor for class picard.util.DbSnpBitSetUtil
Constructor that creates a bit set with bits set to true for the given variant types.
DbSnpBitSetUtil(File, SAMSequenceDictionary, Collection<VariantType>, IntervalList) - Constructor for class picard.util.DbSnpBitSetUtil
Constructor that creates a bit set with bits set to true for the given variant types over the given regions.
DbSnpBitSetUtil(File, SAMSequenceDictionary, Collection<VariantType>, IntervalList, Optional<Log>) - Constructor for class picard.util.DbSnpBitSetUtil
Constructor.
DbSnpBitSetUtil.DbSnpBitSets - Class in org.broadinstitute.hellbender.utils.variant
Little tuple class to contain one bitset for SNPs and another for Indels.
DbSnpBitSetUtil.DbSnpBitSets - Class in picard.util
Little tuple class to contain one bitset for SNPs and another for Indels.
DbSnpVariantType - Enum in org.broadinstitute.hellbender.utils.variant
Enum to hold the possible types of dbSnps.
debug - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerArgumentCollection
 
DEBUG_FREQUENCY - Variable in class picard.util.FifoBuffer
 
debugDump(Logger) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResultSet
Dumps debugging information into a logger.
debugGraphTransformations - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadThreadingAssemblerArgumentCollection
 
Decile - Enum in org.broadinstitute.hellbender.utils.mcmc
Enumerates individual deciles.
DecileCollection - Class in org.broadinstitute.hellbender.utils.mcmc
Represents a set of deciles.
DecileCollection(List<Double>) - Constructor for class org.broadinstitute.hellbender.utils.mcmc.DecileCollection
Constructs a DecileCollection from a list of samples using Apache Commons Percentile.
decode() - Method in class htsjdk.samtools.SAMRecordSparkCodec
Read the next record from the input stream and convert into a java object.
decode(String) - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalCodec
 
decode(String) - Static method in enum org.broadinstitute.hellbender.tools.spark.sv.utils.Strand
 
decode(char) - Static method in enum org.broadinstitute.hellbender.tools.spark.sv.utils.Strand
 
decode(LineIterator) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfCodec
 
decode(B) - Method in class org.broadinstitute.hellbender.utils.codecs.ProgressReportingDelegatingCodec
 
decode(String) - Method in class org.broadinstitute.hellbender.utils.codecs.sampileup.SAMPileupCodec
 
decode(String) - Method in class org.broadinstitute.hellbender.utils.codecs.table.TableCodec
 
decode(String) - Method in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvLocatableTableCodec
 
decode() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEndsForMarkDuplicatesCodec
 
decode() - Method in class picard.sam.markduplicates.util.ReadEndsForMarkDuplicatesCodec
 
decode() - Method in class picard.sam.markduplicates.util.ReadEndsForMarkDuplicatesWithBarcodesCodec
 
decode() - Method in class picard.sam.markduplicates.util.RepresentativeReadIndexerCodec
 
decodeAnnotations(VariantDatum, VariantContext, boolean) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
 
decodeLoc(B) - Method in class org.broadinstitute.hellbender.utils.codecs.ProgressReportingDelegatingCodec
 
decodeLoc(LineIterator) - Method in class org.broadinstitute.hellbender.utils.codecs.sampileup.SAMPileupCodec
For fast indexing
decomposeHaplotypesIntoVariantContexts(List<Haplotype>, byte[], SimpleInterval, List<VariantContext>, int) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerGenotypingEngine
Go through the haplotypes we assembled, and decompose them into their constituent variant contexts
deepCopy() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Return a deep copy of this read.
deepCopy() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
DEFAULT - Static variable in enum org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculatorImplementation
Reference to the default implementation.
DEFAULT_ACTIVE_PROB_THRESHOLD - Static variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCaller
 
DEFAULT_ADAPTER_LENGTH - Static variable in class picard.util.AdapterMarker
 
DEFAULT_ADAPTER_SEQUENCE - Static variable in class picard.analysis.AdapterUtility
 
DEFAULT_AF_FOR_TUMOR_NORMAL_CALLING - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
DEFAULT_AF_FOR_TUMOR_ONLY_CALLING - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
DEFAULT_AF_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
DEFAULT_AF_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
DEFAULT_ARRAY_NAME - Static variable in class org.broadinstitute.hellbender.tools.genomicsdb.GenomicsDBConstants
 
DEFAULT_ARTIFACT_MODE - Static variable in class org.broadinstitute.hellbender.tools.exome.FilterByOrientationBias
 
DEFAULT_ASSEMBLED_IMPRECISE_EVIDENCE_OVERLAP_UNCERTAINTY - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.DiscoverVariantsFromContigsAlignmentsSparkArgumentCollection
 
DEFAULT_ASSEMBLY_REGION_PADDING - Static variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCaller
 
DEFAULT_BANDWIDTH - Static variable in class org.broadinstitute.hellbender.utils.baq.BAQ
 
DEFAULT_BASES_PER_LINE - Static variable in class org.broadinstitute.hellbender.utils.reference.FastaReferenceWriter
Default number of bases per line.
DEFAULT_BIG_DUPLICATE_SET_SIZE - Static variable in class picard.sam.markduplicates.util.OpticalDuplicateFinder
 
DEFAULT_CACHE_SIZE - Static variable in class org.broadinstitute.hellbender.utils.fasta.CachingIndexedFastaSequenceFile
The default cache size in bp
DEFAULT_CALLSETMAP_FILE_NAME - Static variable in class org.broadinstitute.hellbender.tools.genomicsdb.GenomicsDBConstants
 
DEFAULT_CIGAR_STRINGS_FOR_DUP_SEQ_ON_CTG - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications.SmallDuplicationWithPreciseDupRangeBreakpointComplications
 
DEFAULT_CONTAMINATION_FRACTION - Static variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.StandardCallerArgumentCollection
 
DEFAULT_DOWNSAMPLING_TYPE - Static variable in class org.broadinstitute.hellbender.utils.downsampling.DownsamplingMethod
Default type to use if no type is specified
DEFAULT_DROP_RATIO - Static variable in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.RealignmentArgumentCollection
 
DEFAULT_EXPECTED_ORIENTATIONS - Static variable in class picard.analysis.ChimeraUtil
 
DEFAULT_FRAGMENT_SIZE - Static variable in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.FilterAlignmentArtifacts
 
DEFAULT_GATK3_HAPLOTYPE_READ_GROUP_ID - Static variable in class org.broadinstitute.hellbender.utils.haplotype.HaplotypeBAMWriter
 
DEFAULT_GENOTYPING_ERROR_RATE - Static variable in class picard.fingerprint.FingerprintChecker
 
DEFAULT_GERMLINE_TAG_PADDING_IN_BP - Static variable in class org.broadinstitute.hellbender.tools.copynumber.utils.TagGermlineEvents
 
DEFAULT_GOP - Static variable in class org.broadinstitute.hellbender.utils.baq.BAQ
 
DEFAULT_GVCF_INDEX_PARAMETER - Static variable in class org.broadinstitute.hellbender.utils.variant.VcfUtils
 
DEFAULT_GVCF_INDEX_TYPE - Static variable in class org.broadinstitute.hellbender.utils.variant.VcfUtils
 
DEFAULT_HAPLOTYPE_READ_GROUP_ID - Static variable in class org.broadinstitute.hellbender.utils.haplotype.HaplotypeBAMWriter
 
DEFAULT_IMPRECISE_VARIANT_EVIDENCE_THRESHOLD - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.DiscoverVariantsFromContigsAlignmentsSparkArgumentCollection
 
DEFAULT_INDEL_START_TOLERANCE - Static variable in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.FilterAlignmentArtifacts
 
DEFAULT_INSERT_SIZE_LIMIT - Static variable in class picard.analysis.ChimeraUtil
 
DEFAULT_INSERTION_DELETION_QUAL - Static variable in class org.broadinstitute.hellbender.utils.read.ReadUtils
The default quality score for an insertion or deletion, if none are provided for this read.
DEFAULT_MAX_ASSEMBLY_REGION_SIZE - Static variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCaller
 
DEFAULT_MAX_CALLABLE_IMPRECISE_DELETION_SIZE - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.DiscoverVariantsFromContigsAlignmentsSparkArgumentCollection
 
DEFAULT_MAX_DUPLICATE_SET_SIZE - Static variable in class picard.sam.markduplicates.util.OpticalDuplicateFinder
 
DEFAULT_MAX_EVAL - Static variable in class org.broadinstitute.hellbender.utils.OptimizationUtils
 
DEFAULT_MAX_FAILED_REALIGNMENTS - Static variable in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.FilterAlignmentArtifacts
 
DEFAULT_MAX_PROB_PROPAGATION_DISTANCE - Static variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCaller
 
DEFAULT_MAX_READS_PER_ALIGNMENT - Static variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCaller
 
DEFAULT_MAX_REASONABLE_FRAGMENT_LENGTH - Static variable in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.RealignmentArgumentCollection
 
DEFAULT_MAXIMAL_PL_DIFFERENCE - Static variable in class picard.fingerprint.FingerprintChecker
 
DEFAULT_MIN_ALIGNER_SCORE_DIFFERENCE - Static variable in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.RealignmentArgumentCollection
 
DEFAULT_MIN_ALIGNMENT_LENGTH - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.DiscoverVariantsFromContigsAlignmentsSparkArgumentCollection
 
DEFAULT_MIN_ASSEMBLY_REGION_SIZE - Static variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCaller
 
DEFAULT_MIN_BQ_CUTOFF - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
DEFAULT_MIN_SAMPLE_COUNT - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.CreateSomaticPanelOfNormals
 
DEFAULT_MIN_SEED_LENGTH - Static variable in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.RealignmentArgumentCollection
 
DEFAULT_MINIMUM_BASE_QUALITY - Static variable in class picard.fingerprint.FingerprintChecker
 
DEFAULT_MINIMUM_MAPPING_QUALITY - Static variable in class picard.fingerprint.FingerprintChecker
 
DEFAULT_NAME - Static variable in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationFactory
Default name for this data source.
DEFAULT_NUM_ADAPTERS_TO_KEEP - Static variable in class picard.util.AdapterMarker
 
DEFAULT_NUM_REGULAR_CONTIGS - Static variable in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.RealignmentArgumentCollection
 
DEFAULT_OPTICAL_DUPLICATE_DISTANCE - Static variable in class picard.sam.markduplicates.util.OpticalDuplicateFinder
 
DEFAULT_OPTIMIZER - Static variable in class org.broadinstitute.hellbender.utils.OptimizationUtils
 
DEFAULT_PCR_ERROR_QUAL - Static variable in class org.broadinstitute.hellbender.utils.fragments.FragmentUtils
 
DEFAULT_PCR_ERROR_RATE - Static variable in class org.broadinstitute.hellbender.utils.fragments.FragmentUtils
 
DEFAULT_PLATFORM - Variable in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationArgumentCollection
 
DEFAULT_PLOIDY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
 
DEFAULT_PLOIDY - Static variable in class org.broadinstitute.hellbender.utils.variant.HomoSapiensConstants
Standard ploidy for autosomal chromosomes.
DEFAULT_PROPERTIES - Static variable in class org.broadinstitute.hellbender.engine.spark.SparkContextFactory
Default properties, GATK may not run if these are set to bad values.
DEFAULT_PRUNE_ADAPTER_LIST_AFTER_THIS_MANY_ADAPTERS_SEEN - Static variable in class picard.util.AdapterMarker
 
DEFAULT_QUERY_LOOKAHEAD_BASES - Static variable in class org.broadinstitute.hellbender.engine.FeatureDataSource
Default value for queryLookaheadBases, if none is specified.
DEFAULT_QUEUE_SIZE - Static variable in class picard.util.AsyncIterator
 
DEFAULT_READ_LENGTH - Static variable in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
 
DEFAULT_READ_NAME_REGEX - Static variable in class picard.sam.util.ReadNameParser
The read name regular expression (regex) is used to extract three pieces of information from the read name: tile, x location, and y location.
DEFAULT_READ_VALIDATION_STRINGENCY - Static variable in class org.broadinstitute.hellbender.utils.read.ReadConstants
Value used as the default validation stringency for all read input
DEFAULT_READSHARD_SIZE - Static variable in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark
 
DEFAULT_RECORD_LABEL - Static variable in class org.broadinstitute.hellbender.engine.ProgressMeter
Default label for records in logger messages.
DEFAULT_RECORDS_BETWEEN_TIME_CHECKS - Static variable in class org.broadinstitute.hellbender.engine.ProgressMeter
We check the current time every time we process this many records, by default (to cut down on the number of system calls)
DEFAULT_SECONDS_BETWEEN_UPDATES - Static variable in class org.broadinstitute.hellbender.engine.ProgressMeter
By default, we output a line to the logger after this many seconds have elapsed
DEFAULT_SEED_SPLIT_FACTOR - Static variable in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.RealignmentArgumentCollection
 
DEFAULT_SIGMA - Static variable in class org.broadinstitute.hellbender.utils.activityprofile.BandPassActivityProfile
 
DEFAULT_SPARK_MASTER - Static variable in class org.broadinstitute.hellbender.engine.spark.SparkContextFactory
 
DEFAULT_SUFFICIENT_GOOD_REALIGNMENTS - Static variable in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.FilterAlignmentArtifacts
 
DEFAULT_TAGS_TO_DROP - Static variable in class picard.util.LiftoverUtils
 
DEFAULT_TAGS_TO_REVERSE - Static variable in class picard.util.LiftoverUtils
Default list of attributes that need to be reversed or dropped from the INFO field when alleles have been swapped.
DEFAULT_TEMP_EXTENSION - Static variable in class org.broadinstitute.hellbender.utils.test.IntegrationTestSpec
 
DEFAULT_TEMP_PREFIX - Static variable in class org.broadinstitute.hellbender.utils.test.IntegrationTestSpec
 
DEFAULT_TEST_PROPERTIES - Static variable in class org.broadinstitute.hellbender.engine.spark.SparkContextFactory
 
DEFAULT_TIME_FUNCTION - Static variable in class org.broadinstitute.hellbender.engine.ProgressMeter
By default, we use this function to get the current time
DEFAULT_TRANCHE_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.vqsr.Tranche
 
DEFAULT_TRUTH_INTERVAL_PADDING - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.DiscoverVariantsFromContigsAlignmentsSparkArgumentCollection
 
DEFAULT_VCFHEADER_FILE_NAME - Static variable in class org.broadinstitute.hellbender.tools.genomicsdb.GenomicsDBConstants
 
DEFAULT_VERSION_STRING - Static variable in class org.broadinstitute.hellbender.tools.funcotator.DataSourceFuncotationFactory
Default version string for this DataSourceFuncotationFactory.
DEFAULT_VIDMAP_FILE_NAME - Static variable in class org.broadinstitute.hellbender.tools.genomicsdb.GenomicsDBConstants
 
defaultActiveProbThreshold() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
defaultActiveProbThreshold() - Method in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerSpark
 
defaultActiveProbThreshold() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleAssemblyRegionWalker
 
defaultActiveProbThreshold() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleAssemblyRegionWalkerSpark
 
defaultActiveProbThreshold() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCaller
 
defaultActiveProbThreshold() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2
 
defaultAssemblyRegionPadding() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
defaultAssemblyRegionPadding() - Method in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerSpark
 
defaultAssemblyRegionPadding() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleAssemblyRegionWalker
 
defaultAssemblyRegionPadding() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleAssemblyRegionWalkerSpark
 
defaultAssemblyRegionPadding() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCaller
 
defaultAssemblyRegionPadding() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2
 
defaultBaseQualities - Variable in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationArgumentCollection
If reads are missing some or all base quality scores, this value will be used for all base quality scores.
DefaultGATKReadFilterArgumentCollection - Class in org.broadinstitute.hellbender.cmdline.GATKPlugin
Default GATKReadFilterArgumentCollection applied in GATK for optional read filters in the command line.
DefaultGATKReadFilterArgumentCollection() - Constructor for class org.broadinstitute.hellbender.cmdline.GATKPlugin.DefaultGATKReadFilterArgumentCollection
 
DefaultGATKVariantAnnotationArgumentCollection - Class in org.broadinstitute.hellbender.cmdline.GATKPlugin
Arguments for requesting VariantContext annotations to be processed by VariantAnnotatorEngine for tools that process variants objects.
DefaultGATKVariantAnnotationArgumentCollection() - Constructor for class org.broadinstitute.hellbender.cmdline.GATKPlugin.DefaultGATKVariantAnnotationArgumentCollection
 
defaultMaxAssemblyRegionSize() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
defaultMaxAssemblyRegionSize() - Method in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerSpark
 
defaultMaxAssemblyRegionSize() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleAssemblyRegionWalker
 
defaultMaxAssemblyRegionSize() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleAssemblyRegionWalkerSpark
 
defaultMaxAssemblyRegionSize() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCaller
 
defaultMaxAssemblyRegionSize() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2
 
defaultMaxDepthPerSample() - Method in class org.broadinstitute.hellbender.engine.LocusWalker
Returns default value for the LocusWalker.maxDepthPerSample parameter, if none is provided on the command line.
defaultMaxDepthPerSample() - Method in class org.broadinstitute.hellbender.engine.spark.LocusWalkerSpark
Returns default value for the LocusWalkerSpark.maxDepthPerSample parameter, if none is provided on the command line.
defaultMaxProbPropagationDistance() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
defaultMaxProbPropagationDistance() - Method in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerSpark
 
defaultMaxProbPropagationDistance() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleAssemblyRegionWalker
 
defaultMaxProbPropagationDistance() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleAssemblyRegionWalkerSpark
 
defaultMaxProbPropagationDistance() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCaller
 
defaultMaxProbPropagationDistance() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2
 
defaultMaxReadsPerAlignmentStart() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
defaultMaxReadsPerAlignmentStart() - Method in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerSpark
 
defaultMaxReadsPerAlignmentStart() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleAssemblyRegionWalker
 
defaultMaxReadsPerAlignmentStart() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleAssemblyRegionWalkerSpark
 
defaultMaxReadsPerAlignmentStart() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCaller
 
defaultMaxReadsPerAlignmentStart() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2
 
defaultMinAssemblyRegionSize() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
defaultMinAssemblyRegionSize() - Method in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerSpark
 
defaultMinAssemblyRegionSize() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleAssemblyRegionWalker
 
defaultMinAssemblyRegionSize() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleAssemblyRegionWalkerSpark
 
defaultMinAssemblyRegionSize() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCaller
 
defaultMinAssemblyRegionSize() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2
 
defaultReadShardPadding() - Method in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerSpark
 
defaultReadShardPadding() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleAssemblyRegionWalkerSpark
 
defaultReadShardSize() - Method in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerSpark
 
defaultReadShardSize() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleAssemblyRegionWalkerSpark
 
DefaultSkipEmptyFiles - Static variable in class picard.illumina.parser.ParameterizedFileUtil
 
defaultToAC - Variable in class org.broadinstitute.hellbender.tools.walkers.variantutils.CalculateGenotypePosteriors
By default the tool looks for MLEAC first, and then falls back to AC if MLEAC is not found.
delegateFilter - Variable in class org.broadinstitute.hellbender.engine.filters.CountingReadFilter
 
delegateFilter - Variable in class org.broadinstitute.hellbender.engine.filters.CountingVariantFilter
 
deleteFile(String) - Static method in class org.broadinstitute.hellbender.utils.gcs.BucketUtils
Deletes a file: local, GCS or HDFS.
deleteOnExit(String) - Static method in class org.broadinstitute.hellbender.utils.gcs.BucketUtils
Schedule a file to be deleted on JVM shutdown.
deleteRecursivelyOnExit(File) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
Schedule a file or directory to be deleted on jvm exit.
Deletion(NovelAdjacencyAndAltHaplotype, int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.SimpleSVType.Deletion
 
DELETION_BASE - Static variable in class org.broadinstitute.hellbender.utils.pileup.PileupElement
 
DELETION_QUAL - Static variable in class org.broadinstitute.hellbender.utils.pileup.PileupElement
 
DeletionMDElement(int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.TextMDCodec.DeletionMDElement
 
DELETIONS_DEFAULT_QUALITY - Variable in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationArgumentCollection
A default base qualities to use as a prior (reported quality) in the mismatch covariate model.
deletionToDeletion - Static variable in class org.broadinstitute.hellbender.utils.pairhmm.PairHMMModel
Position in the transition probability array for the Deletion-to-Deletion transition.
DelimitedTextFileWithHeaderIterator - Class in picard.util
Iterate through a delimited text file in which columns are found by looking at a header line rather than by position.
DelimitedTextFileWithHeaderIterator(BasicInputParser) - Constructor for class picard.util.DelimitedTextFileWithHeaderIterator
 
DelimitedTextFileWithHeaderIterator.Row - Class in picard.util
 
delimiter_regex - Variable in class org.broadinstitute.hellbender.utils.codecs.table.TableCodec
 
denoise(SimpleCountCollection, int) - Method in interface org.broadinstitute.hellbender.tools.copynumber.denoising.SVDReadCountPanelOfNormals
Standardizes and denoises readCounts using numEigensamples of the eigensamples.
DENOISED_COPY_RATIOS_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.CopyNumberStandardArgument
 
DenoiseReadCounts - Class in org.broadinstitute.hellbender.tools.copynumber
Denoises read counts to produce denoised copy ratios.
DenoiseReadCounts() - Constructor for class org.broadinstitute.hellbender.tools.copynumber.DenoiseReadCounts
 
denormalizeDatum(double, int) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
Convert a normalized point to it's original annotation value norm = (orig - mu) / sigma orig = norm * sigma + mu
deNovoPrior - Variable in class org.broadinstitute.hellbender.tools.walkers.variantutils.CalculateGenotypePosteriors
The de novo mutation prior -- i.e.
DEPRECATED_RecoverDanglingHeads - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadThreadingAssemblerArgumentCollection
Deprecated.
DeprecatedToolsRegistry - Class in org.broadinstitute.hellbender.cmdline
When a tool is removed from GATK (after having been @Deprecated for a suitable period), an entry should be added to this list to issue a message when the user tries to run that tool.
DeprecatedToolsRegistry() - Constructor for class org.broadinstitute.hellbender.cmdline.DeprecatedToolsRegistry
 
DEPTH_CORRECTION_TAU_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineDenoisingModelArgumentCollection
 
DEPTH_WINDOW_SIZE - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.evidence.FindBreakpointEvidenceSpark
 
DepthFilter - Class in picard.vcf.filter
Filters out a record if all variant samples have depth lower than the given value.
DepthFilter(int) - Constructor for class picard.vcf.filter.DepthFilter
 
DepthPerAlleleBySample - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Depth of coverage of each allele per sample
DepthPerAlleleBySample() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.DepthPerAlleleBySample
 
DepthPerSampleHC - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Depth of informative coverage for each sample.
DepthPerSampleHC() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.DepthPerSampleHC
 
DESCRIPTION - Variable in class picard.sam.FastqToSam
 
descriptions - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.ChromosomeCounts
 
descriptors - Variable in class picard.illumina.parser.ReadStructure
 
DESIGN_NAME - Variable in class picard.util.BaitDesigner
 
DESIGN_ON_TARGET_STRAND - Variable in class picard.util.BaitDesigner
 
DESIGN_STRATEGY - Variable in class picard.util.BaitDesigner
 
DESIRED_MINIMUM_HOM_ALT_COUNT - Static variable in class org.broadinstitute.hellbender.tools.walkers.contamination.CalculateContamination
 
destroyBroadcast(Broadcast<T>, String) - Static method in class org.broadinstitute.hellbender.utils.spark.SparkUtils
Sometimes Spark has trouble destroying a broadcast variable, but we'd like the app to continue anyway.
destroyed - Variable in class org.broadinstitute.hellbender.utils.runtime.ProcessControllerBase
 
DETAIL_FILE_EXTENSION - Static variable in class picard.analysis.CollectRrbsMetrics
 
DETAIL_OUTPUT - Variable in class picard.fingerprint.CheckFingerprint
 
DETAILED_METRICS_FILE_EXTENSION - Static variable in class picard.vcf.GenotypeConcordance
 
detailedMetricsExtension - Static variable in class picard.illumina.quality.CollectHiSeqXPfFailMetrics
 
DETAILS - Variable in class picard.metrics.GcBiasMetrics
 
determineFilterSize(double[], double) - Static method in class org.broadinstitute.hellbender.utils.activityprofile.BandPassActivityProfile
 
determineFormats(Set<IlluminaDataType>, IlluminaFileUtil) - Static method in class picard.illumina.parser.IlluminaDataProviderFactory
For all requestedDataTypes return a map of file format to set of provided data types that covers as many requestedDataTypes as possible and chooses the most preferred available formats possible
DetermineGermlineContigPloidy - Class in org.broadinstitute.hellbender.tools.copynumber
Determines the integer ploidy state of all contigs for germline samples given counts data.
DetermineGermlineContigPloidy() - Constructor for class org.broadinstitute.hellbender.tools.copynumber.DetermineGermlineContigPloidy
 
DetermineGermlineContigPloidy.RunMode - Enum in org.broadinstitute.hellbender.tools.copynumber
 
determineQualityFormat(FastqReader, FastqReader, FastqQualityFormat) - Static method in class picard.sam.FastqToSam
Looks at fastq input(s) and attempts to determine the proper quality format Closes the reader(s) by side effect
determineReferenceAllele(List<VariantContext>, Locatable) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Determines the common reference allele
determineState(VariantContext, String, VariantContext, String, int, int, Boolean) - Static method in class picard.vcf.GenotypeConcordance
A method to determine the truth and call states for a pair of variant contexts representing truth and call.
DEVIATIONS - Variable in class picard.analysis.CollectInsertSizeMetrics
 
DiagnosticsAndQCProgramGroup - Class in picard.cmdline.programgroups
Tools that collect sequencing quality-related and comparative metrics
DiagnosticsAndQCProgramGroup() - Constructor for class picard.cmdline.programgroups.DiagnosticsAndQCProgramGroup
 
dict - Variable in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker
 
DICTIONARY_ARGUMENT_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.variantutils.UpdateVCFSequenceDictionary
 
dimension - Static variable in class org.broadinstitute.hellbender.tools.validation.CompareMatrix
 
dimensions - Variable in class org.broadinstitute.hellbender.utils.collections.NestedIntegerArray
 
DiploidGenotype - Enum in org.broadinstitute.hellbender.utils.genotyper
Represents the valid genotypes of a diploid sample.
DiploidGenotype - Enum in picard.fingerprint
A genotype produced by one of the concrete implementations of AbstractAlleleCaller.
DiploidHaplotype - Enum in picard.fingerprint
Simple enum to represent the three possible combinations of major/major, major/minor and minor/minor haplotypes for a diploid individual.
Dirichlet - Class in org.broadinstitute.hellbender.utils
The Dirichlet distribution is a distribution on multinomial distributions: if pi is a vector of positive multinomial weights such that sum_i pi[i] = 1, the Dirichlet pdf is P(pi) = [prod_i Gamma(alpha[i]) / Gamma(sum_i alpha[i])] * prod_i pi[i]^(alpha[i] - 1) The vector alpha comprises the sufficient statistics for the Dirichlet distribution.
Dirichlet(double...) - Constructor for class org.broadinstitute.hellbender.utils.Dirichlet
 
dirichletMultinomial(double[], int[]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Return the likelihood of observing the counts of categories having sampled a population whose categorical frequencies are distributed according to a Dirichlet distribution
dirSize(String) - Static method in class org.broadinstitute.hellbender.utils.gcs.BucketUtils
Returns the total file size of all files in a directory, or the file size if the path specifies a file.
DISABLE_ANNEALING_RATE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection
 
DISABLE_BAM_INDEX_CACHING_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
DISABLE_BAM_INDEX_CACHING_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
DISABLE_CALLER_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection
 
DISABLE_READ_FILTER_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ReadFilterArgumentDefinitions
 
DISABLE_READ_FILTER_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ReadFilterArgumentDefinitions
 
DISABLE_SAMPLER_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection
 
DISABLE_SEQUENCE_DICT_VALIDATION_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
DISABLE_TOOL_DEFAULT_ANNOTATIONS - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
DISABLE_TOOL_DEFAULT_READ_FILTERS - Static variable in class org.broadinstitute.hellbender.cmdline.ReadFilterArgumentDefinitions
 
disableBamIndexCaching - Variable in class org.broadinstitute.hellbender.engine.GATKTool
 
disableContigOrderingCheck - Variable in class org.broadinstitute.hellbender.tools.GatherVcfsCloud
 
disableOptimizations - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerArgumentCollection
If set, certain "early exit" optimizations in HaplotypeCaller, which aim to save compute and time by skipping calculations if an ActiveRegion is determined to contain no variants, will be disabled.
disableToolDefaultReadFilters - Variable in class org.broadinstitute.hellbender.cmdline.GATKPlugin.DefaultGATKReadFilterArgumentCollection
 
discontinuousP(GenomeLoc) - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
 
DiscordantReadPairEvidence(GATKRead, ReadMetadata, int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.DiscordantReadPairEvidence
 
DiscordantReadPairEvidence(Kryo, Input) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.DiscordantReadPairEvidence
 
discoverExtension - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmerArgumentCollection
the maximum extent into the full active region extension that we're willing to go in genotyping our events
discoverVariantsFromChimeras(SvDiscoveryInputMetaData, JavaRDD<AlignedContig>) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.DiscoverVariantsFromContigAlignmentsSAMSpark
Deprecated.
DiscoverVariantsFromContigAlignmentsSAMSpark - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery
(Internal) Examines aligned contigs from local assemblies and calls structural variants
DiscoverVariantsFromContigAlignmentsSAMSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.DiscoverVariantsFromContigAlignmentsSAMSpark
 
DiscoverVariantsFromContigsAlignmentsSparkArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.DiscoverVariantsFromContigsAlignmentsSparkArgumentCollection
 
DISCOVERY_ALT_COVERAGE - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
DISCOVERY_REF_COVERAGE - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
DISCOVERY_VCF_FILTER - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
discoverySampleInVcf - Variable in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
disjointP(GenomeLoc) - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
 
DiskBasedReadEndsForMarkDuplicatesMap - Class in org.broadinstitute.hellbender.utils.read.markduplicates
Disk-based implementation of ReadEndsForMarkDuplicatesMap.
DiskBasedReadEndsForMarkDuplicatesMap(int) - Constructor for class org.broadinstitute.hellbender.utils.read.markduplicates.DiskBasedReadEndsForMarkDuplicatesMap
 
DiskBasedReadEndsForMarkDuplicatesMap - Class in picard.sam.markduplicates.util
Disk-based implementation of ReadEndsForMarkDuplicatesMap.
DiskBasedReadEndsForMarkDuplicatesMap(int, ReadEndsForMarkDuplicatesCodec) - Constructor for class picard.sam.markduplicates.util.DiskBasedReadEndsForMarkDuplicatesMap
 
dispatchJobs(JavaSparkContext, SvDiscoverFromLocalAssemblyContigAlignmentsSpark.AssemblyContigsClassifiedByAlignmentSignatures, SvDiscoveryInputMetaData, JavaRDD<GATKRead>, boolean) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoverFromLocalAssemblyContigAlignmentsSpark
Sends assembly contigs classified based on their alignment signature to a corresponding breakpoint location inference unit.
distance(GenomeLoc) - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
 
distanceAcrossContigs(GenomeLoc, SAMFileHeader) - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
Calculates the distance between two genomeLocs across contigs (if necessary).
distanceSquared(double[], double[]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
distinctAlleleCount() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeAlleleCounts
Returns the number of different alleles that participate in the genotype.
divide(double, double) - Static method in class picard.util.MathUtil
Divide two Doubles but return 0.0 if the denominator is 0
divide(double[], double[]) - Static method in class picard.util.MathUtil
Calculates the ratio of two arrays of the same length.
DIVIDE_BY_GENOME_LENGTH_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
 
DIVIDE_BY_GENOME_LENGTH_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
 
divideByGenomeLength - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
If true, the score contributed by each read is divided by the mapped organism's genome length in the reference.
divideIntervalIntoShards(SimpleInterval, int, int, SAMSequenceDictionary) - Static method in interface org.broadinstitute.hellbender.engine.Shard
Divide an interval into ShardBoundaries.
divideIntervalIntoShards(SimpleInterval, int, int, int, SAMSequenceDictionary) - Static method in interface org.broadinstitute.hellbender.engine.Shard
Divide an interval into ShardBoundaries.
DO_NOT_MARK_UNMAPPED_MATES_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.MarkDuplicatesSparkArgumentCollection
 
DO_NOT_RUN_PHYSICAL_PHASING_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerArgumentCollection
 
DO_NOT_USE_STANDARD_COVARIATES - Static variable in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationArgumentCollection
 
DO_NOT_VALIDATE_FILTERED_RECORDS - Static variable in class org.broadinstitute.hellbender.tools.walkers.variantutils.ValidateVariants
 
doBwaAlignment(JavaRDD<GATKRead>, boolean, Broadcast<SAMFileHeader>) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBwaAlignerSpark
 
DOC_CAT_ANNOTATORS - Static variable in class org.broadinstitute.hellbender.utils.help.HelpConstants
Definition of the group names / descriptions for documentation/help purposes.
DOC_CAT_ANNOTATORS_SUMMARY - Static variable in class org.broadinstitute.hellbender.utils.help.HelpConstants
 
DOC_CAT_BASE_CALLING - Static variable in class picard.util.help.HelpConstants
Definition of the group names / descriptions for documentation/help purposes.
DOC_CAT_BASE_CALLING_SUMMARY - Static variable in class picard.util.help.HelpConstants
 
DOC_CAT_CNV - Static variable in class org.broadinstitute.hellbender.utils.help.HelpConstants
 
DOC_CAT_CNV_SUMMARY - Static variable in class org.broadinstitute.hellbender.utils.help.HelpConstants
 
DOC_CAT_COVERAGE_ANALYSIS - Static variable in class org.broadinstitute.hellbender.utils.help.HelpConstants
 
DOC_CAT_COVERAGE_ANALYSIS_SUMMARY - Static variable in class org.broadinstitute.hellbender.utils.help.HelpConstants
 
DOC_CAT_DIAGNOSTICS_AND_QC - Static variable in class picard.util.help.HelpConstants
 
DOC_CAT_DIAGNOSTICS_AND_QC_SUMMARY - Static variable in class picard.util.help.HelpConstants
 
DOC_CAT_EXAMPLE - Static variable in class org.broadinstitute.hellbender.utils.help.HelpConstants
 
DOC_CAT_EXAMPLE_SUMMARY - Static variable in class org.broadinstitute.hellbender.utils.help.HelpConstants
 
DOC_CAT_INTERVALS_MANIPULATION - Static variable in class picard.util.help.HelpConstants
 
DOC_CAT_INTERVALS_MANIPULATION_SUMMARY - Static variable in class picard.util.help.HelpConstants
 
DOC_CAT_METAGENOMICS - Static variable in class org.broadinstitute.hellbender.utils.help.HelpConstants
 
DOC_CAT_METAGENOMICS_SUMMARY - Static variable in class org.broadinstitute.hellbender.utils.help.HelpConstants
 
DOC_CAT_OTHER - Static variable in class picard.util.help.HelpConstants
 
DOC_CAT_OTHER_SUMMARY - Static variable in class picard.util.help.HelpConstants
 
DOC_CAT_READ_DATA_MANIPULATION - Static variable in class picard.util.help.HelpConstants
 
DOC_CAT_READ_DATA_MANIPULATION_SUMMARY - Static variable in class picard.util.help.HelpConstants
 
DOC_CAT_READFILTERS - Static variable in class org.broadinstitute.hellbender.utils.help.HelpConstants
 
DOC_CAT_READFILTERS_SUMMARY - Static variable in class org.broadinstitute.hellbender.utils.help.HelpConstants
 
DOC_CAT_REFERENCE - Static variable in class picard.util.help.HelpConstants
 
DOC_CAT_REFERENCE_SUMMARY - Static variable in class picard.util.help.HelpConstants
 
DOC_CAT_RNA - Static variable in class org.broadinstitute.hellbender.utils.help.HelpConstants
 
DOC_CAT_RNA_SUMMARY - Static variable in class org.broadinstitute.hellbender.utils.help.HelpConstants
 
DOC_CAT_SHORT_VARIANT_DISCOVERY - Static variable in class org.broadinstitute.hellbender.utils.help.HelpConstants
 
DOC_CAT_SHORT_VARIANT_DISCOVERY_SUMMARY - Static variable in class org.broadinstitute.hellbender.utils.help.HelpConstants
 
DOC_CAT_SV_DISCOVERY - Static variable in class org.broadinstitute.hellbender.utils.help.HelpConstants
 
DOC_CAT_SV_DISCOVERY_SUMMARY - Static variable in class org.broadinstitute.hellbender.utils.help.HelpConstants
 
DOC_CAT_TEST - Static variable in class org.broadinstitute.hellbender.utils.help.HelpConstants
 
DOC_CAT_TEST - Static variable in class picard.util.help.HelpConstants
 
DOC_CAT_TEST_SUMMARY - Static variable in class org.broadinstitute.hellbender.utils.help.HelpConstants
 
DOC_CAT_TEST_SUMMARY - Static variable in class picard.util.help.HelpConstants
 
DOC_CAT_VARIANT_EVALUATION - Static variable in class picard.util.help.HelpConstants
 
DOC_CAT_VARIANT_EVALUATION_SUMMARY - Static variable in class picard.util.help.HelpConstants
 
DOC_CAT_VARIANT_FILTERING - Static variable in class picard.util.help.HelpConstants
 
DOC_CAT_VARIANT_FILTERING_SUMMARY - Static variable in class picard.util.help.HelpConstants
 
DOC_CAT_VARIANT_MANIPULATION - Static variable in class picard.util.help.HelpConstants
 
DOC_CAT_VARIANT_MANIPULATION_SUMMARY - Static variable in class picard.util.help.HelpConstants
 
DOC_SUPERCAT_EXCLUDE - Static variable in class picard.util.help.HelpConstants
 
DOC_SUPERCAT_TOOLS - Static variable in class picard.util.help.HelpConstants
List of "supercategory" values used for doc purposes.
DOC_SUPERCAT_UTILITIES - Static variable in class picard.util.help.HelpConstants
 
doesReadContainAllele(PileupElement, Allele) - Static method in class org.broadinstitute.hellbender.utils.GATKProtectedVariantContextUtils
TODO: Test.
doFilter(JavaRDD<GATKRead>, PSFilterLogger) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilter
Main PathSeq filtering method.
done - Variable in class org.broadinstitute.hellbender.utils.read.ArtificialReadIterator
 
doNotRecoverDanglingBranches - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadThreadingAssemblerArgumentCollection
By default, the read threading assembler will attempt to recover dangling heads and tails.
doNotRequireSoftclipsOnBothEnds - Variable in class org.broadinstitute.hellbender.engine.filters.OverclippedReadFilter
 
doNotRunPhysicalPhasing - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerArgumentCollection
As of GATK 3.3, HaplotypeCaller outputs physical (read-based) information (see version 3.3 release notes and documentation for details).
DoNotSubclass - Annotation Type in org.broadinstitute.hellbender.engine
Classes annotated with this annotation are NOT intended or designed to be extended and should be treated as final.
doNotUseTristateCorrection - Variable in class org.broadinstitute.hellbender.utils.pairhmm.PairHMM
 
doNotUseTristateCorrection() - Method in class org.broadinstitute.hellbender.utils.pairhmm.PairHMM
 
DONT_REQUIRE_SOFT_CLIPS_BOTH_ENDS_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ReadFilterArgumentDefinitions
 
DONT_SKIP_ALREADY_FILTERED_VARIANTS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.FilterAlignmentArtifacts
 
DONT_USE_SOFT_CLIPPED_BASES_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerArgumentCollection
 
dontGenotype - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerArgumentCollection
This argument is intended for benchmarking and scalability testing.
dontIncreaseKmerSizesForCycles - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadThreadingAssemblerArgumentCollection
When graph cycles are detected, the normal behavior is to increase kmer sizes iteratively until the cycles are resolved.
dontMarkUnmappedMates - Variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.MarkDuplicatesSparkArgumentCollection
 
dontTrimActiveRegions - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmerArgumentCollection
 
dontUseMates - Variable in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.RealignmentArgumentCollection
Turn off the default mate-aware realignment
dontUseSoftClippedBases - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerArgumentCollection
 
doPaired(FastqReader, FastqReader, SAMFileWriter) - Method in class picard.sam.FastqToSam
More complicated method that takes two fastq files and builds pairing information in the SAM.
doPhysicalPhasing - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerGenotypingEngine
 
doProfiling - Static variable in class org.broadinstitute.hellbender.utils.pairhmm.PairHMM
 
doReadFilterArgumentWarnings(GATKReadFilterPluginDescriptor, Logger) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
doSolve() - Method in class org.broadinstitute.hellbender.utils.solver.RobustBrentSolver
 
doTileProcessing() - Method in class picard.illumina.IlluminaBasecallsConverter
Do the work, i.e.
doTileProcessing() - Method in class picard.illumina.NewIlluminaBasecallsConverter
 
dotProduct(double[], double[]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
DOUBLE_FORMAT - Static variable in class org.broadinstitute.hellbender.tools.copynumber.formats.CopyNumberFormatsUtils
 
doubleWithinRangeWithTolerance(double, double, double, double) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Checks that value is between min and max, inclusive, with a specified tolerance.
doUnpaired(FastqReader, SAMFileWriter) - Method in class picard.sam.FastqToSam
Creates a simple SAM file from a single fastq file.
DownsampleableSparkReadShard - Class in org.broadinstitute.hellbender.tools
A simple shard implementation intended to be used for splitting reads by partition in Spark tools
DownsampleableSparkReadShard(ShardBoundary, Iterable<GATKRead>, ReadsDownsampler) - Constructor for class org.broadinstitute.hellbender.tools.DownsampleableSparkReadShard
 
DOWNSAMPLED_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
Downsampler<T> - Class in org.broadinstitute.hellbender.utils.downsampling
The basic downsampler API, with no reads-specific operations.
Downsampler() - Constructor for class org.broadinstitute.hellbender.utils.downsampling.Downsampler
 
DownsampleSam - Class in picard.sam
Summary
DownsampleSam() - Constructor for class picard.sam.DownsampleSam
 
DownsampleType - Enum in org.broadinstitute.hellbender.utils.downsampling
Type of downsampling method to invoke.
DOWNSAMPLING_STRIDE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
DOWNSAMPLING_STRIDE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
DownsamplingMethod - Class in org.broadinstitute.hellbender.utils.downsampling
Describes the method for downsampling reads at a given locus.
DownsamplingMethod(DownsampleType, Integer, Double) - Constructor for class org.broadinstitute.hellbender.utils.downsampling.DownsamplingMethod
If type is null, then DEFAULT_DOWNSAMPLING_TYPE will be used.
downsamplingStride - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
Downsample a pool of reads starting within a range of one or more bases.
doWork() - Method in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
Do the work after command line has been parsed.
doWork() - Method in class org.broadinstitute.hellbender.cmdline.PicardCommandLineProgramExecutor
 
doWork() - Method in class org.broadinstitute.hellbender.engine.GATKTool
 
doWork() - Method in class org.broadinstitute.hellbender.engine.spark.SparkCommandLineProgram
 
doWork() - Method in class org.broadinstitute.hellbender.tools.BwaMemIndexImageCreator
 
doWork() - Method in class org.broadinstitute.hellbender.tools.ConvertHeaderlessHadoopBamShardToBam
 
doWork() - Method in class org.broadinstitute.hellbender.tools.copynumber.CallCopyRatioSegments
 
doWork() - Method in class org.broadinstitute.hellbender.tools.copynumber.DenoiseReadCounts
 
doWork() - Method in class org.broadinstitute.hellbender.tools.copynumber.DetermineGermlineContigPloidy
 
doWork() - Method in class org.broadinstitute.hellbender.tools.copynumber.GermlineCNVCaller
 
doWork() - Method in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
doWork() - Method in class org.broadinstitute.hellbender.tools.copynumber.plotting.PlotDenoisedCopyRatios
 
doWork() - Method in class org.broadinstitute.hellbender.tools.copynumber.plotting.PlotModeledSegments
 
doWork() - Method in class org.broadinstitute.hellbender.tools.GatherVcfsCloud
 
doWork() - Method in class org.broadinstitute.hellbender.tools.IndexFeatureFile
 
doWork() - Method in class org.broadinstitute.hellbender.tools.spark.CreateHadoopBamSplittingIndex
 
doWork() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildKmers
Get the list of distinct kmers in the reference, and write them to a file as a HopScotch set or Bloom filter.
doWork() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildReferenceTaxonomy
 
doWork() - Method in class org.broadinstitute.hellbender.tools.validation.CompareBaseQualities
 
doWork() - Method in class org.broadinstitute.hellbender.tools.walkers.bqsr.AnalyzeCovariates
 
doWork() - Method in class org.broadinstitute.hellbender.tools.walkers.bqsr.GatherBQSRReports
 
doWork() - Method in class org.broadinstitute.hellbender.tools.walkers.contamination.CalculateContamination
 
doWork() - Method in class org.broadinstitute.hellbender.tools.walkers.markduplicates.EstimateLibraryComplexityGATK
Method that does most of the work.
doWork() - Method in class org.broadinstitute.hellbender.tools.walkers.markduplicates.MarkDuplicatesGATK
Main work method.
doWork() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.CreateSomaticPanelOfNormals
 
doWork() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.CNNVariantTrain
 
doWork() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.CNNVariantWriteTensors
 
doWork() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.FilterVariantTranches
 
doWork() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.GatherTranches
 
doWork() - Method in class picard.analysis.artifacts.ConvertSequencingArtifactToOxoG
 
doWork() - Method in class picard.analysis.CollectJumpingLibraryMetrics
Calculates the detailed statistics about the jumping library and then generates the results.
doWork() - Method in class picard.analysis.CollectMultipleMetrics
 
doWork() - Method in class picard.analysis.CollectOxoGMetrics
 
doWork() - Method in class picard.analysis.CollectRrbsMetrics
 
doWork() - Method in class picard.analysis.CollectWgsMetrics
 
doWork() - Method in class picard.analysis.CollectWgsMetricsWithNonZeroCoverage
 
doWork() - Method in class picard.analysis.CompareMetrics
 
doWork() - Method in class picard.analysis.directed.CollectTargetedMetrics
Asserts that files are readable and writable and then fires off an HsMetricsCalculator instance to do the real work.
doWork() - Method in class picard.analysis.replicates.CollectIndependentReplicateMetrics
 
doWork() - Method in class picard.analysis.SinglePassSamProgram
Final implementation of doWork() that checks and loads the input and optionally reference sequence files and the runs the sublcass through the setup() acceptRead() and finish() steps.
doWork() - Method in class picard.cmdline.CommandLineProgram
Do the work after command line has been parsed.
doWork() - Method in class picard.fastq.BamToBfq
 
doWork() - Method in class picard.fingerprint.CheckFingerprint
 
doWork() - Method in class picard.fingerprint.ClusterCrosscheckMetrics
 
doWork() - Method in class picard.fingerprint.CrosscheckFingerprints
 
doWork() - Method in class picard.fingerprint.CrosscheckReadGroupFingerprints
Deprecated.
 
doWork() - Method in class picard.fingerprint.IdentifyContaminant
 
doWork() - Method in class picard.illumina.CheckIlluminaDirectory
 
doWork() - Method in class picard.illumina.CollectIlluminaBasecallingMetrics
 
doWork() - Method in class picard.illumina.CollectIlluminaLaneMetrics
 
doWork() - Method in class picard.illumina.ExtractIlluminaBarcodes
 
doWork() - Method in class picard.illumina.IlluminaBasecallsToFastq
 
doWork() - Method in class picard.illumina.IlluminaBasecallsToSam
 
doWork() - Method in class picard.illumina.MarkIlluminaAdapters
 
doWork() - Method in class picard.illumina.quality.CollectHiSeqXPfFailMetrics
 
doWork() - Method in class picard.reference.ExtractSequences
 
doWork() - Method in class picard.reference.NonNFastaSize
 
doWork() - Method in class picard.reference.NormalizeFasta
 
doWork() - Method in class picard.sam.AddCommentsToBam
 
doWork() - Method in class picard.sam.AddOrReplaceReadGroups
 
doWork() - Method in class picard.sam.BamIndexStats
Main method for the program.
doWork() - Method in class picard.sam.BuildBamIndex
Main method for the program.
doWork() - Method in class picard.sam.CalculateReadGroupChecksum
 
doWork() - Method in class picard.sam.CheckTerminatorBlock
 
doWork() - Method in class picard.sam.CleanSam
Do the work after command line has been parsed.
doWork() - Method in class picard.sam.CompareSAMs
Do the work after command line has been parsed.
doWork() - Method in class picard.sam.CreateSequenceDictionary
Do the work after command line has been parsed.
doWork() - Method in class picard.sam.DownsampleSam
 
doWork() - Method in class picard.sam.FastqToSam
 
doWork() - Method in class picard.sam.FilterSamReads
 
doWork() - Method in class picard.sam.FixMateInformation
 
doWork() - Method in class picard.sam.GatherBamFiles
 
doWork() - Method in class picard.sam.markduplicates.EstimateLibraryComplexity
Method that does most of the work.
doWork() - Method in class picard.sam.markduplicates.MarkDuplicates
Main work method.
doWork() - Method in class picard.sam.markduplicates.MarkDuplicatesWithMateCigar
Main work method.
doWork() - Method in class picard.sam.markduplicates.SimpleMarkDuplicatesWithMateCigar
Main work method.
doWork() - Method in class picard.sam.markduplicates.UmiAwareMarkDuplicatesWithMateCigar
 
doWork() - Method in class picard.sam.MergeBamAlignment
 
doWork() - Method in class picard.sam.MergeSamFiles
Combines multiple SAM/BAM files into one.
doWork() - Method in class picard.sam.PositionBasedDownsampleSam
 
doWork() - Method in class picard.sam.ReorderSam
 
doWork() - Method in class picard.sam.ReplaceSamHeader
Do the work after command line has been parsed.
doWork() - Method in class picard.sam.RevertOriginalBaseQualitiesAndAddMateCigar
 
doWork() - Method in class picard.sam.RevertSam
 
doWork() - Method in class picard.sam.SamFormatConverter
 
doWork() - Method in class picard.sam.SamToFastq
 
doWork() - Method in class picard.sam.SetNmMdAndUqTags
 
doWork() - Method in class picard.sam.SortSam
 
doWork() - Method in class picard.sam.SplitSamByLibrary
 
doWork() - Method in class picard.sam.SplitSamByNumberOfReads
 
doWork() - Method in class picard.sam.ValidateSamFile
Do the work after command line has been parsed.
doWork() - Method in class picard.sam.ViewSam
 
doWork() - Method in class picard.util.BaitDesigner
Main method that coordinates the checking of inputs, designing of baits and then the writing out of all necessary files.
doWork() - Method in class picard.util.BedToIntervalList
 
doWork() - Method in class picard.util.FifoBuffer
 
doWork() - Method in class picard.util.IntervalListToBed
 
doWork() - Method in class picard.util.IntervalListTools
 
doWork() - Method in class picard.util.LiftOverIntervalList
Do the work after command line has been parsed.
doWork() - Method in class picard.util.ScatterIntervalsByNs
 
doWork() - Method in class picard.vcf.AccumulateVariantCallingMetrics
 
doWork() - Method in class picard.vcf.CollectVariantCallingMetrics
 
doWork() - Method in class picard.vcf.filter.FilterVcf
 
doWork() - Method in class picard.vcf.FixVcfHeader
 
doWork() - Method in class picard.vcf.GatherVcfs
 
doWork() - Method in class picard.vcf.GenotypeConcordance
 
doWork() - Method in class picard.vcf.LiftoverVcf
 
doWork() - Method in class picard.vcf.MakeSitesOnlyVcf
 
doWork() - Method in class picard.vcf.MendelianViolations.FindMendelianViolations
 
doWork() - Method in class picard.vcf.MergeVcfs
 
doWork() - Method in class picard.vcf.RenameSampleInVcf
 
doWork() - Method in class picard.vcf.SortVcf
 
doWork() - Method in class picard.vcf.SplitVcfs
 
doWork() - Method in class picard.vcf.UpdateVcfSequenceDictionary
 
doWork() - Method in class picard.vcf.VcfFormatConverter
 
doWork() - Method in class picard.vcf.VcfToIntervalList
 
draw() - Method in class picard.analysis.TheoreticalSensitivity.RouletteWheel
 
drivingVariantFile - Variable in class org.broadinstitute.hellbender.engine.spark.VariantWalkerSpark
 
drivingVariantFile - Variable in class org.broadinstitute.hellbender.engine.VariantWalker
 
drivingVariantFiles - Variable in class org.broadinstitute.hellbender.engine.MultiVariantWalker
 
dropAggregateData() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
Remove all VariantDatum's from the data list which are marked as aggregate data
dropRatio - Variable in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.RealignmentArgumentCollection
BWA-mem extension drop ratio
dumpConfigSettings(T, Path) - Static method in class org.broadinstitute.hellbender.utils.config.ConfigFactory
Dump the configuration to a file that can be easily read into Properties.
DUP_ANNOTATIONS_IMPRECISE - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
DUP_IMPRECISE_AFFECTED_RANGE - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
DUP_INV_INTERNAL_ID_START_STRING - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
DUP_ORIENTATIONS - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
DUP_REPEAT_UNIT_REF_SPAN - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
DUP_SEQ_CIGARS - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
DUP_TAN_CONTRACTION_INTERNAL_ID_START_STRING - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
DUP_TAN_CONTRACTION_STRING - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
DUP_TAN_EXPANSION_INTERNAL_ID_START_STRING - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
DUP_TAN_EXPANSION_STRING - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
dupBytes(byte, int) - Static method in class org.broadinstitute.hellbender.utils.Utils
Create a new byte array that's n copies of b
dupChar(char, int) - Static method in class org.broadinstitute.hellbender.utils.Utils
Create a new string that's n copies of c
DUPLICATE_READS_FILTERED - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterMetrics
The number of filtered duplicate reads
DUPLICATE_SAMPLE_STRATEGY_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.CreateSomaticPanelOfNormals
 
DUPLICATE_SCORING_STRATEGY - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.AbstractMarkDuplicatesCommandLineProgram
 
DUPLICATE_SCORING_STRATEGY - Variable in class picard.sam.markduplicates.util.AbstractMarkDuplicatesCommandLineProgram
 
DUPLICATE_SCORING_STRATEGY_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
DUPLICATE_SCORING_STRATEGY_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
DUPLICATE_SET_INDEX_TAG - Static variable in class picard.sam.markduplicates.MarkDuplicates
The attribute in the SAM/BAM file used to store which read was selected as representative out of a duplicate set
DUPLICATE_SET_SIZE_TAG - Static variable in class picard.sam.markduplicates.MarkDuplicates
The attribute in the SAM/BAM file used to store the size of a duplicate set
DUPLICATE_SETS_IGNORING_UMI - Variable in class picard.sam.markduplicates.UmiMetrics
Number of duplicate sets found before taking UMIs into account
DUPLICATE_SETS_WITH_UMI - Variable in class picard.sam.markduplicates.UmiMetrics
Number of duplicate sets found after taking UMIs into account
DUPLICATE_TYPE_LIBRARY - Static variable in class picard.sam.markduplicates.MarkDuplicates
The duplicate type tag value for duplicate type: library.
DUPLICATE_TYPE_SEQUENCING - Static variable in class picard.sam.markduplicates.MarkDuplicates
The duplicate type tag value for duplicate type: sequencing (optical & pad-hopping, or "co-localized").
DUPLICATE_TYPE_TAG - Static variable in class picard.sam.markduplicates.MarkDuplicates
The optional attribute in SAM/BAM files used to store the duplicate type.
DUPLICATED_EVIDENCE_FILTER_NAME - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
duplicateFlags - Variable in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
duplicateSetSize - Variable in class picard.sam.markduplicates.util.ReadEndsForMarkDuplicates
 
duplicatesScoringStrategy - Variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.MarkDuplicatesSparkArgumentCollection
 
DUPLICATION_NUMBERS - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
DuplicationInverted(NovelAdjacencyAndAltHaplotype, int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.SimpleSVType.DuplicationInverted
 
DuplicationMetrics - Class in picard.sam
Metrics that are calculated during the process of marking duplicates within a stream of SAMRecords.
DuplicationMetrics() - Constructor for class picard.sam.DuplicationMetrics
 
DuplicationTandem(NovelAdjacencyAndAltHaplotype, int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.SimpleSVType.DuplicationTandem
 
dupString(String, int) - Static method in class org.broadinstitute.hellbender.utils.Utils
Create a new string thats a n duplicate copies of s
DUST_MASK_QUALITY_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
DUST_MASK_QUALITY_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
DUST_T_SCORE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
DUST_T_SCORE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
DUST_WINDOW_SIZE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
DUST_WINDOW_SIZE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
dustMask - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
DUSTReadTransformer - Class in org.broadinstitute.hellbender.transformers
Masks read bases and base qualities using the symmetric DUST algorithm
DUSTReadTransformer(int, int, double) - Constructor for class org.broadinstitute.hellbender.transformers.DUSTReadTransformer
 
dustT - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
Controls the stringency of low-complexity filtering.
dustW - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 

E

EarliestFragmentPrimaryAlignmentSelectionStrategy - Class in org.broadinstitute.hellbender.utils.read.mergealignment
When it is necessary to pick a primary alignment from a group of alignments for a read, pick the one that maps the earliest base in the read.
EarliestFragmentPrimaryAlignmentSelectionStrategy() - Constructor for class org.broadinstitute.hellbender.utils.read.mergealignment.EarliestFragmentPrimaryAlignmentSelectionStrategy
 
EarliestFragmentPrimaryAlignmentSelectionStrategy - Class in picard.sam
When it is necessary to pick a primary alignment from a group of alignments for a read, pick the one that maps the earliest base in the read.
EarliestFragmentPrimaryAlignmentSelectionStrategy() - Constructor for class picard.sam.EarliestFragmentPrimaryAlignmentSelectionStrategy
 
ebeAdd(int[], int[]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
eChromosomeCount - Variable in class org.broadinstitute.hellbender.utils.read.ArtificialReadIterator
 
EDGE_MULTIPLICITY_ORDER - Static variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseEdge
Sorts a collection of BaseEdges in decreasing order of weight, so that the most heavily weighted is at the start of the list
editIntervals(List<SimpleInterval>) - Method in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerSpark
Note that this sets intervalShards as a side effect, in order to add padding to the intervals.
editIntervals(List<SimpleInterval>) - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
Transform the intervals during loading.
effectiveLog10MultinomialWeights() - Method in class org.broadinstitute.hellbender.utils.Dirichlet
 
effectiveMultinomialWeights() - Method in class org.broadinstitute.hellbender.utils.Dirichlet
 
EMISSION_LOD_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
EMISSION_LOG_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
emissionLod - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
Only variants with tumor LODs exceeding this threshold will be written to the VCF, regardless of filter status.
emitEmptyLoci() - Method in class org.broadinstitute.hellbender.engine.LocusWalker
Does this tool emit information for uncovered loci? Tools that do should override to return true.
emitEmptyLoci() - Method in class org.broadinstitute.hellbender.engine.spark.LocusWalkerSpark
Does this tool emit information for uncovered loci? Tools that do should override to return true.
emitEmptyLoci() - Method in class org.broadinstitute.hellbender.tools.copynumber.CollectAllelicCounts
 
emitOriginalQuals - Variable in class org.broadinstitute.hellbender.tools.ApplyBQSRUniqueArgumentCollection
The tool is capable of writing out the original quality scores of each read in the recalibrated output file under the "OQ" tag.
emitReferenceConfidence - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerArgumentCollection
The reference confidence mode makes it possible to emit a per-bp or summarized confidence estimate for a site being strictly homozygous-reference.
emitReferenceConfidence() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerEngine
Are we emitting a reference confidence in some form, or not?
EMPIRICAL_Q_REPORTED_DECIMAL_PLACES - Static variable in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
 
EMPIRICAL_QUAL_DECIMAL_PLACES - Static variable in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
 
EMPIRICAL_QUALITY_COLUMN_NAME - Static variable in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
 
EmpiricalPhasingMetricsOutReader - Class in picard.illumina.parser.readers
 
EmpiricalPhasingMetricsOutReader(File) - Constructor for class picard.illumina.parser.readers.EmpiricalPhasingMetricsOutReader
 
EmpiricalPhasingMetricsOutReader.IlluminaPhasingMetrics - Class in picard.illumina.parser.readers
 
EMPTY - Static variable in class org.broadinstitute.hellbender.utils.runtime.StreamOutput
Empty stream output when no output is captured due to an error.
EMPTY - Static variable in class picard.vcf.GenotypeConcordanceScheme
 
EMPTY_COUNT - Variable in class picard.vcf.GenotypeConcordanceContingencyMetrics
The empty (no contingency info) count across all variants
EMPTY_LIST - Static variable in interface org.broadinstitute.hellbender.utils.genotyper.AlleleList
 
EMPTY_LIST - Static variable in interface org.broadinstitute.hellbender.utils.genotyper.SampleList
 
emptyAlleleList() - Static method in interface org.broadinstitute.hellbender.utils.genotyper.AlleleList
Returns an unmodifiable empty allele-list.
emptyCallContext(FeatureContext, ReferenceContext, AlignmentContext, SAMFileHeader) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
Produces an empty variant-call context to output when there is no enough data provided to call anything.
EmptyFragment - Class in org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords
Dummy class representing a mated read fragment at a particular start position to be used for accounting when deciding whether to duplicate unmatched fragments.
EmptyFragment(GATKRead, SAMFileHeader) - Constructor for class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.EmptyFragment
special constructor for creating empty fragments this only includes the necessary data to locate the read, the rest is unnecessary because it will appear in the paired bucket
EmptyIntersection(String) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.EmptyIntersection
 
emptyRead(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Creates an "empty", unmapped read with the provided read's read group and mate information, but empty (not-null) fields: - Cigar String - Read Bases - Base Qualities Use this method if you want to create a new empty read based on another read
emptySampleList() - Static method in interface org.broadinstitute.hellbender.utils.genotyper.SampleList
Empty list.
emptyTranche(List<VariantDatum>, int, double, VariantRecalibratorArgumentCollection.Mode) - Static method in class org.broadinstitute.hellbender.tools.walkers.vqsr.Tranche
 
emptyTranche(List<VariantDatum>, int, double, VariantRecalibratorArgumentCollection.Mode) - Static method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VQSLODTranche
 
ENABLE_ALL_ANNOTATIONS - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
ENABLE_BIAS_FACTORS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineDenoisingModelArgumentCollection
 
enableBAQ - Variable in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationArgumentCollection
 
enableTestSparkContext() - Static method in class org.broadinstitute.hellbender.engine.spark.SparkContextFactory
Register a shared global JavaSparkContext for this JVM; this should only be used for testing.
encode(SAMRecord) - Method in class htsjdk.samtools.SAMRecordSparkCodec
Write object to OutputStream.
encode(List<Integer>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_StrandBiasTest
 
encode(ReadEndsForMarkDuplicates) - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEndsForMarkDuplicatesCodec
 
encode(ReadEndsForMarkDuplicates) - Method in class picard.sam.markduplicates.util.ReadEndsForMarkDuplicatesCodec
 
encode(ReadEndsForMarkDuplicates) - Method in class picard.sam.markduplicates.util.ReadEndsForMarkDuplicatesWithBarcodesCodec
 
encode(RepresentativeReadIndexer) - Method in class picard.sam.markduplicates.util.RepresentativeReadIndexerCodec
 
encodeBQTag(GATKRead, byte[]) - Static method in class org.broadinstitute.hellbender.utils.baq.BAQ
 
encodeStringList(List<String>) - Static method in class org.broadinstitute.hellbender.tools.walkers.annotator.AnnotationUtils
Helper function to convert a List of Strings to a comma-separated String
encodeValueList(List<Double>, String) - Static method in class org.broadinstitute.hellbender.tools.walkers.annotator.AnnotationUtils
Helper function to parse the list into the annotation string
END - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
end() - Method in class org.broadinstitute.hellbender.utils.logging.BunnyLog
 
end() - Method in class picard.annotation.Gene.Transcript
 
end - Variable in class picard.annotation.Gene.Transcript.Exon
 
end - Variable in class picard.illumina.parser.Range
 
END_COL_COMMENT - Static variable in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalCodec
 
END_OF_CONTIG - Static variable in class org.broadinstitute.hellbender.utils.SimpleInterval
 
endInAssembledContig - Variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
 
endOfShard(int, int) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
last offset in this shard (1-based).
endpointSpan(GenomeLoc) - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
Returns a new GenomeLoc that represents the region between the endpoints of this and that.
ENFORCE_SAME_SAMPLES - Variable in class picard.vcf.FixVcfHeader
 
ensureCapacity(int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFPriorProvider
Make sure that structures have enough capacity to hold the information up to the given total-ploidy.
ensureReadCapacity(int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeLikelihoodCalculator
Makes sure that temporal arrays and matrices are prepared for a number of reads to process.
ensureUntouched() - Method in class org.broadinstitute.hellbender.utils.read.ArtificialReadQueryIterator
make sure we haven't been used as an iterator yet; this is to miror the MergingSamIterator2 action.
entryCollides() - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchCollection
in a general multiset there is no uniqueness criterion, so there is never a collision
entryCollides() - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchMap
in a map, uniqueness is on the key value, so we compare keys to see if we already have an entry for that key
entryCollides() - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchSet
in a set, uniqueness is on the entry, so we just compare entries to see if we already have an identical one
entryCollides() - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchUniqueMultiMap
in a unique multimap, uniqueness is on the entry, so we just compare entries to see if we already have one
eof() - Method in class org.broadinstitute.hellbender.utils.nio.ChannelAsSeekableStream
 
equalFields(BreakpointEvidence) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence
 
equalRange(byte[], int, byte[], int, int) - Static method in class org.broadinstitute.hellbender.utils.Utils
Compares sections from to byte arrays to verify whether they contain the same values.
equals(Object) - Method in class org.broadinstitute.hellbender.engine.FeatureInput
Test FeatureInputs for equality
equals(Object) - Method in class org.broadinstitute.hellbender.engine.ReadContextData
 
equals(Object) - Method in class org.broadinstitute.hellbender.engine.ReferenceShard
 
equals(Object) - Method in class org.broadinstitute.hellbender.engine.ShardBoundary
 
equals(Object) - Method in class org.broadinstitute.hellbender.engine.VariantShard
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.collections.AbstractRecordCollection
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.metadata.SimpleLocatableMetadata
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.metadata.SimpleSampleLocatableMetadata
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.metadata.SimpleSampleMetadata
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AlleleFractionSegment
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AllelicCount
If all fields are specified for both AllelicCount objects, they are all used to check for equality.
equals(Object) - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AnnotatedInterval
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AnnotationSet
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CalledCopyRatioSegment
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CopyNumberPosteriorDistribution
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CopyRatio
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CopyRatioSegment
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CoveragePerContig
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.IntegerCopyNumberSegment
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.IntervalCopyNumberGenotypingData
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.MultidimensionalSegment
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.SimpleCount
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.copynumber.gcnv.IntegerCopyNumberState
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedInterval
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalCollection
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.FlagStat.FlagStatus
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.TableFuncotation
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerBloomFilter
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerSet
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTree
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTreeNode
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignedAssembly
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignedContig
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigAlignmentsConfigPicker.GoodAndBadMappings
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications.IntraChrStrandSwitchBreakpointComplications
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications.SmallDuplicationWithImpreciseDupRangeBreakpointComplications
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications.SmallDuplicationWithPreciseDupRangeBreakpointComplications
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.NovelAdjacencyAndAltHaplotype
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SimpleChimera
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SimpleNovelAdjacencyAndChimericAlignmentEvidence
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.EvidenceTargetLink
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.KmerAndInterval
 
equals(KmerAndInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.KmerAndInterval
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.QNameAndInterval
 
equals(QNameAndInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.QNameAndInterval
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.PairedStrandedIntervals
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.StrandedInterval
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVInterval
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerLong
 
equals(SVKmerLong) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerLong
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerShort
 
equals(SVKmerShort) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerShort
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVLocation
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.TextMDCodec.MDElement
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchSet
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LargeLongHopscotchSet
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongBloomFilter
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongHopscotchSet
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.ExactACcounts
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.ExactACset
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeAlleleCounts
equals(Object) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseVertex
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KBestHaplotype
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.SeqVertex
Two SeqVertex are equal only if their ids are equal
equals(Object) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.Kmer
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.MultiDeBruijnVertex
 
equals(Object) - Method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.OverhangFixingManager.Splice
 
equals(Object) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfExonFeature
 
equals(Object) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
equals(Object) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.OptionalField
 
equals(Object) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeatureBaseData
 
equals(Object) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfGeneFeature
 
equals(Object) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfTranscriptFeature
 
equals(Object) - Method in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvTableFeature
 
equals(Object) - Method in class org.broadinstitute.hellbender.utils.collections.IndexedSet
Compares this with another indexed set.
equals(IndexedSet<?>) - Method in class org.broadinstitute.hellbender.utils.collections.IndexedSet
Compare to another indexed set.
equals(Object) - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
Check to see whether two genomeLocs are equal.
equals(AlleleList<A>, AlleleList<A>) - Static method in interface org.broadinstitute.hellbender.utils.genotyper.AlleleList
Checks whether two allele lists are in fact the same.
equals(SampleList, SampleList) - Static method in interface org.broadinstitute.hellbender.utils.genotyper.SampleList
Checks whether two sample lists are in fact the same.
equals(Object) - Method in class org.broadinstitute.hellbender.utils.haplotype.Haplotype
 
equals(Object) - Method in class org.broadinstitute.hellbender.utils.IndexRange
 
equals(Object) - Method in class org.broadinstitute.hellbender.utils.KV
 
equals(Object) - Method in class org.broadinstitute.hellbender.utils.read.PrimaryAlignmentKey
 
equals(Object) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
equals(Object) - Method in class org.broadinstitute.hellbender.utils.reference.ReferenceBases
 
equals(GATKReport) - Method in class org.broadinstitute.hellbender.utils.report.GATKReport
Checks that the reports are exactly the same.
equals(GATKReportTable) - Method in class org.broadinstitute.hellbender.utils.report.GATKReportTable
Checks that the tables are exactly the same.
equals(GATKReportVersion) - Method in enum org.broadinstitute.hellbender.utils.report.GATKReportVersion
 
equals(Object) - Method in class org.broadinstitute.hellbender.utils.samples.Sample
 
equals(Object) - Method in class org.broadinstitute.hellbender.utils.SimpleInterval
 
equals(Object) - Method in class org.broadinstitute.hellbender.utils.variant.MinimalVariant
 
equals(Object) - Method in class org.broadinstitute.hellbender.utils.variant.VariantContextVariantAdapter
 
equals(Object) - Method in class picard.annotation.Gene
 
equals(Object) - Method in class picard.annotation.Gene.Transcript
 
equals(Object) - Method in class picard.fingerprint.FingerprintIdDetails
 
equals(Object) - Method in class picard.fingerprint.HaplotypeBlock
 
equals(Object) - Method in class picard.fingerprint.Snp
 
equals(Object) - Method in class picard.illumina.parser.FourChannelIntensityData
 
equals(Object) - Method in class picard.illumina.parser.Range
 
equals(Object) - Method in class picard.illumina.parser.ReadDescriptor
 
equals(Object) - Method in class picard.illumina.parser.readers.AbstractIlluminaPositionFileReader.PositionInfo
 
equals(Object) - Method in class picard.illumina.parser.readers.TileMetricsOutReader.IlluminaLaneTileCode
 
equals(Object) - Method in class picard.illumina.parser.readers.TileMetricsOutReader.IlluminaTileMetrics
 
equals(Object) - Method in class picard.illumina.parser.ReadStructure
 
equals(Object) - Method in class picard.sam.markduplicates.util.PhysicalLocationForMateCigar
 
equals(Object) - Method in class picard.vcf.GenotypeConcordanceStates.TruthAndCallStates
 
equalsIgnoreReads(AssemblyRegion) - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
Is this region equal to other, excluding any reads in either region in the comparison
equalSites(VariantContext, VariantContext) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Are vc1 and 2 equal including their position and alleles?
equateIntervals(List<GenomeLoc>, List<GenomeLoc>) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
computes whether the test interval list is equivalent to master.
ERROR_BAR_WIDTH - Variable in class picard.analysis.GcBiasDetailMetrics
The radius of error bars in this bin based on the number of observations made.
ERROR_CORRECT_READS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerArgumentCollection
 
ERROR_RATE - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasDetailMetrics
The bait bias error rate, calculated as max(1e-10, FWD_ERROR_RATE - REV_ERROR_RATE).
ERROR_RATE - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterDetailMetrics
The estimated error rate due to this artifact.
ERROR_SUMMARY_EXT - Static variable in class picard.analysis.artifacts.SequencingArtifactMetrics
 
errorCorrectKmers - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingAssembler
 
errorCorrectKmers - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadThreadingAssemblerArgumentCollection
Enabling this argument may cause fundamental problems with the assembly graph itself.
errorCorrectReads - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerArgumentCollection
Enabling this argument may cause fundamental problems with the assembly graph itself.
errorIfMissingData - Variable in class org.broadinstitute.hellbender.tools.walkers.variantutils.VariantsToTable
By default, this tool will write NA for missing data.
errorProbToQual(double) - Static method in class org.broadinstitute.hellbender.utils.QualityUtils
Convert a probability of being wrong to a phred-scaled quality score (0.01 => 20).
errorProbToQual(double, byte) - Static method in class org.broadinstitute.hellbender.utils.QualityUtils
Convert a probability of being wrong to a phred-scaled quality score (0.01 => 20).
errorProbToQual(double, int) - Static method in class org.broadinstitute.hellbender.utils.QualityUtils
 
ErrorSummaryMetrics - Class in picard.analysis.artifacts
Summary metrics produced by CollectSequencingArtifactMetrics as a roll up of the context-specific error rates, to provide global error rates per type of base substitution.
ErrorSummaryMetrics() - Constructor for class picard.analysis.artifacts.ErrorSummaryMetrics
 
ESCAPE_CHARACTER - Static variable in class org.broadinstitute.hellbender.utils.tsv.TableUtils
Escape character .
ESCAPE_STRING - Static variable in class org.broadinstitute.hellbender.utils.tsv.TableUtils
Escape character as a string.
escapeExpressions(String) - Static method in class org.broadinstitute.hellbender.utils.Utils
Splits expressions in command args by spaces and returns the array of expressions.
escapePeriods(String) - Static method in class picard.illumina.parser.ParameterizedFileUtil
Escape the period character.
ESTIMATED_LIBRARY_SIZE - Variable in class picard.sam.DuplicationMetrics
The estimated number of unique molecules in the library based on PE duplication.
ESTIMATED_Q_REPORTED_COLUMN_NAME - Static variable in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
 
EstimateLibraryComplexity - Class in picard.sam.markduplicates
Attempts to estimate library complexity from sequence alone.
EstimateLibraryComplexity() - Constructor for class picard.sam.markduplicates.EstimateLibraryComplexity
 
EstimateLibraryComplexityGATK - Class in org.broadinstitute.hellbender.tools.walkers.markduplicates
Estimate library complexity from the sequence of read pairs
EstimateLibraryComplexityGATK() - Constructor for class org.broadinstitute.hellbender.tools.walkers.markduplicates.EstimateLibraryComplexityGATK
 
estimateLibrarySize(long, long) - Static method in class picard.sam.DuplicationMetrics
Estimates the size of a library based on the number of paired end molecules observed and the number of unique pairs observed.
estimateLog10ReferenceConfidenceForOneSample(int, double) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
Compute the log10 probability of a sample with sequencing depth and no alt allele is actually truly homozygous reference Assumes the sample is diploid
estimateReferenceConfidence(VariantContext, Map<String, AlignmentContext>, double, boolean, double) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
 
estimateRoi(long, double, long, long) - Static method in class picard.sam.DuplicationMetrics
Estimates the ROI (return on investment) that one would see if a library was sequenced to x higher coverage than the observed coverage.
EVAL_VARIANTS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker
 
EVAL_VARIANTS_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker
 
evaluateData(List<VariantDatum>, GaussianMixtureModel, boolean) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantRecalibratorEngine
 
evaluateIntervalsAndNarls(List<SVInterval>, List<NovelAdjacencyAndAltHaplotype>, SAMSequenceDictionary, StructuralVariationDiscoveryArgumentCollection.DiscoverVariantsFromContigsAlignmentsSparkArgumentCollection, Logger) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoveryUtils
 
evaluations - Variable in class org.broadinstitute.hellbender.utils.solver.SynchronizedUnivariateSolver.UnivariateSolverSummary
 
evalVariantsFile - Variable in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker
 
EVENT_COUNT_IN_HAPLOTYPE_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
EVENT_TYPE_COLUMN_NAME - Static variable in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
 
eventFrom(int) - Static method in enum org.broadinstitute.hellbender.utils.recalibration.EventType
Get the EventType corresponding to its ordinal index
eventFrom(String) - Static method in enum org.broadinstitute.hellbender.utils.recalibration.EventType
Get the EventType with short string representation
EventMap - Class in org.broadinstitute.hellbender.utils.haplotype
Extract simple VariantContext events from a single haplotype
EventMap(Haplotype, byte[], Locatable, String, int) - Constructor for class org.broadinstitute.hellbender.utils.haplotype.EventMap
 
EventMap(Collection<VariantContext>) - Constructor for class org.broadinstitute.hellbender.utils.haplotype.EventMap
For testing.
EventType - Enum in org.broadinstitute.hellbender.utils.recalibration
 
evidenceDir - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
EvidenceTargetLink - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
This class holds information about pairs of intervals on the reference that are connected by one or more BreakpointEvidence objects that have distal targets.
EvidenceTargetLink(StrandedInterval, StrandedInterval, int, int, Set<String>, Set<String>) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.EvidenceTargetLink
 
EvidenceTargetLink(Kryo, Input) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.EvidenceTargetLink
 
EvidenceTargetLink.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
EvidenceTargetLinkClusterer - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
This class is responsible for iterating over a collection of BreakpointEvidence to find clusters of evidence with distal targets (discordant read pairs or split reads) that agree in their location and target intervals and strands.
EvidenceTargetLinkClusterer(ReadMetadata, int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.EvidenceTargetLinkClusterer
 
ExactACcounts - Class in org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc
Stores a vector of counts.
ExactACcounts(int[]) - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.ExactACcounts
Note: this constructor does not make a copy of the argument and stores a live pointer to the given array.
ExactACset - Class in org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc
This class represents a column in the Exact AC calculation matrix
ExactACset(int, ExactACcounts) - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.ExactACset
 
exactCallsLog - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.StandardCallerArgumentCollection
 
ExampleAssemblyRegionWalker - Class in org.broadinstitute.hellbender.tools.examples
Example/toy program that shows how to implement the AssemblyRegionWalker interface.
ExampleAssemblyRegionWalker() - Constructor for class org.broadinstitute.hellbender.tools.examples.ExampleAssemblyRegionWalker
 
ExampleAssemblyRegionWalkerSpark - Class in org.broadinstitute.hellbender.tools.examples
Example/toy program that shows how to implement the AssemblyRegionWalker interface.
ExampleAssemblyRegionWalkerSpark() - Constructor for class org.broadinstitute.hellbender.tools.examples.ExampleAssemblyRegionWalkerSpark
 
ExampleCollectMultiMetricsSpark - Class in org.broadinstitute.hellbender.tools.examples.metrics.multi
Example Spark tool for collecting multi-level metrics.
ExampleCollectMultiMetricsSpark() - Constructor for class org.broadinstitute.hellbender.tools.examples.metrics.multi.ExampleCollectMultiMetricsSpark
 
ExampleCollectSingleMetricsSpark - Class in org.broadinstitute.hellbender.tools.examples.metrics.single
Example Spark tool for collecting example single-level metrics.
ExampleCollectSingleMetricsSpark() - Constructor for class org.broadinstitute.hellbender.tools.examples.metrics.single.ExampleCollectSingleMetricsSpark
 
ExampleFeatureWalker - Class in org.broadinstitute.hellbender.tools.examples
Example/toy program that shows how to implement the FeatureWalker interface.
ExampleFeatureWalker() - Constructor for class org.broadinstitute.hellbender.tools.examples.ExampleFeatureWalker
 
ExampleIntervalWalker - Class in org.broadinstitute.hellbender.tools.examples
Example/toy program that shows how to implement the IntervalWalker interface.
ExampleIntervalWalker() - Constructor for class org.broadinstitute.hellbender.tools.examples.ExampleIntervalWalker
 
ExampleIntervalWalkerSpark - Class in org.broadinstitute.hellbender.tools.examples
Example/toy program that shows how to implement the IntervalWalker interface.
ExampleIntervalWalkerSpark() - Constructor for class org.broadinstitute.hellbender.tools.examples.ExampleIntervalWalkerSpark
 
ExampleLocusWalker - Class in org.broadinstitute.hellbender.tools.examples
Example/toy program that shows how to implement the LocusWalker interface.
ExampleLocusWalker() - Constructor for class org.broadinstitute.hellbender.tools.examples.ExampleLocusWalker
 
ExampleMultiMetrics - Class in org.broadinstitute.hellbender.tools.examples.metrics.multi
An example multi-level metrics collector that just counts the number of reads (per unit/level)
ExampleMultiMetrics(String, String, String) - Constructor for class org.broadinstitute.hellbender.tools.examples.metrics.multi.ExampleMultiMetrics
 
ExampleMultiMetricsArgumentCollection - Class in org.broadinstitute.hellbender.tools.examples.metrics.multi
Example argument collection for multi-level metrics.
ExampleMultiMetricsArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.examples.metrics.multi.ExampleMultiMetricsArgumentCollection
 
ExampleMultiMetricsCollector - Class in org.broadinstitute.hellbender.tools.examples.metrics.multi
Example multi-level metrics collector for illustrating how to collect metrics on specified accumulation levels.
ExampleMultiMetricsCollector() - Constructor for class org.broadinstitute.hellbender.tools.examples.metrics.multi.ExampleMultiMetricsCollector
 
ExampleMultiMetricsCollectorSpark - Class in org.broadinstitute.hellbender.tools.examples.metrics.multi
Example implementation of a multi-level Spark metrics collector.
ExampleMultiMetricsCollectorSpark() - Constructor for class org.broadinstitute.hellbender.tools.examples.metrics.multi.ExampleMultiMetricsCollectorSpark
 
ExampleNioCountReads - Class in org.broadinstitute.hellbender.tools.examples
Example of how to use Spark on Google Cloud Storage directly, without using the GCS Hadoop Connector.
ExampleNioCountReads() - Constructor for class org.broadinstitute.hellbender.tools.examples.ExampleNioCountReads
 
ExamplePostTraversalPythonExecutor - Class in org.broadinstitute.hellbender.tools.examples
Example/toy ReadWalker program that uses a Python script.
ExamplePostTraversalPythonExecutor() - Constructor for class org.broadinstitute.hellbender.tools.examples.ExamplePostTraversalPythonExecutor
 
ExampleProgramGroup - Class in org.broadinstitute.hellbender.cmdline.programgroups
Program group for Example programs
ExampleProgramGroup() - Constructor for class org.broadinstitute.hellbender.cmdline.programgroups.ExampleProgramGroup
 
ExampleReadWalkerWithReference - Class in org.broadinstitute.hellbender.tools.examples
Example/toy program that prints reads from the provided file or files with corresponding reference bases (if a reference is provided).
ExampleReadWalkerWithReference() - Constructor for class org.broadinstitute.hellbender.tools.examples.ExampleReadWalkerWithReference
 
ExampleReadWalkerWithReferenceSpark - Class in org.broadinstitute.hellbender.tools.examples
Example/toy program that prints reads from the provided file or files with corresponding reference bases (if a reference is provided).
ExampleReadWalkerWithReferenceSpark() - Constructor for class org.broadinstitute.hellbender.tools.examples.ExampleReadWalkerWithReferenceSpark
 
ExampleReadWalkerWithVariants - Class in org.broadinstitute.hellbender.tools.examples
Example/toy program that prints reads from the provided file or files along with overlapping variants (if a source of variants is provided).
ExampleReadWalkerWithVariants() - Constructor for class org.broadinstitute.hellbender.tools.examples.ExampleReadWalkerWithVariants
 
ExampleSingleMetrics - Class in org.broadinstitute.hellbender.tools.examples.metrics.single
 
ExampleSingleMetrics() - Constructor for class org.broadinstitute.hellbender.tools.examples.metrics.single.ExampleSingleMetrics
 
ExampleSingleMetricsArgumentCollection - Class in org.broadinstitute.hellbender.tools.examples.metrics.single
Argument argument collection for Example single level metrics.
ExampleSingleMetricsArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.examples.metrics.single.ExampleSingleMetricsArgumentCollection
 
ExampleSingleMetricsCollectorSpark - Class in org.broadinstitute.hellbender.tools.examples.metrics.single
ExampleSingleMetricsCollector for Spark.
ExampleSingleMetricsCollectorSpark() - Constructor for class org.broadinstitute.hellbender.tools.examples.metrics.single.ExampleSingleMetricsCollectorSpark
 
ExampleStreamingPythonExecutor - Class in org.broadinstitute.hellbender.tools.examples
Example ReadWalker program that uses a Python streaming executor to stream summary data from a BAM input file to a Python process through a FIFO.
ExampleStreamingPythonExecutor() - Constructor for class org.broadinstitute.hellbender.tools.examples.ExampleStreamingPythonExecutor
 
ExampleTwoPassVariantWalker - Class in org.broadinstitute.hellbender.tools.examples
This walker makes two traversals through variants in a vcf.
ExampleTwoPassVariantWalker() - Constructor for class org.broadinstitute.hellbender.tools.examples.ExampleTwoPassVariantWalker
 
ExampleVariantWalker - Class in org.broadinstitute.hellbender.tools.examples
Example/toy program that shows how to implement the VariantWalker interface.
ExampleVariantWalker() - Constructor for class org.broadinstitute.hellbender.tools.examples.ExampleVariantWalker
 
ExampleVariantWalkerSpark - Class in org.broadinstitute.hellbender.tools.examples
Example/toy program that shows how to implement the VariantWalker interface.
ExampleVariantWalkerSpark() - Constructor for class org.broadinstitute.hellbender.tools.examples.ExampleVariantWalkerSpark
 
EXCESS_HET_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
ExcessHet - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Phred-scaled p-value for exact test of excess heterozygosity.
ExcessHet(Set<String>) - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.ExcessHet
 
ExcessHet(File) - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.ExcessHet
 
ExcessHet() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.ExcessHet
 
EXCLUDE_INTERVALS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.IntervalArgumentCollection
 
EXCLUDE_INTERVALS_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.IntervalArgumentCollection
 
excludeIntervalStrings - Variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.IntervalArgumentCollection
Use this argument to exclude certain parts of the genome from the analysis (like -L, but the opposite).
excludeReadFromBAQ(GATKRead) - Method in class org.broadinstitute.hellbender.utils.baq.BAQ
Returns true if we don't think this read is eligible for the BAQ calculation.
excludingAllele(LikelihoodMatrix<A>, Allele) - Static method in class org.broadinstitute.hellbender.tools.walkers.mutect.SubsettedLikelihoodMatrix
 
excludingNonOverlaps(VcfFileSegmentGenerator, OverlapDetector<T>) - Static method in class picard.vcf.processor.VcfFileSegmentGenerator
Returns a decorated VcfFileSegmentGenerator that filters out VcfFileSegments that have no overlap with the provided OverlapDetector.
exclusionIntervalPadding - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
exclusionIntervalsFile - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
This is a file that calls out the coordinates of intervals in the reference assembly to exclude from consideration when calling putative breakpoints.
exec() - Method in class org.broadinstitute.hellbender.utils.R.RScriptExecutor
 
exec(String[]) - Static method in class org.broadinstitute.hellbender.utils.runtime.ProcessController
Similar to Runtime.exec() but drains the output and error streams.
exec(ProcessSettings) - Method in class org.broadinstitute.hellbender.utils.runtime.ProcessController
Executes a command line program with the settings and waits for it to return, processing the output on a background thread.
executableMissing() - Method in class org.broadinstitute.hellbender.utils.runtime.ScriptExecutor
 
executeArgs(List<String>) - Method in class org.broadinstitute.hellbender.utils.python.PythonScriptExecutor
Executes the Python executor using the values in rawArgs
executeCommand(String, List<String>, List<String>) - Method in class org.broadinstitute.hellbender.utils.python.PythonScriptExecutor
Execute a python command (-c).
executeCuratedArgs(String[]) - Method in class org.broadinstitute.hellbender.utils.runtime.ScriptExecutor
Execute the script represented by the arguments in commandLineArguments.
executeFromClasspath(String, String...) - Static method in class picard.util.RExecutor
Executes the given R script that is stored in a file on the classpath.
executeFromFile(File, String...) - Static method in class picard.util.RExecutor
Executes the given R script that is stored in a file by a call to Rscript.
executeModule(String, List<String>, List<String>) - Method in class org.broadinstitute.hellbender.utils.python.PythonScriptExecutor
Execute a python module (-m).
executeScript(Resource, List<String>, List<String>) - Method in class org.broadinstitute.hellbender.utils.python.PythonScriptExecutor
Execute a python script from a Resource file.
executeScript(String, List<String>, List<String>) - Method in class org.broadinstitute.hellbender.utils.python.PythonScriptExecutor
Execute a python script.
executeTest(String, CommandLineProgramTester) - Method in class org.broadinstitute.hellbender.utils.test.IntegrationTestSpec
 
executorService - Static variable in class org.broadinstitute.hellbender.utils.runtime.ProcessControllerBase
 
existingRecalibrationReport - Variable in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationArgumentCollection
 
EXIT_CODE_WHEN_CONTIG_NOT_IN_REFERENCE - Static variable in class picard.vcf.LiftoverVcf
 
EXIT_CODE_WHEN_MISMATCH - Variable in class picard.fingerprint.CrosscheckFingerprints
 
ExomeStandardArgumentDefinitions - Class in org.broadinstitute.hellbender.cmdline
Created by davidben on 11/30/15.
ExomeStandardArgumentDefinitions() - Constructor for class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
Exon(int, int) - Constructor for class picard.annotation.Gene.Transcript.Exon
 
exonId - Variable in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeatureBaseData
 
exonNumber - Variable in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeatureBaseData
 
exons - Variable in class picard.annotation.Gene.Transcript
 
expandAssemblyGraph - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
ExpandingArrayList<E> - Class in org.broadinstitute.hellbender.utils.collections
ArrayList class that automatically expands whenever ExpandingArrayList.expandingGet(int, Object) or ExpandingArrayList.set(int, Object) are called and the requested index exceeds the current ArrayList size.
ExpandingArrayList() - Constructor for class org.broadinstitute.hellbender.utils.collections.ExpandingArrayList
 
ExpandingArrayList(Collection<? extends E>) - Constructor for class org.broadinstitute.hellbender.utils.collections.ExpandingArrayList
 
ExpandingArrayList(int) - Constructor for class org.broadinstitute.hellbender.utils.collections.ExpandingArrayList
 
expandingGet(int, E) - Method in class org.broadinstitute.hellbender.utils.collections.ExpandingArrayList
 
expandWithinContig(int, int) - Method in class org.broadinstitute.hellbender.utils.SimpleInterval
Returns a new SimpleInterval that represents this interval as expanded by the specified amount in both directions, bounded by the contig start/stop if necessary.
expandWithinContig(int, SAMSequenceDictionary) - Method in class org.broadinstitute.hellbender.utils.SimpleInterval
Returns a new SimpleInterval that represents this interval as expanded by the specified amount in both directions, bounded by the contig start/stop if necessary.
EXPECT_ALL_GROUPS_TO_MATCH - Variable in class picard.fingerprint.CrosscheckFingerprints
 
EXPECT_ALL_READ_GROUPS_TO_MATCH - Variable in class picard.fingerprint.CrosscheckReadGroupFingerprints
Deprecated.
 
EXPECTED_ALLELE_FRACTION_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.AnnotateVcfWithExpectedAlleleFraction
 
EXPECTED_COLUMN_COUNT - Static variable in class org.broadinstitute.hellbender.tools.walkers.vqsr.Tranche
 
EXPECTED_GENOTYPE - Variable in class picard.analysis.FingerprintingDetailMetrics
The expected genotype of the sample at the SNP locus.
EXPECTED_INSERT_SIZE_SHORT_NAME - Static variable in class picard.cmdline.StandardOptionDefinitions
 
EXPECTED_ORIENTATIONS - Variable in class picard.sam.MergeBamAlignment
 
EXPECTED_PAIR_ORIENTATIONS - Variable in class picard.analysis.CollectAlignmentSummaryMetrics
 
EXPECTED_SAMPLE_ALIAS - Variable in class picard.fingerprint.CheckFingerprint
 
EXPECTED_VERSION - Static variable in class picard.illumina.parser.readers.FilterFileReader
Expected Version
expectedFileNames() - Method in class org.broadinstitute.hellbender.utils.test.IntegrationTestSpec
 
expectedHeaderLinesInVCF - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
expectedNumberOfReads() - Method in class org.broadinstitute.hellbender.utils.read.ArtificialBAMBuilder
 
expectsException() - Method in class org.broadinstitute.hellbender.utils.test.IntegrationTestSpec
 
expressionAlleleConcordance - Variable in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotator
If this argument is specified, add annotations (specified by --expression) from an external resource (specified by --resource) to the input VCF (specified by --variant) only if the alleles are concordant between input and the resource VCFs.
expressionsToUse - Variable in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotator
This option enables you to add annotations from one VCF to another.
extendedSpan - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmer.Result
The trimmed variant region span including the extension.
extension - Variable in class picard.illumina.parser.ParameterizedFileUtil
The file extension for this class, file extension does not have the standard meaning in this instance.
EXTERNAL_CNV_CALLS - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
ExternalEvidence(int, int, int, int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.ExternalEvidence
 
ExternalEvidence(SVInterval, int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.ExternalEvidence
 
ExternalEvidence(Kryo, Input) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.ExternalEvidence
 
externalEvidenceFile - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
externalEvidenceUncertainty - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
externalEvidenceWeight - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
externalExecutableExists() - Method in class org.broadinstitute.hellbender.utils.runtime.ScriptExecutor
 
externalScriptExecutableName - Variable in class org.broadinstitute.hellbender.utils.runtime.ScriptExecutor
 
EXTRA_FIELD_KEY_VALUE_SPLITTER - Static variable in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
extraAttributes - Variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvType
 
extract(JavaRDD<VariantContext>, SvDiscoveryInputMetaData, JavaRDD<GATKRead>) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SegmentedCpxVariantSimpleVariantExtractor
 
EXTRACT_CONTAMINATED - Variable in class picard.fingerprint.IdentifyContaminant
 
ExtractIlluminaBarcodes - Class in picard.illumina
Determine the barcode for each read in an Illumina lane.
ExtractIlluminaBarcodes() - Constructor for class picard.illumina.ExtractIlluminaBarcodes
 
ExtractIlluminaBarcodes.BarcodeMetric - Class in picard.illumina
Metrics produced by the ExtractIlluminaBarcodes program that is used to parse data in the basecalls directory and determine to which barcode each read should be assigned.
ExtractIlluminaBarcodes.PerTileBarcodeExtractor - Class in picard.illumina
Extracts barcodes and accumulates metrics for an entire tile.
ExtractIlluminaBarcodes.PerTileBarcodeExtractor.BarcodeMatch - Class in picard.illumina
Utility class to hang onto data about the best match for a given barcode
extractInts(Object) - Static method in class org.broadinstitute.hellbender.tools.walkers.variantutils.PosteriorProbabilitiesUtils
Check the formatting on the Object returned by a call to VariantContext::getAttribute() and parse appropriately
ExtractOriginalAlignmentRecordsByNameSpark - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
Subsets reads by name
ExtractOriginalAlignmentRecordsByNameSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.ExtractOriginalAlignmentRecordsByNameSpark
 
ExtractSequences - Class in picard.reference
Simple command line program that allows sub-sequences represented by an interval list to be extracted from a reference sequence file.
ExtractSequences() - Constructor for class picard.reference.ExtractSequences
 
ExtractSVEvidenceSpark - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
(Internal) Extracts evidence of structural variations from reads
ExtractSVEvidenceSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.ExtractSVEvidenceSpark
 
EXTREME_OUTLIER_TRUNCATION_PERCENTILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.CreateReadCountPanelOfNormals
 
EXTREME_SAMPLE_MEDIAN_PERCENTILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.CreateReadCountPanelOfNormals
 

F

F - Static variable in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
F - Static variable in class picard.sam.markduplicates.util.ReadEnds
 
F1R2_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
F2R1_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
failMissingValues - Variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
By default, if JEXL cannot evaluate your expression for a particular record because one of the annotations is not present, the whole expression evaluates as PASSing.
FailsStrictValidation(String, ValidateVariants.ValidationType, String) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.FailsStrictValidation
 
failsVendorQualityCheck() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
failsVendorQualityCheck() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
FAIR_BINOMIAL_PROB_LOG10_0_5 - Static variable in class org.broadinstitute.hellbender.utils.MathUtils
 
FAKE_FILES - Variable in class picard.illumina.CheckIlluminaDirectory
 
fakeBciFile(File, List<Integer>) - Method in class picard.illumina.parser.fakers.BciFileFaker
 
fakeFile(ByteBuffer) - Method in class picard.illumina.parser.fakers.BarcodeFileFaker
 
fakeFile(ByteBuffer) - Method in class picard.illumina.parser.fakers.BciFileFaker
 
fakeFile(ByteBuffer) - Method in class picard.illumina.parser.fakers.BclFileFaker
 
fakeFile(ByteBuffer) - Method in class picard.illumina.parser.fakers.ClocsFileFaker
 
fakeFile(ByteBuffer) - Method in class picard.illumina.parser.fakers.FileFaker
 
fakeFile(File, int, int, String) - Method in class picard.illumina.parser.fakers.FileFaker
 
fakeFile(File, List<Integer>, int, String) - Method in class picard.illumina.parser.fakers.FileFaker
 
fakeFile(File, Integer) - Method in class picard.illumina.parser.fakers.FileFaker
 
fakeFile(ByteBuffer) - Method in class picard.illumina.parser.fakers.FilterFileFaker
 
fakeFile(ByteBuffer) - Method in class picard.illumina.parser.fakers.LocsFileFaker
 
fakeFile(ByteBuffer) - Method in class picard.illumina.parser.fakers.MultiTileBclFileFaker
 
fakeFile(ByteBuffer) - Method in class picard.illumina.parser.fakers.MultiTileLocsFileFaker
 
fakeFile(ByteBuffer) - Method in class picard.illumina.parser.fakers.PosFileFaker
 
fakeFiles(List<Integer>, int[], IlluminaFileUtil.SupportedIlluminaFormat) - Method in class picard.illumina.parser.MultiTileBclFileUtil
 
fakeFiles(List<Integer>, int[], IlluminaFileUtil.SupportedIlluminaFormat) - Method in class picard.illumina.parser.MultiTileFileUtil
 
fakeFiles(List<Integer>, int[], IlluminaFileUtil.SupportedIlluminaFormat) - Method in class picard.illumina.parser.ParameterizedFileUtil
Given the expected tiles/expected cycles for this file type create a set of fake files such that the verification criteria are met.
fakeFiles(List<Integer>, int[], IlluminaFileUtil.SupportedIlluminaFormat) - Method in class picard.illumina.parser.PerTileFileUtil
 
fakeFiles(List<Integer>, int[], IlluminaFileUtil.SupportedIlluminaFormat) - Method in class picard.illumina.parser.PerTilePerCycleFileUtil
 
faker - Variable in class picard.illumina.parser.ParameterizedFileUtil
 
FakeReferenceSource - Class in org.broadinstitute.hellbender.utils.test
 
FakeReferenceSource() - Constructor for class org.broadinstitute.hellbender.utils.test.FakeReferenceSource
 
falseNegative(VariantContext) - Static method in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker.TruthVersusEval
 
falsePositive(VariantContext) - Static method in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker.TruthVersusEval
 
FalsePositiveRecord - Class in org.broadinstitute.hellbender.tools.walkers.validation
Created by tsato on 2/14/17.
FalsePositiveRecord(String, long, long, long) - Constructor for class org.broadinstitute.hellbender.tools.walkers.validation.FalsePositiveRecord
 
FAMILY_ID - Variable in class picard.vcf.MendelianViolations.MendelianViolationMetrics
The family ID assigned to the trio for which these metrics are calculated.
FamilyLikelihoods - Class in org.broadinstitute.hellbender.tools.walkers.variantutils
Utility to compute genotype posteriors given family priors.
FamilyLikelihoods(SampleDB, double, Set<String>, Map<String, Set<Sample>>) - Constructor for class org.broadinstitute.hellbender.tools.walkers.variantutils.FamilyLikelihoods
 
FastaReferenceWriter - Class in org.broadinstitute.hellbender.utils.reference
Writes a FASTA formatted reference file.
FastaReferenceWriter(Path, boolean, boolean) - Constructor for class org.broadinstitute.hellbender.utils.reference.FastaReferenceWriter
Creates a reference FASTA file writer.
FastaReferenceWriter(Path, int, boolean, boolean) - Constructor for class org.broadinstitute.hellbender.utils.reference.FastaReferenceWriter
Creates a reference FASTA file writer.
FastaReferenceWriter(Path, Path, Path) - Constructor for class org.broadinstitute.hellbender.utils.reference.FastaReferenceWriter
Creates a reference FASTA file writer.
FastaReferenceWriter(Path, int, Path, Path) - Constructor for class org.broadinstitute.hellbender.utils.reference.FastaReferenceWriter
Creates a reference FASTA file writer.
FastaReferenceWriter(OutputStream, int, OutputStream, OutputStream) - Constructor for class org.broadinstitute.hellbender.utils.reference.FastaReferenceWriter
Creates a reference FASTA file writer.
FASTQ - Variable in class picard.sam.FastqToSam
 
FASTQ - Variable in class picard.sam.SamToFastq
 
FASTQ2 - Variable in class picard.sam.FastqToSam
 
fastqDir - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
FastqRead(GATKRead) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils.FastqRead
 
FastqRead(GATKRead, boolean) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils.FastqRead
 
FastqToSam - Class in picard.sam
Converts a FASTQ file to an unaligned BAM or SAM file.
FastqToSam() - Constructor for class picard.sam.FastqToSam
 
fastRound(double) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
FastWgsMetricsCollector - Class in picard.analysis
Class represents fast algorithm for collecting data from AbstractLocusInfo with a list of aligned EdgingRecordAndOffset objects.
FastWgsMetricsCollector(CollectWgsMetrics, int, IntervalList) - Constructor for class picard.analysis.FastWgsMetricsCollector
Creates a collector and initializes the inner data structures
FATHER - Variable in class picard.vcf.MendelianViolations.MendelianViolationMetrics
The ID of the father within the trio.
fdrToTiTv(double, double) - Static method in class org.broadinstitute.hellbender.tools.walkers.vqsr.TrancheManager
 
FEATURE_ARGUMENT_KEY_VALUE_PAIR_DELIMITER - Static variable in class org.broadinstitute.hellbender.engine.FeatureInput
Delimiter between key-value pairs in the --argument_name logical_name,key1=value1,key2=value2:feature_file syntax.
FEATURE_ARGUMENT_KEY_VALUE_SEPARATOR - Static variable in class org.broadinstitute.hellbender.engine.FeatureInput
Separator between keys and values in the --argument_name logical_name,key1=value1,key2=value2:feature_file syntax.
FEATURE_ARGUMENT_TAG_DELIMITER - Static variable in class org.broadinstitute.hellbender.engine.FeatureInput
Delimiter between the logical name and the file name in the --argument_name logical_name:feature_file syntax
FEATURE_CACHE_LOOKAHEAD - Static variable in class org.broadinstitute.hellbender.engine.ReadWalker
This number controls the size of the cache for our FeatureInputs (specifically, the number of additional bases worth of overlapping records to cache when querying feature sources).
FEATURE_CACHE_LOOKAHEAD - Static variable in class org.broadinstitute.hellbender.engine.spark.ReadWalkerSpark
This number controls the size of the cache for our FeatureInputs (specifically, the number of additional bases worth of overlapping records to cache when querying feature sources).
FEATURE_CACHE_LOOKAHEAD - Static variable in class org.broadinstitute.hellbender.engine.spark.VariantWalkerSpark
This number controls the size of the cache for our primary and auxiliary FeatureInputs (specifically, the number of additional bases worth of overlapping records to cache when querying feature sources).
FEATURE_CACHE_LOOKAHEAD - Static variable in class org.broadinstitute.hellbender.engine.VariantWalkerBase
This number controls the size of the cache for our primary and auxiliary FeatureInputs (specifically, the number of additional bases worth of overlapping records to cache when querying feature sources).
FEATURE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
FEATURE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
FeatureContext - Class in org.broadinstitute.hellbender.engine
Wrapper around FeatureManager that presents Feature data from a particular interval to a client tool without improperly exposing engine internals.
FeatureContext() - Constructor for class org.broadinstitute.hellbender.engine.FeatureContext
Creates an empty FeatureContext with no backing data source.
FeatureContext(FeatureManager, SimpleInterval) - Constructor for class org.broadinstitute.hellbender.engine.FeatureContext
Creates a new FeatureContext given a FeatureManager and a query interval.
FeatureDataSource<T extends htsjdk.tribble.Feature> - Class in org.broadinstitute.hellbender.engine
Enables traversals and queries over sources of Features, which are metadata associated with a location on the genome in a format supported by our file parsing framework, Tribble.
FeatureDataSource(File) - Constructor for class org.broadinstitute.hellbender.engine.FeatureDataSource
Creates a FeatureDataSource backed by the provided File.
FeatureDataSource(String) - Constructor for class org.broadinstitute.hellbender.engine.FeatureDataSource
Creates a FeatureDataSource backed by the provided path.
FeatureDataSource(File, String) - Constructor for class org.broadinstitute.hellbender.engine.FeatureDataSource
Creates a FeatureDataSource backed by the provided File and assigns this data source the specified logical name.
FeatureDataSource(File, String, int) - Constructor for class org.broadinstitute.hellbender.engine.FeatureDataSource
Creates a FeatureDataSource backed by the provided File and assigns this data source the specified logical name.
FeatureDataSource(String, String, int, Class<? extends Feature>) - Constructor for class org.broadinstitute.hellbender.engine.FeatureDataSource
Creates a FeatureDataSource backed by the resource at the provided path.
FeatureDataSource(FeatureInput<T>, int, Class<? extends Feature>) - Constructor for class org.broadinstitute.hellbender.engine.FeatureDataSource
Creates a FeatureDataSource backed by the provided FeatureInput.
FeatureDataSource(String, String, int, Class<? extends Feature>, int, int) - Constructor for class org.broadinstitute.hellbender.engine.FeatureDataSource
Creates a FeatureDataSource backed by the resource at the provided path.
FeatureDataSource(FeatureInput<T>, int, Class<? extends Feature>, int, int) - Constructor for class org.broadinstitute.hellbender.engine.FeatureDataSource
Creates a FeatureDataSource backed by the provided FeatureInput.
FeatureDataSource(FeatureInput<T>, int, Class<? extends Feature>, int, int, Path) - Constructor for class org.broadinstitute.hellbender.engine.FeatureDataSource
Creates a FeatureDataSource backed by the provided FeatureInput.
featureFile - Variable in class org.broadinstitute.hellbender.tools.IndexFeatureFile
 
featureFiles - Variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.OptionalFeatureInputArgumentCollection
 
featureFiles - Variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.RequiredFeatureInputArgumentCollection
 
featureFileToIntervals(GenomeLocParser, String) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Converts a Feature-containing file to a list of intervals
FeatureInput<T extends htsjdk.tribble.Feature> - Class in org.broadinstitute.hellbender.engine
Class to represent a Feature-containing input file.
FeatureInput(String, String, Map<String, String>) - Constructor for class org.broadinstitute.hellbender.engine.FeatureInput
Construct a FeatureInput from raw components: name, key value pairs and the file.
FeatureManager - Class in org.broadinstitute.hellbender.engine
Handles discovery of available codecs and Feature arguments, file format detection and codec selection, and creation/management/querying of FeatureDataSources for each source of Features.
FeatureManager(CommandLineProgram) - Constructor for class org.broadinstitute.hellbender.engine.FeatureManager
Create a FeatureManager given a CommandLineProgram tool instance, discovering all FeatureInput arguments in the tool and creating query-able FeatureDataSources for them.
FeatureManager(CommandLineProgram, int) - Constructor for class org.broadinstitute.hellbender.engine.FeatureManager
Create a FeatureManager given a CommandLineProgram tool instance, discovering all FeatureInput arguments in the tool and creating query-able FeatureDataSources for them.
FeatureManager(CommandLineProgram, int, int, int) - Constructor for class org.broadinstitute.hellbender.engine.FeatureManager
Create a FeatureManager given a CommandLineProgram tool instance, discovering all FeatureInput arguments in the tool and creating query-able FeatureDataSources for them.
FeatureManager(CommandLineProgram, int, int, int, Path) - Constructor for class org.broadinstitute.hellbender.engine.FeatureManager
Create a FeatureManager given a CommandLineProgram tool instance, discovering all FeatureInput arguments in the tool and creating query-able FeatureDataSources for them.
featureOrderNumber - Variable in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeatureBaseData
The relative order of this Feature.
features - Variable in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
 
featuresFile - Variable in class org.broadinstitute.hellbender.tools.examples.ExampleFeatureWalker
 
featureType - Variable in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeatureBaseData
Type of this feature.
FeatureWalker<F extends htsjdk.tribble.Feature> - Class in org.broadinstitute.hellbender.engine
A FeatureWalker is a tool that processes a Feature at a time from a source of Features, with optional contextual information from a reference, sets of reads, and/or supplementary sources of Features.
FeatureWalker() - Constructor for class org.broadinstitute.hellbender.engine.FeatureWalker
 
FEMALE_CHROMS - Variable in class picard.vcf.MendelianViolations.FindMendelianViolations
 
FermiLiteAssemblyHandler - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
LocalAssemblyHandler that uses FermiLite.
FermiLiteAssemblyHandler(String, int, String, boolean, boolean, boolean, boolean, int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.FermiLiteAssemblyHandler
 
fetch(long) - Method in class org.broadinstitute.hellbender.utils.nio.SeekableByteChannelPrefetcher
 
FF - Static variable in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
FF - Static variable in class picard.sam.markduplicates.util.ReadEnds
 
FIELD_DELIMITER - Static variable in class org.broadinstitute.hellbender.tools.funcotator.vcfOutput.VcfOutputRenderer
The delimiter for each field within the VCF Funcotation field.
FifoBuffer - Class in picard.util
Summary
FifoBuffer(InputStream, PrintStream) - Constructor for class picard.util.FifoBuffer
Constructor that defaults to QUIET since Fifos don't do anything beyond buffering having their start/end information logged is often undesirable.
FifoBuffer() - Constructor for class picard.util.FifoBuffer
Constructor that defaults to QUIET since Fifos don't do anything beyond buffering having their start/end information logged is often undesirable.
FILE_EXTENSION - Variable in class picard.analysis.artifacts.CollectSequencingArtifactMetrics
 
FILE_EXTENSION - Variable in class picard.analysis.CollectMultipleMetrics
 
FILE_EXTENSION - Variable in class picard.illumina.CollectIlluminaLaneMetrics
 
FILE_PREFIX - Static variable in class org.broadinstitute.hellbender.utils.gcs.BucketUtils
 
fileExists(String) - Static method in class org.broadinstitute.hellbender.utils.gcs.BucketUtils
Returns true if we can read the first byte of the file.
FileFaker - Class in picard.illumina.parser.fakers
 
FileFaker() - Constructor for class picard.illumina.parser.fakers.FileFaker
 
filesAvailable() - Method in class picard.illumina.parser.MultiTileBclFileUtil
 
filesAvailable() - Method in class picard.illumina.parser.MultiTileFileUtil
 
filesAvailable() - Method in class picard.illumina.parser.ParameterizedFileUtil
Determine whether or not files are available
filesAvailable() - Method in class picard.illumina.parser.PerTileFileUtil
 
filesAvailable() - Method in class picard.illumina.parser.PerTileOrPerRunFileUtil
 
filesAvailable() - Method in class picard.illumina.parser.PerTilePerCycleFileUtil
 
fileSize(String) - Static method in class org.broadinstitute.hellbender.utils.gcs.BucketUtils
Returns the file size of a file pointed to by a GCS/HDFS/local path
fileToTile(String) - Static method in class picard.illumina.parser.NewIlluminaDataProvider
 
fileToTile(String) - Method in class picard.illumina.parser.ParameterizedFileUtil
Returns only lane and tile information as PerTileFt's do not have End information.
FILL_POOLS - Variable in class picard.util.BaitDesigner
 
fillContext(ReferenceMultiSource, ContextShard) - Static method in class org.broadinstitute.hellbender.engine.spark.AddContextDataToReadSparkOptimized
Given a shard that has reads and variants, query Google Genomics' Reference server and get reference info (including an extra margin on either side), and fill that and the correct variants into readContext.
fillIdx - Variable in class org.broadinstitute.hellbender.tools.spark.sv.evidence.KSWindowFinder
 
fillQualsFromLikelihood(VariantContext, ReadLikelihoods<Allele>, List<Double>, List<Double>, int) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.RankSumTest
 
fillVariants(List<SimpleInterval>, List<GATKVariant>, int) - Static method in class org.broadinstitute.hellbender.engine.spark.AddContextDataToReadSparkOptimized
Given a list of shards and a list of variants, add each variant to every (shard+margin) that it overlaps.
fillWithRandomBases(byte[], int, int) - Static method in class org.broadinstitute.hellbender.utils.BaseUtils
Fill an array section with random bases.
filter(IntPredicate) - Method in class org.broadinstitute.hellbender.utils.IndexRange
Find the elements of this range for which an int -> boolean predicate is true
FILTER - Variable in class picard.sam.FilterSamReads
 
filter(VariantContext) - Method in class picard.vcf.filter.AlleleBalanceFilter
 
filter(VariantContext, Genotype) - Method in class picard.vcf.filter.DepthFilter
 
filter(VariantContext) - Method in class picard.vcf.filter.FisherStrandFilter
 
filter(VariantContext, Genotype) - Method in interface picard.vcf.filter.GenotypeFilter
Test whether or not the genotype should be filtered out.
filter(VariantContext, Genotype) - Method in class picard.vcf.filter.GenotypeQualityFilter
 
filter(VariantContext) - Method in class picard.vcf.filter.QdFilter
 
filter(VariantContext) - Method in interface picard.vcf.filter.VariantFilter
Check to see if the VariantContext should have a filter applied to it.
FILTER_ANALYSIS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.Concordance
 
FILTER_BWA_IMAGE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
FILTER_BWA_IMAGE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
FILTER_BWA_SEED_LENGTH_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
FILTER_BWA_SEED_LENGTH_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
FILTER_CANNOT_LIFTOVER_INDEL - Static variable in class picard.vcf.LiftoverVcf
Filter name to use when a target cannot be lifted over.
FILTER_DUPLICATES_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
FILTER_DUPLICATES_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
FILTER_ENTRY_SEPARATOR - Static variable in class org.broadinstitute.hellbender.engine.filters.ReadGroupBlackListReadFilter
 
FILTER_EXPRESSION_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
 
FILTER_INDEL_STRADDLES_TWO_INTERVALS - Static variable in class picard.vcf.LiftoverVcf
Filter name to use when an indel cannot be lifted over since it straddles two intervals in a chain which means that it is unclear what are the right alleles to be used.
FILTER_METRICS_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
FILTER_METRICS_FILE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
FILTER_MISMATCHING_REF_ALLELE - Static variable in class picard.vcf.LiftoverVcf
Filter name to use when a target is lifted over, but the reference allele doesn't match the new reference.
FILTER_NAME - Static variable in class picard.vcf.filter.QdFilter
 
FILTER_NAME_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
 
FILTER_NO_TARGET - Static variable in class picard.vcf.LiftoverVcf
Filter name to use when a target cannot be lifted over.
FILTER_NOT_IN_MASK_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
 
FILTER_READS_PER_PARTITION_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
FILTER_READS_PER_PARTITION_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
FILTER_TOO_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ReadFilterArgumentDefinitions
 
FilterAlignmentArtifacts - Class in org.broadinstitute.hellbender.tools.walkers.realignmentfilter
Filter false positive alignment artifacts from a VCF callset.
FilterAlignmentArtifacts() - Constructor for class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.FilterAlignmentArtifacts
 
filterAnalysis - Variable in class org.broadinstitute.hellbender.tools.walkers.validation.Concordance
 
FilterAnalysisRecord - Class in org.broadinstitute.hellbender.tools.walkers.validation
 
FilterAnalysisRecord(String, int, int, int, int) - Constructor for class org.broadinstitute.hellbender.tools.walkers.validation.FilterAnalysisRecord
 
filterAndConvertToAlignedContigDirect(Iterable<AlignedAssemblyOrExcuse>, List<String>, SAMFileHeader) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryPipelineSpark.InMemoryAlignmentParser
Filter out "failed" assemblies, unmapped and secondary (i.e.
filterAndConvertToAlignedContigViaSAM(List<AlignedAssemblyOrExcuse>, SAMFileHeader, JavaSparkContext) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryPipelineSpark.InMemoryAlignmentParser
Filters out "failed" assemblies, unmapped and secondary (i.e.
FilterApplyingVariantIterator - Class in picard.vcf.filter
Iterator that dynamically applies filter strings to VariantContext records supplied by an underlying iterator.
FilterApplyingVariantIterator(Iterator<VariantContext>, Collection<VariantFilter>, Collection<GenotypeFilter>) - Constructor for class picard.vcf.filter.FilterApplyingVariantIterator
Constructs an iterator from an underlying iterator and the provided (possibly empty) collections of variant and genotype filters.
filterArgs - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqFilterSpark
 
filterArgs - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqPipelineSpark
 
FilterByOrientationBias - Class in org.broadinstitute.hellbender.tools.exome
Additionally filter Mutect2 somatic variant calls for sequence context-dependent artifacts, e.g.
FilterByOrientationBias() - Constructor for class org.broadinstitute.hellbender.tools.exome.FilterByOrientationBias
 
filterDuplicates - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
If true, then for any two reads with identical sequences (or identical to the other's reverse complement), one will be filtered.
FILTERED_INDELS - Variable in class picard.vcf.CollectVariantCallingMetrics.VariantCallingSummaryMetrics
The number of indels that are filtered
FILTERED_SNPS - Variable in class picard.vcf.CollectVariantCallingMetrics.VariantCallingSummaryMetrics
The number of SNPs that are filtered
FILTERED_TRUE_NEGATIVES_AND_FALSE_NEGATIVES_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.Concordance
 
FILTERED_TRUE_NEGATIVES_AND_FALSE_NEGATIVES_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.Concordance
 
filteredCount - Variable in class org.broadinstitute.hellbender.engine.filters.CountingReadFilter
 
filteredCount - Variable in class org.broadinstitute.hellbender.engine.filters.CountingVariantFilter
 
filteredFalseNegative(VariantContext, VariantContext) - Static method in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker.TruthVersusEval
 
filteredTrueNegative(VariantContext) - Static method in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker.TruthVersusEval
 
filteredTrueNegativesAndFalseNegativesVcf - Variable in class org.broadinstitute.hellbender.tools.walkers.validation.Concordance
 
filterExpressions - Variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
VariantFiltration accepts any number of JEXL expressions (so you can have two named filters by using --filterName One --filterExpression "X < 1" --filterName Two --filterExpression "X > 2").
FilterFileFaker - Class in picard.illumina.parser.fakers
Created by jcarey on 3/13/14.
FilterFileFaker() - Constructor for class picard.illumina.parser.fakers.FilterFileFaker
 
FilterFileReader - Class in picard.illumina.parser.readers
Illumina uses an algorithm described in "Theory of RTA" that determines whether or not a cluster passes filter("PF") or not.
FilterFileReader(File) - Constructor for class picard.illumina.parser.readers.FilterFileReader
 
FILTERING_STATUS_VCF_KEY - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2FilteringEngine
 
filterMetricsFileUri - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
If specified, records the number of reads remaining after each of the following steps: Pre-aligned host read filtering Low-quality and low-complexity sequence filtering Host read subtraction Read deduplication
FilterMutectCalls - Class in org.broadinstitute.hellbender.tools.walkers.mutect
Filter variants in a Mutect2 VCF callset.
FilterMutectCalls() - Constructor for class org.broadinstitute.hellbender.tools.walkers.mutect.FilterMutectCalls
 
filterNames - Variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
This name is put in the FILTER field for variants that get filtered.
filterOut(SAMRecord) - Method in class picard.filter.CountingFilter
 
filterOut(SAMRecord, SAMRecord) - Method in class picard.filter.CountingFilter
 
filterPoorlyModeledReads(double) - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Removes those read that the best possible likelihood given any allele is just too low.
filterPoorlyModeledReads(double) - Method in class org.broadinstitute.hellbender.utils.genotyper.UnfilledReadsLikelihoods
 
filterReadsPerPartition - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
This is a parameter for fine-tuning memory performance.
filterRecordsNotInMask - Variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
By default, if the -mask argument is used, any variant falling in a mask will be filtered.
filterReferenceConfidenceAnnotations(Collection<Annotation>) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerEngine
Common method to use in order to remove unwanted annotations from the list returned by the plugin specifically for reference confidence mode.
FilterSamReads - Class in picard.sam
Summary
FilterSamReads() - Constructor for class picard.sam.FilterSamReads
 
FilterSamReads.Filter - Enum in picard.sam
 
filterSuspectSites() - Method in class picard.fingerprint.Fingerprint
Attempts to filter out haplotypes that may have suspect genotyping by removing haplotypes that reach a minimum confidence score yet have a significant fraction of observations from a third or fourth allele.
filterToOnlyOverlappingUnclippedReads(SimpleInterval) - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Remove those reads that do not overlap certain genomic location.
filterToOnlyOverlappingUnclippedReads(SimpleInterval) - Method in class org.broadinstitute.hellbender.utils.genotyper.UnfilledReadsLikelihoods
 
FilterVariantTranches - Class in org.broadinstitute.hellbender.tools.walkers.vqsr
Apply tranche filtering to VCF based on scores from the INFO field.
FilterVariantTranches() - Constructor for class org.broadinstitute.hellbender.tools.walkers.vqsr.FilterVariantTranches
 
FilterVcf - Class in picard.vcf.filter
Applies a set of hard filters to Variants and to Genotypes within a VCF.
FilterVcf() - Constructor for class picard.vcf.filter.FilterVcf
Constructor to default to having index creation on.
FINAL_FIT_FILE_TAG - Static variable in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
FINAL_PAIRED_READS - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterMetrics
The number of non-host reads that have mates
FINAL_TOTAL_READS - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterMetrics
The number of non-host reads in total
FINAL_UNPAIRED_READS - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterMetrics
The number of non-host unpaired reads
finalize() - Method in class org.broadinstitute.hellbender.utils.runtime.ProcessControllerBase
 
finalizeAndWriteMetrics(LibraryIdGenerator) - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.AbstractMarkDuplicatesCommandLineProgram
Writes the metrics given by the libraryIdGenerator to the METRICS_FILE.
finalizeAndWriteMetrics(LibraryIdGenerator) - Method in class picard.sam.markduplicates.util.AbstractMarkDuplicatesCommandLineProgram
Writes the metrics given by the libraryIdGenerator to the METRICS_FILE.
finalizeAnnotations(VariantContext, VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotatorEngine
Finalize reducible annotations (those that use raw data in gVCFs)
finalizeData() - Method in class org.broadinstitute.hellbender.utils.recalibration.BaseRecalibrationEngine
Finalize, if appropriate, all derived data in recalibrationTables.
finalizeMetrics(Map<String, ExtractIlluminaBarcodes.BarcodeMetric>, ExtractIlluminaBarcodes.BarcodeMetric) - Static method in class picard.illumina.ExtractIlluminaBarcodes
 
finalizeRawData(VariantContext, VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_QualByDepth
Uses the "AS_QUAL" key, which must be computed by the genotyping engine in GenotypeGVCFs, to calculate the final AS_QD annotation on the read.
finalizeRawData(VariantContext, VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RankSumTest
Parses the raw data histograms generated for each allele and outputs the median value for each histogram as a representative double value.
finalizeRawData(VariantContext, VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RMSMappingQuality
Takes combined raw annotation data sums, and calculates per allele the average root mean squared from the raw data using expected Allele Depth counts data.
finalizeRawData(VariantContext, VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_StrandBiasTest
Parses the raw data stings of combined contingency matrix data and calls client methods calculateReducedData(myData) implementation to generate double digest of provided allele information which is stored in '|' delineated lists.
finalizeRawData(VariantContext, VariantContext) - Method in interface org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.ReducibleAnnotation
Calculate the final annotation value from the raw data which was generated by either annotateRawData or calculateRawData
finalizeRawData(VariantContext, VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.RMSMappingQuality
 
finalizeRawMQ(VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.RMSMappingQuality
converts GATKVCFConstants.RAW_RMS_MAPPING_QUALITY_KEY into VCFConstants.RMS_MAPPING_QUALITY_KEY annotation if present
finalizeRecalibrationTables(RecalibrationTables) - Static method in class org.broadinstitute.hellbender.utils.recalibration.BaseRecalibrationEngine
Finalize, if appropriate, all derived data in recalibrationTables.
finalizeRegion(AssemblyRegion, boolean, boolean, byte, SAMFileHeader, SampleList) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerUtils
 
finalPos - Variable in class org.broadinstitute.hellbender.utils.read.ArtificialReadQueryIterator
 
find(SVInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree
Find an interval.
find(Object) - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchCollection
find an entry equivalent to the key, or return null
find(String, Class<?>) - Method in class picard.cmdline.ClassFinder
Scans the classpath for classes within the specified package and sub-packages that extend the parentType.
findAndProcessHeaderLine() - Method in class org.broadinstitute.hellbender.utils.tsv.TableReader
Process the first lines of the input source until the header line.
FindBadGenomicKmersSpark - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
Identifies sequences that occur at high frequency in a reference
FindBadGenomicKmersSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.FindBadGenomicKmersSpark
 
findBestBarcodeAndUpdateMetrics(byte[][], byte[][], boolean, Map<String, ExtractIlluminaBarcodes.BarcodeMetric>, ExtractIlluminaBarcodes.BarcodeMetric, int, int, int, int) - Static method in class picard.illumina.ExtractIlluminaBarcodes.PerTileBarcodeExtractor
Find the best barcode match for the given read sequence, and accumulate metrics
FindBreakpointEvidenceSpark - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
(Internal) Produces local assemblies of genomic regions that may harbor structural variants
FindBreakpointEvidenceSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.FindBreakpointEvidenceSpark
 
FindBreakpointEvidenceSpark.AssembledEvidenceResults - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
FindBreakpointEvidenceSpark.IntPair - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
FindBreakpointEvidenceSparkArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
findByIndex(int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree
Find the nth interval in the tree.
findChangepoints(int, BiFunction<DATA, DATA, Double>, int, List<Integer>, double, double, KernelSegmenter.ChangepointSortOrder) - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.segmentation.KernelSegmenter
Returns a list of the indices of the changepoints, either sorted by decreasing change to the global segmentation cost or by increasing index order.
findEach(Object) - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchCollection
get an iterator over each of the elements equivalent to the key
findFirstPositionWhereHaplotypesDiffer(byte[], byte[]) - Static method in class org.broadinstitute.hellbender.utils.pairhmm.PairHMM
Compute the first position at which two haplotypes differ If the haplotypes are exact copies of each other, returns the min length of the two haplotypes.
findIndexOfClipSequence(byte[], byte[], int, double) - Static method in class picard.util.ClippingUtility
Finds the first index of the adapterSequence sequence in the read sequence requiring at least minMatch bases of pairwise alignment with a maximum number of errors dictated by maxErrorRate.
findIndexOfFirstNonClippingOperation(List<CigarElement>, boolean) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SvCigarUtils
Returns the index of the first non-clipping operation into the input cigarElements.
findKmer(Kmer) - Method in interface org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KmerSearchableGraph
Returns the vertex that represents or contains the last base of a given kmer.
findKmer(Kmer) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingGraph
 
FindMendelianViolations - Class in picard.vcf.MendelianViolations
Summary
FindMendelianViolations() - Constructor for class picard.vcf.MendelianViolations.FindMendelianViolations
 
findNumberOfRepetitions(byte[], byte[], boolean) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Finds number of repetitions a string consists of.
findNumberOfRepetitions(byte[], int, int, byte[], int, int, boolean) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Finds number of repetitions a string consists of.
findOpticalDuplicates(List<? extends PhysicalLocation>, PhysicalLocation) - Method in class picard.sam.markduplicates.util.OpticalDuplicateFinder
Finds which reads within the list of duplicates that are likely to be optical/co-localized duplicates of one another.
findPlausiblePairs(List<BwaMemAlignment>, List<BwaMemAlignment>, int) - Static method in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.RealignmentEngine
 
findPreferredFormat(IlluminaDataType, IlluminaFileUtil) - Static method in class picard.illumina.parser.IlluminaDataProviderFactory
Given a data type find the most preferred file format even if files are not available
findRepeatedSubstring(byte[]) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Find out if a string can be represented as a tandem number of substrings.
findSegmentation(int, double, int, List<Integer>, double, double) - Method in class org.broadinstitute.hellbender.tools.copynumber.segmentation.AlleleFractionKernelSegmenter
Segments the internally held AllelicCountCollection using a separate KernelSegmenter for each chromosome.
findSegmentation(int, double, int, List<Integer>, double, double) - Method in class org.broadinstitute.hellbender.tools.copynumber.segmentation.CopyRatioKernelSegmenter
Segments the internally held CopyRatioCollection using a separate KernelSegmenter for each chromosome.
findSegmentation(int, double, double, double, int, List<Integer>, double, double) - Method in class org.broadinstitute.hellbender.tools.copynumber.segmentation.MultidimensionalKernelSegmenter
Segments the internally held CopyRatioCollection and AllelicCountCollection using a separate KernelSegmenter for each chromosome.
findTile(int) - Method in class picard.illumina.parser.TileIndex
 
findTranche(List<VariantDatum>, TrancheManager.SelectionMetric, double, VariantRecalibratorArgumentCollection.Mode) - Static method in class org.broadinstitute.hellbender.tools.walkers.vqsr.TrancheManager
 
findTranches(List<VariantDatum>, List<Double>, TrancheManager.SelectionMetric, VariantRecalibratorArgumentCollection.Mode) - Static method in class org.broadinstitute.hellbender.tools.walkers.vqsr.TrancheManager
 
findTranches(List<VariantDatum>, List<Double>, TrancheManager.SelectionMetric, VariantRecalibratorArgumentCollection.Mode, File) - Static method in class org.broadinstitute.hellbender.tools.walkers.vqsr.TrancheManager
 
findUnmatchedTypes(Set<IlluminaDataType>, Map<IlluminaFileUtil.SupportedIlluminaFormat, Set<IlluminaDataType>>) - Static method in class picard.illumina.parser.IlluminaDataProviderFactory
Given a set of formats to data types they provide, find any requested data types that do not have a format associated with them and return them
findVQSLODTranche(List<VariantDatum>, TrancheManager.SelectionMetric, double, VariantRecalibratorArgumentCollection.Mode) - Static method in class org.broadinstitute.hellbender.tools.walkers.vqsr.TrancheManager
 
findVQSLODTranches(List<VariantDatum>, List<Double>, TrancheManager.SelectionMetric, VariantRecalibratorArgumentCollection.Mode) - Static method in class org.broadinstitute.hellbender.tools.walkers.vqsr.TrancheManager
 
Fingerprint - Class in picard.fingerprint
Small class to represent a genetic fingerprint as a set of HaplotypeProbabilities objects that give the relative probabilities of each of the possible haplotypes at a locus.
Fingerprint(String, Path, String) - Constructor for class picard.fingerprint.Fingerprint
 
FINGERPRINT_DETAIL_FILE_SUFFIX - Static variable in class picard.fingerprint.CheckFingerprint
 
FINGERPRINT_SUMMARY_FILE_SUFFIX - Static variable in class picard.fingerprint.CheckFingerprint
 
FingerprintChecker - Class in picard.fingerprint
Major class that coordinates the activities involved in comparing genetic fingerprint data whether the source is from a genotyping platform or derived from sequence data.
FingerprintChecker(File) - Constructor for class picard.fingerprint.FingerprintChecker
Creates a fingerprint checker that will work with the set of haplotypes stored in the supplied file.
FingerprintChecker(HaplotypeMap) - Constructor for class picard.fingerprint.FingerprintChecker
Creates a fingerprint checker that will work with the set of haplotyped provided.
fingerprintFiles(Collection<Path>, int, int, TimeUnit) - Method in class picard.fingerprint.FingerprintChecker
Fingerprints one or more SAM/BAM/VCF files at all available loci within the haplotype map, using multiple threads to speed up the processing.
FingerprintIdDetails - Class in picard.fingerprint
class to hold the details of a element of fingerprinting PU tag
FingerprintIdDetails() - Constructor for class picard.fingerprint.FingerprintIdDetails
 
FingerprintIdDetails(String, String) - Constructor for class picard.fingerprint.FingerprintIdDetails
 
FingerprintIdDetails(SAMReadGroupRecord, String) - Constructor for class picard.fingerprint.FingerprintIdDetails
 
FingerprintingDetailMetrics - Class in picard.analysis
Detailed metrics about an individual SNP/Haplotype comparison within a fingerprint comparison.
FingerprintingDetailMetrics() - Constructor for class picard.analysis.FingerprintingDetailMetrics
 
FingerprintingSummaryMetrics - Class in picard.analysis
Summary fingerprinting metrics and statistics about the comparison of the sequence data from a single read group (lane or index within a lane) vs.
FingerprintingSummaryMetrics() - Constructor for class picard.analysis.FingerprintingSummaryMetrics
 
FingerprintResults - Class in picard.fingerprint
Class that is used to represent the results of comparing a read group within a SAM file, or a sample within a VCF against one or more set of fingerprint genotypes.
FingerprintResults(Path, String, String) - Constructor for class picard.fingerprint.FingerprintResults
 
fingerprintSamFile(Path, IntervalList) - Method in class picard.fingerprint.FingerprintChecker
Generates a Fingerprint per read group in the supplied SAM file using the loci provided in the interval list.
FingerprintUtils - Class in picard.fingerprint
A set of utilities used in the fingerprinting environment
FingerprintUtils() - Constructor for class picard.fingerprint.FingerprintUtils
 
FingerprintUtils.VariantContextSet - Class in picard.fingerprint
A class that holds VariantContexts sorted by genomic position
fingerprintVcf(Path) - Method in class picard.fingerprint.FingerprintChecker
 
finish(MetricsFile<InsertSizeMetrics, Integer>, String) - Method in class org.broadinstitute.hellbender.metrics.InsertSizeMetricsCollector
Finish the metrics collection by saving any results to a metrics file.
finish() - Method in class org.broadinstitute.hellbender.metrics.MultiLevelCollector
Call finish on all PerUnitMetricCollectors
finish() - Method in class org.broadinstitute.hellbender.metrics.MultiLevelReducibleCollector
Call finish on all PerUnitMetricCollectors
finish() - Method in class org.broadinstitute.hellbender.metrics.PerUnitInsertSizeMetricsCollector
 
finish() - Method in interface org.broadinstitute.hellbender.metrics.PerUnitMetricCollector
When all records have been collected, compute any final values needed to finish constructing metrics/Histogram
finish() - Method in class org.broadinstitute.hellbender.metrics.QualityYieldMetrics
 
finish() - Method in class org.broadinstitute.hellbender.tools.examples.metrics.multi.ExampleMultiMetrics
Complete any calculations/processing.
finish() - Method in class org.broadinstitute.hellbender.tools.examples.metrics.multi.PerUnitExampleMultiMetricsCollector
 
finish() - Method in class org.broadinstitute.hellbender.tools.examples.metrics.single.ExampleSingleMetrics
 
finish() - Method in class picard.analysis.artifacts.CollectSequencingArtifactMetrics
 
finish() - Method in class picard.analysis.CollectAlignmentSummaryMetrics
 
finish() - Method in class picard.analysis.CollectBaseDistributionByCycle
 
finish() - Method in class picard.analysis.CollectGcBiasMetrics
 
finish() - Method in class picard.analysis.CollectInsertSizeMetrics
 
finish() - Method in class picard.analysis.CollectQualityYieldMetrics
 
finish() - Method in class picard.analysis.CollectQualityYieldMetrics.QualityYieldMetricsCollector
 
finish() - Method in class picard.analysis.CollectRnaSeqMetrics
 
finish() - Method in class picard.analysis.directed.InsertSizeMetricsCollector.PerUnitInsertSizeMetricsCollector
 
finish() - Method in class picard.analysis.directed.RnaSeqMetricsCollector.PerUnitRnaSeqMetricsCollector
 
finish() - Method in class picard.analysis.directed.TargetMetricsCollector.PerUnitTargetMetricCollector
 
finish() - Method in class picard.analysis.GcBiasMetricsCollector.PerUnitGcBiasMetricsCollector
 
finish() - Method in class picard.analysis.MeanQualityByCycle
 
finish() - Method in class picard.analysis.QualityScoreDistribution
 
finish() - Method in class picard.analysis.SinglePassSamProgram
Should be implemented by subclasses to do one-time finalization work.
finish() - Method in class picard.metrics.MultiLevelCollector
Call finish on all PerUnitMetricCollectors
finish() - Method in interface picard.metrics.PerUnitMetricCollector
When all records have been collected, compute any final values needed to finish constructing metrics/Histogram
first(int) - Static method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeAlleleCounts
Instantiates the first genotype possible provided a total ploidy.
FIRST_OF_PAIR - Static variable in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary
 
FIRST_TILE - Variable in class picard.illumina.IlluminaBasecallsToFastq
 
FIRST_TILE - Variable in class picard.illumina.IlluminaBasecallsToSam
 
firstBase(int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmer
 
firstBase(int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerLong
 
firstBase(int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerShort
 
FirstOfPairReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.FirstOfPairReadFilter
 
firstPassApply(GATKRead, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.engine.TwoPassReadWalker
Process an individual read (with optional contextual information) on the first pass through the reads.
firstPassApply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.engine.TwoPassVariantWalker
First pass through the variants.
firstPassApply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.examples.ExampleTwoPassVariantWalker
 
firstPassApply(GATKRead, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.SplitNCigarReads
 
firstTrimer(int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmer
 
firstTrimer(int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerLong
 
firstTrimer(int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerShort
 
FISHER_STRAND_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
FisherExactTest - Class in org.broadinstitute.hellbender.utils
Implements the Fisher's exact test for 2x2 tables assuming the null hypothesis of odd ratio of 1.
FisherExactTest() - Constructor for class org.broadinstitute.hellbender.utils.FisherExactTest
 
FisherStrand - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Strand bias estimated using Fisher's Exact Test
FisherStrand() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.FisherStrand
 
FisherStrandFilter - Class in picard.vcf.filter
Filters records based on the phred scaled p-value from the Fisher Strand test stored in the FS attribute.
FisherStrandFilter(double) - Constructor for class picard.vcf.filter.FisherStrandFilter
 
FIVE_PRIME_ADAPTER - Variable in class picard.illumina.IlluminaBasecallsToSam
 
FIVE_PRIME_ADAPTER - Variable in class picard.illumina.MarkIlluminaAdapters
 
FixCallSetSampleOrdering - Class in org.broadinstitute.hellbender.tools
 
FixCallSetSampleOrdering() - Constructor for class org.broadinstitute.hellbender.tools.FixCallSetSampleOrdering
 
FixedAFCalculatorProvider - Class in org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc
A single fixed instance AF calculator provider.
FixedAFCalculatorProvider(StandardCallerArgumentCollection, boolean) - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.FixedAFCalculatorProvider
Constructs a fixed AF Calculator provider.
FixedAFCalculatorProvider(GenotypeCalculationArgumentCollection, boolean) - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.FixedAFCalculatorProvider
Constructs a fixed AF Calculator provider.
FixedAFCalculatorProvider(AFCalculatorImplementation, GenotypeCalculationArgumentCollection, boolean) - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.FixedAFCalculatorProvider
Constructs a fixed AF Calculator provider.
FixedWindowFunction(int, int) - Constructor for class org.broadinstitute.hellbender.engine.datasources.ReferenceWindowFunctions.FixedWindowFunction
 
fixGenotypes(GenotypesContext, List<Allele>, List<Allele>) - Static method in class picard.util.LiftoverUtils
 
FixMateInformation - Class in picard.sam
Summary
FixMateInformation() - Constructor for class picard.sam.FixMateInformation
 
FixMisencodedBaseQualityReads - Class in org.broadinstitute.hellbender.tools
 
FixMisencodedBaseQualityReads() - Constructor for class org.broadinstitute.hellbender.tools.FixMisencodedBaseQualityReads
 
fixNmMdAndUq(SAMRecord, ReferenceSequenceFileWalker, boolean) - Static method in class picard.sam.AbstractAlignmentMerger
Calculates and sets the NM, MD, and and UQ tags from the record and the reference
fixOverlaps() - Method in class org.broadinstitute.hellbender.utils.pileup.ReadPileup
Fixes the quality of all the elements that come from an overlapping pair in the same way as samtools does function in samtools.
fixTooHighQD(double) - Static method in class org.broadinstitute.hellbender.tools.walkers.annotator.QualByDepth
The haplotype caller generates very high quality scores when multiple events are on the same haplotype.
fixUq(SAMRecord, ReferenceSequenceFileWalker, boolean) - Static method in class picard.sam.AbstractAlignmentMerger
Calculates and sets UQ tag from the record and the reference
FixVcfHeader - Class in picard.vcf
Tool for replacing or fixing up a VCF header.
FixVcfHeader() - Constructor for class picard.vcf.FixVcfHeader
 
FlagStat - Class in org.broadinstitute.hellbender.tools
Accumulate flag statistics given a BAM file, e.g.
FlagStat() - Constructor for class org.broadinstitute.hellbender.tools.FlagStat
 
FlagStat.FlagStatus - Class in org.broadinstitute.hellbender.tools
 
FlagStatSpark - Class in org.broadinstitute.hellbender.tools.spark.pipelines
Spark tool to accumulate flag statistics given a BAM file, e.g.
FlagStatSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.pipelines.FlagStatSpark
 
FlagStatus() - Constructor for class org.broadinstitute.hellbender.tools.FlagStat.FlagStatus
 
flatBAQArray(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.recalibration.BaseRecalibrationEngine
Create a BAQ style array that indicates no alignment uncertainty
FlatMapGluer<I,O> - Class in org.broadinstitute.hellbender.tools.spark.utils
A little shim that let's you implement a mapPartitions operation (which takes an iterator over all items in the partition, and returns an iterator over all items to which they are mapped) in terms of a flatMap function (which takes a single input item, and returns an iterator over any number of output items).
FlatMapGluer(Function<I, Iterator<O>>, Iterator<? extends I>) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.FlatMapGluer
 
FlatMapGluer(Function<I, Iterator<O>>, Iterator<? extends I>, I) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.FlatMapGluer
 
flattenSplitIntervals(List<List<GenomeLoc>>) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
 
flip() - Method in class picard.fingerprint.Snp
Returns a new SNP object with the alleles swapped and MAF corrected.
FLOWCELL_BARCODE - Variable in class picard.fastq.BamToBfq
 
FLOWCELL_BARCODE - Variable in class picard.illumina.IlluminaBasecallsToFastq
 
flush() - Method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.OverhangFixingManager
Close out the manager stream by clearing the read cache
flushSingleSampleMultiplicity() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.MultiSampleEdge
update the single sample multiplicities by adding the current single sample multiplicity to the priority queue, and reset the current single sample multiplicity to 0.
FN_COUNT - Variable in class picard.vcf.GenotypeConcordanceContingencyMetrics
The FN (false negative) count across all variants
FN_ONLY - Static variable in class picard.vcf.GenotypeConcordanceScheme
 
fnvByteArray64(byte[]) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVUtils
64-bit FNV-1a hash for byte arrays
fnvByteArray64(long, byte[]) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVUtils
 
fnvLong64(long) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVUtils
64-bit FNV-1a hash for long's
fnvLong64(long, long) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVUtils
 
FOB - Static variable in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasFilterConstants
 
FOLD_80_BASE_PENALTY - Variable in class picard.analysis.directed.HsMetrics
The fold over-coverage necessary to raise 80% of bases in "non-zero-cvg" targets to the mean coverage level in those targets.
FOLD_80_BASE_PENALTY - Variable in class picard.analysis.directed.TargetedPcrMetrics
The fold over-coverage necessary to raise 80% of bases in "non-zero-cvg" targets to the mean coverage level in those targets.
FOLD_80_BASE_PENALTY - Variable in class picard.analysis.directed.TargetMetrics
The fold over-coverage necessary to raise 80% of bases in "non-zero-cvg" targets to the mean coverage level in those targets.
FOLD_ENRICHMENT - Variable in class picard.analysis.directed.HsMetrics
The fold by which the baited region has been amplified above genomic background.
FOLD_ENRICHMENT - Variable in class picard.analysis.directed.TargetedPcrMetrics
The fold by which the amplicon region has been amplified above genomic background.
FOLD_ENRICHMENT - Variable in class picard.analysis.directed.TargetMetrics
The fold by which the probed region has been amplified above genomic background, (ON_PROBE_BASES/(ON_PROBE_BASES + NEAR_PROBE_BASES + OFF_PROBE_BASES))/(PROBE_TERRITORY/GENOME_SIZE)
foldInto(T, Collection<T>) - Static method in class picard.vcf.CollectVariantCallingMetrics.VariantCallingSummaryMetrics
 
FORCE_GC - Variable in class picard.illumina.IlluminaBasecallsToFastq
 
FORCE_GC - Variable in class picard.illumina.IlluminaBasecallsToSam
 
FORCE_PLATFORM - Variable in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationArgumentCollection
 
forceJVMLocaleToUSEnglish() - Static method in class org.broadinstitute.hellbender.utils.Utils
Set the Locale to US English so that numbers will always be formatted in the US style.
forceKeepAllele(Allele) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
Checks whether even if the allele is not well supported by the data, we should keep it for genotyping.
forceKeepAllele(Allele) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.MinimalGenotypingEngine
 
forceKeepAllele(Allele) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerGenotypingEngine
 
forceKeepAllele(Allele) - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.SomaticGenotypingEngine
 
forceSiteEmission() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
Indicates whether we have to emit any site no matter what.
forceSiteEmission() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.MinimalGenotypingEngine
 
forceSiteEmission() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerGenotypingEngine
 
forEach(IntConsumer) - Method in class org.broadinstitute.hellbender.utils.IndexRange
Iterate through all indexes in the range in ascending order to be processed by the provided integer consumer lambda function.
forEach(Consumer<? super String>) - Method in class org.broadinstitute.hellbender.utils.nio.PathLineIterator
 
forEachAlleleIndexAndCount(IntBiConsumer) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeAlleleCounts
 
forKey(byte) - Static method in class org.broadinstitute.hellbender.utils.test.XorWrapper
 
FORMAT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.CollectReadCounts
 
formatAssemblyID(int) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.AlignedAssemblyOrExcuse
 
formatContigInfo(Tuple2<String, List<String>>) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignedContig
Format provided tigNameAndMappings for debugging.
formatContigName(int, int) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.AlignedAssemblyOrExcuse
 
formatDouble(double) - Static method in class org.broadinstitute.hellbender.tools.copynumber.formats.CopyNumberFormatsUtils
 
formatException(String) - Method in class org.broadinstitute.hellbender.utils.tsv.TableReader
Composes the exception to be thrown due to a formatting error.
formatExceptionWithoutLocation(String) - Method in class org.broadinstitute.hellbender.utils.tsv.TableReader
Composes the exception to be thrown due to a formatting error.
formatKey(int) - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.ContextCovariate
 
formatKey(int) - Method in interface org.broadinstitute.hellbender.utils.recalibration.covariates.Covariate
Converts the internal representation of the key to String format for file output.
formatKey(int) - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.CycleCovariate
 
formatKey(int) - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.QualityScoreCovariate
 
formatKey(int) - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.ReadGroupCovariate
 
formattedValue(double) - Static method in class org.broadinstitute.hellbender.tools.walkers.annotator.StrandOddsRatio
 
formatToDataTypes - Variable in class picard.illumina.parser.IlluminaDataProviderFactory
A Map of file formats to the dataTypes they will provide for this run.
forRead(GATKRead) - Static method in enum org.broadinstitute.hellbender.tools.spark.sv.evidence.TemplateFragmentOrdinal
 
forTotalPloidy(int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFPriorProvider
Returns the priors given a total-ploidy (the total number of genome copies across all samples).
forumPost(String) - Static method in class org.broadinstitute.hellbender.utils.help.HelpConstants
 
forVcf(File) - Method in class picard.vcf.processor.VcfFileSegmentGenerator
 
FORWARD - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_StrandBiasTest
 
ForwardBackwardAlgorithm - Class in org.broadinstitute.hellbender.utils.hmm
Performs the Forward-backward algorithm for HMM on a sequence of data points and positions.
ForwardBackwardAlgorithm() - Constructor for class org.broadinstitute.hellbender.utils.hmm.ForwardBackwardAlgorithm
 
ForwardBackwardAlgorithm.Result<D,T,S> - Interface in org.broadinstitute.hellbender.utils.hmm
The forward-backward algorithm result query interface.
forwardStrand - Variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
 
FourChannelIntensityData - Class in picard.illumina.parser
Holds a 4 short values for each cycle of a read.
FourChannelIntensityData(int) - Constructor for class picard.illumina.parser.FourChannelIntensityData
 
FP_COUNT - Variable in class picard.vcf.GenotypeConcordanceContingencyMetrics
The FP (false positive) count across all variants
FP_FN - Static variable in class picard.vcf.GenotypeConcordanceScheme
 
FP_ONLY - Static variable in class picard.vcf.GenotypeConcordanceScheme
 
FP_TN - Static variable in class picard.vcf.GenotypeConcordanceScheme
 
FP_TN_FN - Static variable in class picard.vcf.GenotypeConcordanceScheme
 
FR - Static variable in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
FR - Static variable in class picard.sam.markduplicates.util.ReadEnds
 
FRACTION - Variable in class picard.sam.PositionBasedDownsampleSam
 
FractionalDownsampler - Class in org.broadinstitute.hellbender.utils.downsampling
Fractional Downsampler: selects a specified fraction of the reads for inclusion.
FractionalDownsampler(double) - Constructor for class org.broadinstitute.hellbender.utils.downsampling.FractionalDownsampler
Construct a FractionalDownsampler
Fragment - Class in org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords
Class representing a single read fragment at a particular start location without a mapped mate.
Fragment(GATKRead, SAMFileHeader, int, MarkDuplicatesScoringStrategy) - Constructor for class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Fragment
 
FRAGMENT_NUMBER_SEPARATOR_CHR - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils
 
FRAGMENT_SIZE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.FilterAlignmentArtifacts
 
FragmentCollection<T> - Class in org.broadinstitute.hellbender.utils.fragments
Represents the results of the reads -> fragment calculation.
FragmentLength - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Median fragment length of reads supporting each allele.
FragmentLength() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.FragmentLength
 
FragmentLengthReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Keep only read pairs (0x1) with absolute insert length less than or equal to the given value.
FragmentLengthReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.FragmentLengthReadFilter
 
FRAGMENTS - Variable in class picard.analysis.JumpingLibraryMetrics
The number of fragments in the SAM file
FragmentUtils - Class in org.broadinstitute.hellbender.utils.fragments
 
from - Variable in class org.broadinstitute.hellbender.utils.IndexRange
First index in the range.
fromBases(byte[]) - Static method in enum picard.fingerprint.DiploidGenotype
Converts a pair of bases into a DiploidGenotype regardless of base order or case
fromBases(byte, byte) - Static method in enum picard.fingerprint.DiploidGenotype
Converts a pair of bases into a DiploidGenotype regardless of base order or case
fromCalculatorClass(Class<? extends AFCalculator>) - Static method in enum org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculatorImplementation
Returns the value that corresponds to a given implementation calculator class.
fromCode(int) - Static method in enum picard.pedigree.Sex
Decodes the Sex from a numeric code.
fromFile(File, boolean) - Static method in class picard.pedigree.PedFile
Attempts to read a pedigree file into memory.
fromFormatString(String) - Static method in enum org.broadinstitute.hellbender.utils.report.GATKReportDataType
Returns a GATK report data type from the format string specified.
fromHeader(SAMFileHeader, Metadata.Type) - Static method in class org.broadinstitute.hellbender.tools.copynumber.formats.metadata.MetadataUtils
 
fromHeader(String) - Static method in enum org.broadinstitute.hellbender.utils.report.GATKReportVersion
Returns the GATK Report Version from the file header.
fromIndex(int) - Method in interface org.broadinstitute.hellbender.utils.collections.Permutation
Given an index on the resulting list, it gives you the index of that element on the original list.
fromIndex(int) - Method in class org.broadinstitute.hellbender.utils.genotyper.AlleleList.ActualPermutation
 
fromIndex(int) - Method in class org.broadinstitute.hellbender.utils.genotyper.AlleleList.NonPermutation
 
fromList(List<ReadFilter>, SAMFileHeader) - Static method in class org.broadinstitute.hellbender.engine.filters.CountingReadFilter
Return a composite (and) CountingReadFilter constructed from a list of ReadFilter.
fromList(List<VariantFilter>) - Static method in class org.broadinstitute.hellbender.engine.filters.CountingVariantFilter
Return a composite (and) CountingVariantFilter constructed from a list of VariantFilter.
fromList(List<ReadFilter>, SAMFileHeader) - Static method in class org.broadinstitute.hellbender.engine.filters.ReadFilter
Return a composite (and) ReadFilter constructed from a list of ReadFilter.
fromList() - Method in interface org.broadinstitute.hellbender.utils.collections.Permutation
Returns an unmodifiable view to the original element list.
fromList() - Method in class org.broadinstitute.hellbender.utils.genotyper.AlleleList.ActualPermutation
 
fromList() - Method in class org.broadinstitute.hellbender.utils.genotyper.AlleleList.NonPermutation
 
fromObject(Object) - Static method in enum org.broadinstitute.hellbender.utils.report.GATKReportDataType
Returns a GATK report data type from the Object specified.
fromRead(GATKRead, SAMFileHeader) - Static method in enum org.broadinstitute.hellbender.utils.NGSPlatform
Convenience get -- get the NGSPlatform from a Read.
fromReadGroupPL(String) - Static method in enum org.broadinstitute.hellbender.utils.NGSPlatform
Returns the NGSPlatform corresponding to the PL tag in the read group
fromSexMap(Map<String, Sex>) - Static method in class picard.pedigree.PedFile
Function that accepts a map from sample-name to its sex and creates a PEDFile documenting the sexes.
fromSize() - Method in interface org.broadinstitute.hellbender.utils.collections.Permutation
Length of the original element list.
fromSize() - Method in class org.broadinstitute.hellbender.utils.genotyper.AlleleList.ActualPermutation
 
fromSize() - Method in class org.broadinstitute.hellbender.utils.genotyper.AlleleList.NonPermutation
 
Funcotation - Interface in org.broadinstitute.hellbender.tools.funcotator
Abstract class representing a Funcotator annotation.
Funcotator - Class in org.broadinstitute.hellbender.tools.funcotator
Funcotator (FUNCtional annOTATOR) analyzes given variants for their function (as retrieved from a set of data sources) and produces the analysis in a specified output file.
Funcotator() - Constructor for class org.broadinstitute.hellbender.tools.funcotator.Funcotator
 
FUNCOTATOR_VCF_FIELD_NAME - Static variable in class org.broadinstitute.hellbender.tools.funcotator.vcfOutput.VcfOutputRenderer
The name of the field inside the VCF INFO field in which to put Funcotator results.
FuncotatorArgumentDefinitions - Class in org.broadinstitute.hellbender.tools.funcotator
Class to store argument definitions specific to Funcotator.
FuncotatorArgumentDefinitions() - Constructor for class org.broadinstitute.hellbender.tools.funcotator.FuncotatorArgumentDefinitions
 
FuncotatorArgumentDefinitions.DataSourceType - Enum in org.broadinstitute.hellbender.tools.funcotator
An enum to handle the different types of input files for data sources.
FuncotatorArgumentDefinitions.OutputFormatType - Enum in org.broadinstitute.hellbender.tools.funcotator
The file format of the output file.
FuncotatorUtils - Class in org.broadinstitute.hellbender.tools.funcotator
 
FuncotatorUtils.TranscriptCodingSequenceException - Exception in org.broadinstitute.hellbender.tools.funcotator
Class representing exceptions that arise when trying to create a coding sequence for a variant:
FWD_CXT_ALT_BASES - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasDetailMetrics
The number of REF_BASE:ALT_BASE alignments at sites with the given reference context.
FWD_CXT_REF_BASES - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasDetailMetrics
The number of REF_BASE:REF_BASE alignments at sites with the given reference context.
FWD_ERROR_RATE - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasDetailMetrics
The substitution rate of REF_BASE:ALT_BASE, calculated as max(1e-10, FWD_CXT_ALT_BASES / (FWD_CXT_ALT_BASES + FWD_CXT_REF_BASES)).
FwdIterator(SVIntervalTree.Node<V>) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree.FwdIterator
 

G

G_FOLLOWED_BY_INSERTION_BASE - Static variable in class org.broadinstitute.hellbender.utils.pileup.PileupElement
 
G_REF_ALT_BASES - Variable in class picard.analysis.CollectOxoGMetrics.CpcgMetrics
The number of alt (A/T) basecalls observed at sites where the genome reference == G.
G_REF_OXO_ERROR_RATE - Variable in class picard.analysis.CollectOxoGMetrics.CpcgMetrics
The rate at which C>A and G>T substitutions are observed at G reference sites above the expected rate if there were no bias between sites with a C reference base vs.
G_REF_OXO_Q - Variable in class picard.analysis.CollectOxoGMetrics.CpcgMetrics
G_REF_OXO_ERROR_RATE expressed as a phred-scaled quality score.
G_REF_REF_BASES - Variable in class picard.analysis.CollectOxoGMetrics.CpcgMetrics
The number of ref basecalls observed at sites where the genome reference == G.
GA4GH_CLIENT_SECRETS - Variable in class picard.cmdline.CommandLineProgram
 
GA4GHScheme - Class in picard.vcf
The scheme is defined in the constructor.
GA4GHScheme() - Constructor for class picard.vcf.GA4GHScheme
 
GA4GHSchemeWithMissingAsHomRef - Class in picard.vcf
The default scheme is derived from the GA4GH Benchmarking Work Group's proposed evaluation scheme.
GA4GHSchemeWithMissingAsHomRef() - Constructor for class picard.vcf.GA4GHSchemeWithMissingAsHomRef
 
gapLen(SVInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVInterval
 
GAPPED_ALIGNMENT_BREAK_DEFAULT_SENSITIVITY - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.DiscoverVariantsFromContigsAlignmentsSparkArgumentCollection
 
GATHER_TYPE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.GatherVcfsCloud
 
GatherBamFiles - Class in picard.sam
Concatenate efficiently BAM files that resulted from a scattered parallel analysis.
GatherBamFiles() - Constructor for class picard.sam.GatherBamFiles
 
GatherBQSRReports - Class in org.broadinstitute.hellbender.tools.walkers.bqsr
 
GatherBQSRReports() - Constructor for class org.broadinstitute.hellbender.tools.walkers.bqsr.GatherBQSRReports
 
gatherEvidenceAndWriteContigSamFile(JavaSparkContext, StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection, SAMFileHeader, JavaRDD<GATKRead>, String, Logger) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.FindBreakpointEvidenceSpark
Gathers evidence reads and outputs them in a directory where reads are written out as interleaved FASTQ's.
gatherReports(List<File>) - Static method in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationReport
Gathers a set of files containing RecalibrationReports into a single GATKReport.
gatherReportsIntoOneFile(List<File>, File) - Static method in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationReport
Gather multiple RecalibrationReports into a single file
GatherTranches - Class in org.broadinstitute.hellbender.tools.walkers.vqsr
 
GatherTranches() - Constructor for class org.broadinstitute.hellbender.tools.walkers.vqsr.GatherTranches
 
gatherType - Variable in class org.broadinstitute.hellbender.tools.GatherVcfsCloud
 
GatherVcfs - Class in picard.vcf
Simple little class that combines multiple VCFs that have exactly the same set of samples and totally discrete sets of loci.
GatherVcfs() - Constructor for class picard.vcf.GatherVcfs
 
GatherVcfsCloud - Class in org.broadinstitute.hellbender.tools
This tool combines together rows of variant calls from multiple VCFs, e.g.
GatherVcfsCloud() - Constructor for class org.broadinstitute.hellbender.tools.GatherVcfsCloud
 
GatherVcfsCloud.GatherType - Enum in org.broadinstitute.hellbender.tools
 
GATK_CONFIG_FILE - Variable in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
 
GATK_CONFIG_FILE_OPTION - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
The option specifying a main configuration file.
GATK_FORUM_URL - Static variable in class org.broadinstitute.hellbender.utils.help.HelpConstants
 
GATK_MAIN_SITE - Static variable in class org.broadinstitute.hellbender.utils.help.HelpConstants
 
gatk_stacktrace_on_user_exception() - Method in interface org.broadinstitute.hellbender.utils.config.GATKConfig
 
GATKAnnotationArgumentCollection - Class in org.broadinstitute.hellbender.cmdline.GATKPlugin
An abstract ArgumentCollection for defining the set of annotation descriptor plugin arguments that are exposed to the user on the command line.
GATKAnnotationArgumentCollection() - Constructor for class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKAnnotationArgumentCollection
 
GATKAnnotationPluginDescriptor - Class in org.broadinstitute.hellbender.cmdline.GATKPlugin
A plugin descriptor for managing the dynamic discovery of both InfoFieldAnnotation and GenotypeAnnotation objects within the packages defined by the method getPackageNames() (default org.broadinstitute.hellbender.tools.walkers.annotator).
GATKAnnotationPluginDescriptor(GATKAnnotationArgumentCollection, List<Annotation>, List<Class<? extends Annotation>>) - Constructor for class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKAnnotationPluginDescriptor
Constructor that allows client tools to specify what annotations (optionally with parameters specified) to use as their defaults before discovery of user specified annotations.
GATKAnnotationPluginDescriptor(List<Annotation>, List<Class<? extends Annotation>>) - Constructor for class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKAnnotationPluginDescriptor
Constructor that allows client tools to specify what annotations (optionally with parameters specified) to use as their defaults before discovery of user specified annotations.
GATKConfig - Interface in org.broadinstitute.hellbender.utils.config
Configuration file for GATK options.
GATKDataSource<T> - Interface in org.broadinstitute.hellbender.engine
A GATKDataSource is something that can be iterated over from start to finish and/or queried by genomic interval.
GATKDocWorkUnit - Class in org.broadinstitute.hellbender.utils.help
Custom DocWorkUnit used for generating GATK help/documentation.
GATKDocWorkUnit(DocWorkUnitHandler, DocumentedFeature, ClassDoc, Class<?>) - Constructor for class org.broadinstitute.hellbender.utils.help.GATKDocWorkUnit
 
GATKDuplicationMetrics - Class in org.broadinstitute.hellbender.utils.read.markduplicates
Metrics that are calculated during the process of marking duplicates within a stream of SAMRecords.
GATKDuplicationMetrics() - Constructor for class org.broadinstitute.hellbender.utils.read.markduplicates.GATKDuplicationMetrics
 
GATKException - Exception in org.broadinstitute.hellbender.exceptions

Class GATKException.

GATKException(String) - Constructor for exception org.broadinstitute.hellbender.exceptions.GATKException
 
GATKException(String, Throwable) - Constructor for exception org.broadinstitute.hellbender.exceptions.GATKException
 
GATKException.MissingReadField - Exception in org.broadinstitute.hellbender.exceptions
 
GATKException.ReadAttributeTypeMismatch - Exception in org.broadinstitute.hellbender.exceptions
 
GATKException.ShouldNeverReachHereException - Exception in org.broadinstitute.hellbender.exceptions

For wrapping errors that are believed to never be reachable

GATKGSONWorkUnit - Class in org.broadinstitute.hellbender.utils.help
Class representing a GSONWorkUnit for GATK work units.
GATKGSONWorkUnit() - Constructor for class org.broadinstitute.hellbender.utils.help.GATKGSONWorkUnit
 
GATKHelpDoclet - Class in org.broadinstitute.hellbender.utils.help
Custom Barclay-based Javadoc Doclet used for generating GATK help/documentation.
GATKHelpDoclet() - Constructor for class org.broadinstitute.hellbender.utils.help.GATKHelpDoclet
 
GATKHelpDocWorkUnitHandler - Class in org.broadinstitute.hellbender.utils.help
The GATK Documentation work unit handler class that is the companion to GATKHelpDoclet.
GATKHelpDocWorkUnitHandler(HelpDoclet) - Constructor for class org.broadinstitute.hellbender.utils.help.GATKHelpDocWorkUnitHandler
 
GATKProtectedVariantContextUtils - Class in org.broadinstitute.hellbender.utils
Miscellaneous utilities to work with Variant data structures.
GATKProtectedVariantContextUtils() - Constructor for class org.broadinstitute.hellbender.utils.GATKProtectedVariantContextUtils
 
GATKRead - Interface in org.broadinstitute.hellbender.utils.read
Unified read interface for use throughout the GATK.
GATKReadFilterArgumentCollection - Class in org.broadinstitute.hellbender.cmdline.GATKPlugin
An abstract ArgumentCollection for defining the set of read filter descriptor plugin arguments that are exposed to the user on the command line.
GATKReadFilterArgumentCollection() - Constructor for class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKReadFilterArgumentCollection
 
GATKReadFilterPluginDescriptor - Class in org.broadinstitute.hellbender.cmdline.GATKPlugin
A CommandLinePluginDescriptor for ReadFilter plugins
GATKReadFilterPluginDescriptor(GATKReadFilterArgumentCollection, List<ReadFilter>) - Constructor for class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKReadFilterPluginDescriptor
 
GATKReadFilterPluginDescriptor(List<ReadFilter>) - Constructor for class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKReadFilterPluginDescriptor
 
GATKReadToBDGAlignmentRecordConverter - Class in org.broadinstitute.hellbender.utils.read
Converts a GATKRead to a BDG AlignmentRecord
GATKReadToBDGAlignmentRecordConverter(SAMFileHeader) - Constructor for class org.broadinstitute.hellbender.utils.read.GATKReadToBDGAlignmentRecordConverter
 
GATKReadWriter - Interface in org.broadinstitute.hellbender.utils.read
Interface for classes that are able to write GATKReads to some output destination.
GATKRegistrator - Class in org.broadinstitute.hellbender.engine.spark
GATKRegistrator registers Serializers for our project.
GATKRegistrator() - Constructor for class org.broadinstitute.hellbender.engine.spark.GATKRegistrator
 
GATKReport - Class in org.broadinstitute.hellbender.utils.report
Container class for GATK report tables
GATKReport() - Constructor for class org.broadinstitute.hellbender.utils.report.GATKReport
Create a new, empty GATKReport.
GATKReport(String) - Constructor for class org.broadinstitute.hellbender.utils.report.GATKReport
Create a new GATKReport with the contents of a GATKReport on disk.
GATKReport(File) - Constructor for class org.broadinstitute.hellbender.utils.report.GATKReport
Create a new GATKReport with the contents of a GATKReport on disk.
GATKReport(InputStream) - Constructor for class org.broadinstitute.hellbender.utils.report.GATKReport
 
GATKReport(GATKReportTable...) - Constructor for class org.broadinstitute.hellbender.utils.report.GATKReport
Create a new GATK report from GATK report tables
GATKREPORT_HEADER_PREFIX - Static variable in class org.broadinstitute.hellbender.utils.report.GATKReport
 
GATKReportColumn - Class in org.broadinstitute.hellbender.utils.report
column information within a GATK report table
GATKReportColumn(String, String) - Constructor for class org.broadinstitute.hellbender.utils.report.GATKReportColumn
Construct the column object, specifying the column name, default value, whether or not the column should be displayed, and the format string.
GATKReportColumnFormat - Class in org.broadinstitute.hellbender.utils.report
Column width and left/right alignment.
GATKReportColumnFormat(int, GATKReportColumnFormat.Alignment) - Constructor for class org.broadinstitute.hellbender.utils.report.GATKReportColumnFormat
 
GATKReportColumnFormat.Alignment - Enum in org.broadinstitute.hellbender.utils.report
 
GATKReportDataType - Enum in org.broadinstitute.hellbender.utils.report
The gatherable data types acceptable in a GATK report column.
GATKReportTable - Class in org.broadinstitute.hellbender.utils.report
 
GATKReportTable(BufferedReader, GATKReportVersion) - Constructor for class org.broadinstitute.hellbender.utils.report.GATKReportTable
Construct a new GATK report table from the reader Note that the row ID mappings are just the index -> index
GATKReportTable(String, String, int) - Constructor for class org.broadinstitute.hellbender.utils.report.GATKReportTable
Construct a new GATK report table with the specified name and description Sorting will be done with GATKReportTable.Sorting.SORT_BY_ROW
GATKReportTable(String, String, int, GATKReportTable.Sorting) - Constructor for class org.broadinstitute.hellbender.utils.report.GATKReportTable
Construct a new GATK report table with the specified name and description and whether to sort rows by the row ID.
GATKReportTable.Sorting - Enum in org.broadinstitute.hellbender.utils.report
 
GATKReportTable.TableDataHeaderFields - Enum in org.broadinstitute.hellbender.utils.report
 
GATKReportTable.TableNameHeaderFields - Enum in org.broadinstitute.hellbender.utils.report
 
GATKReportVersion - Enum in org.broadinstitute.hellbender.utils.report
 
GATKSparkTool - Class in org.broadinstitute.hellbender.engine.spark
Base class for GATK spark tools that accept standard kinds of inputs (reads, reference, and/or intervals).
GATKSparkTool() - Constructor for class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
 
GATKSV_CONTIG_ALIGNMENTS_READ_GROUP_ID - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVUtils
 
GATKSVVCFConstants - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
GATKSVVCFConstants() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
GATKSVVCFHeaderLines - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
GATKSVVCFHeaderLines() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFHeaderLines
 
GATKTool - Class in org.broadinstitute.hellbender.engine
Base class for all GATK tools.
GATKTool() - Constructor for class org.broadinstitute.hellbender.engine.GATKTool
 
GATKVariant - Interface in org.broadinstitute.hellbender.utils.variant
Variant is (currently) a minimal variant interface needed by the Hellbender pipeline.
GATKVariantContextUtils - Class in org.broadinstitute.hellbender.utils.variant
 
GATKVariantContextUtils() - Constructor for class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
 
GATKVariantContextUtils.AlleleMapper - Class in org.broadinstitute.hellbender.utils.variant
 
GATKVariantContextUtils.FilteredRecordMergeType - Enum in org.broadinstitute.hellbender.utils.variant
 
GATKVariantContextUtils.GenotypeMergeType - Enum in org.broadinstitute.hellbender.utils.variant
 
GATKVCFConstants - Class in org.broadinstitute.hellbender.utils.variant
This class contains any constants (primarily FORMAT/INFO keys) in VCF files used by the GATK.
GATKVCFConstants() - Constructor for class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
GATKVCFHeaderLines - Class in org.broadinstitute.hellbender.utils.variant
This class contains the VCFHeaderLine definitions for the annotation keys in GATKVCFConstants.
GATKVCFHeaderLines() - Constructor for class org.broadinstitute.hellbender.utils.variant.GATKVCFHeaderLines
 
GATKVCFIndexType - Enum in org.broadinstitute.hellbender.utils.variant
Choose the Tribble indexing strategy
GC - Variable in class picard.analysis.GcBiasDetailMetrics
The G+C content of the reference sequence represented by this bin.
GC_CONTENT_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
GC_CURVE_STANDARD_DEVIATION_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineDenoisingModelArgumentCollection
 
GC_DROPOUT - Variable in class picard.analysis.directed.HsMetrics
A measure of how undercovered >= 50% GC regions are relative to the mean.
GC_DROPOUT - Variable in class picard.analysis.directed.TargetedPcrMetrics
A measure of how regions of high GC content (>= 50% GC) are undercovered relative to the mean coverage value.
GC_DROPOUT - Variable in class picard.analysis.directed.TargetMetrics
A measure of how undercovered >= 50% GC regions are relative to the mean.
GC_DROPOUT - Variable in class picard.analysis.GcBiasSummaryMetrics
Illumina-style GC dropout metric.
GC_NC_0_19 - Variable in class picard.analysis.GcBiasSummaryMetrics
Normalized coverage over quintile of GC content ranging from 0 - 19.
GC_NC_20_39 - Variable in class picard.analysis.GcBiasSummaryMetrics
Normalized coverage over each quintile of GC content ranging from 20 - 39.
GC_NC_40_59 - Variable in class picard.analysis.GcBiasSummaryMetrics
Normalized coverage over each quintile of GC content ranging from 40 - 59.
GC_NC_60_79 - Variable in class picard.analysis.GcBiasSummaryMetrics
Normalized coverage over each quintile of GC content ranging from 60 - 79.
GC_NC_80_100 - Variable in class picard.analysis.GcBiasSummaryMetrics
Normalized coverage over each quintile of GC content ranging from 80 - 100.
GCBiasCorrector - Class in org.broadinstitute.hellbender.tools.copynumber.denoising
Learn multiplicative correction factors as a function of GC content using a simple regression.
GcBiasDetailMetrics - Class in picard.analysis
Class that holds detailed metrics about reads that fall within windows of a certain GC bin on the reference genome.
GcBiasDetailMetrics() - Constructor for class picard.analysis.GcBiasDetailMetrics
 
GcBiasMetrics - Class in picard.metrics
 
GcBiasMetrics() - Constructor for class picard.metrics.GcBiasMetrics
 
GcBiasMetricsCollector - Class in picard.analysis
Calculates GC Bias Metrics on multiple levels Created by kbergin on 3/23/15.
GcBiasMetricsCollector(Set<MetricAccumulationLevel>, int[], List<SAMReadGroupRecord>, int, boolean) - Constructor for class picard.analysis.GcBiasMetricsCollector
 
GcBiasMetricsCollector(Set<MetricAccumulationLevel>, int[], List<SAMReadGroupRecord>, int, boolean, boolean) - Constructor for class picard.analysis.GcBiasMetricsCollector
 
GcBiasMetricsCollector.PerUnitGcBiasMetricsCollector - Class in picard.analysis
 
GcBiasSummaryMetrics - Class in picard.analysis
High level metrics that capture how biased the coverage in a certain lane is.
GcBiasSummaryMetrics() - Constructor for class picard.analysis.GcBiasSummaryMetrics
 
GcBiasUtils - Class in picard.analysis
Utilities to calculate GC Bias Created by kbergin on 9/23/15.
GcBiasUtils() - Constructor for class picard.analysis.GcBiasUtils
 
gcpHMM - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.LikelihoodEngineArgumentCollection
 
GCS_PREFIX - Static variable in class org.broadinstitute.hellbender.utils.gcs.BucketUtils
 
gcsMaxRetries() - Method in interface org.broadinstitute.hellbender.utils.config.GATKConfig
 
GENBANK_CATALOG_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildReferenceTaxonomy
 
GENBANK_CATALOG_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildReferenceTaxonomy
 
genbankCatalogPath - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildReferenceTaxonomy
This may be supplied alone or in addition to the RefSeq catalog in the case that sequences from GenBank are present in the reference.
GENCODE_GTF_FILE_EXTENSION - Static variable in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfCodec
 
GENCODE_GTF_FILE_PREFIX - Static variable in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfCodec
 
GENCODE_GTF_MAX_VERSION_NUM_INCLUSIVE - Static variable in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfCodec
Maximum version of gencode that will not generate a warning.
GENCODE_GTF_MIN_VERSION_NUM_INCLUSIVE - Static variable in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfCodec
 
GencodeFuncotation - Class in org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode
A class to represent a Functional Annotation from the Gencode data source.
GencodeFuncotation() - Constructor for class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
Basic constructor for a GencodeFuncotation.
GencodeFuncotation(GencodeFuncotation) - Constructor for class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
Copy constructor for a GencodeFuncotation.
GencodeFuncotation.VariantClassification - Enum in org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode
Represents the type and severity of a variant.
GencodeFuncotation.VariantType - Enum in org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode
 
GencodeFuncotationBuilder - Class in org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode
A builder object to create GencodeFuncotations.
GencodeFuncotationBuilder() - Constructor for class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
 
GencodeFuncotationFactory - Class in org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode
A factory to create GencodeFuncotations.
GencodeFuncotationFactory(Path, String, String, TranscriptSelectionMode, Set<String>, LinkedHashMap<String, String>) - Constructor for class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationFactory
 
GencodeGtfCDSFeature - Class in org.broadinstitute.hellbender.utils.codecs.gencode
A Gencode GTF Feature representing a CDS.
GencodeGtfCodec - Class in org.broadinstitute.hellbender.utils.codecs.gencode
Tribble Codec to read data from a GENCODE GTF file.
GencodeGtfCodec() - Constructor for class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfCodec
 
GencodeGtfExonFeature - Class in org.broadinstitute.hellbender.utils.codecs.gencode
A Gencode GTF Feature representing an exon.
GencodeGtfFeature - Class in org.broadinstitute.hellbender.utils.codecs.gencode
A GencodeGtfFeature represents data in a GENCODE GTF file.
GencodeGtfFeature(String[]) - Constructor for class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
Populate this GencodeGtfFeature with the given data.
GencodeGtfFeature(GencodeGtfFeatureBaseData) - Constructor for class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
Populate this GencodeGtfFeature with the given data.
GencodeGtfFeature.AnnotationSource - Enum in org.broadinstitute.hellbender.utils.codecs.gencode
Keyword identifying the source of the feature, like a program (e.g.
GencodeGtfFeature.FeatureTag - Enum in org.broadinstitute.hellbender.utils.codecs.gencode
Additional relevant information appended to a feature.
GencodeGtfFeature.FeatureType - Enum in org.broadinstitute.hellbender.utils.codecs.gencode
Type of the feature represented in a single line of a GENCODE GTF File.
GencodeGtfFeature.GeneTranscriptStatus - Enum in org.broadinstitute.hellbender.utils.codecs.gencode
Indication of whether a feature is new, tenatative, or already known.
GencodeGtfFeature.GeneTranscriptType - Enum in org.broadinstitute.hellbender.utils.codecs.gencode
Biotype / transcript type for the transcript or gene represented in a feature.
GencodeGtfFeature.GenomicPhase - Enum in org.broadinstitute.hellbender.utils.codecs.gencode
Whether the first base of the CDS segment is the first (frame 0), second (frame 1) or third (frame 2) \ in the codon of the ORF.
GencodeGtfFeature.LocusLevel - Enum in org.broadinstitute.hellbender.utils.codecs.gencode
Status of how a position was annotated / verified: 1 - verified locus 2 - manually annotated locus 3 - automatically annotated locus For more information, see: https://www.gencodegenes.org/data_format.html https://en.wikipedia.org/wiki/General_feature_format
GencodeGtfFeature.OptionalField<T> - Class in org.broadinstitute.hellbender.utils.codecs.gencode
 
GencodeGtfFeature.RemapStatus - Enum in org.broadinstitute.hellbender.utils.codecs.gencode
Attribute that indicates the status of the mapping.
GencodeGtfFeature.RemapTargetStatus - Enum in org.broadinstitute.hellbender.utils.codecs.gencode
Attribute that compares the mapping to the existing target annotations.
GencodeGtfFeature.TranscriptSupportLevel - Enum in org.broadinstitute.hellbender.utils.codecs.gencode
Transcript score according to how well mRNA and EST alignments match over its full length.
GencodeGtfFeatureBaseData - Class in org.broadinstitute.hellbender.utils.codecs.gencode
Struct-like container class for the fields in a GencodeGtfFeature This is designed to be a basic dummy class to make feature instantiation easier.
GencodeGtfFeatureBaseData() - Constructor for class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeatureBaseData
 
GencodeGtfFeatureBaseData(int, String, GencodeGtfFeature.AnnotationSource, GencodeGtfFeature.FeatureType, int, int, Strand, GencodeGtfFeature.GenomicPhase, String, String, GencodeGtfFeature.GeneTranscriptType, GencodeGtfFeature.GeneTranscriptStatus, String, GencodeGtfFeature.GeneTranscriptType, GencodeGtfFeature.GeneTranscriptStatus, String, int, String, GencodeGtfFeature.LocusLevel, List<GencodeGtfFeature.OptionalField<?>>, String) - Constructor for class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeatureBaseData
 
GencodeGtfGeneFeature - Class in org.broadinstitute.hellbender.utils.codecs.gencode
A Gencode GTF Feature representing a gene.
GencodeGtfSelenocysteineFeature - Class in org.broadinstitute.hellbender.utils.codecs.gencode
A Gencode GTF Feature representing a selenocysteine.
GencodeGtfStartCodonFeature - Class in org.broadinstitute.hellbender.utils.codecs.gencode
A Gencode GTF Feature representing a start codon.
GencodeGtfStopCodonFeature - Class in org.broadinstitute.hellbender.utils.codecs.gencode
A Gencode GTF Feature representing a stop codon.
GencodeGtfTranscriptFeature - Class in org.broadinstitute.hellbender.utils.codecs.gencode
A Gencode GTF Feature representing a transcript.
GencodeGtfUTRFeature - Class in org.broadinstitute.hellbender.utils.codecs.gencode
A Gencode GTF Feature representing an untranslated region.
Gene - Class in picard.annotation
Holds annotation of a gene for storage in an OverlapDetector.
Gene(String, int, int, boolean, String) - Constructor for class picard.annotation.Gene
 
Gene.Transcript - Class in picard.annotation
A single transcript of a gene.
Gene.Transcript.Exon - Class in picard.annotation
1-based, inclusive representation of an exon.
GeneAnnotationReader - Class in picard.annotation
Load gene annotations into an OverlapDetector of Gene objects.
GeneAnnotationReader() - Constructor for class picard.annotation.GeneAnnotationReader
 
geneId - Variable in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeatureBaseData
 
geneName - Variable in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeatureBaseData
 
GeneralPloidyExactAFCalculator - Class in org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc
 
GeneralPloidyExactAFCalculator() - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.GeneralPloidyExactAFCalculator
 
GeneralPloidyFailOverAFCalculatorProvider - Class in org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc
Provider that defaults to the general ploidy implementation when the preferred one does not handle the required ploidy.
GeneralPloidyFailOverAFCalculatorProvider(GenotypeCalculationArgumentCollection) - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.GeneralPloidyFailOverAFCalculatorProvider
Creates a new AF calculator provider given the genotyping arguments and logger reference.
generateAdditionalWriters(List<SAMReadGroupRecord>, FastqWriterFactory) - Method in class picard.sam.SamToFastq
 
generateAdditionalWriters(List<SAMReadGroupRecord>, FastqWriterFactory) - Method in class picard.sam.SamToFastqWithTags
 
generateCigarList(int) - Static method in class org.broadinstitute.hellbender.utils.test.ReadClipperTestUtils
This function generates every valid permutation of cigar strings (with a given set of cigarElement) with a given length.
generateCigarList(int, CigarElement[]) - Static method in class org.broadinstitute.hellbender.utils.test.ReadClipperTestUtils
This function generates every valid permutation of cigar strings (with a given set of cigarElement) with a given length.
generateCsv(File, Map<String, RecalibrationReport>) - Static method in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
Prints out a collection of reports into a file in Csv format in a way that can be used by R scripts (such as the plot generator script).
generateFilterString(double) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.ApplyVQSR
Generate the VCF filter string for this record based on the provided lod score
generateFilterStringFromAlleles(VariantContext, double) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.ApplyVQSR
Generate the VCF filter string for this record based on the ApplyRecalibration modes run so far
generateHiddenStateChain(List<T>) - Method in interface org.broadinstitute.hellbender.utils.hmm.HMM
 
generateModel(List<VariantDatum>, int) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantRecalibratorEngine
 
generatePlots(File, File, File) - Static method in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
s Write recalibration plots into a file
generatePythonArguments(GermlineCNVCaller.RunMode) - Method in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineCallingArgumentCollection
 
generatePythonArguments(DetermineGermlineContigPloidy.RunMode) - Method in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineContigPloidyModelArgumentCollection
 
generatePythonArguments(GermlineCNVCaller.RunMode) - Method in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineDenoisingModelArgumentCollection
Generates arguments for the python CLI tool.
generatePythonArguments() - Method in class org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection
 
generateReadName(ClusterData, Integer) - Method in class picard.fastq.Casava18ReadNameEncoder
 
generateReadName(ClusterData, Integer) - Method in class picard.fastq.IlluminaReadNameEncoder
 
generateReadName(ClusterData, Integer) - Method in interface picard.fastq.ReadNameEncoder
Generates a read name string for the provided cluster.
generateReportTable() - Method in class org.broadinstitute.hellbender.utils.recalibration.QuantizationInfo
 
generateReportTable(String) - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationArgumentCollection
 
generateReportTables(RecalibrationTables, StandardCovariateList) - Static method in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
 
generateWgsMetrics(IntervalList, Histogram<Integer>, Histogram<Integer>, double, double, double, double, double, double, double, int, Histogram<Integer>, int) - Method in class picard.analysis.CollectRawWgsMetrics
 
generateWgsMetrics(IntervalList, Histogram<Integer>, Histogram<Integer>, double, double, double, double, double, double, double, int, Histogram<Integer>, int) - Method in class picard.analysis.CollectWgsMetrics
 
generateWgsMetrics(IntervalList, Histogram<Integer>, Histogram<Integer>, double, double, double, double, double, double, double, int, Histogram<Integer>, int) - Method in class picard.analysis.CollectWgsMetricsWithNonZeroCoverage
 
generatingAccumulatorsBy(VariantProcessor.AccumulatorGenerator<A, R>) - Static method in class picard.vcf.processor.VariantProcessor.Builder
 
geneStatus - Variable in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeatureBaseData
 
geneType - Variable in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeatureBaseData
 
GENOME_ASSEMBLY - Variable in class picard.sam.CreateSequenceDictionary
 
GENOME_SIZE - Variable in class picard.analysis.directed.HsMetrics
The number of bases in the reference genome used for alignment.
GENOME_SIZE - Variable in class picard.analysis.directed.TargetedPcrMetrics
The number of bases in the reference genome used for alignment
GENOME_SIZE - Variable in class picard.analysis.directed.TargetMetrics
The number of bases in the reference genome used for alignment.
GENOME_TERRITORY - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The number of non-N bases in the genome reference over which coverage will be evaluated.
GenomeLoc - Class in org.broadinstitute.hellbender.utils
Genome location representation.
GenomeLoc(String, int, int, int) - Constructor for class org.broadinstitute.hellbender.utils.GenomeLoc
 
GenomeLocParser - Class in org.broadinstitute.hellbender.utils
Factory class for creating GenomeLocs
GenomeLocParser(ReferenceSequenceFile) - Constructor for class org.broadinstitute.hellbender.utils.GenomeLocParser
set our internal reference contig order
GenomeLocParser(SAMSequenceDictionary) - Constructor for class org.broadinstitute.hellbender.utils.GenomeLocParser
Create a new GenomeLocParser based on seqDictionary with the standard validation level
GenomeLocParser(SAMSequenceDictionary, GenomeLocParser.ValidationLevel) - Constructor for class org.broadinstitute.hellbender.utils.GenomeLocParser
Create a genome loc parser based on seqDict with the specified level of validation
GenomeLocParser.ValidationLevel - Enum in org.broadinstitute.hellbender.utils
How much validation should we do at runtime with this parser?
genomeLocsFromLocatables(GenomeLocParser, Collection<? extends Locatable>) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Generates a list of GenomeLoc instances given the appropriate GenomeLocParser factory and a collection of Locatable instances.
GenomeLocSortedSet - Class in org.broadinstitute.hellbender.utils

Class GenomeLocCollection

a set of genome locations.

GenomeLocSortedSet(GenomeLocParser) - Constructor for class org.broadinstitute.hellbender.utils.GenomeLocSortedSet
Create a new, empty GenomeLocSortedSet
GenomeLocSortedSet(GenomeLocParser, GenomeLoc) - Constructor for class org.broadinstitute.hellbender.utils.GenomeLocSortedSet
Create a new GenomeLocSortedSet containing location e
GenomeLocSortedSet(GenomeLocParser, Collection<GenomeLoc>) - Constructor for class org.broadinstitute.hellbender.utils.GenomeLocSortedSet
Create a new GenomeLocSortedSet containing locations l The elements in l can be in any order, and can be overlapping.
GENOMIC_DB_URI_SCHEME - Static variable in class org.broadinstitute.hellbender.engine.FeatureDataSource
identifies a path as a GenomicsDB URI
genomicPhase - Variable in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeatureBaseData
Frame/phase of this feature.
genomicPosition - Variable in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeatureBaseData
Location of this feature on the genome.
GenomicsDBConstants - Class in org.broadinstitute.hellbender.tools.genomicsdb
Constants related to GenomicsDB
GenomicsDBImport - Class in org.broadinstitute.hellbender.tools.genomicsdb
Import single-sample GVCFs into GenomicsDB before joint genotyping.
GenomicsDBImport() - Constructor for class org.broadinstitute.hellbender.tools.genomicsdb.GenomicsDBImport
 
GenomicsDBTestUtils - Class in org.broadinstitute.hellbender.utils.test
 
genomicStrand - Variable in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeatureBaseData
Which strand this feature is on.
GENOTYPE_AND_VALIDATE_STATUS_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
GENOTYPE_CONCORDANCE - Variable in class picard.vcf.GenotypeConcordanceSummaryMetrics
The genotype concordance for all possible states.
GENOTYPE_FILTER_EXPRESSION_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
 
GENOTYPE_FILTER_NAME_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
 
GENOTYPE_GERMLINE_SITES_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
GENOTYPE_LOD_THRESHOLD - Variable in class picard.fingerprint.CheckFingerprint
 
GENOTYPE_PON_SITES_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
GENOTYPE_PRIOR_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
GenotypeAlleleCounts - Class in org.broadinstitute.hellbender.tools.walkers.genotyper
Collection of allele counts for a genotype.
genotypeAlleleCountsAt(int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeLikelihoodCalculator
Returns the genotype associated to a particular likelihood index.
GenotypeAnnotation - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Represents an annotation that is computed for a single genotype.
GenotypeAnnotation() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.GenotypeAnnotation
 
genotypeArgs - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.StandardCallerArgumentCollection
 
GenotypeAssignmentMethod - Enum in org.broadinstitute.hellbender.tools.walkers.genotyper
Created by davidben on 6/10/16.
GenotypeCalculationArgumentCollection - Class in org.broadinstitute.hellbender.tools.walkers.genotyper
 
GenotypeCalculationArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeCalculationArgumentCollection
Creates a GenotypeCalculationArgumentCollection with default values.
GenotypeCalculationArgumentCollection(GenotypeCalculationArgumentCollection) - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeCalculationArgumentCollection
Creates a GenotypeCalculationArgumentCollection with the values from other
GenotypeConcordance - Class in picard.vcf
Summary
GenotypeConcordance() - Constructor for class picard.vcf.GenotypeConcordance
 
GenotypeConcordance.Alleles - Class in picard.vcf
A simple structure to return the results of getAlleles.
GenotypeConcordanceContingencyMetrics - Class in picard.vcf
Class that holds metrics about the Genotype Concordance contingency tables.
GenotypeConcordanceContingencyMetrics() - Constructor for class picard.vcf.GenotypeConcordanceContingencyMetrics
Empty constructor - needed for unit tests
GenotypeConcordanceContingencyMetrics(VariantContext.Type, GenotypeConcordanceCounts, String, String, boolean) - Constructor for class picard.vcf.GenotypeConcordanceContingencyMetrics
 
GenotypeConcordanceCounts - Class in picard.vcf
A class to store the counts for various truth and call state classifications relative to a reference.
GenotypeConcordanceCounts() - Constructor for class picard.vcf.GenotypeConcordanceCounts
 
GenotypeConcordanceDetailMetrics - Class in picard.vcf
Class that holds detail metrics about Genotype Concordance
GenotypeConcordanceDetailMetrics() - Constructor for class picard.vcf.GenotypeConcordanceDetailMetrics
 
GenotypeConcordanceScheme - Class in picard.vcf
This defines for each valid TruthState and CallState tuple, the set of contingency table entries that to which the tuple should contribute.
GenotypeConcordanceScheme() - Constructor for class picard.vcf.GenotypeConcordanceScheme
 
GenotypeConcordanceSchemeFactory - Class in picard.vcf
Created by kbergin on 6/19/15.
GenotypeConcordanceSchemeFactory() - Constructor for class picard.vcf.GenotypeConcordanceSchemeFactory
 
GenotypeConcordanceStateCodes - Enum in picard.vcf
Created by kbergin on 7/30/15.
GenotypeConcordanceStates - Class in picard.vcf
A class to store the various classifications for: 1.
GenotypeConcordanceStates() - Constructor for class picard.vcf.GenotypeConcordanceStates
 
GenotypeConcordanceStates.CallState - Enum in picard.vcf
These states represent the relationship between the call genotype and the truth genotype relative to a reference sequence.
GenotypeConcordanceStates.ContingencyState - Enum in picard.vcf
A specific state for a 2x2 contingency table.
GenotypeConcordanceStates.TruthAndCallStates - Class in picard.vcf
A minute class to store the truth and call state respectively.
GenotypeConcordanceStates.TruthState - Enum in picard.vcf
These states represent the relationship between a truth genotype and the reference sequence.
GenotypeConcordanceSummaryMetrics - Class in picard.vcf
Class that holds summary metrics about Genotype Concordance
GenotypeConcordanceSummaryMetrics() - Constructor for class picard.vcf.GenotypeConcordanceSummaryMetrics
Empty constructor - needed for unit tests
GenotypeConcordanceSummaryMetrics(VariantContext.Type, GenotypeConcordanceCounts, String, String, boolean) - Constructor for class picard.vcf.GenotypeConcordanceSummaryMetrics
 
genotypeCount() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeLikelihoodCalculator
Returns the number of possible genotypes given ploidy and the maximum allele index.
genotypeCount(int, int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeLikelihoodCalculators
Returns the number of possible genotypes given the ploidy and number of different alleles.
GenotypeCounts - Class in org.broadinstitute.hellbender.utils
 
GenotypeCounts(double, double, double) - Constructor for class org.broadinstitute.hellbender.utils.GenotypeCounts
 
GenotypeFilter - Interface in picard.vcf.filter
An interface for classes that perform Genotype filtration.
genotypeFilteredAlleles - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.StandardCallerArgumentCollection
When set to true an when in GENOTYPE_GIVEN_ALLELES mode all given alleles, even filtered ones, are genotyped
genotypeFilterExpressions - Variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
Similar to the INFO field based expressions, but used on the FORMAT (genotype) fields instead.
genotypeFilterNames - Variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
Similar to the INFO field based expressions, but used on the FORMAT (genotype) fields instead.
genotypeGermlineSites - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
Usually we exclude sites in the panel of normals from active region determination, which saves time.
GenotypeGVCFs - Class in org.broadinstitute.hellbender.tools.walkers
Perform joint genotyping on one or more samples pre-called with HaplotypeCaller
GenotypeGVCFs() - Constructor for class org.broadinstitute.hellbender.tools.walkers.GenotypeGVCFs
 
genotypeIndexMap(int[], GenotypeLikelihoodCalculators) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeLikelihoodCalculator
Composes a genotype index map given a allele index recoding.
GenotypeLikelihoodCalculator - Class in org.broadinstitute.hellbender.tools.walkers.genotyper
Helper to calculate genotype likelihoods given a ploidy and an allele count (number of possible distinct alleles).
GenotypeLikelihoodCalculator(int, int, int[][], GenotypeAlleleCounts[][]) - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeLikelihoodCalculator
Creates a new calculator providing its ploidy and number of genotyping alleles.
GenotypeLikelihoodCalculators - Class in org.broadinstitute.hellbender.tools.walkers.genotyper
Genotype likelihood calculator utility.
GenotypeLikelihoodCalculators() - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeLikelihoodCalculators
 
genotypeLikelihoods(LikelihoodMatrix<A>) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeLikelihoodCalculator
Calculate the likelihoods given the list of alleles and the likelihood map.
GenotypeLikelihoodsCalculationModel - Enum in org.broadinstitute.hellbender.tools.walkers.genotyper
The model representing how we calculate genotype likelihoods
genotypePonSites - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
Usually we exclude sites in the panel of normals from active region determination, which saves time.
GenotypeQualityFilter - Class in picard.vcf.filter
Genotype filter that filters out genotypes below a given quality threshold.
GenotypeQualityFilter(int) - Constructor for class picard.vcf.filter.GenotypeQualityFilter
 
GENOTYPES - Variable in class picard.fingerprint.CheckFingerprint
 
GenotypeSummaries - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Summarize genotype statistics from all samples at the site level
GenotypeSummaries() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.GenotypeSummaries
 
GenotypeUtils - Class in org.broadinstitute.hellbender.utils
 
GENOTYPING_BASE_ERROR_RATE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
GENOTYPING_ERROR_RATE - Variable in class picard.fingerprint.CrosscheckFingerprints
 
GENOTYPING_HOMOZYGOUS_LOG_RATIO_THRESHOLD_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
GenotypingData<A extends htsjdk.variant.variantcontext.Allele> - Class in org.broadinstitute.hellbender.tools.walkers.genotyper
Encapsulates the data use to make the genotype calls.
GenotypingData(PloidyModel, ReadLikelihoods<A>) - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingData
Constructs a new genotyping-data collection providing the ploidy model to apply to the input model and the read-likelihoods collection.
GenotypingEngine<Config extends StandardCallerArgumentCollection> - Class in org.broadinstitute.hellbender.tools.walkers.genotyper
Base class for genotyper engines.
GenotypingEngine(Config, SampleList, AFCalculatorProvider, boolean) - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
Construct a new genotyper engine, on a specific subset of samples.
GenotypingGivenAllelesUtils - Class in org.broadinstitute.hellbender.tools.walkers.genotyper
Compendium of utils to work in GENOTYPE_GIVEN_ALLELES mode.
GenotypingGivenAllelesUtils() - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingGivenAllelesUtils
 
GenotypingLikelihoods<A extends htsjdk.variant.variantcontext.Allele> - Class in org.broadinstitute.hellbender.tools.walkers.genotyper
Genotyping Likelihoods collection.
GenotypingOutputMode - Enum in org.broadinstitute.hellbender.tools.walkers.genotyper
Enumeration of possible genotyping modes.
genotypingOutputMode - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.StandardCallerArgumentCollection
 
GERMLINE_POSTERIORS_VCF_ATTRIBUTE - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
GERMLINE_RESOURCE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
GERMLINE_RISK_FILTER_NAME - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
GERMLINE_TAG_HEADER - Static variable in class org.broadinstitute.hellbender.tools.copynumber.utils.TagGermlineEvents
 
GermlineCallingArgumentCollection - Class in org.broadinstitute.hellbender.tools.copynumber.arguments
 
GermlineCallingArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineCallingArgumentCollection
 
GermlineCNVCaller - Class in org.broadinstitute.hellbender.tools.copynumber
Calls copy-number variants in germline samples given their counts and the corresponding output of DetermineGermlineContigPloidy.
GermlineCNVCaller() - Constructor for class org.broadinstitute.hellbender.tools.copynumber.GermlineCNVCaller
 
GermlineCNVCaller.RunMode - Enum in org.broadinstitute.hellbender.tools.copynumber
 
GermlineCNVHybridADVIArgumentCollection - Class in org.broadinstitute.hellbender.tools.copynumber.arguments
 
GermlineCNVHybridADVIArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineCNVHybridADVIArgumentCollection
 
GermlineCNVIntervalVariantComposer - Class in org.broadinstitute.hellbender.tools.copynumber.gcnv
Helper class for PostprocessGermlineCNVCalls for single-sample postprocessing of GermlineCNVCaller calls into genotyped intervals.
GermlineCNVIntervalVariantComposer(VariantContextWriter, String, IntegerCopyNumberState, Set<String>) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.gcnv.GermlineCNVIntervalVariantComposer
Constructor for PostprocessGermlineCNVCalls Postprocessor
GermlineCNVNamingConstants - Class in org.broadinstitute.hellbender.tools.copynumber.gcnv
This class stores naming standards in the GermlineCNVCaller.
GermlineCNVNamingConstants() - Constructor for class org.broadinstitute.hellbender.tools.copynumber.gcnv.GermlineCNVNamingConstants
 
GermlineCNVSegmentVariantComposer - Class in org.broadinstitute.hellbender.tools.copynumber.gcnv
Helper class for PostprocessGermlineCNVCalls for single-sample postprocessing of segmented GermlineCNVCaller calls.
GermlineCNVSegmentVariantComposer(VariantContextWriter, String, IntegerCopyNumberState, Set<String>) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.gcnv.GermlineCNVSegmentVariantComposer
Constructor.
GermlineCNVVariantComposer<DATA extends htsjdk.samtools.util.Locatable> - Class in org.broadinstitute.hellbender.tools.copynumber.gcnv
GermlineContigPloidyHybridADVIArgumentCollection - Class in org.broadinstitute.hellbender.tools.copynumber.arguments
 
GermlineContigPloidyHybridADVIArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineContigPloidyHybridADVIArgumentCollection
 
GermlineContigPloidyModelArgumentCollection - Class in org.broadinstitute.hellbender.tools.copynumber.arguments
 
GermlineContigPloidyModelArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineContigPloidyModelArgumentCollection
 
GermlineDenoisingModelArgumentCollection - Class in org.broadinstitute.hellbender.tools.copynumber.arguments
 
GermlineDenoisingModelArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineDenoisingModelArgumentCollection
 
GermlineDenoisingModelArgumentCollection.CopyNumberPosteriorExpectationMode - Enum in org.broadinstitute.hellbender.tools.copynumber.arguments
 
GermlineProbabilityCalculator - Class in org.broadinstitute.hellbender.tools.walkers.mutect
Created by David Benjamin on 5/4/17.
GermlineProbabilityCalculator() - Constructor for class org.broadinstitute.hellbender.tools.walkers.mutect.GermlineProbabilityCalculator
 
germlineResource - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
A resource, such as gnomAD, containing population allele frequencies of common and rare variants.
get(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.TableFuncotation
Get the value in this TableFuncotation corresponding to the given key.
get(int) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KBestHaplotypeFinder
 
get(int) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadErrorCorrector.CorrectionSet
Get list of corrections for a particular offset
get(Allele) - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.PerAlleleCollection
Get the value for an allele, REF or ALT
get(int, int) - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.SubsettedLikelihoodMatrix
 
get(String) - Method in class org.broadinstitute.hellbender.utils.codecs.table.TableFeature
Gets the value associated with the key.
get(String) - Method in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvTableFeature
Get a value from this XsvTableFeature.
get(int) - Method in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvTableFeature
Get a value from this XsvTableFeature.
get(int) - Method in class org.broadinstitute.hellbender.utils.collections.ExpandingArrayList
Returns the element at the specified position in this list.
get(int) - Method in class org.broadinstitute.hellbender.utils.collections.IndexedSet
Returns the element given its index within the set.
get(int...) - Method in class org.broadinstitute.hellbender.utils.collections.NestedIntegerArray
 
get(Object) - Method in class org.broadinstitute.hellbender.utils.config.ConfigFactory
Wrapper around ConfigCache.get(Object).
get(int, int) - Method in interface org.broadinstitute.hellbender.utils.genotyper.LikelihoodMatrix
Returns the likelihood of a read given a haplotype.
get(Double) - Method in class org.broadinstitute.hellbender.utils.Histogram
Return the count of items in the bin corresponding to the provided value
get(Decile) - Method in class org.broadinstitute.hellbender.utils.mcmc.DecileCollection
Gets the specified decile.
get(T, Class<U>) - Method in class org.broadinstitute.hellbender.utils.mcmc.ParameterizedState
Returns the value of a Parameter contained in the collection held by the ParameterizedState, given the ParameterEnum key and type of the Parameter.
get(Nucleotide) - Method in class org.broadinstitute.hellbender.utils.Nucleotide.Counter
Returns the current count for a given nucleotide.
get(int) - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.CovariateKeyCache
Get the cached value for the given readlength or null is no value is cached.
get(int) - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.StandardCovariateList
Get the covariate by the index.
get(Object, String) - Method in class org.broadinstitute.hellbender.utils.report.GATKReportTable
Get a value from the given position in the table
get(int, String) - Method in class org.broadinstitute.hellbender.utils.report.GATKReportTable
Get a value from the given position in the table
get(int, int) - Method in class org.broadinstitute.hellbender.utils.report.GATKReportTable
Get a value from the given position in the table
get(int) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Returns the string value in a column by its index.
get(String) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Returns the string value in a column by its index.
get(String, String) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Returns the string value in a column by its index.
get(Enum<?>) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Returns the string value of a column by its name.
get(int) - Method in class picard.analysis.CounterManager.Counter
 
get(int) - Method in class picard.illumina.parser.readers.BclIndexReader
 
get(int) - Method in class picard.illumina.parser.ReadStructure.Substructure
 
get1Key(int) - Method in class org.broadinstitute.hellbender.utils.collections.NestedIntegerArray
Specialized version of get for 1 parameter.
get2Keys(int, int) - Method in class org.broadinstitute.hellbender.utils.collections.NestedIntegerArray
Specialized version of get for 2 parameters.
get3Keys(int, int, int) - Method in class org.broadinstitute.hellbender.utils.collections.NestedIntegerArray
Specialized version of get for 3 parameters.
get3PrimeAdapter() - Method in interface org.broadinstitute.hellbender.utils.illumina.AdapterPair
 
get3PrimeAdapter() - Method in enum org.broadinstitute.hellbender.utils.illumina.IlluminaAdapterPair
 
get3PrimeAdapter() - Method in interface picard.util.AdapterPair
 
get3PrimeAdapter() - Method in enum picard.util.IlluminaUtil.IlluminaAdapterPair
 
get3PrimeAdapterBytes() - Method in interface picard.util.AdapterPair
 
get3PrimeAdapterBytes() - Method in enum picard.util.IlluminaUtil.IlluminaAdapterPair
 
get3PrimeAdapterBytesInReadOrder() - Method in interface picard.util.AdapterPair
 
get3PrimeAdapterBytesInReadOrder() - Method in enum picard.util.IlluminaUtil.IlluminaAdapterPair
 
get3PrimeAdapterInReadOrder() - Method in interface picard.util.AdapterPair
 
get3PrimeAdapterInReadOrder() - Method in enum picard.util.IlluminaUtil.IlluminaAdapterPair
 
get4Keys(int, int, int, int) - Method in class org.broadinstitute.hellbender.utils.collections.NestedIntegerArray
Specialized version of get for 4 parameters.
get5PrimeAdapter() - Method in interface org.broadinstitute.hellbender.utils.illumina.AdapterPair
 
get5PrimeAdapter() - Method in enum org.broadinstitute.hellbender.utils.illumina.IlluminaAdapterPair
 
get5PrimeAdapter() - Method in interface picard.util.AdapterPair
 
get5PrimeAdapter() - Method in enum picard.util.IlluminaUtil.IlluminaAdapterPair
 
get5PrimeAdapterBytes() - Method in interface picard.util.AdapterPair
 
get5PrimeAdapterBytes() - Method in enum picard.util.IlluminaUtil.IlluminaAdapterPair
 
get5PrimeAdapterBytesInReadOrder() - Method in interface picard.util.AdapterPair
 
get5PrimeAdapterBytesInReadOrder() - Method in enum picard.util.IlluminaUtil.IlluminaAdapterPair
 
get5PrimeAdapterInReadOrder() - Method in interface picard.util.AdapterPair
 
get5PrimeAdapterInReadOrder() - Method in enum picard.util.IlluminaUtil.IlluminaAdapterPair
 
getA() - Method in class picard.illumina.parser.FourChannelIntensityData
 
getAbbreviation() - Method in enum org.broadinstitute.hellbender.tools.walkers.validation.ConcordanceState
 
getAbsoluteAccuracy() - Method in class org.broadinstitute.hellbender.utils.solver.UnivariateSolverSpecifications
 
getAccessionLength(String) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenReferenceTaxonProperties
 
getAccessions() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenReferenceTaxonProperties
 
getACcounts() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.ExactACset
 
getAccumulatedOutput() - Method in class org.broadinstitute.hellbender.utils.python.StreamingPythonScriptExecutor
Return all data accumulated since the last call to StreamingPythonScriptExecutor.getAccumulatedOutput() (either directly, or indirectly through StreamingPythonScriptExecutor.sendSynchronousCommand(java.lang.String), collected until an output prompt is detected.
getAccurateKmerCoverage(int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata
 
getACsum() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.ExactACset
sum of all the non-reference alleles
getActualTiles(List<IlluminaFileUtil.SupportedIlluminaFormat>) - Method in class picard.illumina.parser.IlluminaFileUtil
Get the available tiles for the given formats, if the formats have tile lists that differ then throw an exception, if any of the format
getADAMReads(String, TraversalParameters, SAMFileHeader) - Method in class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSource
Loads ADAM reads stored as Parquet.
getAdaptorBoundary() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Finds the adaptor boundary around the read and returns the first base inside the adaptor that is closest to the read boundary.
getAdaptorBoundary(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Finds the adaptor boundary around the read and returns the first base inside the adaptor that is closest to the read boundary.
getAdaptorBoundary() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getAdditionalCovariates() - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.StandardCovariateList
returns an unmodifiable view of the additional covariates stored in this list.
getAdditionalInfo() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseVertex
 
getAdditionalInfo() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.MultiDeBruijnVertex
 
getAdditionalSequence(V) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Pull out the additional sequence implied by traversing this node in the graph
getAdditionalSequence(boolean) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseVertex
Get the sequence unique to this vertex This function may not return the entire sequence stored in the vertex, as kmer graphs really only provide 1 base of additional sequence (the last base of the kmer).
getAdditionalSequence(boolean) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.MultiDeBruijnVertex
Get the sequence unique to this vertex This function may not return the entire sequence stored in the vertex, as kmer graphs really only provide 1 base of additional sequence (the last base of the kmer).
getAdditionalTables() - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationTables
 
getAffection() - Method in class org.broadinstitute.hellbender.utils.samples.Sample
 
getAfterLastAlignedBaseOffset(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Returns the offset (0-based) after the last base in the record that is aligned against the reference.
getAlignedAlternateAllele() - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
getAlignedAlternateAlleleStop() - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
getAlignedAssemblyOrExcuseList() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.FindBreakpointEvidenceSpark.AssembledEvidenceResults
 
getAlignedCodingSequenceAllele(String, Integer, Integer, Allele, Integer, Strand) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Gets the coding sequence for the allele with given start and stop positions, codon-aligned to the start of the reference sequence.
getAlignedCodingSequenceAlleleStart() - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
getAlignedCodingSequenceAlternateAllele() - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
getAlignedCodingSequenceReferenceAllele() - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
getAlignedContigs() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignedContigGenerator
 
getAlignedContigs() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoverFromLocalAssemblyContigAlignmentsSpark.SAMFormattedContigAlignmentParser
 
getAlignedContigs() - Method in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryPipelineSpark.InMemoryAlignmentParser
 
getAlignedContigsInOneAssembly(AlignedAssemblyOrExcuse, List<String>, SAMFileHeader) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryPipelineSpark.InMemoryAlignmentParser
Work on "successful" assembly and turn its contigs' alignments to custom AlignmentInterval format.
getAlignedEndPosition(int) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Get the sequence-aligned end position for the given allele end position.
getAlignedPosition(int) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Gets the sequence aligned position (1-based, inclusive) for the given coding sequence position.
getAlignedRefAllele(String, int, Allele, int, int) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Get the aligned coding sequence for the given reference allele.
getAlignedReferenceAllele() - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
getAlignedReferenceAlleleStop() - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
getAligner() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SingleSequenceReferenceAligner
Gives access to the underlying aligner so that you can modify its options.
getAligner(SmithWatermanAligner.Implementation) - Static method in interface org.broadinstitute.hellbender.utils.smithwaterman.SmithWatermanAligner
Factory method to get an instance of an aligner corresponding to the given implementation
getAlignment() - Method in class org.broadinstitute.hellbender.utils.report.GATKReportColumnFormat
 
getAlignmentContext() - Method in class org.broadinstitute.hellbender.engine.spark.LocusWalkerContext
 
getAlignmentEnd() - Method in class org.broadinstitute.hellbender.utils.read.ArtificialBAMBuilder
 
getAlignmentEvidence() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SimpleNovelAdjacencyAndChimericAlignmentEvidence
 
getAlignmentOffset() - Method in interface org.broadinstitute.hellbender.utils.smithwaterman.SmithWatermanAlignment
 
getAlignments(JavaSparkContext) - Method in class org.broadinstitute.hellbender.engine.spark.LocusWalkerSpark
Loads alignments and the corresponding reference and features into a JavaRDD for the intervals specified.
getAlignments() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignedContig
 
getAlignments() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments
 
getAlignmentSignatureBasicType() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments
 
getAlignmentStart() - Method in class org.broadinstitute.hellbender.utils.read.ArtificialBAMBuilder
 
getAlignmentStartHapwrtRef() - Method in class org.broadinstitute.hellbender.utils.haplotype.Haplotype
 
getAll() - Method in class org.broadinstitute.hellbender.utils.mcmc.DecileCollection
Gets a list of all deciles.
getAllAnnotations() - Static method in class org.broadinstitute.hellbender.utils.test.VariantContextTestUtils
Uses the AnnotationsPlugin interface to instantiate and return a list of every annotation currently visible to the gatk
getAllele(int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingData
 
getAllele(int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingLikelihoods
 
getAllele(int) - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.SubsettedLikelihoodMatrix
 
getAllele(int) - Method in class org.broadinstitute.hellbender.utils.genotyper.AlleleList.ActualPermutation
 
getAllele(int) - Method in interface org.broadinstitute.hellbender.utils.genotyper.AlleleList
Returns the allele at the given index in this AlleleList.
getAllele(int) - Method in class org.broadinstitute.hellbender.utils.genotyper.AlleleList.NonPermutation
 
getAllele(int) - Method in class org.broadinstitute.hellbender.utils.genotyper.IndexedAlleleList
 
getAllele(int) - Method in interface org.broadinstitute.hellbender.utils.genotyper.LikelihoodMatrix
Returns the allele given its index.
getAllele(int) - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Returns the allele given its index.
getAllele1() - Method in enum picard.fingerprint.DiploidGenotype
 
getAllele1() - Method in class picard.fingerprint.Snp
 
getAllele2() - Method in enum picard.fingerprint.DiploidGenotype
 
getAllele2() - Method in class picard.fingerprint.Snp
 
getAlleleCount(Allele) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.HeterozygosityCalculator
 
getAlleleCountAtMLE(Allele) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculationResult
Returns the AC of allele a la #getAlleleCountsOfMLE
getAlleleCountsOfMLE() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculationResult
Returns a vector with maxAltAlleles values containing AC values at the MLE The values of the ACs for this call are stored in the getAllelesUsedInGenotyping order, starting from index 0 (i.e., the first alt allele is at 0).
getAlleleFrequency() - Method in class org.broadinstitute.hellbender.tools.walkers.contamination.PileupSummary
 
getAlleleFrequencyPriors(VariantContext, int, GenotypeLikelihoodsCalculationModel) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
Returns the log10 prior probability for all possible allele counts from 0 to N where N is the total number of genomes (total-ploidy).
getAlleles() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AlleleSpecificAnnotationData
 
getAlleles() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.ReducibleAnnotationData
Note: parent class ReducibleAnnotationData is non-allele specific and stores all values with the no-call allele
getAlleleStart() - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
getAlleleString() - Method in class picard.fingerprint.Snp
 
getAllelesUsedInGenotyping() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculationResult
Get the list of alleles actually used in genotyping.
getAllelicCounts() - Method in class org.broadinstitute.hellbender.tools.copynumber.datacollection.AllelicCountCollector
Get the allelic counts gathered so far.
getAllFeatures() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfExonFeature
 
getAllFeatures() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfGeneFeature
 
getAllFeatures() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfTranscriptFeature
 
getAllFilterLines() - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVCFHeaderLines
 
getAllFormatLines() - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVCFHeaderLines
 
getAllInfoLines() - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVCFHeaderLines
 
getAllIntervals() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils.Mapping
 
getAllIntervals() - Method in class org.broadinstitute.hellbender.utils.test.ReadsPreprocessingPipelineTestData
 
getAllIntervalsForReference(SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Builds a list of intervals that cover the whole given sequence.
getAllLeaves() - Method in class org.broadinstitute.hellbender.utils.collections.NestedIntegerArray
 
getAllLibraryStatistics() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata
 
getAllowedShortFragmentOverhang() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.SVReadFilter
 
getAllowedValuesForDescriptorHelp(String) - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKAnnotationPluginDescriptor
Return the allowed values for annotationNames/disableAnnotations/annotationGroups for use by the help system.
getAllowedValuesForDescriptorHelp(String) - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKReadFilterPluginDescriptor
Return the allowed values for read-filter/disable-read-filter names for use by the help system.
getAllReadsCollector() - Method in class org.broadinstitute.hellbender.metrics.MultiLevelCollector
Get the PerUnitMetricCollector that collects reads for all levels
getAllReadsCollector() - Method in class org.broadinstitute.hellbender.metrics.MultiLevelReducibleCollector
Get the PerUnitMetricCollector that collects reads for all levels
getAllReadsCollector() - Method in class picard.metrics.MultiLevelCollector
Get the PerUnitMetricCollector that collects reads for all levels
getAllReferenceBases() - Method in class org.broadinstitute.hellbender.engine.datasources.ReferenceFileSource
 
getAllSequenceDictionaries() - Method in class org.broadinstitute.hellbender.engine.FeatureManager
Returns the sequence dictionaries associated with all feature sources.
getAllSnps() - Method in class picard.fingerprint.HaplotypeMap
Returns an unmodifiable collection of all SNPs in all Haplotype blocks.
getAllTiles() - Method in class picard.illumina.parser.readers.CbclReader
 
getAllValues() - Method in class org.broadinstitute.hellbender.utils.codecs.table.TableFeature
Gets all the values in order.
getAllValues() - Method in class org.broadinstitute.hellbender.utils.collections.NestedIntegerArray
 
getAllVariantContexts(List<Haplotype>) - Static method in class org.broadinstitute.hellbender.utils.haplotype.EventMap
Get all of the VariantContexts in the event maps for all haplotypes, sorted by their start position
getAllVariantHeaders() - Method in class org.broadinstitute.hellbender.engine.FeatureManager
This method finds and returns all of the variant headers from the feature sources.
getAlt(Allele) - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.PerAlleleCollection
 
getAltAllele() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getAltAllele() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.TableFuncotation
 
getAltAllele() - Method in interface org.broadinstitute.hellbender.tools.funcotator.Funcotation
 
getAltAllele() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvType
 
getAltAlleles() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.PerAlleleCollection
 
getAltCount() - Method in class org.broadinstitute.hellbender.tools.walkers.contamination.PileupSummary
 
getAlternate() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.BasicValidationResult
 
getAlternateAllele() - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
getAlternateAlleleFraction() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AllelicCount
 
getAlternateAminoAcidSequence() - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
getAlternateSequence(String, int, Allele, Allele) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Get the full alternate sequence given a reference coding sequence, and two alleles.
getAltFraction() - Method in class org.broadinstitute.hellbender.tools.walkers.contamination.PileupSummary
 
getAltHaplotypeSequence() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.NovelAdjacencyAndAltHaplotype
 
getAltHaplotypeSequence() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SimpleNovelAdjacencyAndChimericAlignmentEvidence
 
getAltNucleotide() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AllelicCount
 
getAltReadCount() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AllelicCount
 
getAminoAcidByLetter(String) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Returns the AminoAcid corresponding to the given single-letter abbreviation.
getAminoAcidByLetter(char) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Returns the AminoAcid corresponding to the given single-letter abbreviation.
getAminoAcidCodes() - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
 
getAminoAcidNames() - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
 
getAndValidateConfigFileContents(Path) - Static method in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvLocatableTableCodec
Get the properties from the given configFilePath, validate that all required properties are present, and return the property map.
getAndValidateDataSourcesFromPaths(String, List<String>) - Static method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
Initializes the data sources for Funcotator.
getAnnotationFeatureClass() - Method in class org.broadinstitute.hellbender.tools.funcotator.DataSourceFuncotationFactory
 
getAnnotationFeatureClass() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.cosmic.CosmicFuncotationFactory
 
getAnnotationFeatureClass() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationFactory
 
getAnnotationFeatureClass() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.vcf.VcfFuncotationFactory
 
getAnnotationFeatureClass() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv.LocatableXsvFuncotationFactory
 
getAnnotationFeatureClass() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv.SimpleKeyXsvFuncotationFactory
 
getAnnotationKeys() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
 
getAnnotations() - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedInterval
Returns a copy of the annotations as a map.
getAnnotations() - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalCollection
 
getAnnotations() - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalHeader
 
getAnnotationSet() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AnnotatedInterval
 
getAnnotationSource() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
getAnnotationTranscript() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getAnnotationValue(String) - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedInterval
 
getAnnotationValueOrDefault(String, String) - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedInterval
 
getAnonymousOptionalFields() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
getApprisRank() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getAppropriateVCFInfoHeaders() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
 
getApproximateCommandLine() - Method in class org.broadinstitute.hellbender.utils.python.PythonExecutorBase
Return a (not necessarily executable) string representing the current command line for this executor for error reporting purposes.
getApproximateCommandLine() - Method in class org.broadinstitute.hellbender.utils.python.PythonScriptExecutor
Return a (not necessarily executable) string representing the current command line for this executor for error reporting purposes.
getApproximateCommandLine() - Method in class org.broadinstitute.hellbender.utils.python.StreamingPythonScriptExecutor
Return a (not necessarily executable) string representing the current command line for this executor for error reporting purposes.
getApproximateCommandLine() - Method in class org.broadinstitute.hellbender.utils.R.RScriptExecutor
 
getApproximateCommandLine() - Method in class org.broadinstitute.hellbender.utils.runtime.ScriptExecutor
Return a (not necessarily executable) string representing the command line for this executor for error reporting purposes.
getArgs() - Method in class org.broadinstitute.hellbender.utils.test.IntegrationTestSpec
 
getArgs() - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
getArgsArray() - Method in class org.broadinstitute.hellbender.utils.test.ArgumentsBuilder
 
getArgsList() - Method in class org.broadinstitute.hellbender.utils.test.ArgumentsBuilder
 
getArtifactMode() - Method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationSampleTransitionSummary
 
getArtifactModeComplement() - Method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationSampleTransitionSummary
 
getArtificialReadsBasedOnSATag(SAMFileHeader) - Method in class org.broadinstitute.hellbender.utils.SATagBuilder
Returns a list of artificial GATKReads corresponding to the reads described by the SA tag in read.
getAsRealMatrix(LikelihoodMatrix<Allele>) - Static method in class org.broadinstitute.hellbender.tools.walkers.mutect.SomaticGenotypingEngine
 
getAssembledIntervals() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoveryInputMetaData.SampleSpecificData
 
getAssembledIntervals() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.FindBreakpointEvidenceSpark.AssembledEvidenceResults
 
getAssembly() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.AlignedAssemblyOrExcuse
 
getAssemblyId() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.AlignedAssemblyOrExcuse
 
getAssemblyRegion() - Method in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerContext
 
getAssemblyRegionReference(ReferenceSequenceFile) - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
getAssemblyRegionReference(ReferenceSequenceFile, int) - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
Get the reference bases from referenceReader spanned by the extended location of this active region, including additional padding bp on either side.
getAssemblyRegions(JavaSparkContext) - Method in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerSpark
Loads assembly regions and the corresponding reference and features into a JavaRDD for the intervals specified.
getAssignedContig() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
getAssignedContig() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getAssignedReferenceIndex(GATKRead, SAMFileHeader) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Returns the reference index in the given header of the read's assigned contig.
getAssignedStart() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
getAssignedStart() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getAsynchronousStreamWriterService(OutputStream, Function<T, ByteArrayOutputStream>) - Method in class org.broadinstitute.hellbender.utils.python.StreamingPythonScriptExecutor
Return a AsynchronousStreamWriterService to be used to write to an output stream, typically on a FIFO, on a background thread.
getAsynchronousStreamWriterService(OutputStream, Function<T, ByteArrayOutputStream>) - Method in class org.broadinstitute.hellbender.utils.runtime.StreamingProcessController
Return a AsynchronousStreamWriterService to be used to write to a stream on a background thread.
getAttribute(String) - Method in class org.broadinstitute.hellbender.engine.FeatureInput
Gets the value for the given key associated with this Feature source or null if no value is associated with a given key.
getAttribute(Allele) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.ReducibleAnnotationData
 
getAttributeAsByteArray(String) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Retrieve the value of a particular attribute typed as a byte array.
getAttributeAsByteArray(String) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getAttributeAsDouble(Genotype, String, double) - Static method in class org.broadinstitute.hellbender.utils.GATKProtectedVariantContextUtils
Returns an attribute as a double.
getAttributeAsDoubleArray(VariantContext, String, Supplier<double[]>, double) - Static method in class org.broadinstitute.hellbender.utils.GATKProtectedVariantContextUtils
Composes the double array from a genotype annotation.
getAttributeAsDoubleArray(Genotype, String, Supplier<double[]>, double) - Static method in class org.broadinstitute.hellbender.utils.GATKProtectedVariantContextUtils
Composes the double array from a genotype annotation.
getAttributeAsInt(Genotype, String, int) - Static method in class org.broadinstitute.hellbender.utils.GATKProtectedVariantContextUtils
Returns an attribute as an integer.
getAttributeAsIntArray(Genotype, String, Supplier<int[]>, int) - Static method in class org.broadinstitute.hellbender.utils.GATKProtectedVariantContextUtils
Composes the double array from a genotype annotation.
getAttributeAsInteger(String) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Retrieve the value of a particular attribute typed as an integer.
getAttributeAsInteger(String) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getAttributeAsObject(Genotype, String, Function<String, T>, T) - Static method in class org.broadinstitute.hellbender.utils.GATKProtectedVariantContextUtils
Gets an attribute value by transforming the string its string representation using an translation function.
getAttributeAsString(Genotype, String, String) - Static method in class org.broadinstitute.hellbender.utils.GATKProtectedVariantContextUtils
Returns an attribute as a string.
getAttributeAsString(String) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Retrieve the value of a particular attribute typed as a String.
getAttributeAsString(String) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getAttributeMap() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.ReducibleAnnotationData
Get the stored raw per-allele data
getAttributesToReverse() - Method in class picard.sam.AbstractAlignmentMerger
Gets the set of attributes to be reversed on reads marked as negative strand.
getAttributesToReverseComplement() - Method in class picard.sam.AbstractAlignmentMerger
Gets the set of attributes to be reverse complemented on reads marked as negative strand.
getAuthenticatedGcs(String, String, byte[]) - Static method in class org.broadinstitute.hellbender.utils.gcs.BucketUtils
Get an authenticated GCS-backed NIO FileSystem object representing the selected projected and bucket.
getAuthenticatedGcs(String) - Method in class org.broadinstitute.hellbender.utils.test.BaseTest
Get a FileSystem that uses the explicit credentials instead of the default credentials.
getAvailableTiles() - Method in class picard.illumina.parser.IlluminaDataProviderFactory
Return the list of tiles available for this flowcell and lane.
getAvgReadLen() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata
 
getBadMappings() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigAlignmentsConfigPicker.GoodAndBadMappings
 
getBadMappingsAsCompactStrings() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigAlignmentsConfigPicker.GoodAndBadMappings
 
getBAMOutputHeader() - Method in class org.broadinstitute.hellbender.utils.haplotype.HaplotypeBAMDestination
Get the SAMFileHeader that is used for writing the output for this destination.
getBandSize() - Method in class org.broadinstitute.hellbender.utils.activityprofile.BandPassActivityProfile
Get the size (in bp) of the band pass filter
getBandWidth() - Method in class org.broadinstitute.hellbender.utils.baq.BAQ
 
getBAQTag(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.baq.BAQ
Get the BAQ attribute from the tag in read.
getBarcode() - Method in class picard.illumina.ExtractIlluminaBarcodes.PerTileBarcodeExtractor.BarcodeMatch
 
getBarcodeValue(SAMRecord) - Method in class picard.sam.markduplicates.EstimateLibraryComplexity
 
getBase() - Method in class org.broadinstitute.hellbender.engine.ReferenceContext
Get the base at the given locus.
getBase() - Method in class org.broadinstitute.hellbender.utils.codecs.sampileup.SAMPileupElement
Get the base
getBase() - Method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Get the base aligned to the genome at this location If the current element is a deletion returns PileupElement.DELETION_BASE.
getBase(int) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
getBase(int) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getBaseCounts() - Method in class org.broadinstitute.hellbender.utils.pileup.ReadPileup
Get counts of A, C, G, T in order, which returns a int[4] vector with counts according to BaseUtils.simpleBaseToBaseIndex for each base.
getBaseDeletionQual() - Method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Get the Base Deletion quality at this pileup position
getBaseDeletionQualities(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Default utility to query the base deletion quality of a read.
getBaseInsertionQual() - Method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Get the Base Insertion quality at this pileup position
getBaseInsertionQualities(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Default utility to query the base insertion quality of a read.
getBaselineIntegerCopyNumberState() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.IntegerCopyNumberSegment
 
getBaselineIntegerCopyNumberState() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.IntervalCopyNumberGenotypingData
 
getBasePileup() - Method in class org.broadinstitute.hellbender.engine.AlignmentContext
 
getBaseQualities() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
getBaseQualities(GATKRead, EventType) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
getBaseQualities() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getBaseQualitiesNoCopy() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
getBaseQualitiesNoCopy() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getBaseQuality() - Method in class org.broadinstitute.hellbender.utils.codecs.sampileup.SAMPileupElement
Get the quality
getBaseQuality(int) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
getBaseQuality(int) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getBaseQualityCount() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
getBaseQualityCount() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getBaseQualityString(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Returns the base qualities for the read as a string.
getBaseQuals() - Method in class org.broadinstitute.hellbender.utils.codecs.sampileup.SAMPileupFeature
Gets the PHRED base qualities.
getBaseQuals() - Method in class org.broadinstitute.hellbender.utils.pileup.ReadPileup
Returns an array of the quals in this pileup.
getBases() - Method in class org.broadinstitute.hellbender.engine.ReferenceContext
Get all reference bases in this context.
getBases(SimpleInterval) - Method in class org.broadinstitute.hellbender.engine.ReferenceContext
Get all reference bases in this context with the given window.
getBases(int, int) - Method in class org.broadinstitute.hellbender.engine.ReferenceContext
Get all reference bases in this context with the given leading / trailing bases as the window.
getBases() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils.FastqRead
returns bases with values like 'A', 'C', 'G', and 'T'
getBases() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.Path
The base sequence for this path.
getBases() - Method in class org.broadinstitute.hellbender.utils.codecs.sampileup.SAMPileupFeature
Gets the bases in byte array form Note: this call costs O(n) and allocates fresh array each time
getBases() - Method in class org.broadinstitute.hellbender.utils.pileup.ReadPileup
Returns an array of the bases in this pileup.
getBases() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
getBases() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getBases() - Method in class org.broadinstitute.hellbender.utils.reference.ReferenceBases
 
getBases() - Method in class picard.illumina.parser.BclData
 
getBases() - Method in class picard.illumina.parser.ReadData
 
getBasesCoveringRefInterval(int, int, byte[], int, Cigar) - Static method in class org.broadinstitute.hellbender.utils.read.AlignmentUtils
Get the byte[] from bases that cover the reference interval refStart -> refEnd given the alignment of bases to the reference (basesToRefCigar) and the start offset of the bases on the reference refStart and refEnd are 0 based offsets that we want to obtain.
getBasesExcludedBy(CountingFilter) - Method in class picard.analysis.CollectWgsMetrics
If INTERVALS is specified, this will count bases beyond the interval list when the read overlaps the intervals and extends beyond the edge.
getBasesInWindowAroundReferenceAllele(Allele, Allele, Strand, int, ReferenceContext) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Get a string of bases around a variant (specified by reference and alternate alleles), including the reference allele itself.
getBasesNoCopy() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
getBasesNoCopy() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getBasesOfImmediatelyFollowingInsertion() - Method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Get the bases for an insertion that immediately follows this alignment state, or null if none exists
getBasesReverseComplement(byte[]) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Returns the reverse complement of the read bases
getBasesReverseComplement(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Returns the reverse complement of the read bases
getBasesStream() - Method in class org.broadinstitute.hellbender.utils.codecs.sampileup.SAMPileupFeature
Get the bases as a stream
getBasesString() - Method in class org.broadinstitute.hellbender.utils.codecs.sampileup.SAMPileupFeature
Returns pile of observed bases over the genomic location.
getBasesString() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
getBciFile() - Method in class picard.illumina.parser.readers.BclIndexReader
 
getBestAvailableSequenceDictionary() - Method in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker
 
getBestAvailableSequenceDictionary() - Method in class org.broadinstitute.hellbender.engine.GATKTool
Returns the "best available" sequence dictionary or null if there is no single best dictionary.
getBestAvailableSequenceDictionary() - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
Returns the "best available" sequence dictionary.
getBestAvailableSequenceDictionary() - Method in class org.broadinstitute.hellbender.engine.spark.VariantWalkerSpark
 
getBestAvailableSequenceDictionary() - Method in class org.broadinstitute.hellbender.engine.VariantWalkerBase
Overriding the superclass method to preferentially choose the sequence dictionary from the driving source of variants.
getBestAvailableSequenceDictionary() - Method in class org.broadinstitute.hellbender.tools.genomicsdb.GenomicsDBImport
Overriding getBestAvailableSequenceDictionary() to prefer the mergedVCFHeader's sequence directory, if present, over any other dictionaries
getBetweenNextPosition() - Method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Get the cigar elements that occur after the current position but before the next position on the genome
getBetweenPrevPosition() - Method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Get the cigar elements that occur before the current position but after the previous position on the genome For example, if we are in the 3M state of 1M2I3M state then 2I occurs before this position.
getBoolean(int) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Returns the boolean value in a column by its index.
getBoolean(String) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Returns the boolean value in a column by its index.
getBQSRSpecificReadFilterList() - Static method in class org.broadinstitute.hellbender.tools.walkers.bqsr.BaseRecalibrator
Return the list of basic, raw read filters used for BQSR contexts, not including WellFormed.
getBreakPointIntervals(int, SAMSequenceDictionary, boolean) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVContext
Returns break point intervals for this structural variant.
getBucket(String) - Static method in class org.broadinstitute.hellbender.utils.gcs.BucketUtils
Given a path of the form "gs://bucket/folder/folder/file", returns "bucket".
getBufferBytes() - Method in class org.broadinstitute.hellbender.utils.runtime.CapturedStreamOutput
 
getBufferBytes() - Method in class org.broadinstitute.hellbender.utils.runtime.StreamOutput
Returns the content as a string.
getBufferedReaderGz(String) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBuildReferenceTaxonomyUtils
Gets a buffered reader for a gzipped file
getBufferedReaderTarGz(String, String) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBuildReferenceTaxonomyUtils
Gets a Reader for a file in a gzipped tarball
getBufferSize() - Method in class org.broadinstitute.hellbender.utils.runtime.OutputStreamSettings
 
getBufferString() - Method in class org.broadinstitute.hellbender.utils.runtime.StreamOutput
Returns the content as a string.
getBuilder() - Static method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getByteBufferIterator(int, int, File) - Static method in class picard.illumina.parser.readers.MMapBackedIteratorFactory
 
getByteIterator(int, File) - Static method in class picard.illumina.parser.readers.MMapBackedIteratorFactory
 
getBytesAvailableToRead() - Method in class picard.util.CircularByteBuffer
Returns the number of bytes that are in the buffer at the time of the method invocation.
getC() - Method in class picard.illumina.parser.FourChannelIntensityData
 
getCacheHits() - Method in class org.broadinstitute.hellbender.utils.fasta.CachingIndexedFastaSequenceFile
 
getCacheMisses() - Method in class org.broadinstitute.hellbender.utils.fasta.CachingIndexedFastaSequenceFile
 
getCacheSize() - Method in class org.broadinstitute.hellbender.utils.fasta.CachingIndexedFastaSequenceFile
 
getCall() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CalledCopyRatioSegment
 
getCallableRegion() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmer.Result
Returns the trimmed variant containing region
getCalledHaplotypes() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerGenotypingEngine.CalledHaplotypes
Get the set of haplotypes that we actually called (i.e., underlying one of the VCs in getCalls().
getCallIntegerCopyNumberState() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.IntegerCopyNumberSegment
 
getCalls() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerGenotypingEngine.CalledHaplotypes
Get the list of calls made at this location
getCanonicalChromosomes(String, SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoveryUtils
 
getCanonicalChromosomesBroadcast() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoveryInputMetaData.ReferenceData
 
getCapacity() - Method in class picard.util.CircularByteBuffer
Returns the total capacity of the buffer (empty+filled).
getCDF() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.LibraryStatistics
 
getCDF() - Method in class org.broadinstitute.hellbender.tools.spark.utils.IntHistogram
 
getcDnaChange() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getCds() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfExonFeature
 
getCenter() - Method in class org.broadinstitute.hellbender.utils.mcmc.PosteriorSummary
 
getChainedPgIds(SAMFileHeader) - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.AbstractMarkDuplicatesCommandLineProgram
We have to re-chain the program groups based on this algorithm.
getChainedPgIds(SAMFileHeader) - Method in class picard.sam.markduplicates.util.AbstractMarkDuplicatesCommandLineProgram
We have to re-chain the program groups based on this algorithm.
getChannel(IntensityChannel) - Method in class picard.illumina.parser.FourChannelIntensityData
 
getChannels() - Method in enum org.broadinstitute.hellbender.tools.walkers.vqsr.TensorType
 
getChild() - Method in class org.broadinstitute.hellbender.utils.samples.Trio
 
getChildID() - Method in class org.broadinstitute.hellbender.utils.samples.Trio
 
getChildren() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTreeNode
 
getChildrenOf(int) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTree
 
getChr() - Method in class org.broadinstitute.hellbender.utils.codecs.sampileup.SAMPileupFeature
Deprecated.
getChrom() - Method in class picard.fingerprint.Snp
 
getChromosome() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getChromosomeName() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
getCigar() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils.Mapping
Returns the cigar of the primary interval, or the empty cigar if unmapped.
getCigar() - Method in class org.broadinstitute.hellbender.utils.haplotype.Haplotype
Get the cigar for this haplotype.
getCigar() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
getCigar() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getCigar() - Method in interface org.broadinstitute.hellbender.utils.smithwaterman.SmithWatermanAlignment
 
getCigarElement(int) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Return the cigar element at a given index.
getCigarElement(int) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
This implementation avoids the creation of the unmodifiable view of the underlying list of CigarElements and simply retrieves the element that is requested.
getCigarElements() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
getCigarElements() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
This implementation does not make a new Cigar object but instead provides an unmodifiable view of the underlying list of CigarElements.
getCigarOperator() - Method in class org.broadinstitute.hellbender.utils.locusiterator.AlignmentStateMachine
Convenience accessor of the CigarOperator of the current cigar element Robust to the case where we're on the edge, and currentElement is null, in which case this function returns null as well
getCigarString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.ReadEvidence
 
getClasses() - Method in class picard.cmdline.ClassFinder
Fetches the set of classes discovered so far.
getClassesOfType(Class<?>, List<Class<?>>) - Static method in class org.broadinstitute.hellbender.utils.ClassUtils
Gets a list of classes that are either the same as, or a subclass/subinterface of a parent target class.
getClassForPluginHelp(String) - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKAnnotationPluginDescriptor
Return the class representing the instance of the plugin specified by pluginName
getClassForPluginHelp(String) - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKReadFilterPluginDescriptor
Return the class object for the plugin with simple class name pluginName Used for help/usage and documentation generation.
getClassList() - Method in class org.broadinstitute.hellbender.Main
The single classes we wish to include in our command line.
getCloudStorageConfiguration(int) - Static method in class org.broadinstitute.hellbender.utils.gcs.BucketUtils
The config we want to use.
getClusterCount() - Method in class picard.illumina.parser.Tile
Returns the number of on this tile.
getClusterDensity() - Method in class picard.illumina.parser.Tile
Returns the cluster density of this tile, in units of [cluster/mm^2].
getCnvCallsBroadcast() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoveryInputMetaData.SampleSpecificData
 
getCode() - Method in enum org.broadinstitute.hellbender.tools.funcotator.AminoAcid
 
getCode() - Method in enum picard.vcf.GenotypeConcordanceStates.CallState
 
getCode() - Method in enum picard.vcf.GenotypeConcordanceStates.TruthState
 
getCodecForFile(File) - Static method in class org.broadinstitute.hellbender.engine.FeatureManager
Utility method that determines the correct codec to use to read Features from the provided file.
getCodecForFile(File, Class<? extends Feature>) - Static method in class org.broadinstitute.hellbender.engine.FeatureManager
Utility method that determines the correct codec to use to read Features from the provided file, optionally considering only codecs that produce a particular type of Feature.
getCodecForFile(Path, Class<? extends Feature>) - Static method in class org.broadinstitute.hellbender.engine.FeatureManager
Utility method that determines the correct codec to use to read Features from the provided file, optionally considering only codecs that produce a particular type of Feature.
getCodingSequence(ReferenceContext, List<? extends Locatable>, Strand) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Deprecated.
getCodingSequenceAlleleStart() - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
getCodingSequenceChangeString(SequenceComparison) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Get the coding sequence change string from the given SequenceComparison This method is assumed to be called only when the variant occurs in a coding region of the genome.
getCodingSequenceChangeStringForExonSpliceSite(int) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Get the coding sequence change string from the given SequenceComparison
getCodonChange() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getCodonChangeString(SequenceComparison) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Creates the string representation of the codon change for the given SequenceComparison.
getCodons() - Method in enum org.broadinstitute.hellbender.tools.funcotator.AminoAcid
 
getCollector(int, IntervalList) - Method in class picard.analysis.CollectWgsMetrics
Creates AbstractWgsMetricsCollector implementation according to this#USE_FAST_ALGORITHM value.
getCollector(int, IntervalList) - Method in class picard.analysis.CollectWgsMetricsWithNonZeroCoverage
 
getColumnFormat() - Method in class org.broadinstitute.hellbender.utils.report.GATKReportColumn
Get the display width for this column.
getColumnInfo() - Method in class org.broadinstitute.hellbender.utils.report.GATKReportTable
 
getColumnMedians(RealMatrix) - Static method in class org.broadinstitute.hellbender.utils.MatrixSummaryUtils
Return an array containing the median for each column in the given matrix.
getColumnName() - Method in class org.broadinstitute.hellbender.utils.report.GATKReportColumn
 
getColumnNames() - Method in class picard.util.DelimitedTextFileWithHeaderIterator
 
getColumnNames() - Method in class picard.util.TabbedTextFileWithHeaderParser
 
getCommand() - Method in class org.broadinstitute.hellbender.utils.runtime.ProcessSettings
 
getCommandLine() - Method in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
 
getCommandLine() - Method in class picard.cmdline.CommandLineProgram
 
getCommandLineName() - Method in class org.broadinstitute.hellbender.Main
Returns the command line that will appear in the usage.
getCommandLineParser() - Method in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
 
getCommandLineParser() - Method in class picard.cmdline.CommandLineProgram
 
getCommandString() - Method in class org.broadinstitute.hellbender.utils.runtime.ProcessSettings
 
getComments() - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalCollection
Creates a copy from the SAM File header or an empty list if no sam file header and no comments.
getCommonContigsByName(SAMSequenceDictionary, SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.utils.SequenceDictionaryUtils
Returns the set of contig names found in both dicts.
getComparator() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.collections.AbstractLocatableCollection
 
getComparator(Set<String>) - Method in enum org.broadinstitute.hellbender.tools.funcotator.TranscriptSelectionMode
 
getComplement(byte) - Static method in class org.broadinstitute.hellbender.utils.BaseUtils
 
getCompleteHeader() - Static method in class org.broadinstitute.hellbender.utils.test.VariantContextTestUtils
Method which returns a complete header with all the GATK and HTSJDK standard header lines for testing purposes
getComplication() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.NovelAdjacencyAndAltHaplotype
 
getCompressedBlockSize() - Method in class picard.illumina.parser.readers.BaseBclReader.TileData
 
getConcordance() - Method in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker.TruthVersusEval
 
getConcordanceStateArray(GenotypeConcordanceStates.TruthState, GenotypeConcordanceStates.CallState) - Method in class picard.vcf.GenotypeConcordanceScheme
Get the concordance state array associate with the given truth state and call state tuple.
getConcordanceStateArray(GenotypeConcordanceStates.TruthAndCallStates) - Method in class picard.vcf.GenotypeConcordanceScheme
Get the concordance state array associate with the given truth state and call state tuple.
getConfigfile(Path) - Static method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
Gets the Path config file in the given directory.
getConfigFilenameFromArgs(String[], String) - Static method in class org.broadinstitute.hellbender.utils.config.ConfigFactory
Get the configuration file name from the given arguments.
getConfigFilePath(Path) - Static method in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvLocatableTableCodec
Gets the path to the corresponding configuration file for the given inputFilePath.
getConfiguration() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
Returns a reference to the engine configuration
getConsensusCorrection(int) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadErrorCorrector.CorrectionSet
Get consensus correction for a particular offset.
getConsolidatedPaddedCigar(int) - Method in class org.broadinstitute.hellbender.utils.haplotype.Haplotype
Get the haplotype cigar extended by padSize M at the tail, consolidated into a clean cigar
getContamination() - Method in class org.broadinstitute.hellbender.tools.walkers.contamination.ContaminationRecord
 
getContig() - Method in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker.TruthVersusEval
 
getContig() - Method in class org.broadinstitute.hellbender.engine.AlignmentContext
 
getContig() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
 
getContig() - Method in class org.broadinstitute.hellbender.engine.ReferenceShard
 
getContig() - Method in interface org.broadinstitute.hellbender.engine.Shard
 
getContig() - Method in class org.broadinstitute.hellbender.engine.ShardBoundary
 
getContig() - Method in class org.broadinstitute.hellbender.engine.VariantShard
 
getContig() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AlleleFractionSegment
 
getContig() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AllelicCount
 
getContig() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AnnotatedInterval
 
getContig() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CopyRatio
 
getContig() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CopyRatioSegment
 
getContig() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.IntegerCopyNumberSegment
 
getContig() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.IntervalCopyNumberGenotypingData
 
getContig() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.ModeledSegment
 
getContig() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.MultidimensionalSegment
 
getContig() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.SimpleCount
 
getContig() - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedInterval
 
getContig() - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
getContig() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils.Mapping
Returns the contig as per the primary interval, or null if unmapped.
getContig() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVInterval
 
getContig() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVLocation
 
getContig() - Method in class org.broadinstitute.hellbender.tools.walkers.contamination.MinorAlleleFractionRecord
 
getContig() - Method in class org.broadinstitute.hellbender.tools.walkers.contamination.PileupSummary
 
getContig() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.BasicValidationResult
 
getContig() - Method in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfile
 
getContig() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
getContig() - Method in class org.broadinstitute.hellbender.utils.codecs.sampileup.SAMPileupFeature
 
getContig() - Method in class org.broadinstitute.hellbender.utils.codecs.table.TableFeature
 
getContig() - Method in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvTableFeature
 
getContig() - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
 
getContig() - Method in class org.broadinstitute.hellbender.utils.locusiterator.AlignmentStateMachine
Get the contig of the underlying read
getContig() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getContig() - Method in class org.broadinstitute.hellbender.utils.SimpleInterval
 
getContig() - Method in class org.broadinstitute.hellbender.utils.variant.MinimalVariant
 
getContig() - Method in class org.broadinstitute.hellbender.utils.variant.VariantContextVariantAdapter
 
getContigAlignments() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.AlignedAssemblyOrExcuse
List is equal in length to the number of contigs in the assembly.
getContigColumn() - Method in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvLocatableTableCodec
Do not call before XsvLocatableTableCodec.readActualHeader(LineIterator) or exception will be thrown..
getContigColumnName() - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalHeader
 
getContigID(String) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata
 
getContigIndex() - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
 
getContigIndex(String) - Method in class org.broadinstitute.hellbender.utils.GenomeLocParser
Returns the contig index of a specified string version of the contig
getContigIndexWithoutException(String) - Method in class org.broadinstitute.hellbender.utils.GenomeLocParser
 
getContigInfo(String) - Method in class org.broadinstitute.hellbender.utils.GenomeLocParser
get the contig's SAMSequenceRecord
getContigName() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignedContig
 
getContigName() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments
 
getContigName(int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata
 
getContigNameMap() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata
 
getContigNames(SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.utils.SequenceDictionaryUtils
 
getContigNamesList(SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.utils.SequenceDictionaryUtils
 
getContigSequence() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignedContig
 
getContigSequence() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments
 
getContigSizes(Path) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Returns a map of contig names with their sizes.
getContigsWithSignatureClassifiedAsComplex() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoverFromLocalAssemblyContigAlignmentsSpark.AssemblyContigsClassifiedByAlignmentSignatures
 
getContigsWithSignatureClassifiedAsSimpleChimera() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoverFromLocalAssemblyContigAlignmentsSpark.AssemblyContigsClassifiedByAlignmentSignatures
 
getContigsWithSignatureClassifiedAsUnknown() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoverFromLocalAssemblyContigAlignmentsSpark.AssemblyContigsClassifiedByAlignmentSignatures
 
getContingencyStateCounts(GenotypeConcordanceScheme) - Method in class picard.vcf.GenotypeConcordanceCounts
Returns the total number of times each contingency state is encountered, summed across all truth/call state pairs.
getContingencyStateSet(GenotypeConcordanceStates.ContingencyState[]) - Method in class picard.vcf.GenotypeConcordanceScheme
Get the contingency state array as a set
getContingencyStateString(GenotypeConcordanceStates.TruthState, GenotypeConcordanceStates.CallState) - Method in class picard.vcf.GenotypeConcordanceScheme
Get the contingency state array as a parse-able string
getContingencyTable(ReadLikelihoods<Allele>, VariantContext, int) - Static method in class org.broadinstitute.hellbender.tools.walkers.annotator.StrandBiasTest
Allocate and fill a 2x2 strand contingency table.
getContingencyTable(ReadLikelihoods<Allele>, VariantContext, int, Collection<String>) - Static method in class org.broadinstitute.hellbender.tools.walkers.annotator.StrandBiasTest
Allocate and fill a 2x2 strand contingency table.
getCopyNumber() - Method in class org.broadinstitute.hellbender.tools.copynumber.gcnv.IntegerCopyNumberState
 
getCopyNumberPosterior(IntegerCopyNumberState) - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CopyNumberPosteriorDistribution
Get the probability for a given copy number state
getCopyNumberPosteriorDistribution() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.IntervalCopyNumberGenotypingData
 
getCount() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.SimpleCount
 
getCount() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.AggregatedSubHaplotypeFinder
 
getCount(GenotypeConcordanceStates.TruthState, GenotypeConcordanceStates.CallState) - Method in class picard.vcf.GenotypeConcordanceCounts
Returns the count defined by the truth state set and call state set.
getCount(GenotypeConcordanceStates.TruthAndCallStates) - Method in class picard.vcf.GenotypeConcordanceCounts
Returns the count defined by the truth state set and call state set.
getCountedKmers() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.KMerCounter
Get an unordered collection of the counted kmers in this counter
getCounterSize() - Method in class picard.vcf.GenotypeConcordanceCounts
 
getCountMap() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.AllelePileupCounter
 
getCounts() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.collections.SimpleCountCollection
 
getCounts() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.ExactACcounts
 
getCovariateByParsedName(String) - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.StandardCovariateList
Retrieves a covariate by the parsed name Covariate.parseNameForReport() or null if no covariate with that name exists in the list.
getCovariateForTable(NestedIntegerArray<RecalDatum>) - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationTables
 
getCovariates() - Method in class org.broadinstitute.hellbender.utils.recalibration.BaseRecalibrationEngine
 
getCovariates() - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationReport
 
getCovariatesValues() - Method in class org.broadinstitute.hellbender.utils.recalibration.ReadRecalibrationInfo
Get the ReadCovariates object carrying the mapping from offsets -> covariate key sets
getCoverage(String) - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CoveragePerContig
 
getCoverage() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.LibraryStatistics
 
getCoverage() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata
 
getCoverageByTarget() - Method in class picard.analysis.directed.TargetMetricsCollector.PerUnitTargetMetricCollector
Returns the accumulated coverage per target.
getCurrentCigarElement() - Method in class org.broadinstitute.hellbender.utils.locusiterator.AlignmentStateMachine
Get the cigar element we're currently aligning with.
getCurrentCigarElement() - Method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Get the cigar element aligning this element to the genome
getCurrentCigarElementOffset() - Method in class org.broadinstitute.hellbender.utils.locusiterator.AlignmentStateMachine
Get the offset of the current cigar element among all cigar elements in the read Suppose our read's cigar is 1M2D3M, and we're at the first 1M.
getCurrentCigarOffset() - Method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Get the offset of this cigar element in the Cigar of the current read (0-based) Suppose the cigar is 1M2D3I4D.
getCurrentLine() - Method in class picard.util.BasicInputParser
Provides access to the current (just parsed) line in pre-parsed format.
getCurrentLine() - Method in class picard.util.DelimitedTextFileWithHeaderIterator.Row
 
getCurrentLine() - Method in class picard.util.TabbedTextFileWithHeaderParser.Row
 
getCurrentLineNumber() - Method in class picard.util.BasicInputParser
NOTE: Because AbstractInputParser pre-fetches the next line, this method actually returns the next line, not the most recent line returned by next().
getCurrentLineNumber() - Method in class picard.util.DelimitedTextFileWithHeaderIterator
 
getCurrentLineNumber() - Method in class picard.util.TabbedTextFileWithHeaderParser
 
getCycleData() - Method in class picard.illumina.parser.readers.CbclReader
 
getCycleFromDir(File) - Static method in class picard.illumina.parser.PerTilePerCycleFileUtil
 
getCycleIndexRanges() - Method in class picard.illumina.parser.OutputMapping
 
getCycleIndexRanges() - Method in class picard.illumina.parser.ReadStructure.Substructure
 
getCycles() - Method in class picard.illumina.parser.ReadStructure.Substructure
 
getData() - Method in class org.broadinstitute.hellbender.tools.ClipReads.ReadClipperWithData
 
getData() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
 
getDataSourceInfoString() - Method in class org.broadinstitute.hellbender.tools.funcotator.OutputRenderer
 
getDataSourceName() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getDataSourceName() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.TableFuncotation
 
getDataSourceName() - Method in interface org.broadinstitute.hellbender.tools.funcotator.Funcotation
 
getDataSourceName() - Method in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvTableFeature
 
getDataType() - Method in class org.broadinstitute.hellbender.utils.report.GATKReportColumn
 
getDateTimeForDisplay(ZonedDateTime) - Static method in class org.broadinstitute.hellbender.utils.Utils
Return the given dateTime formatted as string for display.
getDecile10() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.ModeledSegment.SimplePosteriorSummary
 
getDecile50() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.ModeledSegment.SimplePosteriorSummary
 
getDecile90() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.ModeledSegment.SimplePosteriorSummary
 
getDeciles(T) - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.collections.ParameterDecileCollection
 
getDeciles() - Method in class org.broadinstitute.hellbender.utils.mcmc.PosteriorSummary
getDefaultAlleleFrequency() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
getDefaultCloudIndexPrefetchBufferSize() - Method in class org.broadinstitute.hellbender.engine.GATKTool
 
getDefaultCloudIndexPrefetchBufferSize() - Method in class org.broadinstitute.hellbender.tools.genomicsdb.GenomicsDBImport
 
getDefaultCloudPrefetchBufferSize() - Method in class org.broadinstitute.hellbender.engine.GATKTool
 
getDefaultCloudPrefetchBufferSize() - Method in class org.broadinstitute.hellbender.tools.genomicsdb.GenomicsDBImport
 
getDefaultHeaders() - Method in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
Returns the (live) list of default metrics headers used by this tool.
getDefaultHeaders() - Method in class picard.cmdline.CommandLineProgram
 
getDefaultInstances() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKAnnotationPluginDescriptor
Get the list of default plugins used for this instance of this descriptor.
getDefaultInstances() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKReadFilterPluginDescriptor
Get the list of default plugins used for this instance of this descriptor.
getDefaultPartsDirectory(String) - Static method in class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSink
Gets the default parts directory for a given file by appending .parts/ to the end of it
getDefaultPlatform() - Method in enum org.broadinstitute.hellbender.utils.NGSPlatform
Returns a representative PL string for this platform
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
Returns the default list of CommandLineReadFilters that are used for this tool.
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.engine.GATKTool
Returns the default list of ReadFilters that are used for this tool.
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.engine.LocusWalker
Returns the default list of CommandLineReadFilters that are used for this tool.
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.engine.ReadWalker
Returns the default list of CommandLineReadFilters that are used for this tool.
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerSpark
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
Returns the default list of ReadFilters that are used for this tool.
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.metrics.InsertSizeMetricsCollector
Return the read filter for InsertSizeMetrics collector.
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.AnnotatePairOrientation
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.copynumber.CollectAllelicCounts
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.copynumber.CollectReadCounts
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.examples.metrics.multi.ExampleCollectMultiMetricsSpark
Return the read filters required for this collector
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.examples.metrics.multi.ExampleMultiMetricsCollector
Return the read filter for example metrics collector.
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.examples.metrics.multi.ExampleMultiMetricsCollectorSpark
Return the read filters to be used for this collector.
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.examples.metrics.single.ExampleCollectSingleMetricsSpark
Return the read filter required for this collector
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.spark.BaseRecalibratorSpark
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.spark.bwa.BwaSpark
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.spark.PileupSpark
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectBaseDistributionByCycleSpark
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectInsertSizeMetricsSpark
Return the read filters required for this collector
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectQualityYieldMetricsSpark
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.InsertSizeMetricsCollectorSpark
Return the read filters to be used for this collector.
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.MeanQualityByCycleSpark
 
getDefaultReadFilters() - Method in interface org.broadinstitute.hellbender.tools.spark.pipelines.metrics.MetricsCollectorSpark
Return the read filters used for this collector.
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.MetricsCollectorSparkTool
The following MetricsCollectorSpark methods must be implemented by subclasses and should be forwarded to the embedded collector.
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.QualityScoreDistributionSpark
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.SortSamSpark
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.DiscoverVariantsFromContigAlignmentsSAMSpark
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.CpxVariantReInterpreterSpark
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoverFromLocalAssemblyContigAlignmentsSpark
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.spark.transforms.markduplicates.MarkDuplicatesSpark
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotator
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.walkers.bqsr.BaseRecalibrator
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.walkers.contamination.GetPileupSummaries
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCaller
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.walkers.qc.CheckPileup
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.walkers.qc.Pileup
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.FilterAlignmentArtifacts
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.walkers.RevertBaseQualityScores
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.ASEReadCounter
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.SplitNCigarReads
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.walkers.UnmarkDuplicates
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
getDefaultReadFilters() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.CNNScoreVariants
 
getDefaultToolVCFHeaderLines() - Method in class org.broadinstitute.hellbender.engine.GATKTool
 
getDefaultValue(HybridADVIArgumentCollection.HybridADVIArgument) - Method in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineCNVHybridADVIArgumentCollection
 
getDefaultValue(HybridADVIArgumentCollection.HybridADVIArgument) - Method in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineContigPloidyHybridADVIArgumentCollection
 
getDefaultValue(HybridADVIArgumentCollection.HybridADVIArgument) - Method in class org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection
 
getDefaultVariantAnnotationGroups() - Method in class org.broadinstitute.hellbender.engine.GATKTool
Returns the default list of annotation groups that are used for this tool.
getDefaultVariantAnnotationGroups() - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
 
getDefaultVariantAnnotationGroups() - Method in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark
 
getDefaultVariantAnnotationGroups() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.ReadsPipelineSpark
 
getDefaultVariantAnnotationGroups() - Method in class org.broadinstitute.hellbender.tools.walkers.CombineGVCFs
 
getDefaultVariantAnnotationGroups() - Method in class org.broadinstitute.hellbender.tools.walkers.GenotypeGVCFs
 
getDefaultVariantAnnotationGroups() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCaller
 
getDefaultVariantAnnotationGroups() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2
 
getDefaultVariantAnnotations() - Method in class org.broadinstitute.hellbender.engine.GATKTool
Returns the default list of Annotations that are used for this tool.
getDefaultVariantAnnotations() - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
 
getDelegatee() - Method in class org.broadinstitute.hellbender.utils.codecs.ProgressReportingDelegatingCodec
 
getDeleteOnExit() - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
getDeletionsKeySet() - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.ReadCovariates
 
getDeletionsKeySet(int) - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.ReadCovariates
 
getDenoisedCopyRatios() - Method in class org.broadinstitute.hellbender.tools.copynumber.denoising.SVDDenoisedCopyRatioResult
 
getDensity() - Method in class picard.illumina.parser.readers.TileMetricsOutReader
 
getDepthHistogram() - Method in class picard.analysis.CollectWgsMetricsWithNonZeroCoverage.WgsMetricsWithNonZeroCoverageCollector
 
getDepths() - Method in class picard.analysis.directed.TargetMetricsCollector.Coverage
Gets the coverage depths as an array of ints.
getDescendentScore() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenTaxonScore
 
getDescription() - Method in class org.broadinstitute.hellbender.cmdline.programgroups.CopyNumberProgramGroup
 
getDescription() - Method in class org.broadinstitute.hellbender.cmdline.programgroups.CoverageAnalysisProgramGroup
 
getDescription() - Method in class org.broadinstitute.hellbender.cmdline.programgroups.ExampleProgramGroup
 
getDescription() - Method in class org.broadinstitute.hellbender.cmdline.programgroups.MetagenomicsProgramGroup
 
getDescription() - Method in class org.broadinstitute.hellbender.cmdline.programgroups.ShortVariantDiscoveryProgramGroup
 
getDescription() - Method in class org.broadinstitute.hellbender.cmdline.programgroups.StructuralVariantDiscoveryProgramGroup
 
getDescription() - Method in class org.broadinstitute.hellbender.cmdline.TestProgramGroup
 
getDescription() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils.FastqRead
 
getDescription() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.BaseQuality
 
getDescription() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.FragmentLength
 
getDescription() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.MappingQuality
 
getDescription() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.PerAlleleAnnotation
 
getDescription() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.ReadPosition
 
getDescription() - Method in class picard.cmdline.programgroups.BaseCallingProgramGroup
 
getDescription() - Method in class picard.cmdline.programgroups.DiagnosticsAndQCProgramGroup
 
getDescription() - Method in class picard.cmdline.programgroups.IntervalsManipulationProgramGroup
 
getDescription() - Method in class picard.cmdline.programgroups.OtherProgramGroup
 
getDescription() - Method in class picard.cmdline.programgroups.ReadDataManipulationProgramGroup
 
getDescription() - Method in class picard.cmdline.programgroups.ReferenceProgramGroup
 
getDescription() - Method in class picard.cmdline.programgroups.Testing
 
getDescription() - Method in class picard.cmdline.programgroups.VariantEvaluationProgramGroup
 
getDescription() - Method in class picard.cmdline.programgroups.VariantFilteringProgramGroup
 
getDescription() - Method in class picard.cmdline.programgroups.VariantManipulationProgramGroup
 
getDescriptions() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.ChromosomeCounts
 
getDescriptions() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.Coverage
 
getDescriptions() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.DepthPerAlleleBySample
 
getDescriptions() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.DepthPerSampleHC
 
getDescriptions() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.GenotypeAnnotation
Return the descriptions used for the VCF FORMAT meta field.
getDescriptions() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.InfoFieldAnnotation
Returns the descriptions used for the VCF INFO meta field.
getDescriptions() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.MappingQualityZero
 
getDescriptions() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.OxoGReadCounts
 
getDescriptions() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.PerAlleleAnnotation
 
getDescriptions() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.ReferenceBases
 
getDescriptions() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.RMSMappingQuality
 
getDescriptions() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.StrandArtifact
 
getDescriptions() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.StrandBiasBySample
 
getDescriptions() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.UniqueAltReadCount
 
getDescriptorLengths() - Method in class picard.illumina.parser.ReadStructure.Substructure
 
getDetectedCycles() - Method in class picard.illumina.parser.PerTilePerCycleFileUtil
 
getDictionaryAsString(SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.utils.SequenceDictionaryUtils
Returns a compact String representation of the sequence dictionary it's passed The format of the returned String is: [ contig1Name(length: contig1Length) contig2Name(length: contig2Length) ...
getDictionaryForMergedBam() - Method in class picard.sam.AbstractAlignmentMerger
 
getDictionaryForMergedBam() - Method in class picard.sam.SamAlignmentMerger
 
getDictionaryOrderComparator(SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
The order of contigs/sequences in the dictionary is the order of the sorting here.
getDifferingPositions(Kmer, int, int[], byte[]) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.Kmer
Gets a set of differing positions and bases from another k-mer, limiting up to a max distance.
getDimensions() - Method in class org.broadinstitute.hellbender.utils.collections.NestedIntegerArray
 
getDiploidHaplotype(Snp, DiploidGenotype) - Method in class picard.fingerprint.HaplotypeBlock
Gets the diploid haplotype for this haplotype block given the provided SNP and SNP genotype.
getDirectory() - Method in class org.broadinstitute.hellbender.utils.runtime.ProcessSettings
 
getDisableToolDefaultAnnotations() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.DefaultGATKVariantAnnotationArgumentCollection
 
getDisableToolDefaultAnnotations() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKAnnotationArgumentCollection
Returns true if all tool-default annotations are disabled; false otherwise.
getDisableToolDefaultReadFilters() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.DefaultGATKReadFilterArgumentCollection
Returns true if all default filters are disabled; false otherwise.
getDisableToolDefaultReadFilters() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKReadFilterArgumentCollection
Returns true if all default filters are disabled; false otherwise.
getDiscoverStageArgs() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoveryInputMetaData
 
getDiscoveryAltCount() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.BasicValidationResult
 
getDiscoveryRefCount() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.BasicValidationResult
 
getDisplayName() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKAnnotationPluginDescriptor
Return a display name to identify this plugin to the user
getDisplayName() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKReadFilterPluginDescriptor
Return a display name to identify this plugin to the user
getDisplayNameForToolClass(Class<?>) - Method in class org.broadinstitute.hellbender.Main
 
getDisplaySummaryForTool(Class<?>, CommandLineProgramProperties) - Method in class org.broadinstitute.hellbender.Main
Return a summary string for a command line tool suitable for display.
getDistalTargets(ReadMetadata, int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.DiscordantReadPairEvidence
In the case of a discordant read pair, the distal target interval is a StrandedInterval where the interval location is the possible breakpoint interval given by the inferred rest-of-fragment interval for the mate read (ie the region that would contain the mate's mated read if its fragment size had been drawn from the non-outlier fragment size distribution), and the strand can be easily computed as the strand of the reference the mate mapped to.
getDistalTargets(ReadMetadata, int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence
Returns the distal interval implicated as a candidate adjacency to the breakpoint by this piece of evidence.
getDistalTargets(ReadMetadata, int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.SplitRead
In the case of a split read with an SA tag, the distal target interval is a StrandedInterval where the interval location is the possible breakpoint interval given by the clipping location on the supplementary alignment, and the strand indicates whether or not the rest of the supplementary alignment is upstream or downstream of of the breakpoint.
getDistance() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.EvidenceTargetLink
Distance between the two intervals.
getDotLabel() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseEdge
Get the DOT format label for this edge, to be displayed when printing this edge to a DOT file
getDotLabel() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.MultiSampleEdge
 
getDouble(int) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Returns the double value in a column by its index.
getDouble(int, Function<String, RuntimeException>) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Returns the double value in a column by its index.
getDouble(String) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Returns the double value in a column by its index.
getDouble(Enum<?>) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Returns the double value of a column by its name.
getDownsamplingInfo() - Method in class org.broadinstitute.hellbender.engine.LocusWalker
Returns the downsampling info using LocusWalker.maxDepthPerSample as target coverage.
getDownsamplingInfo() - Method in class org.broadinstitute.hellbender.engine.spark.LocusWalkerSpark
Returns the downsampling info using LocusWalkerSpark.maxDepthPerSample as target coverage.
getDownsamplingInfo() - Method in class org.broadinstitute.hellbender.utils.locusiterator.AlignmentContextIteratorBuilder
 
getDrivingFeatureFile() - Method in class org.broadinstitute.hellbender.engine.FeatureWalker
Returns the file that contains the driving features.
getDrivingFeatureFile() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleFeatureWalker
 
getDrivingVariantsFeatureInput() - Method in class org.broadinstitute.hellbender.engine.VariantWalker
Returns the feature input for the driving variants file.
getDrivingVariantsFeatureInputs() - Method in class org.broadinstitute.hellbender.engine.MultiVariantWalker
Returns a list of feature inputs used for the driving variants for this source.
getDuplicatedItems(Collection<T>) - Static method in class org.broadinstitute.hellbender.utils.Utils
Gets duplicated items in the collection.
getDuplicateSetIterator(AbstractMarkDuplicatesCommandLineProgram.SamHeaderAndIterator, SAMRecordDuplicateComparator) - Method in class picard.sam.markduplicates.SimpleMarkDuplicatesWithMateCigar
 
getDuplicateSetIterator(AbstractMarkDuplicatesCommandLineProgram.SamHeaderAndIterator, SAMRecordDuplicateComparator) - Method in class picard.sam.markduplicates.UmiAwareMarkDuplicatesWithMateCigar
 
getDupSeqRepeatUnitRefSpan() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications.IntraChrStrandSwitchBreakpointComplications
 
getEdges() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.Path
Get the edges of this path in order.
getEffectiveCounts(LikelihoodMatrix<Allele>) - Static method in class org.broadinstitute.hellbender.tools.walkers.mutect.SomaticGenotypingEngine
 
getEffectiveCounts(RealMatrix, double[]) - Static method in class org.broadinstitute.hellbender.tools.walkers.mutect.SomaticLikelihoodsEngine
Given data log likelihoods and a Dirichlet prior for a categorical distribution, obtain the array of total responsibilities for each category
getEigensampleVectors() - Method in class org.broadinstitute.hellbender.tools.copynumber.denoising.HDF5SVDReadCountPanelOfNormals
 
getEigensampleVectors() - Method in interface org.broadinstitute.hellbender.tools.copynumber.denoising.SVDReadCountPanelOfNormals
Returns a modifiable copy of an array containing the orthnonormal matrix of eigensample vectors.
getElementForPileupElement(PileupElement, int) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RankSumTest
 
getElementForPileupElement(PileupElement, int) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.BaseQualityRankSumTest
 
getElementForPileupElement(PileupElement, int) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.ClippingRankSumTest
 
getElementForPileupElement(PileupElement, int) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.LikelihoodRankSumTest
 
getElementForPileupElement(PileupElement, int) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.MappingQualityRankSumTest
 
getElementForPileupElement(PileupElement, int) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.RankSumTest
Get the element for the given read at the given reference position This can return an OptionalDouble.empty() if the annotation should not be computed based on the pileups.
getElementForPileupElement(PileupElement, int) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.ReadPosRankSumTest
 
getElementForRead(GATKRead, int) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_BaseQualityRankSumTest
Get the element for the given read at the given reference position
getElementForRead(GATKRead, int) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_MappingQualityRankSumTest
 
getElementForRead(GATKRead, int) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_ReadPosRankSumTest
 
getElementForRead(GATKRead, int) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.BaseQualityRankSumTest
 
getElementForRead(GATKRead, int) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.ClippingRankSumTest
 
getElementForRead(GATKRead, int, ReadLikelihoods<Allele>.BestAllele) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.LikelihoodRankSumTest
 
getElementForRead(GATKRead, int) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.LikelihoodRankSumTest
 
getElementForRead(GATKRead, int) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.MappingQualityRankSumTest
 
getElementForRead(GATKRead, int, ReadLikelihoods<Allele>.BestAllele) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.RankSumTest
Get the element for the given read at the given reference position
getElementForRead(GATKRead, int) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.RankSumTest
Get the element for the given read at the given reference position
getElementForRead(GATKRead, int) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.ReadPosRankSumTest
 
getEmpiricalErrorRate() - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalDatum
Returns the error rate (in real space) of this interval, or 0 if there are no observations
getEmpiricalQuality() - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalDatum
 
getEmpiricalQuality(double) - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalDatum
 
getEmpiricalQualityAsByte() - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalDatum
 
getEnableAllAnnotations() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.DefaultGATKVariantAnnotationArgumentCollection
 
getEnableAllAnnotations() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKAnnotationArgumentCollection
Returns true if all annotations are enabled; false otherwise.
getEncapsulatedSamRecord() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getEnd() - Method in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker.TruthVersusEval
 
getEnd() - Method in class org.broadinstitute.hellbender.engine.AlignmentContext
 
getEnd() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
 
getEnd() - Method in interface org.broadinstitute.hellbender.engine.Shard
 
getEnd() - Method in class org.broadinstitute.hellbender.engine.ShardBoundary
 
getEnd() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AlleleFractionSegment
 
getEnd() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AllelicCount
 
getEnd() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AnnotatedInterval
 
getEnd() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CopyRatio
 
getEnd() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CopyRatioSegment
 
getEnd() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.IntegerCopyNumberSegment
 
getEnd() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.IntervalCopyNumberGenotypingData
 
getEnd() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.ModeledSegment
 
getEnd() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.MultidimensionalSegment
 
getEnd() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.SimpleCount
 
getEnd() - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedInterval
 
getEnd() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getEnd() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVContext
The end position of this variant context.
getEnd() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils.Mapping
Returns the primary interval end position, or SAMRecord.NO_ALIGNMENT_START if unmapped.
getEnd() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVInterval
 
getEnd() - Method in class org.broadinstitute.hellbender.tools.walkers.contamination.MinorAlleleFractionRecord
 
getEnd() - Method in class org.broadinstitute.hellbender.tools.walkers.contamination.PileupSummary
 
getEnd() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.BasicValidationResult
 
getEnd() - Method in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfile
 
getEnd() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
getEnd() - Method in class org.broadinstitute.hellbender.utils.codecs.sampileup.SAMPileupFeature
 
getEnd() - Method in class org.broadinstitute.hellbender.utils.codecs.table.TableFeature
 
getEnd() - Method in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvTableFeature
 
getEnd() - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
 
getEnd() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getEnd() - Method in class org.broadinstitute.hellbender.utils.SimpleInterval
 
getEnd() - Method in class org.broadinstitute.hellbender.utils.variant.MinimalVariant
 
getEnd() - Method in class org.broadinstitute.hellbender.utils.variant.VariantContextVariantAdapter
 
getEndColumn() - Method in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvLocatableTableCodec
Do not call before XsvLocatableTableCodec.readActualHeader(LineIterator) or exception will be thrown..
getEndColumnName() - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalHeader
 
getEnum(String) - Static method in enum org.broadinstitute.hellbender.tools.funcotator.FuncotatorArgumentDefinitions.DataSourceType
 
getEnum(String) - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.FeatureTag
 
getEnum(String) - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.FeatureType
 
getEnum(String) - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.GeneTranscriptType
 
getEnum(String) - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.GenomicPhase
 
getEnum(String) - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.LocusLevel
 
getEnum(String) - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.RemapStatus
 
getEnum(String) - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.RemapTargetStatus
 
getEnum(String) - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.TranscriptSupportLevel
 
getEnvironment() - Method in class org.broadinstitute.hellbender.utils.runtime.ProcessSettings
 
getError() - Method in class org.broadinstitute.hellbender.tools.walkers.contamination.ContaminationRecord
 
getErrorFraction(EventType, int) - Method in class org.broadinstitute.hellbender.utils.recalibration.ReadRecalibrationInfo
Get the error fraction for event type at offset The error fraction is a value between 0 and 1 that indicates how much certainty we have in the error occurring at offset.
getErrorMessage() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.AlignedAssemblyOrExcuse
Either this is null, or the assembly and list of alignments is null.
getErrorRate() - Method in class org.broadinstitute.hellbender.utils.recalibration.QualQuantizer.QualInterval
 
getEstimatedQReported() - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalDatum
 
getEstimatedQReportedAsByte() - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalDatum
 
getEukaryoticAminoAcidByCodon(String) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Returns the AminoAcid corresponding to the given three-letter Eukaryotic codon The codons given are expected to be valid for Eukaryotic DNA.
getEval() - Method in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker.TruthVersusEval
 
getEvalHeader() - Method in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker
 
getEvaluationData() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
 
getEventMap() - Method in class org.broadinstitute.hellbender.utils.haplotype.Haplotype
 
getEvidenceTargetLinks() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoveryInputMetaData.SampleSpecificData
 
getEvidenceTargetLinks() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.FindBreakpointEvidenceSpark.AssembledEvidenceResults
 
getException() - Method in class picard.illumina.ExtractIlluminaBarcodes.PerTileBarcodeExtractor
 
getExecutableName() - Method in enum org.broadinstitute.hellbender.utils.python.PythonExecutorBase.PythonExecutableName
 
getExistingBaseDeletionQualities(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
getExistingBaseInsertionQualities(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
getExitValue() - Method in class org.broadinstitute.hellbender.utils.runtime.ProcessOutput
 
getExonEndPosition() - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
getExonId() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
getExonNumber() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
getExons() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfTranscriptFeature
 
getExonStartPosition() - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
getExpectedException() - Method in class org.broadinstitute.hellbender.utils.test.IntegrationTestSpec
 
getExpectedSortOrder() - Method in class org.broadinstitute.hellbender.tools.examples.metrics.multi.ExampleCollectMultiMetricsSpark
Return the sort order required/expected by this collector.
getExpectedSortOrder() - Method in class org.broadinstitute.hellbender.tools.examples.metrics.single.ExampleCollectSingleMetricsSpark
Return the sort order required/expected by this collector.
getExpectedSortOrder() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectInsertSizeMetricsSpark
 
getExpectedSortOrder() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectQualityYieldMetricsSpark
 
getExpectedSortOrder() - Method in interface org.broadinstitute.hellbender.tools.spark.pipelines.metrics.MetricsCollectorSpark
Return the sort order this collect requires.
getExpectedSortOrder() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.MetricsCollectorSparkTool
 
getExpectedTiles() - Method in class picard.illumina.parser.IlluminaFileUtil
Return the list of tiles we would expect for this lane based on the metrics found in InterOp/TileMetricsOut.bin
getExtendedSpan() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
Get the span of this assembly region including the extension value
getExtension() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
Get the extension applied to this region The extension is >= 0 bp in size, and indicates how much padding was requested for the region
getExtension() - Static method in class picard.illumina.IlluminaLaneMetrics
This property is not exposed in a field to avoid complications with MetricBase's dependency on reflection.
getExtension() - Static method in class picard.illumina.IlluminaPhasingMetrics
This property is not exposed in a field to avoid complications with MetricBase's dependency on reflection.
getExtension() - Static method in class picard.vcf.MendelianViolations.MendelianViolationMetrics
 
getF1R2(Genotype) - Static method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasUtils
 
getF2R1(Genotype) - Static method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasUtils
 
getFalseNegativeCount() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.FilterAnalysisRecord
 
getFalseNegatives() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.ConcordanceSummaryRecord
 
getFalsePositiveProbability() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerBloomFilter
 
getFalsePositiveProbability() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerSet
 
getFalsePositives() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.ConcordanceSummaryRecord
 
getFamilies() - Method in class org.broadinstitute.hellbender.utils.samples.SampleDB
Returns a map from family ID -> set of family members.
getFamilies(Collection<String>) - Method in class org.broadinstitute.hellbender.utils.samples.SampleDB
 
getFamily(String) - Method in class org.broadinstitute.hellbender.utils.samples.SampleDB
Return all samples with a given family ID
getFamilyID() - Method in class org.broadinstitute.hellbender.utils.samples.Sample
 
getFamilyId() - Method in class picard.pedigree.PedFile.PedTrio
 
getFamilyIDs() - Method in class org.broadinstitute.hellbender.utils.samples.SampleDB
Returns a sorted set of the family IDs in all samples
getFaqLink() - Static method in class picard.cmdline.CommandLineProgram
 
getFastaDictionaryFileName(String) - Static method in class org.broadinstitute.hellbender.utils.reference.ReferenceUtils
Given a fasta filename, return the name of the corresponding dictionary file.
getFastaIndexFileName(String) - Static method in class org.broadinstitute.hellbender.utils.reference.ReferenceUtils
Given a fasta filename, return the name of the corresponding index file.
getFather(Sample) - Method in class org.broadinstitute.hellbender.utils.samples.SampleDB
Get the sample's father
getFather() - Method in class org.broadinstitute.hellbender.utils.samples.Trio
 
getFeatureCodecClass() - Method in class org.broadinstitute.hellbender.engine.FeatureInput
 
getFeatureContext() - Method in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerContext
 
getFeatureContext() - Method in class org.broadinstitute.hellbender.engine.spark.IntervalWalkerContext
 
getFeatureContext() - Method in class org.broadinstitute.hellbender.engine.spark.LocusWalkerContext
 
getFeatureContext() - Method in class org.broadinstitute.hellbender.engine.spark.ReadWalkerContext
 
getFeatureContext() - Method in class org.broadinstitute.hellbender.engine.spark.VariantWalkerContext
 
getFeatureIterator(FeatureInput<T>) - Method in class org.broadinstitute.hellbender.engine.FeatureManager
Given a FeatureInput argument field from our tool, returns an iterator to its features starting from the first one.
getFeatureOrderNumber() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
getFeaturePath() - Method in class org.broadinstitute.hellbender.engine.FeatureInput
Gets the file backing this source of Features
getFeatures(FeatureInput<T>, SimpleInterval) - Method in class org.broadinstitute.hellbender.engine.FeatureManager
Given a FeatureInput argument field from our tool, queries the data source for that FeatureInput over the specified interval, and returns a List of the Features overlapping that interval from that data source.
getFeatureType() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
getFeatureType() - Method in class org.broadinstitute.hellbender.utils.codecs.ProgressReportingDelegatingCodec
 
getField(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getField(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.TableFuncotation
 
getField(String) - Method in interface org.broadinstitute.hellbender.tools.funcotator.Funcotation
Get the value of a field in this Funcotation.
getField(String) - Method in class picard.util.DelimitedTextFileWithHeaderIterator.Row
 
getField(String) - Method in class picard.util.TabbedTextFileWithHeaderParser.Row
 
getFieldNames() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getFieldNames() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.TableFuncotation
 
getFieldNames() - Method in interface org.broadinstitute.hellbender.tools.funcotator.Funcotation
Get the names of the fields in this Funcotation.
getFields() - Method in class picard.util.DelimitedTextFileWithHeaderIterator.Row
 
getFields() - Method in class picard.util.TabbedTextFileWithHeaderParser.Row
 
getFIFOForWrite() - Method in class org.broadinstitute.hellbender.utils.python.StreamingPythonScriptExecutor
Obtain a temporary FIFO to be used to transfer data to Python.
getFile() - Method in class picard.illumina.parser.readers.AbstractIlluminaPositionFileReader
 
getFile() - Method in class picard.illumina.parser.TileIndex
 
getFileExtension() - Static method in class picard.vcf.CollectVariantCallingMetrics.VariantCallingDetailMetrics
 
getFileExtension() - Static method in class picard.vcf.CollectVariantCallingMetrics.VariantCallingSummaryMetrics
 
getFileName() - Method in class picard.util.AbstractInputParser
 
getFileName() - Method in class picard.util.BasicInputParser
Gets the name of the file being parsed
getFiles(List<Integer>, int[]) - Method in class picard.illumina.parser.MultiTileBclFileUtil
 
getFiles() - Method in class picard.illumina.parser.PerTileFileUtil
 
getFiles(List<Integer>) - Method in class picard.illumina.parser.PerTileFileUtil
 
getFiles() - Method in class picard.illumina.parser.PerTilePerCycleFileUtil
 
getFiles(List<Integer>) - Method in class picard.illumina.parser.PerTilePerCycleFileUtil
 
getFiles(int[]) - Method in class picard.illumina.parser.PerTilePerCycleFileUtil
Returns a cycleIlluminaFileMap with all available tiles but limited to the cycles passed in.
getFiles(List<Integer>, int[]) - Method in class picard.illumina.parser.PerTilePerCycleFileUtil
Returns a cycleIlluminaFileMap that contains only the tiles and cycles specified (and fewer if the original CycleIlluminaFileMap, created on util instantiation, doesn't contain any of these tiles/cycles).
getFilesForCycle(int) - Method in class picard.illumina.parser.readers.CbclReader
 
getFilter() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.FilterAnalysisRecord
 
getFilteredBases() - Method in class picard.filter.CountingFilter
Gets the number of bases that have been filtered out thus far.
getFilteredCount() - Method in class org.broadinstitute.hellbender.engine.filters.CountingReadFilter
 
getFilteredCount() - Method in class org.broadinstitute.hellbender.engine.filters.CountingVariantFilter
 
getFilteredRecords() - Method in class picard.filter.CountingFilter
Gets the number of records that have been filtered out thus far.
getFilteredSize() - Method in class org.broadinstitute.hellbender.utils.activityprofile.BandPassActivityProfile
Get the filter size (which is the size of each wing of the band, minus the center point)
getFilterLine(String) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFHeaderLines
 
getFilterLine(String) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVCFHeaderLines
 
getFilterLines() - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFHeaderLines
 
getFilters() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.BasicValidationResult
 
getFinalRecalibrationTables() - Method in class org.broadinstitute.hellbender.utils.recalibration.BaseRecalibrationEngine
Get the final recalibration tables, after finalizeData() has been called This returns the finalized recalibration table collected by this engine.
getFinalSampleDB() - Method in class org.broadinstitute.hellbender.utils.samples.SampleDBBuilder
 
getFinalVariantReadPosition(GATKRead, int) - Static method in class org.broadinstitute.hellbender.tools.walkers.annotator.ReadPosRankSumTest
Get the position of a variant within a read with respect to the closer end, accounting for hard clipped bases and low quality ends Used by ReadPosRankSum annotations
getFingerprintFile() - Method in class picard.fingerprint.MatchResults
 
getFingerprintIdDetailsStringFunction(CrosscheckMetric.DataType) - Static method in class picard.fingerprint.CrosscheckFingerprints
 
getFingerprintPanels() - Method in class picard.fingerprint.Snp
 
getFirstAlignedBaseOffset(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Returns the offset (0-based index) of the first base in the read that is aligned against the reference.
getFirstAlignedReadPosition(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Returns the first position (1-based) on the original read in 5to3 prime orientation that is aligned against a base on the reference.
getFirstContig() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.PartitionStatistics
 
getFirstContigID() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.PartitionBounds
 
getFirstInsertionOffset(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
If a read starts in INSERTION, returns the first element length.
getFirstLocation() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.PartitionStatistics
 
getFirstOfPair(int) - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.HitsForInsert
 
getFirstRefIndex() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.EmptyFragment
 
getFirstRefIndex() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Fragment
 
getFirstRefIndex() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Pair
 
getFirstRefIndex() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.PairedEnds
 
getFirstSnp() - Method in class picard.fingerprint.HaplotypeBlock
Gets the arbitrarily first SNP in the haplotype.
getFirstStart() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.PartitionBounds
 
getFirstStartPosition() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.EmptyFragment
 
getFirstStartPosition() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Fragment
 
getFirstStartPosition() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Pair
 
getFirstStartPosition() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.PairedEnds
 
getFirstVertex() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.Path
Get the first vertex in this path
getFloatIterator(int, File) - Static method in class picard.illumina.parser.readers.MMapBackedIteratorFactory
 
getForceSort() - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.SamAlignmentMerger
 
getForceSort() - Method in class picard.sam.SamAlignmentMerger
 
getFormat() - Method in class org.broadinstitute.hellbender.utils.report.GATKReportColumn
 
getFormatLine(String) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFHeaderLines
 
getFormatLine(String) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVCFHeaderLines
 
getFormatLines() - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFHeaderLines
 
getForwardBases() - Method in class org.broadinstitute.hellbender.engine.ReferenceContext
Get the bases in this context, from the beginning of the interval to the end of the window.
getFounderGenotypes(VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.PedigreeAnnotation
 
getFounderIds() - Method in class org.broadinstitute.hellbender.utils.samples.SampleDB
 
getFraction(int) - Method in class org.broadinstitute.hellbender.tools.spark.utils.IntHistogram.CDF
 
getFractionUnexpectedAlleleObs() - Method in class picard.fingerprint.HaplotypeProbabilitiesFromSequence
 
getFragment(int) - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.HitsForInsert
 
getFragmentLength() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Returns the observed length of the read's fragment (equivalent to TLEN in SAM).
getFragmentLength() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getFragmentOrdinal() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.ReadEvidence
 
getFullPath() - Method in class org.broadinstitute.hellbender.utils.io.Resource
 
getFullReference(IndexedFastaSequenceFile) - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
See #getActiveRegionReference but using the span including regions not the extended span
getFullReference(IndexedFastaSequenceFile, int) - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
See #getActiveRegionReference but using the span including regions not the extended span
getFullReferenceWithPadding() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResultSet
Returns the current full reference with padding.
getFuncotatorLargeDataValidationTestInputPath() - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest
A path where the test inputs for the Funcotator LargeDataValidationTest are stored.
getFunctionValueAccuracy() - Method in class org.broadinstitute.hellbender.utils.solver.UnivariateSolverSpecifications
 
getG() - Method in class picard.illumina.parser.FourChannelIntensityData
 
getGA4GHEnd() - Method in class org.broadinstitute.hellbender.utils.SimpleInterval
 
getGA4GHStart() - Method in class org.broadinstitute.hellbender.utils.SimpleInterval
 
getGapExtensionProb() - Method in class org.broadinstitute.hellbender.utils.baq.BAQ
 
getGapOpenProb() - Method in class org.broadinstitute.hellbender.utils.baq.BAQ
 
getGATKConfig() - Method in class org.broadinstitute.hellbender.utils.config.ConfigFactory
Quick way to get the GATK configuration.
getGCContent() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AnnotationSet
 
getGcContent() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getGcContent() - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
getGCPTestInputPath() - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest
A GCS path where the test inputs are stored.
getGCPTestProject() - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest
name of the google cloud project that stores the data and will run the code
getGCPTestStaging() - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest
A writable GCS path where java files can be cached and temporary test files can be written, of the form gs://bucket/, or gs://bucket/path/.
getGene() - Method in class picard.annotation.Gene.Transcript
 
getGeneId() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
getGeneName() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
getGenesForPickTranscripts() - Method in class picard.analysis.directed.RnaSeqMetricsCollector.PerUnitRnaSeqMetricsCollector
Derived class may override this method in order to return a different set of genes for picking transcripts for computing coverage, or to cache the value returned by geneOverlapDetector.getAll(), because it can be expensive to compute repeatedly.
getGeneStatus() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
getGeneTranscriptType() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getGeneType() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
getGenomeChange() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getGenomeLocation() - Method in class org.broadinstitute.hellbender.utils.haplotype.Haplotype
Get the span of this haplotype (may be null)
getGenomeLocParser() - Method in class org.broadinstitute.hellbender.utils.GenomeLocSortedSet
Gets the GenomeLocParser used to create this sorted set.
getGenomeOffset() - Method in class org.broadinstitute.hellbender.utils.locusiterator.AlignmentStateMachine
What is the current offset w.r.t.
getGenomePosition() - Method in class org.broadinstitute.hellbender.utils.locusiterator.AlignmentStateMachine
Get the position (1-based as standard) of the current alignment on the genome w.r.t.
getGenomicEndLocation() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
getGenomicPhase() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
getGenomicPosition() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
getGenomicStartLocation() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
getGenomicStrand() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
getGenotypeAnnotations() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotatorEngine
Returns the list of genotype annotations that will be applied.
getGenotypeDouble(Genotype, String, double) - Static method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasUtils
getGenotypeString(Genotype, String) - Static method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasUtils
Get field value as a string.
getGLModel(VariantContext) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerGenotypingEngine
 
getGoodMappings() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigAlignmentsConfigPicker.GoodAndBadMappings
 
getGoogleServiceAccountKeyPath() - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest
A local path where the service account credentials are stored
getGraph() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResult
 
getGraph() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.Path
Get the graph of this path
getGroupMap(DocWorkUnit) - Method in class org.broadinstitute.hellbender.utils.help.GATKHelpDoclet
Adds a super-category so that we can custom-order the categories in the doc index
getGroupMap(DocWorkUnit) - Method in class picard.util.help.PicardHelpDoclet
Adds a super-category so that we can custom-order the categories in the doc index
getHaplotype(Snp) - Method in class picard.fingerprint.HaplotypeMap
Queries a HaplotypeBlock by Snp object.
getHaplotype(String) - Method in class picard.fingerprint.HaplotypeMap
Queries a HaplotypeBlock by Snp name.
getHaplotype(String, int) - Method in class picard.fingerprint.HaplotypeMap
Queries a HaplotypeBlock by Snp chromosome and position.
getHaplotype() - Method in class picard.fingerprint.HaplotypeProbabilities
Returns the haplotype for which the probabilities apply.
getHaplotypeCount() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResultSet
Returns the number of haplotypes in the assembly result set.
getHaplotypeFrequencies() - Method in class picard.fingerprint.HaplotypeBlock
Gets the set of haplotype frequencies.
getHaplotypeFrequency(int) - Method in class picard.fingerprint.HaplotypeBlock
Gets the frequency of the i'th diploid haplotype where haplotypes are ordered accorinding to DiploidHaplotype.
getHaplotypeList() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResultSet
Returns the haplotypes as a list.
getHaplotypeReadGroupID() - Method in class org.broadinstitute.hellbender.utils.haplotype.HaplotypeBAMDestination
Get the read group ID that is used by this writer when writing halpotypes as reads.
getHaplotypes() - Method in class picard.fingerprint.HaplotypeMap
Returns an unmodifiable collection of all the haplotype blocks in the map.
getHaplotypeSampleTag() - Method in class org.broadinstitute.hellbender.utils.haplotype.HaplotypeBAMDestination
Get the sample tag that is used by this writer when writing halpotypes as reads.
getHeadAlignment() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignedContig
 
getHeadAlignment() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments
 
getHeader() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
Returns the header for the reads in this region.
getHeader(FeatureInput<T>) - Method in class org.broadinstitute.hellbender.engine.FeatureContext
Gets the header associated with the provided FeatureInput
getHeader() - Method in class org.broadinstitute.hellbender.engine.FeatureDataSource
Gets the header associated with this data source
getHeader(FeatureInput<T>) - Method in class org.broadinstitute.hellbender.engine.FeatureManager
Get the header associated with a particular FeatureInput
getHeader() - Method in class org.broadinstitute.hellbender.engine.MultiVariantDataSource
Gets the merged header associated with this data source
getHeader() - Method in class org.broadinstitute.hellbender.engine.ReadsDataSource
Returns the SAM header for this data source.
getHeader(String, String) - Method in class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSource
Loads the header using Hadoop-BAM.
getHeader(String) - Static method in class org.broadinstitute.hellbender.engine.spark.datasources.VariantsSparkSource
 
getHeader() - Method in class org.broadinstitute.hellbender.tools.spark.bwa.BwaSparkEngine
 
getHeader() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils.FastqRead
Returns the header line of this Fastq read starting with '@' followed by the read id and description separated by tab characters.
getHeader() - Method in class org.broadinstitute.hellbender.utils.codecs.table.TableFeature
Gets the column names.
getHeader() - Method in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvTableFeature
Get the header from this XsvTableFeature.
getHeader() - Method in class org.broadinstitute.hellbender.utils.read.ArtificialBAMBuilder
 
getHeader() - Method in class org.broadinstitute.hellbender.utils.read.ArtificialReadIterator
 
getHeader() - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
getHeader() - Method in class picard.fingerprint.FingerprintChecker
 
getHeader() - Method in class picard.fingerprint.HaplotypeMap
 
getHeader() - Method in class picard.sam.AbstractAlignmentMerger
 
getHeaderBroadcast() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoveryInputMetaData.SampleSpecificData
 
getHeaderForFeatures(FeatureInput<T>) - Method in class org.broadinstitute.hellbender.engine.GATKTool
Returns the header for the specified source of Features
getHeaderForReads() - Method in class org.broadinstitute.hellbender.engine.GATKTool
Returns the SAM header for the reads data source.
getHeaderForReads() - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
 
getHeaderForSAMWriter() - Method in class org.broadinstitute.hellbender.engine.GATKTool
Returns the SAM header suitable for writing SAM/BAM/CRAM files produced by this tool.
getHeaderForVariants() - Method in class org.broadinstitute.hellbender.engine.MultiVariantWalker
Gets the header associated with our driving source of variants as a VCFHeader.
getHeaderForVariants() - Method in class org.broadinstitute.hellbender.engine.spark.VariantWalkerSpark
Gets the header associated with our driving source of variants as a VCFHeader.
getHeaderForVariants() - Method in class org.broadinstitute.hellbender.engine.VariantWalker
Gets the header associated with our driving source of variants as a VCFHeader.
getHeaderForVariants() - Method in class org.broadinstitute.hellbender.engine.VariantWalkerBase
Return the VCFHeader to be used for the driving variants for this tool.
getHeaderSize() - Method in class picard.illumina.parser.readers.CbclReader
 
getHeaderWithoutLocationColumns() - Method in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvLocatableTableCodec
Get the header from this XsvLocatableTableCodec without the columns that contain location information.
getHeaderWithoutLocationColumns() - Method in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvTableFeature
Get the header from this XsvTableFeature without the columns that contain location information.
getHelpDoc() - Method in enum org.broadinstitute.hellbender.tools.walkers.vqsr.TensorType
 
getHelpDoc() - Method in enum picard.sam.FilterSamReads.Filter
 
getHelpDoc() - Method in enum picard.sam.RevertSam.FileType
 
getHelpDoc() - Method in enum picard.util.IntervalListTools.Action
 
getHet(int, int) - Static method in enum picard.vcf.GenotypeConcordanceStates.CallState
 
getHetCount(Allele) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.HeterozygosityCalculator
Get the count of heterozygotes in vc for a specific altAllele (both reference and non-reference hets, e.g.
getHeterogyzousGenotype() - Method in class picard.fingerprint.Snp
 
getHets() - Method in class org.broadinstitute.hellbender.utils.GenotypeCounts
 
getHighQualityDepthHistogram() - Method in class picard.analysis.AbstractWgsMetricsCollector
 
getHistogram(long[], String, String) - Method in class picard.analysis.AbstractWgsMetricsCollector
 
getHom(int) - Static method in enum picard.vcf.GenotypeConcordanceStates.CallState
 
getHom(int) - Static method in enum picard.vcf.GenotypeConcordanceStates.TruthState
 
getHomologyForwardStrandRep() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications
 
getHomozygousAllele1Genotype() - Method in class picard.fingerprint.Snp
 
getHomozygousAllele2Genotype() - Method in class picard.fingerprint.Snp
 
getHoms() - Method in class org.broadinstitute.hellbender.utils.GenotypeCounts
 
getHugoSymbol() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getId() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils.FastqRead
 
getId() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.SeqVertex
Get the unique ID for this SeqVertex
getId() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.FalsePositiveRecord
 
getID(SAMReadGroupRecord) - Static method in class org.broadinstitute.hellbender.utils.recalibration.covariates.ReadGroupCovariate
Get the ID of the readgroup.
getID() - Method in class org.broadinstitute.hellbender.utils.samples.Sample
 
getId() - Method in class org.broadinstitute.hellbender.utils.UniqueIDWrapper
 
getIdealSpan() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmer.Result
Returns the ideal trimming span.
getIDString(NovelAdjacencyAndAltHaplotype, boolean) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.BreakEndVariantType
 
getIndelCounter() - Method in class picard.vcf.GenotypeConcordance
 
getIndelFalsePositiveRate() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.FalsePositiveRecord
 
getIndelFalsePositives() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.FalsePositiveRecord
 
getIndentString(int) - Method in class org.broadinstitute.hellbender.engine.filters.CountingReadFilter
 
getIndentString(int) - Method in class org.broadinstitute.hellbender.engine.filters.CountingVariantFilter
 
getIndex(SVInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree
Find the rank of the specified interval.
getIndex() - Method in class org.broadinstitute.hellbender.tools.spark.transforms.markduplicates.MarkDuplicatesSparkUtils.IndexPair
 
getIndex() - Method in class org.broadinstitute.hellbender.utils.solver.UnivariateSolverJobDescription
 
getIndexTemplateName() - Method in class org.broadinstitute.hellbender.utils.help.GATKHelpDoclet
Return the name of the freemarker template to be used for the index generated by Barclay.
getIndexTemplateName() - Method in class picard.util.help.PicardHelpDoclet
Return the name of the freemarker template to be used for the index generated by Barclay.
getIndices() - Method in class picard.illumina.parser.ReadStructure.Substructure
 
getIndividualId() - Method in class picard.pedigree.PedFile.PedTrio
 
getInfo() - Method in class picard.fingerprint.Fingerprint
 
getInfoAnnotations() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotatorEngine
Returns the list of info annotations that will be applied.
getInfoLine(String) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFHeaderLines
 
getInfoLine(String) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVCFHeaderLines
 
getInfoLines() - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFHeaderLines
 
getInfoString() - Method in class org.broadinstitute.hellbender.tools.funcotator.DataSourceFuncotationFactory
 
getInfoString() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationFactory
 
getInitialGuess() - Method in class org.broadinstitute.hellbender.utils.solver.UnivariateSolverJobDescription
 
getInput() - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
getInputArguments() - Method in class org.broadinstitute.hellbender.tools.examples.metrics.multi.ExampleCollectMultiMetricsSpark
Return the embedded argument collection.
getInputArguments() - Method in class org.broadinstitute.hellbender.tools.examples.metrics.single.ExampleCollectSingleMetricsSpark
Return the embedded argument collection.
getInputArguments() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectInsertSizeMetricsSpark
 
getInputArguments() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectQualityYieldMetricsSpark
 
getInputArguments() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.MetricsCollectorSparkTool
To be implemented by subclasses; return the fully initialized and populated argument collection that will be passed to the collector
getInputBuffer() - Method in class org.broadinstitute.hellbender.utils.runtime.InputStreamSettings
 
getInputFile() - Method in class org.broadinstitute.hellbender.utils.runtime.InputStreamSettings
 
getInputFile() - Method in class picard.fingerprint.FingerprintResults
 
getInputStream() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEndsForMarkDuplicatesCodec
 
getInputStream() - Method in class picard.sam.markduplicates.util.ReadEndsForMarkDuplicatesCodec
 
getInputStream() - Method in class picard.sam.markduplicates.util.RepresentativeReadIndexerCodec
 
getInsertedSequence() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVContext
Returns the inserted sequence.
getInsertedSequenceForwardStrandRep() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications
 
getInsertionMappings() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments
 
getInsertionsKeySet() - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.ReadCovariates
 
getInsertionsKeySet(int) - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.ReadCovariates
 
getInstance() - Static method in class org.broadinstitute.hellbender.tools.walkers.annotator.RMSMappingQuality
 
getInstance(VariantContext, int, int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculatorProvider
Returns a AF calculator capable to handle a particular variant-context.
getInstance(int, int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculatorProvider
Returns a AF calculator given the required homogeneous ploidy and maximum alt allele count.
getInstance(VariantContext, int, int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.ConcurrentAFCalculatorProvider
 
getInstance(int, int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.ConcurrentAFCalculatorProvider
 
getInstance(VariantContext, int, int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.FixedAFCalculatorProvider
 
getInstance(int, int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.FixedAFCalculatorProvider
 
getInstance(int, int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.GeneralPloidyFailOverAFCalculatorProvider
Returns a AF calculator given the required homogeneous ploidy and maximum alt allele count.
getInstance(int, int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeLikelihoodCalculators
Returns an instance given its ploidy and the number of alleles.
getInstance(String) - Static method in class org.broadinstitute.hellbender.utils.bwa.BwaMemIndexCache
Returns a BwaMemIndex instance that corresponds to given index image file.
getInstance() - Static method in class org.broadinstitute.hellbender.utils.config.ConfigFactory
 
getInstance() - Static method in class org.broadinstitute.hellbender.utils.smithwaterman.SmithWatermanJavaAligner
return the stateless singleton instance of SmithWatermanJavaAligner
getInt(int) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Returns the int value in a column by its index.
getInt(String) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Returns the int value in a column by its index.
getInt(Enum<?>) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Returns the int value of a column by its name.
getIntegerCopyNumberStateList() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CopyNumberPosteriorDistribution
 
getIntegerField(String) - Method in class picard.util.DelimitedTextFileWithHeaderIterator.Row
 
getIntegerField(String) - Method in class picard.util.TabbedTextFileWithHeaderParser.Row
 
getIntegerIterator(int, File) - Static method in class picard.illumina.parser.readers.MMapBackedIteratorFactory
 
getIntermediateStopSites(SimpleInterval, int) - Static method in class org.broadinstitute.hellbender.tools.walkers.CombineGVCFs
 
getInternalVariantId() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvType
 
getInterval() - Method in class org.broadinstitute.hellbender.engine.FeatureContext
Gets our query interval (the interval that all Features returned by this FeatureContext overlap).
getInterval() - Method in class org.broadinstitute.hellbender.engine.ReadsContext
Gets the interval spanned by this context (returned reads will overlap this interval).
getInterval() - Method in class org.broadinstitute.hellbender.engine.ReferenceContext
Get the location on the reference represented by this context, without including any extra bases of requested context around this interval.
getInterval() - Method in interface org.broadinstitute.hellbender.engine.Shard
 
getInterval() - Method in class org.broadinstitute.hellbender.engine.ShardBoundary
 
getInterval() - Method in class org.broadinstitute.hellbender.engine.ShardBoundaryShard
 
getInterval() - Method in class org.broadinstitute.hellbender.engine.ShardToMultiIntervalShardAdapter
 
getInterval() - Method in class org.broadinstitute.hellbender.engine.spark.IntervalWalkerContext
 
getInterval() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AlleleFractionSegment
 
getInterval() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AllelicCount
 
getInterval() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AnnotatedInterval
 
getInterval() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CopyRatio
 
getInterval() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CopyRatioSegment
 
getInterval() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.IntegerCopyNumberSegment
 
getInterval() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.IntervalCopyNumberGenotypingData
 
getInterval() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.ModeledSegment
 
getInterval() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.MultidimensionalSegment
 
getInterval() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.SimpleCount
 
getInterval() - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedInterval
Returns a copy
getInterval() - Method in class org.broadinstitute.hellbender.tools.DownsampleableSparkReadShard
 
getInterval() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.StrandedInterval
 
getInterval() - Method in interface org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree.Entry
 
getInterval() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.BasicValidationResult
 
getInterval() - Method in class org.broadinstitute.hellbender.utils.reference.ReferenceBases
 
getIntervalExclusionPadding() - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.IntervalArgumentCollection
Get the interval exclusion padding specified on the command line.
getIntervalFile() - Method in class picard.analysis.CollectWgsMetrics.CollectWgsMetricsIntervalArgumentCollection
 
getIntervalFile() - Method in interface picard.cmdline.argumentcollections.IntervalArgumentCollection
 
getIntervalId() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.KmerAndInterval
 
getIntervalId() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.QNameAndInterval
 
getIntervalList() - Method in class picard.fingerprint.HaplotypeMap
Returns an IntervalList with an entry for every SNP in every Haplotype in the map.
getIntervalMergingRule() - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.IntervalArgumentCollection
Get the interval merging rule specified on the command line.
getIntervalPadding() - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.IntervalArgumentCollection
Get the interval padding specified on the command line.
getIntervals(SAMSequenceDictionary) - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.IntervalArgumentCollection
Get the intervals specified on the command line.
getIntervals() - Method in class org.broadinstitute.hellbender.engine.MultiIntervalLocalReadShard
 
getIntervals() - Method in interface org.broadinstitute.hellbender.engine.MultiIntervalShard
 
getIntervals() - Method in class org.broadinstitute.hellbender.engine.ShardToMultiIntervalShardAdapter
 
getIntervals() - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
 
getIntervals(JavaSparkContext) - Method in class org.broadinstitute.hellbender.engine.spark.IntervalWalkerSpark
Loads intervals and the corresponding reads, reference and features into a JavaRDD.
getIntervals() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.collections.AbstractLocatableCollection
 
getIntervalSetRule() - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.IntervalArgumentCollection
Get the interval set rule specified on the command line.
getIntervalsForTraversal() - Method in class org.broadinstitute.hellbender.engine.TraversalParameters
 
getIntervalsToExamine() - Method in class picard.analysis.CollectWgsMetrics
Gets the intervals over which we will calculate metrics.
getIntervalStrings() - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.IntervalArgumentCollection
Subclasses must provide a -L argument and override this to return the results of that argument.
getIntervalStrings() - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.OptionalIntervalArgumentCollection
 
getIntervalStrings() - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.RequiredIntervalArgumentCollection
 
getIntervalsWithFlanks(GenomeLocParser, List<GenomeLoc>, int) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Returns a list of intervals between the passed int locs.
getIntervalsWithFlanks(List<SimpleInterval>, int, SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Pads the provided intervals by the specified amount, sorts the resulting intervals, and merges intervals that are adjacent/overlapping after padding.
getKBest(int) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.AggregatedSubHaplotypeFinder
 
getKernel() - Method in class org.broadinstitute.hellbender.utils.activityprofile.BandPassActivityProfile
Get the kernel of this band pass filter.
getKey() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.KmerAndInterval
 
getKey() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.QNameAndInterval
 
getKey() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.KmerAndCount
 
getKey() - Method in class org.broadinstitute.hellbender.utils.KV
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_BaseQualityRankSumTest
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_FisherStrand
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_InbreedingCoeff
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_MappingQualityRankSumTest
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_QualByDepth
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_ReadPosRankSumTest
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RMSMappingQuality
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_StrandOddsRatio
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.BaseQualityRankSumTest
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.ChromosomeCounts
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.ClippingRankSumTest
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.Coverage
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.DepthPerAlleleBySample
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.DepthPerSampleHC
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.ExcessHet
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.FisherStrand
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.GenotypeSummaries
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.InbreedingCoeff
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.LikelihoodRankSumTest
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.MappingQualityRankSumTest
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.MappingQualityZero
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.OxoGReadCounts
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.PerAlleleAnnotation
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.PossibleDeNovo
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.QualByDepth
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.ReadPosRankSumTest
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.ReferenceBases
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.RMSMappingQuality
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.SampleList
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.StrandArtifact
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.StrandBiasBySample
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.StrandOddsRatio
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.TandemRepeat
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.UniqueAltReadCount
 
getKeyNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotation
Return the keys
getKeySet(int, EventType) - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.ReadCovariates
Get the keys for all covariates at read position for error model
getKeySet(EventType) - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.ReadCovariates
 
getKingdomTaxonId() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenTaxonScore
 
getKmerCount(Kmer) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.KMerCounter
Get the count of kmer in this kmer counter
getKmers(Collection<SeqVertex>) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.GraphUtils
Get the list of kmers as byte[] from the vertices in the graph
getKmerSize() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResult
 
getKmerSize() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
How big of a kmer did we use to create this graph?
getKmerSize() - Method in interface org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KmerSearchableGraph
The kmer-size of indexed kmers.
getKmerSize() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.MultiDeBruijnVertex
Get the kmer size for this DeBruijnVertex
getKmersWithCountsAtLeast(int) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.KMerCounter
Get kmers that have minCount or greater in this counter
getKvReadContextData() - Method in class org.broadinstitute.hellbender.utils.test.ReadsPreprocessingPipelineTestData
 
getKvReadiVariantBroken() - Method in class org.broadinstitute.hellbender.utils.test.ReadsPreprocessingPipelineTestData
The dataflow version is currently broken (Issue #795).
getKvReadiVariantFixed() - Method in class org.broadinstitute.hellbender.utils.test.ReadsPreprocessingPipelineTestData
 
getKvReadsRefBases() - Method in class org.broadinstitute.hellbender.utils.test.ReadsPreprocessingPipelineTestData
 
getKvReadVariant() - Method in class org.broadinstitute.hellbender.utils.test.ReadsPreprocessingPipelineTestData
 
getKvRefBasesiReads() - Method in class org.broadinstitute.hellbender.utils.test.ReadsPreprocessingPipelineTestData
 
getKvRefShardiReads() - Method in class org.broadinstitute.hellbender.utils.test.ReadsPreprocessingPipelineTestData
 
getKvVariantShardRead() - Method in class org.broadinstitute.hellbender.utils.test.ReadsPreprocessingPipelineTestData
 
getKvVariantShardVariant() - Method in class org.broadinstitute.hellbender.utils.test.ReadsPreprocessingPipelineTestData
 
getLane() - Method in class picard.illumina.parser.ClusterData
 
getLane() - Method in class picard.illumina.parser.IlluminaFileUtil
Return the lane we're inspecting
getLane() - Method in class picard.illumina.parser.readers.AbstractIlluminaPositionFileReader
 
getLaneNumber() - Method in class picard.illumina.parser.readers.TileMetricsOutReader.IlluminaLaneTileCode
 
getLaneNumber() - Method in class picard.illumina.parser.readers.TileMetricsOutReader.IlluminaTileMetrics
 
getLaneNumber() - Method in class picard.illumina.parser.Tile
Returns the number of this tile's parent lane.
getLaneTileCode() - Method in class picard.illumina.parser.readers.TileMetricsOutReader.IlluminaTileMetrics
 
getLastAlignedReadPosition(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Returns the last position (1-based) on the original unclipped nor reverse-complemented read that is mapped against the reference.
getLastContig() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.PartitionStatistics
 
getLastContigID() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.PartitionBounds
 
getLastEnd() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.PartitionBounds
 
getLastInsertionOffset(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
If a read ends in INSERTION, returns the last element length.
getLastLocation() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.PartitionStatistics
 
getLastThreeFields(String, char, int[]) - Static method in class picard.sam.util.ReadNameParser
Given a string, splits the string by the delimiter, and returns the the last three fields parsed as integers.
getLastVertex() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.Path
Get the final vertex of the path
getLCA(Collection<Integer>) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTree
Get lowest common ancester of the set of given nodes.
getLeft() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.PairedStrandedIntervals
 
getLeftClipPoint(byte[]) - Method in class org.broadinstitute.hellbender.transformers.BaseQualityClipReadTransformer
Returns left clip point or -1 if no clip
getLeftJustifiedLeftRefLoc() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.NovelAdjacencyAndAltHaplotype
 
getLeftJustifiedRightRefLoc() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.NovelAdjacencyAndAltHaplotype
 
getLegalSizeAbove(long, double) - Static method in class org.broadinstitute.hellbender.tools.spark.utils.SetSizeUtils
Computes next largest legal table size for a given number of elements, accounting for load factor
getLegalSizeAbove(long) - Static method in class org.broadinstitute.hellbender.tools.spark.utils.SetSizeUtils
 
getLegalSizeBelow(long, double) - Static method in class org.broadinstitute.hellbender.tools.spark.utils.SetSizeUtils
Computes next smallest legal table size for a given number of elements, accounting for load factor
getLegalSizeBelow(long) - Static method in class org.broadinstitute.hellbender.tools.spark.utils.SetSizeUtils
 
getLength() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTreeNode
 
getLength() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVInterval
 
getLength() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.TextMDCodec.DeletionMDElement
 
getLength() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.TextMDCodec.MatchMDElement
 
getLength() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.TextMDCodec.MDElement
 
getLength() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.TextMDCodec.MismatchMDElement
 
getLength() - Method in class org.broadinstitute.hellbender.utils.clipping.ClippingOp
 
getLength() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
getLength() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getLengthForDupTandem(NovelAdjacencyAndAltHaplotype) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.NovelAdjacencyAndAltHaplotype
Clean expansion of repeat 1 -> 2, or complex expansion, or expansion of 1 repeat on ref to 2 repeats on alt with inserted sequence in between the 2 repeats
getLengthOf(int) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTree
 
getLengthOfImmediatelyFollowingIndel() - Method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Get the length of an immediately following insertion or deletion event, or 0 if no such event exists Only returns a positive value when this pileup element is immediately before an indel.
getLetter() - Method in enum org.broadinstitute.hellbender.tools.funcotator.AminoAcid
 
getLevel() - Method in class org.broadinstitute.hellbender.tools.walkers.contamination.ContaminationRecord
 
getLibrary(GATKRead, SAMFileHeader) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Returns the library associated with the provided read's read group.
getLibraryId(SAMRecord) - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.LibraryIdGenerator
Get the library ID for the given SAM record.
getLibraryId() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
getLibraryId() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Pair
 
getLibraryId(SAMRecord) - Method in class picard.sam.markduplicates.util.LibraryIdGenerator
Get the library ID for the given SAM record.
getLibraryId() - Method in class picard.sam.markduplicates.util.PhysicalLocationForMateCigar
 
getLibraryId() - Method in class picard.sam.markduplicates.util.ReadEnds
 
getLibraryId() - Method in interface picard.sam.util.PhysicalLocation
 
getLibraryId() - Method in class picard.sam.util.PhysicalLocationInt
 
getLibraryIdGenerator() - Method in class picard.sam.markduplicates.MarkDuplicatesWithMateCigarIterator
 
getLibraryIdsMap() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.LibraryIdGenerator
 
getLibraryIdsMap() - Method in class picard.sam.markduplicates.util.LibraryIdGenerator
 
getLibraryName(String) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata
 
getLibraryName() - Method in enum org.broadinstitute.hellbender.utils.R.RScriptLibrary
 
getLibraryName(SAMFileHeader, SAMRecord) - Static method in class org.broadinstitute.hellbender.utils.read.markduplicates.LibraryIdGenerator
Gets the library name from the header for the record.
getLibraryName(SAMFileHeader, String) - Static method in class org.broadinstitute.hellbender.utils.read.markduplicates.LibraryIdGenerator
Gets the library name from the header for the read group id.
getLibraryName(SAMFileHeader, SAMRecord) - Static method in class picard.sam.markduplicates.util.LibraryIdGenerator
Gets the library name from the header for the record.
getLibraryNameToStatisticsMap() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.PartitionStatistics
 
getLibraryStatistics(String) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata
 
getLikelihoods() - Method in class picard.fingerprint.HaplotypeProbabilities
Returns the likelihoods, in order, of the AA, Aa and aa haplotypes given the evidence
getLikelihoods() - Method in class picard.fingerprint.HaplotypeProbabilitiesFromGenotype
 
getLikelihoods() - Method in class picard.fingerprint.HaplotypeProbabilityOfNormalGivenTumor
 
getLineNumber() - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Returns the line number for this data-line.
getLoc() - Method in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfileState
Get the locus associated with the ActivityProfileState
getLocation() - Method in class org.broadinstitute.hellbender.engine.AlignmentContext
 
getLocation() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence
 
getLocation() - Method in class org.broadinstitute.hellbender.utils.codecs.table.TableFeature
Gets the position for the feature.
getLocation() - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
 
getLocation() - Method in class org.broadinstitute.hellbender.utils.haplotype.Haplotype
Get the span of this haplotype (may be null)
getLocation() - Method in interface org.broadinstitute.hellbender.utils.HasGenomeLocation
 
getLocation() - Method in class org.broadinstitute.hellbender.utils.locusiterator.AlignmentStateMachine
Gets #getGenomePosition but as a 1 bp GenomeLoc
getLocation() - Method in class org.broadinstitute.hellbender.utils.pileup.ReadPileup
 
getLocations(ReadEndsForMateCigar) - Method in class picard.sam.markduplicates.util.MarkQueue
Returns the nonDuplicateReadEndsSet of read ends that should be considered for tracking optical duplicates.
getLocationSet() - Method in class picard.sam.markduplicates.util.ReadEndsForMateCigar
 
getLocForOffset(SimpleInterval, int) - Method in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfile
Helper function that gets the interval for a site offset from relativeLoc, protecting ourselves from falling off the edge of the contig.
getLociToGenotype(Collection<Fingerprint>) - Method in class picard.fingerprint.FingerprintChecker
Takes a set of fingerprints and returns an IntervalList containing all the loci that can be productively examined in sequencing data to compare to one or more of the fingerprints.
getLocusIterator(SamReader) - Method in class picard.analysis.CollectWgsMetrics
Creates AbstractLocusIterator implementation according to this#USE_FAST_ALGORITHM value.
getLocusLevel() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getLocusLevel() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
getLocusResults() - Method in class picard.fingerprint.MatchResults
 
getLOD() - Method in class picard.fingerprint.MatchResults
 
getLodMostProbableGenotype() - Method in class picard.fingerprint.HaplotypeProbabilities
Returns the LOD score between the most probable haplotype and the second most probable.
getLodNT() - Method in class picard.fingerprint.MatchResults
 
getLodTN() - Method in class picard.fingerprint.MatchResults
 
getLog10LikelihoodOfAFEq0() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculationResult
Get the log10 unnormalized -- across all ACs -- likelihood of AC == 0 for all alleles
getLog10LikelihoodOfAFGT0() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculationResult
Get the log10 unnormalized -- across all ACs -- likelihood of AC > 0 for any alleles
getLog10Likelihoods() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.ExactACset
 
getLog10PNonRef(VariantContext, int, int, double[]) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculator
Compute the probability of the alleles segregating given the genotype likelihoods of the samples in vc
getLog10PNonRef(VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AlleleFrequencyCalculator
 
getLog10PNonRef(VariantContext, int, int, double[]) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AlleleFrequencyCalculator
Compute the probability of the alleles segregating given the genotype likelihoods of the samples in vc
getLog10PosteriorOfAFEq0() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculationResult
Get the log10 normalized -- across all ACs -- posterior probability of AC == 0 for all alleles
getLog10PosteriorOfAFEq0ForAllele(Allele) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculationResult
Returns the log10 probability that allele is not segregating Note that this function is p not segregating so that we can store internally the log10 value of AF == 0, which grows very quickly negative and yet has sufficient resolution for high confidence tests.
getLog10PosteriorOfAFGT0() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculationResult
Get the log10 normalized -- across all ACs -- posterior probability of AC > 0 for any alleles
getLog10PriorOfAFEq0() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculationResult
Get the log10 unnormalized -- across all ACs -- prior probability of AC == 0 for all alleles
getLog10PriorOfAFGT0() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculationResult
Get the log10 unnormalized -- across all ACs -- prior probability of AC > 0
getLog2CopyRatioSimplePosteriorSummary() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.ModeledSegment
 
getLog2CopyRatioValue() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CopyRatio
 
getLog2CopyRatioValues() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.collections.CopyRatioCollection
 
getLog_of_base() - Method in class picard.util.MathUtil.LogMath
 
getLogLikelihoodArray() - Method in class org.broadinstitute.hellbender.utils.pairhmm.PairHMM
Return the results of the computeLogLikelihoods function
getLogLikelihoods() - Method in class picard.fingerprint.HaplotypeProbabilities
 
getLogLikelihoods() - Method in class picard.fingerprint.HaplotypeProbabilitiesFromContaminatorSequence
 
getLogProbabilityForIndex(int) - Method in class org.broadinstitute.hellbender.utils.genotyper.ProbabilityVector
Return log Probability for original index i
getLogValue(double) - Method in class picard.util.MathUtil.LogMath
Returns the log-representation of the provided decimal value.
getLogValue(double[]) - Method in class picard.util.MathUtil.LogMath
Returns the log-representation of the provided decimal array.
getLong() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerShort
 
getLong(int) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Returns the long value in a column by its index.
getLong(String) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Returns the long value in a column by its index.
getLong(Enum<?>) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Returns the long value in a column by its name expressed as an enum constant.
getLongIterator(int, File) - Static method in class picard.illumina.parser.readers.MMapBackedIteratorFactory
 
getLower() - Method in class org.broadinstitute.hellbender.utils.mcmc.PosteriorSummary
 
getMaf() - Method in class picard.fingerprint.HaplotypeBlock
Returns the minor allele frequency of this haplotype.
getMaf() - Method in class picard.fingerprint.Snp
 
getMapping() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils.FastqRead
 
getMappingQual() - Method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Get the mapping quality of the read of this element
getMappingQuality() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.ReadEvidence
 
getMappingQuality() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
getMappingQuality() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getMappingQuals() - Method in class org.broadinstitute.hellbender.utils.pileup.ReadPileup
Get an array of the mapping qualities.
getMappingsDiffer() - Method in class org.broadinstitute.hellbender.utils.read.SamComparison
 
getMappingsDiffer() - Method in class picard.sam.CompareSAMs
 
getMappingsMatch() - Method in class org.broadinstitute.hellbender.utils.read.SamComparison
 
getMappingsMatch() - Method in class picard.sam.CompareSAMs
 
getMask() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerBloomFilter
 
getMask() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerSet
 
getMask(byte[], int) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerShort
 
getMaskedBaseCount(byte[], int, int) - Static method in class picard.util.BaitDesigner
Returns the total of soft or hard masked bases in the interval of bases.
getMaskedKmersFromLocalReference(ReferenceFileSource, int, int, SVKmerShort) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerUtils
Gets all kmers from a given reference as a Collection of long arrays, while logging handy progress messages.
getMasterSequenceDictionary() - Method in class org.broadinstitute.hellbender.engine.GATKTool
Returns the master sequence dictionary if it has been set, otherwise null.
getMatchedBarcode() - Method in class picard.illumina.parser.ClusterData
 
getMatchesLessDeletions(Cigar, int) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSUtils
 
getMatchResults() - Method in class picard.fingerprint.FingerprintResults
 
getMateContig() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
getMateContig() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getMateForwardStrand(GATKRead) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.DiscordantReadPairEvidence
 
getMateReferenceIndex(GATKRead, SAMFileHeader) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Returns the reference index in the given header of the contig of the read's mate, or SAMRecord.NO_ALIGNMENT_REFERENCE_INDEX if the read's mate is unmapped.
getMateRefLoc(NovelAdjacencyAndAltHaplotype, boolean) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.BreakEndVariantType
 
getMaternalID() - Method in class org.broadinstitute.hellbender.utils.samples.Sample
 
getMaternalID() - Method in class org.broadinstitute.hellbender.utils.samples.Trio
 
getMaternalId() - Method in class picard.pedigree.PedFile.PedTrio
 
getMateStart() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
getMateStart() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getMateTargetInterval(GATKRead, ReadMetadata) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.DiscordantReadPairEvidence
Finds the coordinates implicated by the read's mate as being part of the breakpoint, ie.
getMax() - Method in class org.broadinstitute.hellbender.utils.solver.UnivariateSolverJobDescription
 
getMaxEvaluations() - Method in class org.broadinstitute.hellbender.utils.solver.UnivariateSolverJobDescription
 
getMaximumKmerSize() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResultSet
Returns the maximum kmerSize available.
getMaximumTrackedValue() - Method in class org.broadinstitute.hellbender.tools.spark.utils.IntHistogram
 
getMaxMedianFragmentSize() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata
 
getMaxNonOutlierFragmentSize() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.LibraryStatistics
 
getMaxPairErrorRate() - Method in class picard.util.AdapterMarker
 
getMaxProbPropagationDistance() - Method in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfile
How far away can probability mass be moved around in this profile? This distance puts an upper limit on how far, in bp, we will ever propagate probability mass around when adding a new ActivityProfileState.
getMaxProbPropagationDistance() - Method in class org.broadinstitute.hellbender.utils.activityprofile.BandPassActivityProfile
Our maximize propagation distance is whatever our parent's is, plus our filter size Stops the profile from interpreting sites that aren't yet fully determined due to propagation of the probabilities.
getMaxReadLength(List<GATKRead>) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Calculate the maximum read length from the given list of reads.
getMaxReadsInPartition() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata
 
getMaxSingleEndErrorRate() - Method in class picard.util.AdapterMarker
 
getMaxVal() - Method in class org.broadinstitute.hellbender.utils.genotyper.ProbabilityVector
 
getMayBeNullGoodMappingToNonCanonicalChromosome() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigAlignmentsConfigPicker.GoodAndBadMappings
 
getMeanBaseQuality() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.LibraryStatistics
 
getMeanBaseQuality() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata
 
getMeanLog2CopyRatio() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CopyRatioSegment
 
getMeanLog2CopyRatio() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.MultidimensionalSegment
 
getMeanVector() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
 
getMedian() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.LibraryStatistics
 
getMedianPartitionSpan() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata
 
getMedianPhasingMap() - Method in class picard.illumina.LanePhasingMetricsCollector
 
getMedianPrePhasingMap() - Method in class picard.illumina.LanePhasingMetricsCollector
 
getMedianShift() - Method in class org.broadinstitute.hellbender.utils.MannWhitneyU.Result
 
getMedianValue(List<T>) - Static method in class org.broadinstitute.hellbender.utils.Utils
Streams and sorts a collection of objects and returns the integer median entry of the sorted list
getMergedCountingReadFilter(SAMFileHeader) - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKReadFilterPluginDescriptor
Merge the default filters with the users's command line read filter requests, then initialize the resulting filters.
getMergedReadFilter(SAMFileHeader) - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKReadFilterPluginDescriptor
Merge the default filters with the users's command line read filter requests, then initialize the resulting filters.
getMergedReadFilter(SAMFileHeader, BiFunction<List<ReadFilter>, SAMFileHeader, T>) - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKReadFilterPluginDescriptor
Merge the default filters with the users's command line read filter requests, then initialize the resulting filters.
getMessage(Throwable) - Static method in exception org.broadinstitute.hellbender.exceptions.UserException
 
getMessage(int) - Method in enum picard.sam.RevertOriginalBaseQualitiesAndAddMateCigar.CanSkipSamFile
 
getMetadata() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.collections.AbstractRecordCollection
 
getMetadataType() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.collections.AbstractLocatableCollection
 
getMetadataType() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.collections.AbstractRecordCollection
Subclasses should add an enum to Metadata.Type, a corresponding switch case statement to MetadataUtils.fromHeader(SAMFileHeader, Metadata.Type), and implement this method accordingly.
getMetadataType() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.collections.AbstractSampleLocatableCollection
 
getMetadataType() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.collections.AbstractSampleRecordCollection
 
getMetadataType() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.collections.CoveragePerContigCollection
 
getMetricCode() - Method in class picard.illumina.parser.readers.TileMetricsOutReader.IlluminaLaneTileCode
 
getMetricCode() - Method in class picard.illumina.parser.readers.TileMetricsOutReader.IlluminaTileMetrics
 
getMetrics(CountingFilter, CountingFilter, CountingPairedFilter) - Method in class picard.analysis.AbstractWgsMetricsCollector
Creates CollectWgsMetrics.WgsMetrics - the object holding the result of CollectWgsMetrics
getMetrics() - Method in class picard.illumina.ExtractIlluminaBarcodes.PerTileBarcodeExtractor
 
getMetricsByLibrary(String) - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.LibraryIdGenerator
 
getMetricsByLibrary(String) - Method in class picard.sam.markduplicates.util.LibraryIdGenerator
 
getMetricsByLibraryMap() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.LibraryIdGenerator
 
getMetricsByLibraryMap() - Method in class picard.sam.markduplicates.util.LibraryIdGenerator
 
getMetricsCode() - Method in enum picard.illumina.parser.IlluminaMetricsCode
 
getMetricsFile() - Method in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
Gets a MetricsFile with default headers already written into it.
getMetricsFile() - Method in class picard.cmdline.CommandLineProgram
Gets a MetricsFile with default headers already written into it.
getMetricValue() - Method in class picard.illumina.parser.readers.TileMetricsOutReader.IlluminaTileMetrics
 
getMidpoint() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CopyRatio
The midpoint is used to characterize the interval for the purposes of determining overlaps so that each copy-ratio interval will be uniquely contained in a single segment.
getMidpointOverlapDetector() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.collections.CopyRatioCollection
The midpoint is used to characterize the interval for the purposes of determining overlaps so that each copy-ratio interval will be uniquely contained in a single segment.
getMin() - Method in class org.broadinstitute.hellbender.utils.solver.UnivariateSolverJobDescription
 
getMinBaseQual() - Method in class org.broadinstitute.hellbender.utils.baq.BAQ
 
getMinBaseQualityToUseInAssembly() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingAssembler
 
getMinEvidenceMapQ() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.SVReadFilter
 
getMinEvidenceMatchLength() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.SVReadFilter
 
getMiniCluster(Configuration) - Static method in class org.broadinstitute.hellbender.utils.test.MiniClusterUtils
 
getMiniCluster() - Static method in class org.broadinstitute.hellbender.utils.test.MiniClusterUtils
 
getMinimaIndices() - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.optimization.PersistenceOptimizer
Returns an unmodifiable list of the indices of the local minima, sorted first by decreasing topological persistence and then by increasing index.
getMinimumKmerSize() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResultSet
Returns the minimum kmerSize available.
getMinorAlleleFraction() - Method in class org.broadinstitute.hellbender.tools.walkers.contamination.MinorAlleleFractionRecord
 
getMinorAlleleFraction() - Method in class org.broadinstitute.hellbender.tools.walkers.contamination.PileupSummary
 
getMinorAlleleFractionSimplePosteriorSummary() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.ModeledSegment
 
getMinPairMatchBases() - Method in class picard.util.AdapterMarker
 
getMinSingleEndMatchBases() - Method in class picard.util.AdapterMarker
 
getMinVal() - Method in class org.broadinstitute.hellbender.utils.genotyper.ProbabilityVector
 
getMinValidationReadCount() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.BasicValidationResult
 
getMismatchCount(GATKRead, byte[], int) - Static method in class org.broadinstitute.hellbender.utils.read.AlignmentUtils
 
getMismatchCount(GATKRead, byte[], int, int, int) - Static method in class org.broadinstitute.hellbender.utils.read.AlignmentUtils
Count how many bases mismatch the reference.
getMismatchesKeySet() - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.ReadCovariates
 
getMismatchesKeySet(int) - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.ReadCovariates
 
getMissingLeft() - Method in class org.broadinstitute.hellbender.utils.read.SamComparison
 
getMissingLeft() - Method in class picard.sam.CompareSAMs
 
getMissingRight() - Method in class org.broadinstitute.hellbender.utils.read.SamComparison
 
getMissingRight() - Method in class picard.sam.CompareSAMs
 
getMitochondrialAminoAcidByCodon(String, boolean) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Returns the AminoAcid corresponding to the given three-letter Mitochondrial codon.
getMixingFraction() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.MixingFraction
 
getModeledSegments() - Method in class org.broadinstitute.hellbender.tools.copynumber.models.MultidimensionalModeller
 
getMostLikelyGenotype(Snp) - Method in class picard.fingerprint.HaplotypeProbabilities
Gets the genotype for this Snp given the most likely haplotype.
getMostLikelyHaplotype() - Method in class picard.fingerprint.HaplotypeProbabilities
Gets the most likely haplotype given the probabilities.
getMother(Sample) - Method in class org.broadinstitute.hellbender.utils.samples.SampleDB
Get the sample's mother
getMother() - Method in class org.broadinstitute.hellbender.utils.samples.Trio
 
getMultiplicity() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseEdge
Get the number of observations of paths connecting two vertices
getName() - Method in class org.broadinstitute.hellbender.cmdline.programgroups.CopyNumberProgramGroup
 
getName() - Method in class org.broadinstitute.hellbender.cmdline.programgroups.CoverageAnalysisProgramGroup
 
getName() - Method in class org.broadinstitute.hellbender.cmdline.programgroups.ExampleProgramGroup
 
getName() - Method in class org.broadinstitute.hellbender.cmdline.programgroups.MetagenomicsProgramGroup
 
getName() - Method in class org.broadinstitute.hellbender.cmdline.programgroups.ShortVariantDiscoveryProgramGroup
 
getName() - Method in class org.broadinstitute.hellbender.cmdline.programgroups.StructuralVariantDiscoveryProgramGroup
 
getName() - Method in class org.broadinstitute.hellbender.cmdline.TestProgramGroup
 
getName() - Method in class org.broadinstitute.hellbender.engine.FeatureDataSource
Get the logical name of this data source.
getName() - Method in class org.broadinstitute.hellbender.engine.FeatureInput
Gets the logical name of this Feature source.
getName() - Method in class org.broadinstitute.hellbender.engine.filters.CountingReadFilter.CountingAndReadFilter
 
getName() - Method in class org.broadinstitute.hellbender.engine.filters.CountingReadFilter
 
getName() - Method in class org.broadinstitute.hellbender.engine.filters.CountingVariantFilter.CountingAndVariantFilter
 
getName() - Method in class org.broadinstitute.hellbender.engine.filters.CountingVariantFilter
 
getName() - Method in class org.broadinstitute.hellbender.engine.MultiVariantDataSource
Get the logical name of this data source.
getName() - Method in enum org.broadinstitute.hellbender.tools.funcotator.AminoAcid
 
getName() - Method in class org.broadinstitute.hellbender.tools.funcotator.DataSourceFuncotationFactory
 
getName() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.cosmic.CosmicFuncotationFactory
 
getName() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationFactory
 
getName() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.vcf.VcfFuncotationFactory
 
getName() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv.LocatableXsvFuncotationFactory
 
getName() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv.SimpleKeyXsvFuncotationFactory
 
getName() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenReferenceTaxonProperties
 
getName() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTreeNode
 
getName() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils.FastqRead
 
getName() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.TrancheManager.SelectionMetric
 
getName() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.OptionalField
 
getName() - Method in class org.broadinstitute.hellbender.utils.help.GATKDocWorkUnit
 
getName() - Method in interface org.broadinstitute.hellbender.utils.illumina.AdapterPair
 
getName() - Method in enum org.broadinstitute.hellbender.utils.illumina.IlluminaAdapterPair
 
getName() - Method in class org.broadinstitute.hellbender.utils.mcmc.Parameter
 
getName() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
getName() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.MarkDuplicatesSparkRecord
 
getName() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getName() - Method in class org.broadinstitute.hellbender.utils.recalibration.QualQuantizer.QualInterval
 
getName() - Method in class picard.cmdline.programgroups.BaseCallingProgramGroup
 
getName() - Method in class picard.cmdline.programgroups.DiagnosticsAndQCProgramGroup
 
getName() - Method in class picard.cmdline.programgroups.IntervalsManipulationProgramGroup
 
getName() - Method in class picard.cmdline.programgroups.OtherProgramGroup
 
getName() - Method in class picard.cmdline.programgroups.ReadDataManipulationProgramGroup
 
getName() - Method in class picard.cmdline.programgroups.ReferenceProgramGroup
 
getName() - Method in class picard.cmdline.programgroups.Testing
 
getName() - Method in class picard.cmdline.programgroups.VariantEvaluationProgramGroup
 
getName() - Method in class picard.cmdline.programgroups.VariantFilteringProgramGroup
 
getName() - Method in class picard.cmdline.programgroups.VariantManipulationProgramGroup
 
getName() - Method in class picard.fingerprint.Snp
 
getName() - Method in interface picard.util.AdapterPair
 
getName() - Method in enum picard.util.IlluminaUtil.IlluminaAdapterPair
 
getNameFormat() - Method in class org.broadinstitute.hellbender.utils.report.GATKReportColumnFormat
 
getNameOf(int) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTree
 
getNBases() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.LibraryRawStatistics
 
getNcbiBuild() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getNearProbeDistance() - Method in class picard.analysis.directed.TargetMetricsCollector
Gets the distance that is allowed between a read and the nearest probe for it to be considered "near probe" and "selected.
getNegativeMAD() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.LibraryStatistics
 
getNeighborhood(VariantContext, int) - Method in class org.broadinstitute.hellbender.utils.haplotype.EventMap
Get all of the variant contexts starting at leftMost that are within maxBP of each other
getNextOnGenomeCigarElement() - Method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Get the cigar element of the next genomic aligned position
getNextReadPair(PeekableIterator<SAMRecord>) - Static method in class picard.util.QuerySortedReadPairIteratorUtil
Get the next read pair (where both have the same read name).
getNextReferenceVertex(V) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Traverse the graph and get the next reference vertex if it exists
getNextReferenceVertex(V, boolean, Optional<E>) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Traverse the graph and get the next reference vertex if it exists
getnLoci() - Method in class org.broadinstitute.hellbender.utils.read.ArtificialBAMBuilder
 
getNObservations(int) - Method in class org.broadinstitute.hellbender.tools.spark.utils.IntHistogram
 
getNodeIDs() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTree
 
getNoise() - Method in class picard.illumina.parser.ReadData
 
getNoMatchMetric() - Method in class picard.illumina.ExtractIlluminaBarcodes.PerTileBarcodeExtractor
 
getNonLogValue(double) - Method in class picard.util.MathUtil.LogMath
Returns the decimal representation of the provided log values.
getNonNullEnvironmentVariable(String) - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest
 
getNonOverlappingAltAlleleBaseString(Allele, Allele, boolean) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Get the string of bases that are different from the given alleles.
getNovelAdjacencyReferenceLocations() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SimpleNovelAdjacencyAndChimericAlignmentEvidence
 
getNPartitions() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata
 
getNReads() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.LibraryStatistics
 
getNReads() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata
 
getNReads() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.LibraryRawStatistics
 
getNReads() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.PartitionStatistics
 
getnReadsPerLocus() - Method in class org.broadinstitute.hellbender.utils.read.ArtificialBAMBuilder
 
getNRefBases() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata
 
getNSamples() - Method in class org.broadinstitute.hellbender.utils.read.ArtificialBAMBuilder
 
getNumAdaptersToKeep() - Method in class picard.util.AdapterMarker
 
getNumAlignedBases(GATKRead) - Static method in class org.broadinstitute.hellbender.tools.walkers.annotator.ReadPosRankSumTest
 
getNumAlignedBases(SAMRecord) - Method in class picard.analysis.directed.RnaSeqMetricsCollector.PerUnitRnaSeqMetricsCollector
 
getNumAlignedBasesCountingSoftClips(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.AlignmentUtils
Get the number of bases aligned to the genome, including soft clips If read is not mapped (i.e., doesn't have a cigar) returns 0
getNumAlignmentBlocks(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.AlignmentUtils
Returns number of alignment blocks (continuous stretches of aligned bases) in the specified alignment.
getNumArtifactMode() - Method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationSampleTransitionSummary
 
getNumArtifactModeFiltered() - Method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationSampleTransitionSummary
 
getNumBasesPassingMinimumBaseQuality(SAMRecord, AlignmentBlock, int) - Static method in class picard.analysis.directed.TargetMetricsCollector
Get the the number of bases in the given alignment block and record that have base quality greater or equal to the minimum
getNumberOfClusters(File) - Static method in class picard.illumina.parser.readers.BclReader
 
getNumberOfDiscardedItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.Downsampler
Returns the number of items discarded (so far) during the downsampling process
getNumberOfElements(Predicate<PileupElement>) - Method in class org.broadinstitute.hellbender.utils.pileup.ReadPileup
Returns the number of elements that satisfy the predicate.
getNumberOfEvents() - Method in class org.broadinstitute.hellbender.utils.haplotype.EventMap
How many events do we have?
getNumberOfOpticalDuplicateClusters() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.LibraryIdGenerator
 
getNumberOfOpticalDuplicateClusters() - Method in class picard.sam.markduplicates.util.LibraryIdGenerator
 
getNumberOfRecords() - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
getNumClippedBases(boolean, Cigar) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SvCigarUtils
Returns the number of clipped bases, including both soft and hard, represented in cigarAlong5to3DirectionOfContig from the start or from the end
getNumClippedBases(boolean, List<CigarElement>) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SvCigarUtils
Returns the number of clipped bases, including both soft and hard, represented in cigarElements from the start or from the end
getNumClippedBasesAtEnd(GATKRead) - Static method in class org.broadinstitute.hellbender.tools.walkers.annotator.ReadPosRankSumTest
 
getNumClippedBasesAtStart(GATKRead) - Static method in class org.broadinstitute.hellbender.tools.walkers.annotator.ReadPosRankSumTest
 
getNumClustersInTile() - Method in class picard.illumina.parser.TileIndex.TileIndexRecord
 
getNumColumns() - Method in class org.broadinstitute.hellbender.utils.report.GATKReportTable
 
getNumDescriptors() - Method in class picard.illumina.parser.ReadStructure
 
getNumDuplicates() - Method in class picard.sam.markduplicates.MarkDuplicatesWithMateCigarIterator
 
getNumDuplicates() - Method in class picard.sam.markduplicates.util.MarkQueue
Returns the number of duplicates detected
getNumEigensamples() - Method in class org.broadinstitute.hellbender.tools.copynumber.denoising.HDF5SVDReadCountPanelOfNormals
 
getNumEigensamples() - Method in interface org.broadinstitute.hellbender.tools.copynumber.denoising.SVDReadCountPanelOfNormals
Returns the number of eigensamples.
getNumericalMean() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.BetaBinomialDistribution
 
getNumericalVariance() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.BetaBinomialDistribution
 
getNumHardClippedBases(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.AlignmentUtils
Count the number of bases hard clipped from read If read's cigar is null, return 0
getNumHardClippingBases(boolean, List<CigarElement>) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SvCigarUtils
 
getNumMismatches() - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalDatum
 
getNumNonRefPassingVariants() - Method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationSampleTransitionSummary
 
getNumNotArtifactMode() - Method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationSampleTransitionSummary
 
getNumObservations() - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalDatum
 
getNumOfTies() - Method in class org.broadinstitute.hellbender.utils.MannWhitneyU.RankedData
 
getNumPoints() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AlleleFractionSegment
 
getNumPoints() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CopyRatioSegment
 
getNumPoints() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.IntegerCopyNumberSegment
 
getNumPointsAlleleFraction() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.ModeledSegment
 
getNumPointsAlleleFraction() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.MultidimensionalSegment
 
getNumPointsCopyRatio() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.ModeledSegment
 
getNumPointsCopyRatio() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.MultidimensionalSegment
 
getNumReads() - Method in class picard.illumina.parser.ClusterData
 
getNumReadsProcessed() - Method in class org.broadinstitute.hellbender.utils.recalibration.BaseRecalibrationEngine
 
getNumRecordsWithNoMateCigar() - Method in class picard.sam.markduplicates.MarkDuplicatesWithMateCigarIterator
Useful for statistics after the iterator has been exhausted and closed.
getNumRows() - Method in class org.broadinstitute.hellbender.utils.report.GATKReportTable
 
getNumSoftClippingBases(boolean, List<CigarElement>) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SvCigarUtils
 
getNumTandemRepeatUnits(VariantContext, byte[]) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
 
getNumTandemRepeatUnits(byte[], byte[], byte[]) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
 
getNumTiles() - Method in class picard.illumina.parser.readers.BclIndexReader
 
getNumTiles() - Method in class picard.illumina.parser.TileIndex
 
getObq() - Method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationSampleTransitionSummary
 
getObsAllele1() - Method in class picard.fingerprint.HaplotypeProbabilities
Returns the number of observations of alleles supporting the first/major haplotype allele.
getObsAllele1() - Method in class picard.fingerprint.HaplotypeProbabilitiesFromSequence
Returns the number of bases/reads that support the first allele.
getObsAllele1() - Method in class picard.fingerprint.HaplotypeProbabilityOfNormalGivenTumor
 
getObsAllele2() - Method in class picard.fingerprint.HaplotypeProbabilities
Returns the number of observations of alleles supporting the second/minor haplotype allele.
getObsAllele2() - Method in class picard.fingerprint.HaplotypeProbabilitiesFromSequence
Returns the number of bases/reads that support the second allele.
getObsAllele2() - Method in class picard.fingerprint.HaplotypeProbabilityOfNormalGivenTumor
 
getOffset(Locatable) - Method in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfileState
The offset of state w.r.t.
getOffset() - Method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Get the offset of the this element into the read that aligns that read's base to this genomic position.
getOffsetInCurrentCigar() - Method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Get the offset into the *current* cigar element for this alignment position We can be anywhere from offset 0 (first position) to length - 1 of the current cigar element aligning us to this genomic position.
getOffsetIntoCurrentCigarElement() - Method in class org.broadinstitute.hellbender.utils.locusiterator.AlignmentStateMachine
Get the offset of the current state into the current cigar element That is, suppose we have a read with cigar 2M3D4M, and we're right at the second M position.
getOffsets() - Method in class org.broadinstitute.hellbender.utils.pileup.ReadPileup
Returns a list of the offsets in this pileup.
getOps() - Method in class org.broadinstitute.hellbender.utils.clipping.ReadClipper
Check the list of operations set up for this read.
getOpticalDupesByLibraryId() - Method in class picard.sam.markduplicates.MarkDuplicatesWithMateCigarIterator
 
getOpticalDuplicatesByLibraryIdMap() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.LibraryIdGenerator
 
getOpticalDuplicatesByLibraryIdMap() - Method in class picard.sam.markduplicates.util.LibraryIdGenerator
 
getOptimalNumberOfBits(long, double) - Static method in class org.broadinstitute.hellbender.tools.spark.utils.LongBloomFilter
 
getOptionalDouble(Map<String, String>, String, double) - Static method in class org.broadinstitute.hellbender.tools.walkers.vqsr.Tranche
 
getOptionalField(String) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
getOptionalFields() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
getOptionalIntAttribute(SAMRecord, String) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Encapsulates a integer attribute into an OptionalInt instance.
getOptionalIntAttribute(GATKRead, String) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Encapsulates a integer attribute into an OptionalInt instance.
getOptionalInteger(Map<String, String>, String, int) - Static method in class org.broadinstitute.hellbender.tools.walkers.vqsr.Tranche
 
getOrCreate(Class<? extends T>, Map<?, ?>...) - Method in class org.broadinstitute.hellbender.utils.config.ConfigFactory
Wrapper around ConfigCache.getOrCreate(Class, Map[]) which will ensure that path variables specified in Config.Sources annotations are resolved prior to creation.
getOrCreate(Factory, Class<? extends T>, Map<?, ?>...) - Method in class org.broadinstitute.hellbender.utils.config.ConfigFactory
Wrapper around ConfigCache.getOrCreate(Factory, Class, Map[]) which will ensure that path variables specified in Config.Sources annotations are resolved prior to creation.
getOrCreate(Object, Class<? extends T>, Map<?, ?>...) - Method in class org.broadinstitute.hellbender.utils.config.ConfigFactory
Wrapper around ConfigCache.getOrCreate(Object, Class, Map[]) which will ensure that path variables specified in Config.Sources annotations are resolved prior to creation.
getOrCreate(Factory, Object, Class<? extends T>, Map<?, ?>...) - Method in class org.broadinstitute.hellbender.utils.config.ConfigFactory
Wrapper around ConfigCache.getOrCreate(Factory, Object, Class, Map[]) which will ensure that path variables specified in Config.Sources annotations are resolved prior to creation.
getOrderedMates(NovelAdjacencyAndAltHaplotype, ReferenceMultiSource) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.BreakEndVariantType.InvSuspectBND
 
getOrderedMates(NovelAdjacencyAndAltHaplotype, ReferenceMultiSource, SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.BreakEndVariantType.TransLocBND
 
getOrientationByte(boolean, boolean) - Static method in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
Returns a single byte that encodes the orientation of the two reads in a pair.
getOrientationByte(boolean, boolean) - Static method in class picard.sam.markduplicates.util.ReadEnds
Returns a single byte that encodes the orientation of the two reads in a pair.
getOrientationForOpticalDuplicates() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Pair
Returns the pair orientation suitable for optical duplicates, which always goes by the first then the second end for the strands.
getOrientationForPCRDuplicates() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.EmptyFragment
 
getOrientationForPCRDuplicates() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Fragment
 
getOrientationForPCRDuplicates() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Pair
 
getOrientationForPCRDuplicates() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.PairedEnds
This returns a byte summary spanning from 0-5 representing all combinations of single read or two read forward/reverse strand for the first and second read in the Pair.
getOriginalBaseQualities(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Retrieve the original base qualities of the given read, if present, as stored in the OQ attribute.
getOriginalIntervalGCContent() - Method in class org.broadinstitute.hellbender.tools.copynumber.denoising.HDF5SVDReadCountPanelOfNormals
 
getOriginalIntervalGCContent() - Method in interface org.broadinstitute.hellbender.tools.copynumber.denoising.SVDReadCountPanelOfNormals
Returns a modifiable copy of an array containing the GC content of the original intervals (in the same order as in SVDReadCountPanelOfNormals.getOriginalIntervals()).
getOriginalIntervals() - Method in class org.broadinstitute.hellbender.tools.copynumber.denoising.HDF5SVDReadCountPanelOfNormals
 
getOriginalIntervals() - Method in interface org.broadinstitute.hellbender.tools.copynumber.denoising.SVDReadCountPanelOfNormals
Returns a modifiable copy of the list of the original intervals that were used to build this PoN (no filtering will have been applied).
getOriginalReadCounts() - Method in class org.broadinstitute.hellbender.tools.copynumber.denoising.HDF5SVDReadCountPanelOfNormals
 
getOriginalReadCounts() - Method in interface org.broadinstitute.hellbender.tools.copynumber.denoising.SVDReadCountPanelOfNormals
Returns a modifiable copy of the original matrix of integer read-counts (represented as doubles) used to build the PoN (no filtering will have been applied).
getOriginalToQuantizedMap() - Method in class org.broadinstitute.hellbender.utils.recalibration.QualQuantizer
 
getOtherAltCount() - Method in class org.broadinstitute.hellbender.tools.walkers.contamination.PileupSummary
 
getOtherTranscripts() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getOutput() - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
getOutputCycles() - Method in class picard.illumina.parser.OutputMapping
 
getOutputDescriptors() - Method in class picard.illumina.parser.OutputMapping
 
getOutputDir() - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
getOutputFile() - Method in class org.broadinstitute.hellbender.utils.runtime.OutputStreamSettings
 
getOutputFileName(File) - Static method in class picard.sam.CalculateReadGroupChecksum
Creates a file name (not including the path) for an RG MD5 file based on the name of the input file.
getOutputIndexForCycle(int) - Method in class picard.illumina.parser.OutputMapping
Return an index that where: index.arrayIndex - represents either the read number the cycle will be output too, or (in some cases) an array index into a two dimensional array of byte[][] where the top level array corresponds to read number index.elementIndex - represents the element a cycle will appear in inside it's give read, or the element in an array as described above
getOutputPath() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoveryInputMetaData
 
getOutputReadLengths() - Method in class picard.illumina.parser.OutputMapping
 
getOutputReadStructure() - Method in class picard.illumina.parser.IlluminaDataProviderFactory
Sometimes (in the case of skipped reads) the logical read structure of the output cluster data is different from the input readStructure
getOutputReadStructure() - Method in class picard.illumina.parser.OutputMapping
 
getOutputStream() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEndsForMarkDuplicatesCodec
 
getOutputStream() - Method in class picard.sam.markduplicates.util.ReadEndsForMarkDuplicatesCodec
 
getOutputStream() - Method in class picard.sam.markduplicates.util.RepresentativeReadIndexerCodec
 
getOutputString() - Method in enum org.broadinstitute.hellbender.tools.copynumber.formats.records.CalledCopyRatioSegment.Call
 
getOverlapDetector() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.collections.AbstractLocatableCollection
 
getOverlapNames() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantOverlapAnnotator
Get the collection of names of overlap sets ued by this annotator.
getOverlapping(SimpleInterval) - Method in class org.broadinstitute.hellbender.utils.collections.IntervalsSkipList
Returns all the intervals that overlap with the query.
getOverlapping(SimpleInterval) - Method in class org.broadinstitute.hellbender.utils.collections.IntervalsSkipListOneContig
Returns all the intervals that overlap with the query.
getOverlapping(GenomeLoc) - Method in class org.broadinstitute.hellbender.utils.GenomeLocSortedSet
Return a list of intervals overlapping loc
getOverlappingExonPositions(Allele, Allele, String, int, int, Strand, List<? extends Locatable>) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Get the overlapping exon start/stop as a SimpleInterval for the given altAllele / reference.
getOverlappingFragmentFilteredPileup(SAMFileHeader) - Method in class org.broadinstitute.hellbender.utils.pileup.ReadPileup
Returns a new ReadPileup where only one read from an overlapping read pair is retained.
getOverlappingFragmentFilteredPileup(boolean, Comparator<PileupElement>, SAMFileHeader) - Method in class org.broadinstitute.hellbender.utils.pileup.ReadPileup
Returns a new ReadPileup where only one read from an overlapping read pair is retained.
getOverlappingFullSearch(GenomeLoc) - Method in class org.broadinstitute.hellbender.utils.GenomeLocSortedSet
Return a list of intervals overlapping loc by enumerating all locs and testing for overlap Purely for testing purposes -- this is way to slow for any production code
getOverlappingPairs() - Method in class org.broadinstitute.hellbender.utils.fragments.FragmentCollection
Gets the T elements containing overlapping elements, in no particular order The returned collection is unmodifiable.
getOverlappingReferenceBases() - Method in class org.broadinstitute.hellbender.engine.ReadContextData
 
getOverlappingVariants() - Method in class org.broadinstitute.hellbender.engine.ReadContextData
 
getP() - Method in class org.broadinstitute.hellbender.utils.MannWhitneyU.Result
 
getPackageList() - Method in class org.broadinstitute.hellbender.Main
The packages we wish to include in our command line.
getPackageList() - Static method in class picard.cmdline.PicardCommandLine
The packages we wish to include in our command line
getPackageNames() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKAnnotationPluginDescriptor
A list of package names which will be searched for plugins managed by the descriptor.
getPackageNames() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKReadFilterPluginDescriptor
A list of package names which will be searched for plugins managed by the descriptor.
getPaddedInterval() - Method in interface org.broadinstitute.hellbender.engine.Shard
 
getPaddedInterval() - Method in class org.broadinstitute.hellbender.engine.ShardBoundary
 
getPaddedInterval() - Method in class org.broadinstitute.hellbender.engine.ShardBoundaryShard
 
getPaddedInterval() - Method in class org.broadinstitute.hellbender.engine.ShardToMultiIntervalShardAdapter
 
getPaddedInterval() - Method in class org.broadinstitute.hellbender.tools.DownsampleableSparkReadShard
 
getPaddedIntervals() - Method in class org.broadinstitute.hellbender.engine.MultiIntervalLocalReadShard
 
getPaddedIntervals() - Method in interface org.broadinstitute.hellbender.engine.MultiIntervalShard
 
getPaddedIntervals() - Method in class org.broadinstitute.hellbender.engine.ShardToMultiIntervalShardAdapter
 
getPaddedReferenceLoc(AssemblyRegion, int, ReferenceSequenceFile) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerUtils
 
getPaddedReferenceLoc() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResultSet
Returns the padded reference location.
getPadding() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmer.Result
Returns the required padding around callable variation.
getPairedReads() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPairedUnpairedSplitterSpark
 
getPairedStrandedIntervals() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.EvidenceTargetLink
 
getPairedStrandedIntervals(ReadMetadata, SAMSequenceDictionary, int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVContext
 
getPairHMMArgs() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.PairHMMNativeArgumentCollection
 
getPanelIntervalFractionalMedians() - Method in class org.broadinstitute.hellbender.tools.copynumber.denoising.HDF5SVDReadCountPanelOfNormals
 
getPanelIntervalFractionalMedians() - Method in interface org.broadinstitute.hellbender.tools.copynumber.denoising.SVDReadCountPanelOfNormals
Returns a modifiable copy of an array containing the median (across all samples, before filtering) of the fractional coverage at each panel interval (in the same order as in SVDReadCountPanelOfNormals.getPanelIntervals()).
getPanelIntervals() - Method in class org.broadinstitute.hellbender.tools.copynumber.denoising.HDF5SVDReadCountPanelOfNormals
 
getPanelIntervals() - Method in interface org.broadinstitute.hellbender.tools.copynumber.denoising.SVDReadCountPanelOfNormals
Returns a modifiable copy of the list of the intervals contained in this PoN after all filtering has been applied.
getParallelReads(String, String, TraversalParameters) - Method in class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSource
Loads Reads using Hadoop-BAM.
getParallelReads(String, String, TraversalParameters, long) - Method in class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSource
Loads Reads using Hadoop-BAM.
getParallelReads(String, String) - Method in class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSource
Loads Reads using Hadoop-BAM.
getParallelReads(String, String, int) - Method in class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSource
Loads Reads using Hadoop-BAM.
getParallelVariantContexts(String, List<SimpleInterval>) - Method in class org.broadinstitute.hellbender.engine.spark.datasources.VariantsSparkSource
Loads variants in parallel using Hadoop-BAM for vcfs and bcfs.
getParallelVariants(String, List<SimpleInterval>) - Method in class org.broadinstitute.hellbender.engine.spark.datasources.VariantsSparkSource
Loads variants in parallel using Hadoop-BAM for vcfs and bcfs.
getParallelVariants(List<String>, List<SimpleInterval>) - Method in class org.broadinstitute.hellbender.engine.spark.datasources.VariantsSparkSource
Loads variants from multiple inputs in parallel using Hadoop-BAM for vcfs and bcfs.
getParent() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenReferenceTaxonProperties
 
getParent() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTreeNode
 
getParentOf(int) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTree
 
getParents(Sample) - Method in class org.broadinstitute.hellbender.utils.samples.SampleDB
Get the sample's father and mother
getParentsRefRefChildHet() - Method in class org.broadinstitute.hellbender.utils.samples.MendelianViolation
 
getPartition(Object) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.ComplexityPartitioner
 
getPartitionBounds(int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata
 
getPartitionIndex() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.MarkDuplicatesSparkRecord
 
getPassthrough(GATKRead, int) - Static method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.MarkDuplicatesSparkRecord
 
getPaternalID() - Method in class org.broadinstitute.hellbender.utils.samples.Sample
 
getPaternalID() - Method in class org.broadinstitute.hellbender.utils.samples.Trio
 
getPaternalId() - Method in class picard.pedigree.PedFile.PedTrio
 
getPath(String) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
Converts the given URI to a Path object.
getPath() - Method in class org.broadinstitute.hellbender.utils.io.Resource
 
getPathOf(int) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTree
Returns path of node id's from the input id to the root.
getPathOnGcs(String) - Static method in class org.broadinstitute.hellbender.utils.gcs.BucketUtils
String -> Path.
getPathWithoutBucket(String) - Static method in class org.broadinstitute.hellbender.utils.gcs.BucketUtils
Given a path of the form "gs://bucket/folder/folder/file", returns "folder/folder/file".
getPenalty() - Method in class org.broadinstitute.hellbender.utils.recalibration.QualQuantizer.QualInterval
 
getPersistences() - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.optimization.PersistenceOptimizer
Returns the corresponding unmodifiable list of the topological persistences of the local minima given by PersistenceOptimizer.getMinimaIndices().
getPerTilePerCycleFiles() - Method in class picard.illumina.parser.PerTilePerCycleFileUtil
For the given tiles, populate a CycleIlluminaFileMap that contains all these tiles and will iterate through all the files for these tiles in expectedBase Side Effect: Assigns numCycles
getPhasingCode(int, IlluminaMetricsCode) - Static method in enum picard.illumina.parser.IlluminaMetricsCode
Phasing codes are between 200 and 299 (inclusive).
getPhasingMap() - Method in class picard.illumina.parser.Tile
 
getPhasingMetricsForTiles(long, Collection<Tile>, boolean) - Static method in class picard.illumina.IlluminaPhasingMetrics
Calculate the median phasing & prephasing values for a lane's tiles and create the appropriate IlluminaPhasingMetrics for them
getPhasingValue() - Method in class picard.illumina.parser.TilePhasingValue
 
getPhenotype() - Method in class picard.pedigree.PedFile.PedTrio
 
getPileup(Locatable, Iterable<GATKRead>) - Static method in class org.broadinstitute.hellbender.utils.GATKProtectedVariantContextUtils
Get the pileup of reads covering a locus.
getPileupContingencyTable(Map<String, List<PileupElement>>, Allele, List<Allele>, int, int) - Static method in class org.broadinstitute.hellbender.tools.walkers.annotator.StrandBiasTest
Allocate and fill a 2x2 strand contingency table.
getPileupForLane(String) - Method in class org.broadinstitute.hellbender.utils.pileup.ReadPileup
Make a new pileup from elements whose reads have read groups that agree with the given lane ID.
getPileupForSample(String, SAMFileHeader) - Method in class org.broadinstitute.hellbender.utils.pileup.ReadPileup
Make a new pileup from elements whose reads belong to the given sample.
getPileupString() - Method in class org.broadinstitute.hellbender.utils.codecs.sampileup.SAMPileupFeature
Format in a samtools-like string.
getPileupString(char) - Method in class org.broadinstitute.hellbender.utils.pileup.ReadPileup
Format, assuming a single-sample, in a samtools-like string.
GetPileupSummaries - Class in org.broadinstitute.hellbender.tools.walkers.contamination
Summarizes counts of reads that support reference, alternate and other alleles for given sites.
GetPileupSummaries() - Constructor for class org.broadinstitute.hellbender.tools.walkers.contamination.GetPileupSummaries
 
getPinv() - Method in class org.broadinstitute.hellbender.utils.svd.SimpleSVD
 
getPinv() - Method in interface org.broadinstitute.hellbender.utils.svd.SVD
Get the pseudoinverse as calculated using the SVD
getPlatform(GATKRead, SAMFileHeader) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Returns the platform associated with the provided read's read group.
getPlatformUnit(GATKRead, SAMFileHeader) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Returns the platform unit associated with the provided read's read group.
getPlatformUnit() - Method in class picard.fingerprint.FingerprintIdDetails
 
getPloidyModel() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerGenotypingEngine
Returns the ploidy-model used by this genotyping engine.
getPluginBaseClass() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKAnnotationPluginDescriptor
 
getPluginBaseClass() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKReadFilterPluginDescriptor
 
getPluginDescriptors() - Method in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
Return the list of GATKCommandLinePluginDescriptors to be used for this CLP.
getPluginDescriptors() - Method in class org.broadinstitute.hellbender.engine.GATKTool
Return the list of GATKCommandLinePluginDescriptors to be used for this tool.
getPluginDescriptors() - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
Return the list of GATKCommandLinePluginDescriptor objects to be used for this CLP.
getPluginDescriptors() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.CountVariantsSpark
Return the list of GATKCommandLinePluginDescriptor objects to be used for this CLP.
getPoorQualityFrequencies() - Method in class picard.illumina.parser.readers.BclQualityEvaluationStrategy
Returns a view of number of qualities that failed, where the key is the quality score and the value is the number of observations.
getPopulationAFAnnotation(List<VariantContext>, List<Allele>, double) - Static method in class org.broadinstitute.hellbender.tools.walkers.mutect.GermlineProbabilityCalculator
 
getPopulationLikelihood() - Method in class picard.fingerprint.MatchResults
 
getPos() - Method in class picard.fingerprint.Snp
 
getPosition() - Method in class org.broadinstitute.hellbender.engine.AlignmentContext
 
getPosition() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVLocation
 
getPositionInfo() - Method in class picard.illumina.parser.CbclData
 
getPositiveMAD() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.LibraryStatistics
 
getPosteriorProbabilities() - Method in class picard.fingerprint.HaplotypeProbabilities
Returns the posterior probabilities using the population frequency as a prior.
getPower() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.BasicValidationResult
 
getPrecision() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.ConcordanceSummaryRecord
 
getPrePhasingMap() - Method in class picard.illumina.parser.Tile
 
getPrePhasingValue() - Method in class picard.illumina.parser.TilePhasingValue
 
getPreviousOnGenomeCigarElement() - Method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Get the cigar element of the previous genomic aligned position For example, we might have 1M2I3M, and be sitting at the someone in the 3M.
getPrevReferenceVertex(V) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Traverse the graph and get the previous reference vertex if it exists
getPrimaryInterval() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils.Mapping
 
getPrintableId() - Method in class picard.fingerprint.Fingerprint
 
getPriorProbablities() - Method in class picard.fingerprint.HaplotypeProbabilities
 
getProbabilitiesAsArray() - Method in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfile
Get the probabilities of the states as a single linear array of doubles
getProbabilityVector() - Method in class org.broadinstitute.hellbender.utils.genotyper.ProbabilityVector
 
getProbeIntervals() - Method in class picard.analysis.directed.CollectHsMetrics
 
getProbeIntervals() - Method in class picard.analysis.directed.CollectTargetedMetrics
 
getProbeIntervals() - Method in class picard.analysis.directed.CollectTargetedPcrMetrics
 
getProbeSetName() - Method in class picard.analysis.directed.CollectHsMetrics
 
getProbeSetName() - Method in class picard.analysis.directed.CollectTargetedMetrics
 
getProbeSetName() - Method in class picard.analysis.directed.CollectTargetedPcrMetrics
 
getProcess() - Method in class org.broadinstitute.hellbender.utils.python.StreamingPythonScriptExecutor
Get the Process object associated with this executor.
getProcess() - Method in class org.broadinstitute.hellbender.utils.runtime.ProcessControllerBase
 
getProcessOutputByLine() - Method in class org.broadinstitute.hellbender.utils.runtime.StreamingProcessController
Blocking call to retrieve output from the remote process by line.
getProcessOutputByPrompt() - Method in class org.broadinstitute.hellbender.utils.runtime.StreamingProcessController
Blocking call to retrieve output from the remote process by prompt synchronization.
getProgramName() - Method in class org.broadinstitute.hellbender.engine.spark.SparkCommandLineProgram
Returns the program's name.
getProgramProperty(Class<?>) - Static method in class org.broadinstitute.hellbender.Main
 
getProgramProperty(Class) - Static method in class picard.cmdline.PicardCommandLine
 
getProgramRecord() - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.AbstractAlignmentMerger
 
getProgramRecord() - Method in class picard.sam.AbstractAlignmentMerger
 
getProgressMeterRecordLabel() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
getProgressMeterRecordLabel() - Method in class org.broadinstitute.hellbender.engine.FeatureWalker
 
getProgressMeterRecordLabel() - Method in class org.broadinstitute.hellbender.engine.GATKTool
 
getProgressMeterRecordLabel() - Method in class org.broadinstitute.hellbender.engine.IntervalWalker
 
getProgressMeterRecordLabel() - Method in class org.broadinstitute.hellbender.engine.LocusWalker
 
getProgressMeterRecordLabel() - Method in class org.broadinstitute.hellbender.engine.ReadWalker
 
getProgressMeterRecordLabel() - Method in class org.broadinstitute.hellbender.engine.VariantWalkerBase
 
getProgressMeterRecordLabel() - Method in class org.broadinstitute.hellbender.tools.genomicsdb.GenomicsDBImport
 
getProteinChange() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getProteinChangeEndPosition(Integer, Integer) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Get the Protein change end position (1-based, inclusive) given the protein change start position and aligned alternate allele length.
getProteinChangeEndPosition() - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
getProteinChangePosition(Integer) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Get the Protein change start position (1-based, inclusive) given the aligned position of the coding sequence.
getProteinChangeStartPosition() - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
getProteinChangeString(SequenceComparison) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Creates the string representation of the codon change for the given SequenceComparison.
getPruneFactor() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingAssembler
 
getPruningMultiplicity() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseEdge
A special assessor that returns the multiplicity that should be used by pruning algorithm
getPruningMultiplicity() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.MultiSampleEdge
 
getQName() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.QNameAndInterval
 
getQual() - Method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Get the base quality score of the base at this aligned position on the genome
getQual() - Method in class org.broadinstitute.hellbender.utils.recalibration.QualQuantizer.QualInterval
 
getQual(EventType, int) - Method in class org.broadinstitute.hellbender.utils.recalibration.ReadRecalibrationInfo
Get the qual score for event type at offset
getQualities() - Method in class picard.illumina.parser.BclData
 
getQualities() - Method in class picard.illumina.parser.ReadData
 
getQualityAllCalled() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.IntegerCopyNumberSegment
 
getQualityEnd() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.IntegerCopyNumberSegment
 
getQualityScoreCovariate() - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.StandardCovariateList
 
getQualityScoreTable() - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationTables
 
getQualitySomeCalled() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.IntegerCopyNumberSegment
 
getQualityStart() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.IntegerCopyNumberSegment
 
getQuals() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils.FastqRead
returns phred-scaled quals with no bias
getQualsStream() - Method in class org.broadinstitute.hellbender.utils.codecs.sampileup.SAMPileupFeature
Get the qualities as a stream
getQualsString() - Method in class org.broadinstitute.hellbender.utils.codecs.sampileup.SAMPileupFeature
Returns pile of obseved qualities over the genomic location Note: this call costs O(n) and allocates fresh array each time
getQuantizationInfo() - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationReport
 
getQuantizationLevels() - Method in class org.broadinstitute.hellbender.utils.recalibration.QuantizationInfo
 
getQuantizedQuals() - Method in class org.broadinstitute.hellbender.utils.recalibration.QuantizationInfo
 
getQuerynameSortedAlignedRecords() - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.AbstractAlignmentMerger
 
getQuerynameSortedAlignedRecords() - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.SamAlignmentMerger
Reads the aligned SAM records into a SortingCollection and returns an iterator over that collection
getQuerynameSortedAlignedRecords() - Method in class picard.sam.AbstractAlignmentMerger
 
getQuerynameSortedAlignedRecords() - Method in class picard.sam.SamAlignmentMerger
Reads the aligned SAM records into a SortingCollection and returns an iterator over that collection
getRAC() - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationReport
 
getRandomDataForPlotting(int, List<VariantDatum>, List<VariantDatum>, List<VariantDatum>) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
 
getRandomDataGenerator() - Static method in class org.broadinstitute.hellbender.utils.Utils
 
getRandomGenerator() - Static method in class org.broadinstitute.hellbender.utils.Utils
 
getRank() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenReferenceTaxonProperties
 
getRank() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTreeNode
 
getRank() - Method in class org.broadinstitute.hellbender.utils.MannWhitneyU.RankedData
 
getRankOf(int) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTree
 
getRateFactor() - Method in enum org.broadinstitute.hellbender.tools.walkers.haplotypecaller.PairHMMLikelihoodCalculationEngine.PCRErrorModel
 
getRawData() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.ReducibleAnnotationData
 
getRawDescriptions() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_QualByDepth
 
getRawDescriptions() - Method in interface org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.ReducibleAnnotation
Returns the descriptions used for the VCF INFO meta field corresponding to the annotations raw key.
getRawDescriptions() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.RMSMappingQuality
 
getRawIntensities() - Method in class picard.illumina.parser.ReadData
 
getRawKeyName() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_BaseQualityRankSumTest
 
getRawKeyName() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_MappingQualityRankSumTest
 
getRawKeyName() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_QualByDepth
 
getRawKeyName() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_ReadPosRankSumTest
 
getRawKeyName() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RMSMappingQuality
 
getRawKeyName() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_StrandBiasTest
 
getRawKeyName() - Method in interface org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.ReducibleAnnotation
 
getRawKeyName() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.RMSMappingQuality
 
getRead() - Method in class org.broadinstitute.hellbender.engine.spark.ReadWalkerContext
 
getRead(int) - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.SubsettedLikelihoodMatrix
 
getRead() - Method in class org.broadinstitute.hellbender.utils.clipping.ReadClipper
The original read.
getRead(int) - Method in interface org.broadinstitute.hellbender.utils.genotyper.LikelihoodMatrix
Returns the allele given its index.
getRead() - Method in class org.broadinstitute.hellbender.utils.locusiterator.AlignmentStateMachine
Get the read we are aligning to the genome
getRead() - Method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Get the read for this pileup element.
getRead() - Method in class org.broadinstitute.hellbender.utils.recalibration.ReadRecalibrationInfo
Get the read involved in this recalibration info
getRead(int) - Method in class picard.illumina.parser.ClusterData
 
getReadBarcodeValue(SAMRecord, String) - Static method in class picard.sam.markduplicates.EstimateLibraryComplexity
 
getReadBaseQuality(GATKRead, int) - Static method in class org.broadinstitute.hellbender.tools.walkers.annotator.BaseQualityRankSumTest
 
getReadCoordinateForReferenceCoordinate(GATKRead, int, ReadUtils.ClippingTail) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Pre-processes the results of ReadUtils.getReadCoordinateForReferenceCoordinate(int, Cigar, int, boolean) to take care of two corner cases: 1.
getReadCoordinateForReferenceCoordinate(GATKRead, int) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Returns the read coordinate corresponding to the requested reference coordinate.
getReadCoordinateForReferenceCoordinate(int, Cigar, int, ReadUtils.ClippingTail, boolean) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
getReadCoordinateForReferenceCoordinateUpToEndOfRead(GATKRead, int, ReadUtils.ClippingTail) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
getReadEnds() - Method in class picard.sam.markduplicates.util.PhysicalLocationForMateCigarSet
Gets the set of read ends
getReadEndSetForOpticalDuplicates() - Method in class picard.sam.markduplicates.util.ReadEndsForMateCigar
Gets the read ends for optical duplicate tracking
getReadFiles() - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.OptionalReadInputArgumentCollection
 
getReadFiles() - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.ReadInputArgumentCollection
Get the list of BAM/SAM/CRAM files specified at the command line
getReadFiles() - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.RequiredReadInputArgumentCollection
 
getReadFilesNames() - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.OptionalReadInputArgumentCollection
 
getReadFilesNames() - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.ReadInputArgumentCollection
Get the list of BAM/SAM/CRAM filenames specified at the command line
getReadFilesNames() - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.RequiredReadInputArgumentCollection
 
getReadGroup() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
getReadGroup() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
getReadGroup() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Pair
 
getReadGroup() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getReadGroup() - Method in class picard.fingerprint.FingerprintResults
 
getReadGroup() - Method in class picard.sam.markduplicates.util.PhysicalLocationForMateCigar
 
getReadGroup() - Method in class picard.sam.markduplicates.util.ReadEnds
 
getReadGroup() - Method in interface picard.sam.util.PhysicalLocation
 
getReadGroup() - Method in class picard.sam.util.PhysicalLocationInt
 
getReadGroupCovariate() - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.StandardCovariateList
 
getReadGroupIDs() - Method in class org.broadinstitute.hellbender.utils.pileup.ReadPileup
Gets a set of the read groups represented in this pileup.
getReadGroupIDs(SAMFileHeader) - Static method in class org.broadinstitute.hellbender.utils.recalibration.covariates.ReadGroupCovariate
 
getReadGroupLibraryName(SAMReadGroupRecord) - Static method in class org.broadinstitute.hellbender.utils.read.markduplicates.LibraryIdGenerator
 
getReadGroupLibraryName(SAMReadGroupRecord) - Static method in class picard.sam.markduplicates.util.LibraryIdGenerator
 
getReadGroups() - Method in class org.broadinstitute.hellbender.utils.report.GATKReport
Gets the unique read groups in the table
getReadGroupTable() - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationTables
 
getReadIndexPaths() - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.ReadInputArgumentCollection
 
getReadIntervals() - Method in class org.broadinstitute.hellbender.utils.test.ReadsPreprocessingPipelineTestData
 
getReadLength() - Method in class org.broadinstitute.hellbender.utils.read.ArtificialBAMBuilder
 
getReadMetadata() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoveryInputMetaData.SampleSpecificData
 
getReadMetadata() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.FindBreakpointEvidenceSpark.AssembledEvidenceResults
 
getReadName() - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.HitsForInsert
 
getReadOffset() - Method in class org.broadinstitute.hellbender.utils.locusiterator.AlignmentStateMachine
What is our current offset in the read's bases that aligns us with the reference genome?
getReadPairs() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.EvidenceTargetLink
 
getReadPairTemplateNames() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.EvidenceTargetLink
 
getReadPaths() - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.OptionalReadInputArgumentCollection
 
getReadPaths() - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.ReadInputArgumentCollection
Get the list of BAM/SAM/CRAM files specified at the command line.
getReadPaths() - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.RequiredReadInputArgumentCollection
 
getReadPosition(GATKRead, int) - Static method in class org.broadinstitute.hellbender.tools.walkers.annotator.ReadPosRankSumTest
 
getReads() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
Get an unmodifiable copy of the list of reads currently in this assembly region.
getReads() - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
Loads the reads into a JavaRDD using the intervals specified, and filters them using the filter returned by GATKSparkTool.makeReadFilter().
getReads(JavaSparkContext) - Method in class org.broadinstitute.hellbender.engine.spark.ReadWalkerSpark
Loads reads and the corresponding reference and features into a JavaRDD for the intervals specified.
getReads(JavaSparkContext, int) - Method in class org.broadinstitute.hellbender.utils.nio.NioBam
Parses the BAM file into SAMRecords.
getReads() - Method in class org.broadinstitute.hellbender.utils.pileup.ReadPileup
Returns a list of the reads in this pileup.
getReads() - Method in class org.broadinstitute.hellbender.utils.test.ReadsPreprocessingPipelineTestData
 
getReadsContext() - Method in class org.broadinstitute.hellbender.engine.spark.IntervalWalkerContext
 
getReadsContext() - Method in class org.broadinstitute.hellbender.engine.spark.VariantWalkerContext
 
getReadSourceName() - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
Returns the name of the source of reads data.
getReadSpanLoc() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
The span of this assembly region, including the bp covered by all reads in this region.
getReadStartFrequency() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.LibraryStatistics
 
getReadStartLength() - Method in class org.broadinstitute.hellbender.utils.test.ReadsPreprocessingPipelineTestData
 
getReadToMateMap(ReadsContext, int) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Create a map of reads overlapping interval to their mates by looking for all possible mates within some maximum fragment size.
getReadType() - Method in class picard.illumina.parser.ReadData
 
getReadValidationStringency() - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.ReadInputArgumentCollection
Get the read validation stringency specified at the command line, or the default value if none was specified at the command line.
getRealignments() - Method in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.RealignmentEngine.RealignmentResult
 
getReasonForAlignmentClassificationFailure() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments
 
getRecalibrationTables() - Method in class org.broadinstitute.hellbender.utils.recalibration.BaseRecalibrationEngine
Get a possibly not-final recalibration table, to deal with distributed execution.
getRecalibrationTables() - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationReport
 
getRecommendedNumReducers() - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
Return the recommended number of reducers for a pipeline processing the reads.
getRecord() - Method in class picard.sam.markduplicates.util.ReadEndsForMateCigar
 
getRecordIterator() - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
getRecordReadName() - Method in class picard.sam.markduplicates.util.ReadEndsForMateCigar
 
getRecords() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.collections.AbstractRecordCollection
 
getRecords() - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalCollection
 
getRecordWriter(TaskAttemptContext) - Method in class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSink.SparkBAMOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSink.SparkCRAMOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSink.SparkHeaderlessSAMOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSink.SparkSAMOutputFormat
 
getRecordWriter(TaskAttemptContext, Path) - Method in class org.broadinstitute.hellbender.engine.spark.datasources.VariantsSparkSink.SparkHeaderlessVCFOutputFormat
 
getRecordWriter(TaskAttemptContext, OutputStream) - Method in class org.broadinstitute.hellbender.engine.spark.datasources.VariantsSparkSink.SparkHeaderlessVCFOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.broadinstitute.hellbender.engine.spark.datasources.VariantsSparkSink.SparkHeaderlessVCFOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.broadinstitute.hellbender.engine.spark.datasources.VariantsSparkSink.SparkVCFOutputFormat
 
getRef() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.PerAlleleCollection
 
getRef() - Method in class org.broadinstitute.hellbender.utils.codecs.sampileup.SAMPileupFeature
Returns the reference basse
getRefAllele() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getRefAllele() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AlleleSpecificAnnotationData
Get the reference allele for this allele-specific data.
getRefAllele() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.PerAlleleCollection
 
getRefCount() - Method in class org.broadinstitute.hellbender.tools.walkers.contamination.PileupSummary
 
getReference() - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
 
getReference() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.BasicValidationResult
 
getReference() - Method in class org.broadinstitute.hellbender.utils.read.ArtificialBAMBuilder
 
getReferenceAllele() - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
getReferenceAminoAcidSequence() - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
getReferenceBases(SimpleInterval) - Method in class org.broadinstitute.hellbender.engine.datasources.ReferenceFileSource
 
getReferenceBases(SimpleInterval) - Method in class org.broadinstitute.hellbender.engine.datasources.ReferenceHadoopSource
 
getReferenceBases(SimpleInterval) - Method in class org.broadinstitute.hellbender.engine.datasources.ReferenceMultiSource
Return reference bases for the given interval.
getReferenceBases(SimpleInterval) - Method in interface org.broadinstitute.hellbender.engine.datasources.ReferenceSource
 
getReferenceBases(SimpleInterval) - Method in class org.broadinstitute.hellbender.engine.spark.datasources.ReferenceTwoBitSource
Gets the reference bases spanning the requested interval.
getReferenceBases() - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
getReferenceBasesRDD(JavaSparkContext, int, ReferenceMultiSource, SAMSequenceDictionary, int, int) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVReferenceUtils
Create an RDD from the reference sequences.
getReferenceBroadcast() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoveryInputMetaData.ReferenceData
 
getReferenceBytes(V, V, boolean, boolean) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Walk along the reference path in the graph and pull out the corresponding bases
getReferenceCodingSequence() - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
Return the ReferenceSequence containing the coding region for the transcript of this SequenceComparison.
getReferenceContext() - Method in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerContext
 
getReferenceContext() - Method in class org.broadinstitute.hellbender.engine.spark.IntervalWalkerContext
 
getReferenceContext() - Method in class org.broadinstitute.hellbender.engine.spark.LocusWalkerContext
 
getReferenceContext() - Method in class org.broadinstitute.hellbender.engine.spark.ReadWalkerContext
 
getReferenceContext() - Method in class org.broadinstitute.hellbender.engine.spark.VariantWalkerContext
 
getReferenceContext() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getReferenceData() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoveryInputMetaData
 
getReferenceDictionary() - Method in class org.broadinstitute.hellbender.engine.GATKTool
Returns the reference sequence dictionary if there is a reference (hasReference() == true), otherwise null.
getReferenceFile() - Method in class picard.analysis.CollectAlignmentSummaryMetrics.CollectAlignmentRefArgCollection
 
getReferenceFile() - Method in class picard.analysis.CollectRrbsMetrics.CollectRrbsMetricsReferenceArgumentCollection
 
getReferenceFile() - Method in class picard.cmdline.argumentcollections.OptionalReferenceArgumentCollection
 
getReferenceFile() - Method in interface picard.cmdline.argumentcollections.ReferenceArgumentCollection
 
getReferenceFile() - Method in class picard.cmdline.argumentcollections.RequiredReferenceArgumentCollection
 
getReferenceFile() - Method in class picard.sam.CreateSequenceDictionary.CreateSeqDictReferenceArgumentCollection
 
getReferenceFile() - Method in class picard.sam.ReorderSam.ReorderSamReferenceArgumentCollection
 
getReferenceFile() - Method in class picard.util.ScatterIntervalsByNs.ScatterIntervalsByNReferenceArgumentCollection
 
getReferenceFileName() - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.OptionalReferenceInputArgumentCollection
 
getReferenceFileName() - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.ReferenceInputArgumentCollection
Get the name of the reference file specified at the command line.
getReferenceFileName() - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.RequiredReferenceInputArgumentCollection
 
getReferenceHaplotype() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResultSet
Query the reference haplotype in the result set.
getReferenceIndex(GATKRead, SAMFileHeader) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Returns the reference index in the given header of the read's contig, or SAMRecord.NO_ALIGNMENT_REFERENCE_INDEX if the read is unmapped.
getReferenceLength() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenTaxonScore
 
getReferencePath() - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.ReferenceInputArgumentCollection
Get the Path to the reference, may be null
getReferenceSequence() - Method in class org.broadinstitute.hellbender.metrics.SAMRecordAndReference
 
getReferenceSequence() - Method in class picard.metrics.SAMRecordAndReference
 
getReferenceSequenceDictionary(SAMSequenceDictionary) - Method in class org.broadinstitute.hellbender.engine.datasources.ReferenceFileSource
 
getReferenceSequenceDictionary(SAMSequenceDictionary) - Method in class org.broadinstitute.hellbender.engine.datasources.ReferenceHadoopSource
 
getReferenceSequenceDictionary(SAMSequenceDictionary) - Method in class org.broadinstitute.hellbender.engine.datasources.ReferenceMultiSource
Return a sequence dictionary for the reference.
getReferenceSequenceDictionary(SAMSequenceDictionary) - Method in interface org.broadinstitute.hellbender.engine.datasources.ReferenceSource
 
getReferenceSequenceDictionary(SAMSequenceDictionary) - Method in class org.broadinstitute.hellbender.engine.spark.datasources.ReferenceTwoBitSource
 
getReferenceSequenceDictionary() - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
 
getReferenceSequenceDictionaryBroadcast() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoveryInputMetaData.ReferenceData
 
getReferenceSinkVertex() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
 
getReferenceSourceVertex() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
 
getReferenceWindow() - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
getReferenceWindowForRead(GATKRead, int) - Static method in class org.broadinstitute.hellbender.utils.baq.BAQ
Given a read, get an interval representing the span of reference bases required by BAQ for that read
getReferenceWindowFunction() - Method in class org.broadinstitute.hellbender.engine.datasources.ReferenceMultiSource
 
getReferenceWindowFunction() - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
Window function that controls how much reference context to return for each read when using the reference source returned by GATKSparkTool.getReference().
getReferenceWindowFunction() - Method in class org.broadinstitute.hellbender.tools.spark.BaseRecalibratorSpark
 
getReferenceWindowFunction() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.BQSRPipelineSpark
 
getReferenceWindowFunction() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.ReadsPipelineSpark
 
getRefFrequency() - Method in class org.broadinstitute.hellbender.tools.walkers.contamination.PileupSummary
 
getRefNucleotide() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AllelicCount
 
getRefReadCount() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AllelicCount
 
getRefs() - Method in class org.broadinstitute.hellbender.utils.GenotypeCounts
 
getRegionForGenotyping() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResultSet
Returns the current region for genotyping.
getReInterpretMultiSegmentsCalls() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SegmentedCpxVariantSimpleVariantExtractor.ExtractedSimpleVariants
 
getReInterpretZeroOrOneSegmentCalls() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SegmentedCpxVariantSimpleVariantExtractor.ExtractedSimpleVariants
 
getRelativeAccuracy() - Method in class org.broadinstitute.hellbender.utils.solver.UnivariateSolverSpecifications
 
getRelativeClass() - Method in class org.broadinstitute.hellbender.utils.io.Resource
 
getRepresentativeRead() - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.HitsForInsert
 
getRepresentativeSnp() - Method in class picard.fingerprint.HaplotypeProbabilities
Returns a representative SNP for this haplotype.
getRepresentativeSnp() - Method in class picard.fingerprint.HaplotypeProbabilitiesFromGenotype
Returns the SNP who's genotype was used to construct the likelihoods.
getRepresentativeSnp() - Method in class picard.fingerprint.HaplotypeProbabilityOfNormalGivenTumor
 
getRequestedExpressions() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotatorEngine
 
getRequiredDouble(Map<String, String>, String) - Static method in class org.broadinstitute.hellbender.tools.walkers.vqsr.Tranche
 
getRequiredInteger(Map<String, String>, String) - Static method in class org.broadinstitute.hellbender.tools.walkers.vqsr.Tranche
 
getResolvedInstances() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKAnnotationPluginDescriptor
Merge the default annotations with the users's command line annotation requests, then initialize the resulting annotations.
getResolvedInstances() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKReadFilterPluginDescriptor
 
getResolvedIntervals(String, SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Given an interval query string and a sequence dictionary, determine if the query string can be resolved as a valid interval query against more than one contig in the dictionary, i.e., more than one of: prefix prefix:nnn prefix:nnn+ prefix:nnn-nnn and return the list of all possible interpretations (there can never be more than 2).
getResourceContentsAsFile(String) - Static method in class org.broadinstitute.hellbender.utils.io.Resource
Given a resource path that is either on the file system or in a jar, return a File.
getResourceContentsAsStream() - Method in class org.broadinstitute.hellbender.utils.io.Resource
Get the contents of this resource as an InputStream
getResourcePath() - Method in enum org.broadinstitute.hellbender.utils.R.RScriptLibrary
 
getResultFromFinalState(VariantContext, double[], StateTracker) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculator
Convert the final state of the state tracker into our result as an AFCalculationResult Assumes that stateTracker has been updated accordingly
getResultFromFinalState(VariantContext, double[], StateTracker) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AlleleFrequencyCalculator
 
getResultState() - Method in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfileState
 
getResultValue() - Method in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfileState
 
getRight() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.PairedStrandedIntervals
 
getRightClipPoint(byte[]) - Method in class org.broadinstitute.hellbender.transformers.BaseQualityClipReadTransformer
Returns right clip point or -1 if no clip
getRowMedians(RealMatrix) - Static method in class org.broadinstitute.hellbender.utils.MatrixSummaryUtils
Return an array containing the median for each row in the given matrix.
getRowVariances(RealMatrix) - Static method in class org.broadinstitute.hellbender.utils.MatrixSummaryUtils
Return an array containing the variance for each row in the given matrix.
getRunFile(File, Pattern) - Method in class picard.illumina.parser.ParameterizedFileUtil
 
getRunning() - Static method in class org.broadinstitute.hellbender.utils.runtime.ProcessControllerBase
 
getRunningMetric(int) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.TrancheManager.SelectionMetric
 
getRunningMetric(int) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.TrancheManager.TruthSensitivityMetric
 
getSafeNonExistentFile(String) - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest
Return a File object representing a file with the given name and extension that is guaranteed not to exist.
getSafeNonExistentPath(String) - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest
Return a Path object representing a file with the given name and extension that is guaranteed not to exist.
getSamFileHeader() - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalCollection
Can return null
getSamFileHeader() - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalHeader
Can be null
getSamFileHeader() - Method in class picard.analysis.CollectWgsMetrics
This method should only be called after this.getSamReader() is called.
getSAMFileWriter(String, SAMFileHeader, boolean) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFileUtils
Supported format: BAM and SAM.
getSAMFlagsForRead(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Construct a set of SAM bitwise flags from a GATKRead
getSample() - Method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationSampleTransitionSummary
 
getSample(int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingData
 
getSample(int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingLikelihoods
 
getSample(int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.HeterogeneousPloidyModel
 
getSample(int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.HomogeneousPloidyModel
 
getSample() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.MixingFraction
 
getSample(int) - Method in class org.broadinstitute.hellbender.utils.genotyper.IndexedSampleList
 
getSample(int) - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Returns sample name given its index.
getSample(int) - Method in interface org.broadinstitute.hellbender.utils.genotyper.SampleList
Returns the element given its index within the set.
getSample(String) - Method in class org.broadinstitute.hellbender.utils.samples.SampleDB
Get a sample by its ID If an alias is passed in, return the main sample object
getSample() - Method in class picard.fingerprint.Fingerprint
 
getSample() - Method in class picard.fingerprint.FingerprintIdDetails
 
getSample() - Method in class picard.fingerprint.MatchResults
 
getSampleAlias() - Method in class picard.fingerprint.FingerprintResults
 
getSampleContamination() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.StandardCallerArgumentCollection
Returns an unmodifiable view of the map of SampleId -> contamination.
getSampleCount() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.HeterozygosityCalculator
 
getSampleId() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoveryInputMetaData.SampleSpecificData
 
getSampleId(SAMFileHeader) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVUtils
 
getSampleLikelihood() - Method in class picard.fingerprint.MatchResults
 
getSampleName() - Method in interface org.broadinstitute.hellbender.tools.copynumber.formats.metadata.SampleLocatableMetadata
 
getSampleName() - Method in interface org.broadinstitute.hellbender.tools.copynumber.formats.metadata.SampleMetadata
 
getSampleName() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.metadata.SimpleSampleLocatableMetadata
 
getSampleName() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.metadata.SimpleSampleMetadata
 
getSampleName() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CoveragePerContig
 
GetSampleName - Class in org.broadinstitute.hellbender.tools
Emit a single sample name from the bam header into an output file.
GetSampleName() - Constructor for class org.broadinstitute.hellbender.tools.GetSampleName
 
getSampleName(GATKRead, SAMFileHeader) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Returns the sample name associated with the provided read's read group.
getSamples() - Method in class org.broadinstitute.hellbender.engine.MultiVariantDataSource
Return lexicographically sorted set of uniquified sample names merged from across input data sources
getSamples(V, Class<U>, int) - Method in class org.broadinstitute.hellbender.utils.mcmc.GibbsSampler
Returns a list of samples for a specified model parameter, discarding the first numBurnIn samples.
getSamples(SAMFileHeader) - Method in class org.broadinstitute.hellbender.utils.pileup.ReadPileup
Gets a set of the samples represented in this pileup.
getSamples() - Method in class org.broadinstitute.hellbender.utils.read.ArtificialBAMBuilder
 
getSamples() - Method in class org.broadinstitute.hellbender.utils.samples.SampleDB
 
getSamplesForVariants() - Method in class org.broadinstitute.hellbender.engine.MultiVariantWalker
Get in name-sorted order a list of samples merged from the driving variants files.
getSamplesFromHeader(SAMFileHeader) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Pull out the sample names from a SAMFileHeader note that we use a TreeSet so that they are sorted
getSampleSpecificData() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoveryInputMetaData
 
getSamReader() - Method in class picard.analysis.CollectWgsMetrics
Gets the SamReader from which records will be examined.
getSamReader() - Method in class picard.analysis.CollectWgsMetricsWithNonZeroCoverage
 
getSAMReadGroupRecord(GATKRead, SAMFileHeader) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Returns a SAMReadGroupRecord object corresponding to the provided read's read group.
getSamRecord() - Method in class org.broadinstitute.hellbender.metrics.SAMRecordAndReference
 
getSamRecord() - Method in class picard.metrics.SAMRecordAndReference
 
getSamRecordIndex() - Method in class picard.sam.markduplicates.util.ReadEndsForMateCigar
A number of convenience functions
getSamRecordSetBuilder() - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
getSAMString() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Get a string representation of this read in SAM string format, terminated with '\n'.
getSAMString() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getSanitizedUMI(SAMRecord, String) - Static method in class picard.sam.markduplicates.UmiUtil
Returns an instance of the UMI without dashes
getSAtagForGoodMappingToNonCanonicalChromosome() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments
 
getScatteredFileName(File, long, String) - Static method in class picard.util.IntervalListTools
 
getScheme(boolean) - Method in class picard.vcf.GenotypeConcordanceSchemeFactory
 
getScore() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.Path
Get the total score of this path (bigger is better)
getScore() - Method in class org.broadinstitute.hellbender.utils.haplotype.Haplotype
Get the score (an estimate of the support) of this haplotype
getScore() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.EmptyFragment
 
getScore() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Fragment
 
getScore() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Pair
 
getScore() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.PairedEnds
 
getScoreNormalized() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenTaxonScore
 
getScriptException(String) - Method in class org.broadinstitute.hellbender.utils.python.PythonExecutorBase
Return an exception specific to this executor type, to be thrown on error conditions.
getScriptException(String) - Method in class org.broadinstitute.hellbender.utils.R.RScriptExecutor
Return an exception specific to this executor type, to be thrown on error conditions.
getScriptException(String) - Method in class org.broadinstitute.hellbender.utils.runtime.ScriptExecutor
Called by the script executor when error is encountered.
getSecondaryVariantClassification() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getSecondOfPair(int) - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.HitsForInsert
 
getSecondsInAssembly() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.AlignedAssemblyOrExcuse
 
getSegment() - Method in class org.broadinstitute.hellbender.tools.walkers.contamination.MinorAlleleFractionRecord
 
getSelenocysteines() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfTranscriptFeature
 
getSelfScore() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenTaxonScore
 
getSensitivity() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.ConcordanceSummaryRecord
 
getSensitivity(GenotypeConcordanceScheme, GenotypeConcordanceStates.TruthState[]) - Method in class picard.vcf.GenotypeConcordanceCounts
Returns the sensitivity defined by the scheme across the subset of truth states.
getSentinel() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree
Get the special sentinel value that will be used to signal novelty when putting a new interval into the tree, or to signal "not found" when removing an interval.
getSequence(String) - Method in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark.ReferenceMultiSourceAdapter
 
getSequence() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseVertex
Get the sequence of bases contained in this vertex Do not modify these bytes in any way!
getSequenceDictionary() - Method in class org.broadinstitute.hellbender.engine.FeatureDataSource
Returns the sequence dictionary for this source of Features.
getSequenceDictionary() - Method in class org.broadinstitute.hellbender.engine.MultiVariantDataSource
Returns the aggregate sequence dictionary for this source of Variants.
getSequenceDictionary() - Method in class org.broadinstitute.hellbender.engine.ReadsDataSource
Get the sequence dictionary for this ReadsDataSource
getSequenceDictionary() - Method in interface org.broadinstitute.hellbender.engine.ReferenceDataSource
Get the sequence dictionary for this reference
getSequenceDictionary() - Method in class org.broadinstitute.hellbender.engine.ReferenceFileSource
Get the sequence dictionary for this reference
getSequenceDictionary() - Method in class org.broadinstitute.hellbender.engine.ReferenceMemorySource
Get the sequence dictionary for this reference
getSequenceDictionary() - Method in class org.broadinstitute.hellbender.tools.copynumber.denoising.HDF5SVDReadCountPanelOfNormals
 
getSequenceDictionary() - Method in interface org.broadinstitute.hellbender.tools.copynumber.denoising.SVDReadCountPanelOfNormals
Returns the sequence dictionary common to all of the read counts used to build the PoN.
getSequenceDictionary() - Method in interface org.broadinstitute.hellbender.tools.copynumber.formats.metadata.LocatableMetadata
 
getSequenceDictionary() - Method in interface org.broadinstitute.hellbender.tools.copynumber.formats.metadata.SampleLocatableMetadata
 
getSequenceDictionary() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.metadata.SimpleLocatableMetadata
 
getSequenceDictionary() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.metadata.SimpleSampleLocatableMetadata
 
getSequenceDictionary() - Method in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark.ReferenceMultiSourceAdapter
 
getSequenceDictionary() - Method in class org.broadinstitute.hellbender.utils.GenomeLocParser
Return the master sequence dictionary used within this GenomeLocParser
getSequenceDictionaryForDrivingVariants() - Method in class org.broadinstitute.hellbender.engine.MultiVariantWalker
 
getSequenceDictionaryForDrivingVariants() - Method in class org.broadinstitute.hellbender.engine.VariantWalker
 
getSequenceDictionaryForDrivingVariants() - Method in class org.broadinstitute.hellbender.engine.VariantWalkerBase
Return the primary sequence dictionary to be used for the driving variants for this tool.
getSequenceDictionaryValidationArgumentCollection() - Method in class org.broadinstitute.hellbender.engine.GATKTool
getSequenceDictionaryValidationArgumentCollection() - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
subclasses can override this to provide different default behavior for sequence dictionary validation
getSequenceDictionaryValidationArgumentCollection() - Method in class org.broadinstitute.hellbender.tools.spark.bwa.BwaSpark
 
getSequenceDictionaryValidationArgumentCollection() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.BwaAndMarkDuplicatesPipelineSpark
 
getSequencerType() - Method in enum org.broadinstitute.hellbender.utils.NGSPlatform
The broad "type" of sequencer this platform represents (discrete or flow)
getSequenceString() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseVertex
Get a string representation of the bases in this vertex
getSequentialFileList(File) - Static method in class picard.sam.FastqToSam
Get a list of FASTQs that are sequentially numbered based on the first (base) fastq.
getSets() - Method in class org.broadinstitute.hellbender.tools.spark.utils.LargeLongHopscotchSet
 
getSeverity() - Method in enum org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation.VariantClassification
 
getSex() - Method in class org.broadinstitute.hellbender.utils.samples.Sample
 
getSex() - Method in class picard.pedigree.PedFile.PedTrio
 
getShardedCollectionSortOrder(List<? extends AbstractLocatableCollection<METADATA, RECORD>>) - Static method in class org.broadinstitute.hellbender.tools.copynumber.formats.collections.AbstractLocatableCollection
Gets a list of locatable collections and returns the ascending sort order of collections.
getShardNumber() - Method in class org.broadinstitute.hellbender.engine.ReferenceShard
 
getShardNumber() - Method in class org.broadinstitute.hellbender.engine.VariantShard
 
getShardNumberFromInterval(Locatable) - Static method in class org.broadinstitute.hellbender.engine.ReferenceShard
getShardNumberFromInterval returns the ReferenceShard that overlap the read's start position.
getSigma() - Method in class org.broadinstitute.hellbender.utils.activityprofile.BandPassActivityProfile
Get the Gaussian kernel sigma value
getSingletonReads() - Method in class org.broadinstitute.hellbender.utils.fragments.FragmentCollection
Gets the T elements not containing overlapping elements, in no particular order.
getSingletonSample(VariantContext) - Static method in class picard.vcf.CallingMetricAccumulator
 
getSingularValues() - Method in class org.broadinstitute.hellbender.tools.copynumber.denoising.HDF5SVDReadCountPanelOfNormals
 
getSingularValues() - Method in interface org.broadinstitute.hellbender.tools.copynumber.denoising.SVDReadCountPanelOfNormals
Returns a modifiable copy of an array of the singular values of the eigensamples in decreasing order.
getSingularValues() - Method in class org.broadinstitute.hellbender.utils.svd.SimpleSVD
 
getSingularValues() - Method in interface org.broadinstitute.hellbender.utils.svd.SVD
Get the singular values as an array.
getSinks() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Get the set of sink vertices of this graph
getSizeOf() - Static method in class picard.sam.markduplicates.util.ReadEndsForMarkDuplicates
 
getSizeOf() - Static method in class picard.sam.markduplicates.util.ReadEndsForMarkDuplicatesWithBarcodes
 
getSizeOnRead() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
 
getSkipNLoci() - Method in class org.broadinstitute.hellbender.utils.read.ArtificialBAMBuilder
 
getSnp(String) - Method in class picard.fingerprint.HaplotypeBlock
Gets a SNP by name if it belongs to this haplotype.
getSnp(String, int) - Method in class picard.fingerprint.HaplotypeMap
Queries a Snp by chromosome and position.
getSnpCounter() - Method in class picard.vcf.GenotypeConcordance
 
getSnpFalsePositiveRate() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.FalsePositiveRecord
 
getSnpFalsePositives() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.FalsePositiveRecord
 
getSnpGenotype(Snp, DiploidHaplotype) - Method in class picard.fingerprint.HaplotypeBlock
Gets the expected genotype of the provided SNP given the provided haplotype of this haplotype block.
getSnps() - Method in class picard.fingerprint.HaplotypeBlock
Returns an unmodifiable, unordered, collection of all SNPs in this haplotype block.
getSNPSubstitutionType(VariantContext) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Returns the type of the substitution (transition vs transversion) represented by this variant.
getSoftEnd() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Calculates the reference coordinate for the end of the read taking into account soft clips but not hard clips.
getSoftEnd(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Calculates the reference coordinate for the end of the read taking into account soft clips but not hard clips.
getSoftEnd() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getSoftStart() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Calculates the reference coordinate for the beginning of the read taking into account soft clips but not hard clips.
getSoftStart(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Calculates the reference coordinate for the beginning of the read taking into account soft clips but not hard clips.
getSoftStart() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getSolexaQualityCharFromFourQualities(String[], int, FormatUtil) - Static method in class picard.util.IlluminaUtil
Get a Solexa ASCII quality value from an array of strings that are integer qualities in this order: [cycle-1-A, cycle-1-C, cycle-1-G, cycle-1-T, cycle-2-A, ...].
getSortedSampleSet(Map<String, VCFHeader>, GATKVariantContextUtils.GenotypeMergeType) - Static method in class org.broadinstitute.hellbender.utils.variant.VcfUtils
 
getSource() - Method in class org.broadinstitute.hellbender.utils.nio.ChannelAsSeekableStream
 
getSource() - Method in class org.broadinstitute.hellbender.utils.tsv.TableReader
Returns the reader source name.
getSource() - Method in class picard.fingerprint.Fingerprint
 
getSourceContig() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments
 
getSources() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Get the set of source vertices of this graph
getSpan() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
Get the raw span of this assembly region (excluding the extension)
getSpan() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.PartitionBounds
 
getSpan() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.PartitionStatistics
 
getSpan() - Method in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfile
Get the span of this activity profile, which is from the start of the first state to the stop of the last
getSpanningInterval(List<? extends Locatable>) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
getSpanningInterval returns interval that covers all of the locations passed in.
getSparkContext(String, Map<String, String>, String) - Static method in class org.broadinstitute.hellbender.engine.spark.SparkContextFactory
Get a JavaSparkContext.
getSparkMaster() - Method in class org.broadinstitute.hellbender.engine.spark.SparkCommandLineArgumentCollection
 
getSparkProperties() - Method in class org.broadinstitute.hellbender.engine.spark.SparkCommandLineArgumentCollection
 
getSpecificity(GenotypeConcordanceScheme, GenotypeConcordanceStates.TruthState[]) - Method in class picard.vcf.GenotypeConcordanceCounts
Returns the specificity defined by the scheme across the subset of truth states.
getSplicesForTesting() - Method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.OverhangFixingManager
For testing purposes only
getSplitBy(GATKRead, SAMFileHeader) - Method in class org.broadinstitute.hellbender.tools.readersplitters.ReaderSplitter
Returns the value from this record for this splitter.
getSplitBy(GATKRead, SAMFileHeader) - Method in class org.broadinstitute.hellbender.tools.readersplitters.ReadGroupSplitter
 
getSplitByFunction() - Method in class org.broadinstitute.hellbender.tools.readersplitters.LibraryNameSplitter
 
getSplitByFunction() - Method in class org.broadinstitute.hellbender.tools.readersplitters.ReadGroupIdSplitter
 
getSplitByFunction() - Method in class org.broadinstitute.hellbender.tools.readersplitters.ReadGroupSplitter
 
getSplitByFunction() - Method in class org.broadinstitute.hellbender.tools.readersplitters.SampleNameSplitter
 
getSpliteratorForDrivingVariants() - Method in class org.broadinstitute.hellbender.engine.MultiVariantWalker
 
getSpliteratorForDrivingVariants() - Method in class org.broadinstitute.hellbender.engine.VariantWalker
 
getSpliteratorForDrivingVariants() - Method in class org.broadinstitute.hellbender.engine.VariantWalkerBase
Return a spliterator to be used to iterate over the elements of the driving variants.
getSplitReads() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.EvidenceTargetLink
 
getSplitReadTemplateNames() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.EvidenceTargetLink
 
getSplitsBy(SAMFileHeader) - Method in class org.broadinstitute.hellbender.tools.readersplitters.ReaderSplitter
Returns the values from the header that will be used to split the reader.
getSplitsBy(SAMFileHeader) - Method in class org.broadinstitute.hellbender.tools.readersplitters.ReadGroupSplitter
 
getStandardBQSRReadFilterList() - Static method in class org.broadinstitute.hellbender.tools.walkers.bqsr.BaseRecalibrator
Return the full list of raw read filters used for BQSR contexts, including WellFormed.
getStandardCovariateClassNames() - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.StandardCovariateList
Returns the list of simple class names of standard covariates.
getStandardHaplotypeCallerAnnotationGroups() - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerEngine
 
getStandardizedCopyRatios() - Method in class org.broadinstitute.hellbender.tools.copynumber.denoising.SVDDenoisedCopyRatioResult
 
getStandardMutect2AnnotationGroups() - Static method in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2Engine
 
getStandardUsagePreamble() - Method in class picard.cmdline.CommandLineProgram
 
getStandardUsagePreamble(Class<?>) - Static method in class picard.cmdline.CommandLineProgram
A typical command line program will call this to get the beginning of the usage message, and then typically append a description of the program, like this: public String USAGE = getStandardUsagePreamble(getClass()) + "Frobnicate the freebozle."
getStart() - Method in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker.TruthVersusEval
 
getStart() - Method in class org.broadinstitute.hellbender.engine.AlignmentContext
 
getStart() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
 
getStart() - Method in interface org.broadinstitute.hellbender.engine.Shard
 
getStart() - Method in class org.broadinstitute.hellbender.engine.ShardBoundary
 
getStart() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AlleleFractionSegment
 
getStart() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AllelicCount
 
getStart() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AnnotatedInterval
 
getStart() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CopyRatio
 
getStart() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CopyRatioSegment
 
getStart() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.IntegerCopyNumberSegment
 
getStart() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.IntervalCopyNumberGenotypingData
 
getStart() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.ModeledSegment
 
getStart() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.MultidimensionalSegment
 
getStart() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.SimpleCount
 
getStart() - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedInterval
 
getStart() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getStart() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils.Mapping
Returns the primary interval start position, or SAMRecord.NO_ALIGNMENT_START if unmapped.
getStart() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVInterval
 
getStart() - Method in class org.broadinstitute.hellbender.tools.walkers.contamination.MinorAlleleFractionRecord
 
getStart() - Method in class org.broadinstitute.hellbender.tools.walkers.contamination.PileupSummary
 
getStart() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.BasicValidationResult
 
getStart() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
getStart() - Method in class org.broadinstitute.hellbender.utils.codecs.sampileup.SAMPileupFeature
 
getStart() - Method in class org.broadinstitute.hellbender.utils.codecs.table.TableFeature
 
getStart() - Method in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvTableFeature
 
getStart() - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
 
getStart() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getStart() - Method in class org.broadinstitute.hellbender.utils.SimpleInterval
Gets the 1-based start position of the interval on the contig.
getStart() - Method in class org.broadinstitute.hellbender.utils.variant.MinimalVariant
 
getStart() - Method in class org.broadinstitute.hellbender.utils.variant.VariantContextVariantAdapter
 
getStartCodon() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfExonFeature
 
getStartColumn() - Method in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvLocatableTableCodec
Do not call before XsvLocatableTableCodec.readActualHeader(LineIterator) or exception will be thrown..
getStartColumnName() - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalHeader
 
getStartLocation() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVInterval
 
getStartLocation() - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
 
getStartPosition() - Method in class org.broadinstitute.hellbender.utils.haplotype.Haplotype
 
getStartPositionInTranscript(Locatable, List<? extends Locatable>, Strand) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Gets the position describing where the given allele and variant lie inside the given transcript using transcript-based coordinates.
getStartPositions() - Method in class org.broadinstitute.hellbender.utils.haplotype.EventMap
Get the starting positions of events in this event map
getStateList() - Method in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfile
Get the list of activity profile results in this object
getStateTracker(boolean, int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculator
Retrieves the state tracker.
getStateTracker(boolean, int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AlleleFrequencyCalculator
 
getStatistics() - Method in class org.broadinstitute.hellbender.utils.nio.SeekableByteChannelPrefetcher
 
getStatus() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResult
 
getStderr() - Method in class org.broadinstitute.hellbender.utils.runtime.ProcessOutput
 
getStderrSettings() - Method in class org.broadinstitute.hellbender.utils.runtime.ProcessSettings
 
getStdinSettings() - Method in class org.broadinstitute.hellbender.utils.runtime.ProcessSettings
 
getStdout() - Method in class org.broadinstitute.hellbender.utils.runtime.ProcessOutput
 
getStdoutSettings() - Method in class org.broadinstitute.hellbender.utils.runtime.ProcessSettings
 
getStop() - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
 
getStopCodon() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfExonFeature
 
getStopLocation() - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
 
getStopPosition() - Method in class org.broadinstitute.hellbender.utils.haplotype.Haplotype
 
getStrand() - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
getStrand() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.StrandedInterval
 
getStrandCorrectedAllele(Allele, Strand) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Get the strand-corrected (reverse complemented) Allele for the given Allele and Strand.
getStrandCountsFromLikelihoodMap(VariantContext, ReadLikelihoods<Allele>, ReducibleAnnotationData<List<Integer>>, int) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_StrandBiasTest
Allocate and fill a 2x2 strand contingency table.
getStrandedOffset(boolean, int, int) - Static method in class org.broadinstitute.hellbender.utils.recalibration.covariates.ContextCovariate
Helper method: computes the correct offset to use in computations of covariate values.
getStrandedUnclippedStart(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Returns the read's unclipped start if the read is on the forward strand, or the read's unclipped end if the read is on the reverse strand.
getStrandSwitch() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.NovelAdjacencyAndAltHaplotype
 
getStratifiedPileups(Locatable) - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Collect a map stratified per-sample of the base pileups at the provided Location NOTE: Since we shouldn't need to use the pileup if we have more reliable liklihoods, we want to discourage their use
getStratifiedPileups(Locatable) - Method in class org.broadinstitute.hellbender.utils.genotyper.UnfilledReadsLikelihoods
Collect a map stratified per-sample of the base pileups at the provided Location
getStreamLocations() - Method in class org.broadinstitute.hellbender.utils.runtime.InputStreamSettings
 
getStreamLocations() - Method in class org.broadinstitute.hellbender.utils.runtime.OutputStreamSettings
 
getString() - Method in class org.broadinstitute.hellbender.utils.test.ArgumentsBuilder
 
getStructuralVariantLength() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVContext
Returns the absolute structural variant length as recorded in the SVLEN annotation.
getSubsequenceAt(String, long, long) - Method in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark.ReferenceMultiSourceAdapter
 
getSubsequenceAt(String, long, long) - Method in class org.broadinstitute.hellbender.utils.fasta.CachingIndexedFastaSequenceFile
Gets the subsequence of the contig in the range [start,stop] Uses the sequence cache if possible, or updates the cache to handle the request.
getSubset(SimpleInterval) - Method in class org.broadinstitute.hellbender.utils.reference.ReferenceBases
getSubset returns only the bases of the interval passed in.
getSuffix() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.MultiDeBruijnVertex
Get the suffix byte of this DeBruijnVertex The suffix byte is simply the last byte of the kmer sequence, so if this is holding sequence ACT getSuffix would return T
getSuffixString() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.MultiDeBruijnVertex
Get the string representation of the suffix of this DeBruijnVertex
getSuggestedAlternateCommand(Set<Class<?>>, String) - Method in class org.broadinstitute.hellbender.Main
When a command does not match any known command, searches for similar commands, using the same method as GIT *
getSum(Set<GenotypeConcordanceStates.TruthState>, Set<GenotypeConcordanceStates.CallState>) - Method in class picard.vcf.GenotypeConcordanceCounts
Returns the sum of all pairs of tuples defined by the truth state set and call state set.
getSum() - Method in class picard.vcf.GenotypeConcordanceCounts
Returns the sum of all pairs of tuples defined by the truth state set and call state set.
getSummaryLine() - Method in class org.broadinstitute.hellbender.engine.filters.CountingReadFilter
 
getSummaryLine() - Method in class org.broadinstitute.hellbender.engine.filters.CountingVariantFilter
 
getSummaryLineForLevel(int) - Method in class org.broadinstitute.hellbender.engine.filters.CountingReadFilter
 
getSummaryLineForLevel(int) - Method in class org.broadinstitute.hellbender.engine.filters.CountingVariantFilter
 
getSuperCategoryMap() - Static method in class picard.util.help.HelpConstants
 
getSuperCategoryProperty(String) - Static method in class org.broadinstitute.hellbender.utils.help.HelpConstants
Given a group name, return a supercategory string for use by the online doc system to determine which supercateogry the group is in.
getSuperCategoryProperty(String) - Static method in class picard.util.help.HelpConstants
Given a group name, return a supercategory string for use by the online doc system to determine which supercateogry the group is in.
getSupplementaryIntervals() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils.Mapping
 
getSupportedFuncotationFields() - Method in class org.broadinstitute.hellbender.tools.funcotator.DataSourceFuncotationFactory
 
getSupportedFuncotationFields() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.cosmic.CosmicFuncotationFactory
 
getSupportedFuncotationFields() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationFactory
 
getSupportedFuncotationFields() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.vcf.VcfFuncotationFactory
 
getSupportedFuncotationFields() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv.LocatableXsvFuncotationFactory
 
getSupportedFuncotationFields() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv.SimpleKeyXsvFuncotationFactory
 
getSupportInformation() - Method in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
 
getSupportingContigIds() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVContext
Returns the ids of the assembled contig that support this context's structural variant.
getSupportingStates() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
An ordered list (by genomic coordinate) of the ActivityProfileStates that went into this active region.
getSupportLowerBound() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.BetaBinomialDistribution
 
getSupportUpperBound() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.BetaBinomialDistribution
 
getSVLength() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvType
 
getSymbAltAlleleLine(String) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFHeaderLines
 
getSymbAltAlleleLines() - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFHeaderLines
 
getT() - Method in class picard.illumina.parser.FourChannelIntensityData
 
getTabixFormat() - Method in class org.broadinstitute.hellbender.utils.codecs.ProgressReportingDelegatingCodec
 
getTabixFormat() - Method in class org.broadinstitute.hellbender.utils.codecs.sampileup.SAMPileupCodec
 
getTable(int) - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationTables
 
getTable(String) - Method in class org.broadinstitute.hellbender.utils.report.GATKReport
Return a table with a given name
getTableForCovariate(Covariate) - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationTables
 
getTableFromSamples(GenotypesContext, int) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.StrandBiasTest
Create the contingency table by retrieving the per-sample strand bias annotation and adding them together
getTableName() - Method in class org.broadinstitute.hellbender.utils.report.GATKReportTable
 
getTables() - Method in class org.broadinstitute.hellbender.utils.report.GATKReport
 
getTagFilterPrefix() - Method in class org.broadinstitute.hellbender.utils.help.GATKHelpDocWorkUnitHandler
 
getTagFilterPrefix() - Method in class picard.util.help.PicardHelpDocWorkUnitHandler
 
getTailAlignment() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignedContig
 
getTailAlignment() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments
 
getTarget() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.TrancheManager.SelectionMetric
 
getTarget() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.TrancheManager.TruthSensitivityMetric
 
getTargetPartitionSize() - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
Returns the size of each input partition (in bytes) that is used to determine the recommended number of reducers for running a processing pipeline.
getTargetTerritory() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.FalsePositiveRecord
 
getTempFilePath(String, String) - Static method in class org.broadinstitute.hellbender.utils.gcs.BucketUtils
Get a temporary file path based on the prefix and extension provided.
getTemplateName() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.ReadEvidence
 
getTemplateName(DocWorkUnit) - Method in class org.broadinstitute.hellbender.utils.help.GATKHelpDocWorkUnitHandler
 
getTemplateName(DocWorkUnit) - Method in class picard.util.help.PicardHelpDocWorkUnitHandler
 
getTemplateSize() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.ReadEvidence
 
getTempPath(MiniDFSCluster, String, String) - Static method in class org.broadinstitute.hellbender.utils.test.MiniClusterUtils
 
getTestedClassName() - Method in class org.broadinstitute.hellbender.utils.test.BaseTest
Returns the name of the class being tested.
getTestedToolName() - Method in interface org.broadinstitute.hellbender.utils.test.CommandLineProgramTester
Returns the name for the tested tool.
getTestedToolName() - Method in class org.broadinstitute.hellbender.utils.test.testers.CleanSamTester
 
getTestFile(String) - Method in class org.broadinstitute.hellbender.utils.test.BaseTest
 
getTests(Class<?>) - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest.TestDataProvider
Return all of the data providers in the form expected by TestNG of type class C
getTestSparkContext() - Static method in class org.broadinstitute.hellbender.engine.spark.SparkContextFactory
Get the test JavaSparkContext if it has been registered, otherwise returns null.
getTestSparkContext(Map<String, String>) - Static method in class org.broadinstitute.hellbender.engine.spark.SparkContextFactory
Get the test JavaSparkContext if it has been registered, otherwise returns null.
getTheoreticalFPP(long) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongBloomFilter
 
getThreadingGraph() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResult
 
getThreadLocal() - Static method in class org.broadinstitute.hellbender.utils.runtime.ProcessController
Returns a thread local ProcessController.
getThreshold(double) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.TrancheManager.SelectionMetric
 
getThreshold(double) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.TrancheManager.TruthSensitivityMetric
 
getThresholdForSelectingAdaptersToKeep() - Method in class picard.util.AdapterMarker
 
getTies() - Method in class org.broadinstitute.hellbender.utils.MannWhitneyU.TestStatistic
 
getTile() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
getTile() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Pair
 
getTile() - Method in class picard.illumina.parser.CbclData
 
getTile() - Method in class picard.illumina.parser.ClusterData
 
getTile() - Method in class picard.illumina.parser.readers.AbstractIlluminaPositionFileReader
 
getTile() - Method in interface picard.sam.util.PhysicalLocation
 
getTile() - Method in class picard.sam.util.PhysicalLocationInt
 
getTiledFiles(File, Pattern) - Static method in class picard.illumina.NewIlluminaBasecallsConverter
 
getTiledFiles(File, Pattern) - Method in class picard.illumina.parser.ParameterizedFileUtil
Return all files that match pattern of the given file type in the given base directory
getTileFromReadName(String) - Static method in class picard.util.IlluminaUtil
Parse the tile # from the read name.
getTileInfo() - Method in class picard.illumina.parser.readers.BaseBclReader.CycleData
 
getTileNum() - Method in class picard.illumina.parser.readers.BaseBclReader.TileData
 
getTileNumber() - Method in class picard.illumina.parser.readers.TileMetricsOutReader.IlluminaLaneTileCode
 
getTileNumber() - Method in class picard.illumina.parser.readers.TileMetricsOutReader.IlluminaTileMetrics
 
getTileNumber() - Method in class picard.illumina.parser.Tile
Returns the number/name of this tile.
getTileOfNextCluster() - Method in class picard.illumina.parser.MultiTileParser
 
getTileOfNextCluster() - Method in class picard.illumina.parser.PerTileParser
Return the tile of the NEXT ILLUMINA_DATA object to be returned by the method next.
getTiles() - Method in class picard.illumina.parser.MultiTileBclFileUtil
 
getTiles() - Method in class picard.illumina.parser.MultiTileFileUtil
 
getTiles() - Method in class picard.illumina.parser.ParameterizedFileUtil
Return a list of all tiles available for this file format and run
getTiles() - Method in class picard.illumina.parser.PerTilePerCycleFileUtil
Discover all files of this type in expectedBase that match pattern and construct a list of tiles available based on these files.
getTiles() - Method in class picard.illumina.parser.TileIndex
 
getTileTemplateRead() - Method in class picard.illumina.parser.TilePhasingValue
 
getToCoverage() - Method in class org.broadinstitute.hellbender.utils.locusiterator.LIBSDownsamplingInfo
 
getToMarkQueueMinimumDistance() - Method in class picard.sam.markduplicates.util.MarkQueue
Returns the minimum genomic distance such that we can be assured that all duplicates have been considered.
getToolDeprecationInfo(String) - Static method in class org.broadinstitute.hellbender.cmdline.DeprecatedToolsRegistry
Utility method to pull up the version number at which a tool was deprecated and the suggested replacement, if any
getToolDeprecationMessage(String) - Method in class org.broadinstitute.hellbender.Main
Get deprecation message for a tool
getToolkitName() - Method in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
 
getToolkitShortName() - Method in class org.broadinstitute.hellbender.engine.GATKTool
 
getToolLogger() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoveryInputMetaData
 
getToolName() - Method in class org.broadinstitute.hellbender.engine.GATKTool
Returns the name of this tool.
getToolReturnCode() - Method in exception org.broadinstitute.hellbender.exceptions.PicardNonZeroExitException
 
getToolStatusWarning(boolean) - Method in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
If this tool is either Experimental or Beta, return a warning message advising against use in production environment.
getToolTestDataDir() - Method in class org.broadinstitute.hellbender.utils.test.BaseTest
Returns the location of the resource directory for the command line program.
getTotal() - Method in class picard.analysis.directed.TargetMetricsCollector.Coverage
 
getTotalBaseQuality() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.LibraryRawStatistics
 
getTotalCount() - Method in class org.broadinstitute.hellbender.tools.walkers.contamination.PileupSummary
 
getTotalCycles() - Method in class picard.illumina.parser.ReadStructure.Substructure
 
getTotalHardClipping(Cigar) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SvCigarUtils
 
getTotalInserts() - Method in class org.broadinstitute.hellbender.metrics.PerUnitInsertSizeMetricsCollector
 
getTotalInserts() - Method in class picard.analysis.directed.InsertSizeMetricsCollector.PerUnitInsertSizeMetricsCollector
 
getTotalLength() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenReferenceTaxonProperties
 
getTotalObs() - Method in class picard.fingerprint.HaplotypeProbabilities
Returns the total number of observations of any allele.
getTotalObs() - Method in class picard.fingerprint.HaplotypeProbabilitiesFromSequence
Gets the total number of observations presented at this locus.
getTotalObs() - Method in class picard.fingerprint.HaplotypeProbabilityOfNormalGivenTumor
 
getTotalObservations() - Method in class org.broadinstitute.hellbender.tools.spark.utils.IntHistogram.CDF
 
getTotalObservations() - Method in class org.broadinstitute.hellbender.tools.spark.utils.IntHistogram
 
getTotalOutputCycles() - Method in class picard.illumina.parser.OutputMapping
 
getTotalReadCount() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AllelicCount
 
getTotalReads() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenTaxonScore
 
getTrainingData() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
 
getTrancheIndex() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.Tranche
 
getTrancheIndex() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VQSLODTranche
 
getTrancheString(T) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.Tranche
 
getTranscriptAlleleStart() - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
getTranscriptAlleleStartPosition(VariantContext, List<? extends Locatable>, Strand) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Get the position (1-based, inclusive) of the given VariantContext start relative to the transcript it appears in.
getTranscriptCodingSequence() - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
Return the ReferenceSequence containing the coding region for the transcript of this SequenceComparison.
getTranscriptCoordinate(int) - Method in class picard.annotation.Gene.Transcript
Given a coordinate on the genome (same chromosome) give the corresponding coordinate in the transcript.
getTranscriptExonNumber() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getTranscriptId() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
getTranscriptIdWithoutVersionNumber(String) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Removes the transcript ID version number from the given transcript ID (if it exists).
getTranscriptLength() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getTranscriptName() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
getTranscriptPos() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getTranscripts() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfGeneFeature
 
getTranscriptStatus() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
getTranscriptStrand() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getTranscriptType() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
getTransformedReadStream(ReadFilter) - Method in class org.broadinstitute.hellbender.engine.GATKTool
Returns a stream over the reads, which are: 1.
getTransientAttribute(Object) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
This is used to access the transient attribute store in the underlying SAMRecord.
getTraversalParameters(SAMSequenceDictionary) - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.IntervalArgumentCollection
Returns the full set of traversal parameters specified on the command line, including the parsed intervals and a flag indicating whether unmapped records were requested.
getTrios(boolean) - Method in class org.broadinstitute.hellbender.utils.samples.SampleDB
Returns all the trios present in the sample database.
getTrios() - Method in class org.broadinstitute.hellbender.utils.samples.SampleDB
Returns all the trios present in the db.
getTrueNegativeCount() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.FilterAnalysisRecord
 
getTruePositives() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.ConcordanceSummaryRecord
 
getTrueU() - Method in class org.broadinstitute.hellbender.utils.MannWhitneyU.TestStatistic
 
getTruth() - Method in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker.TruthVersusEval
 
getTruthHeader() - Method in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker
 
getTruthIfPresentElseEval() - Method in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker.TruthVersusEval
 
getTruthSensitivity() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.Tranche
 
getTumorSeqAllele2() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getType() - Method in class org.broadinstitute.hellbender.tools.funcotator.DataSourceFuncotationFactory
 
getType() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.cosmic.CosmicFuncotationFactory
 
getType() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationFactory
 
getType() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.vcf.VcfFuncotationFactory
 
getType() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv.LocatableXsvFuncotationFactory
 
getType() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv.SimpleKeyXsvFuncotationFactory
 
getType() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.EmptyFragment
 
getType() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Fragment
 
getType() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.MarkDuplicatesSparkRecord
 
getType() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Pair
 
getType() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Passthrough
 
getTypeSpecificAttributes() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvType
 
getU() - Method in class org.broadinstitute.hellbender.utils.MannWhitneyU.Result
 
getU() - Method in class org.broadinstitute.hellbender.utils.svd.SimpleSVD
 
getU() - Method in interface org.broadinstitute.hellbender.utils.svd.SVD
Get the U matrix of a Singular Value Decomposition U has the property that V.transpose * V = I Note that U need not be square.
getU1() - Method in class org.broadinstitute.hellbender.utils.MannWhitneyU.TestStatistic
 
getU2() - Method in class org.broadinstitute.hellbender.utils.MannWhitneyU.TestStatistic
 
getUcscGenomeVersion() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
getUnambiguousReads() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenTaxonScore
 
getUnclippedEnd() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Returns the alignment end (1-based, inclusive) adjusted for clipped bases.
getUnclippedEnd() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getUnclippedReadLength(Cigar) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SvCigarUtils
 
getUnclippedStart() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Returns the alignment start (1-based, inclusive) adjusted for clipped bases.
getUnclippedStart() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
getUnclippedStartPosition() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.EmptyFragment
 
getUnclippedStartPosition() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Fragment
 
getUnclippedStartPosition() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Pair
 
getUnclippedStartPosition() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.PairedEnds
 
getUncompressedProbabilityVector() - Method in class org.broadinstitute.hellbender.utils.genotyper.ProbabilityVector
 
getUnfilteredBaseQHistogram() - Method in class picard.analysis.AbstractWgsMetricsCollector
 
getUnfilteredDepthHistogram() - Method in class picard.analysis.AbstractWgsMetricsCollector
 
getUnfilteredReads() - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
Loads the reads into a JavaRDD using the intervals specified, and returns them without applying any filtering.
getUniqueFalseNegativeCount() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.FilterAnalysisRecord
 
getUniqueNameSuffix() - Static method in class org.broadinstitute.hellbender.metrics.InsertSizeMetrics
Return a disambiguating name suffix to be used by the multiple collectors to decorate output names, which are provided by the user in the form of a base name that needs to be disambiguated for each individual collector.
getUniqueNameSuffix() - Static method in class org.broadinstitute.hellbender.metrics.QualityYieldMetrics
Return a disambiguating name suffix to be used by the multiple collectors to decorate output names, which are provided by the user in the form of a base name that needs to be disambiguated for each individual collector.
getUniqueReadThreadingGraph(int) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResultSet
Returns a read-threading graph in the assembly set that has a particular kmerSize.
getUniqueTrueNegativeCount() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.FilterAnalysisRecord
 
getUnknownCommandMessage(Set<Class<?>>, String) - Method in class org.broadinstitute.hellbender.Main
When a command does not match any known command, searches for a deprecation message, if any, or for similar commands.
getUnmappedBoth() - Method in class org.broadinstitute.hellbender.utils.read.SamComparison
 
getUnmappedBoth() - Method in class picard.sam.CompareSAMs
 
getUnmappedLeft() - Method in class org.broadinstitute.hellbender.utils.read.SamComparison
 
getUnmappedLeft() - Method in class picard.sam.CompareSAMs
 
getUnmappedRight() - Method in class org.broadinstitute.hellbender.utils.read.SamComparison
 
getUnmappedRight() - Method in class picard.sam.CompareSAMs
 
getUnpairedReads() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPairedUnpairedSplitterSpark
 
getUpdatedGenotypes(VariantContext, Genotype, Genotype, Genotype, ArrayList<Genotype>) - Method in class org.broadinstitute.hellbender.tools.walkers.variantutils.FamilyLikelihoods
Applies the trio genotype combination to the given trio.
getUpdateMethod() - Method in class org.broadinstitute.hellbender.utils.mcmc.ParameterizedModel
 
getUpper() - Method in class org.broadinstitute.hellbender.utils.mcmc.PosteriorSummary
 
getUsableExtension() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmer.Result
Returns the maximum extension around the original active region span considered for the trimmed variation region.
getUsage() - Method in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
 
getUserDisabledAnnotationNames() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.DefaultGATKVariantAnnotationArgumentCollection
 
getUserDisabledAnnotationNames() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKAnnotationArgumentCollection
Returns the disabled annotation names.
getUserDisabledReadFilterNames() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.DefaultGATKReadFilterArgumentCollection
Returns the set of filters disabled by the user.
getUserDisabledReadFilterNames() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKReadFilterArgumentCollection
Returns the disabled read filter names.
getUserEnabledAnnotationGroups() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.DefaultGATKVariantAnnotationArgumentCollection
 
getUserEnabledAnnotationGroups() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKAnnotationArgumentCollection
Returns the enabled annotation.
getUserEnabledAnnotationNames() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.DefaultGATKVariantAnnotationArgumentCollection
 
getUserEnabledAnnotationNames() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKAnnotationArgumentCollection
Returns the enabled annotation.
getUserEnabledReadFilterNames() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.DefaultGATKReadFilterArgumentCollection
Returns the list with the read filters provided by the user, preserving the order.
getUserEnabledReadFilterNames() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKReadFilterArgumentCollection
Returns the enabled filter names.
getUtil(IlluminaFileUtil.SupportedIlluminaFormat) - Method in class picard.illumina.parser.IlluminaFileUtil
Given a file type, get the Parameterized File Util object associated with it
getUtrs() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfTranscriptFeature
 
getV() - Method in class org.broadinstitute.hellbender.utils.svd.SimpleSVD
 
getV() - Method in interface org.broadinstitute.hellbender.utils.svd.SVD
Get the V matrix of a Singular Value Decomposition.
getValidationAltCount() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.BasicValidationResult
 
getValidationRefCount() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.BasicValidationResult
 
getValidationStringency() - Method in class picard.fingerprint.FingerprintChecker
 
getValue() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.KmerAndInterval
 
getValue() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.QNameAndInterval
 
getValue() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.KmerAndCount
 
getValue() - Method in interface org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree.Entry
 
getValue() - Method in class org.broadinstitute.hellbender.tools.spark.transforms.markduplicates.MarkDuplicatesSparkUtils.IndexPair
 
getValue() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.OptionalField
 
getValue(int) - Method in class org.broadinstitute.hellbender.utils.codecs.table.TableFeature
Gets the value associated with the ith column (first column is 0).
getValue() - Method in class org.broadinstitute.hellbender.utils.KV
 
getValue() - Method in class org.broadinstitute.hellbender.utils.mcmc.Parameter
 
getValueCounts() - Method in class org.broadinstitute.hellbender.utils.CompressedDataList
 
getValueFormat() - Method in class org.broadinstitute.hellbender.utils.report.GATKReportColumnFormat
 
getValueForRead(GATKRead, VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.BaseQuality
 
getValueForRead(GATKRead, VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.FragmentLength
 
getValueForRead(GATKRead, VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.MappingQuality
 
getValueForRead(GATKRead, VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.PerAlleleAnnotation
 
getValueForRead(GATKRead, VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.ReadPosition
 
getValues(FeatureInput<T>) - Method in class org.broadinstitute.hellbender.engine.FeatureContext
Gets all Features from the source represented by the provided FeatureInput argument that overlap this FeatureContext's query interval.
getValues(FeatureInput<T>, int, int) - Method in class org.broadinstitute.hellbender.engine.FeatureContext
Gets all Features from the source represented by the provided FeatureInput argument that overlap this FeatureContext's query interval as expanded by the specified number of leading/trailing bases.
getValues(FeatureInput<T>, SimpleInterval) - Method in class org.broadinstitute.hellbender.engine.FeatureContext
Gets all Features from the source represented by the provided FeatureInput argument that overlap the given interval.
getValues(FeatureInput<T>, int) - Method in class org.broadinstitute.hellbender.engine.FeatureContext
Gets all Features from the source represented by the provided FeatureInput argument that overlap this FeatureContext's query interval AND that start at the specified start position.
getValues(Collection<FeatureInput<T>>) - Method in class org.broadinstitute.hellbender.engine.FeatureContext
Gets all Features from the sources represented by the provided FeatureInput arguments that overlap this FeatureContext's query interval.
getValues(Collection<FeatureInput<T>>, int) - Method in class org.broadinstitute.hellbender.engine.FeatureContext
Gets all Features from the sources represented by the provided FeatureInput arguments that overlap this FeatureContext's query interval, AND that start at the specified start position.
getValues() - Method in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvTableFeature
Get the data from this XsvTableFeature.
getValuesTo(int) - Method in class org.broadinstitute.hellbender.utils.codecs.table.TableFeature
Gets all the values from the first column (0) to the last one specified (exclusive).
getValuesWithoutLocationColumns() - Method in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvTableFeature
Get the data from this XsvTableFeature without the columns that contain location information.
getVar(int, int) - Static method in enum picard.vcf.GenotypeConcordanceStates.TruthState
 
getVarianceVector() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
 
getVariant() - Method in class org.broadinstitute.hellbender.engine.spark.VariantWalkerContext
 
getVariantClassification() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getVariantContexts() - Method in class org.broadinstitute.hellbender.utils.haplotype.EventMap
Get the variant contexts in order of start position in this event map
getVariants(JavaSparkContext) - Method in class org.broadinstitute.hellbender.engine.spark.VariantWalkerSpark
Loads variants and the corresponding reads, reference and features into a JavaRDD for the intervals specified.
getVariants() - Method in class org.broadinstitute.hellbender.utils.test.ReadsPreprocessingPipelineTestData
 
getVariantSequenceDictionaries() - Method in class org.broadinstitute.hellbender.engine.FeatureManager
Returns the list of sequence dictionaries retrieved from the VCF headers of variant Feature inputs.
getVariantShardsFromInterval(Locatable) - Static method in class org.broadinstitute.hellbender.engine.VariantShard
getVariantShardsFromInterval calculates *all* shards overlapping location.
getVariantsList(List<String>) - Static method in class org.broadinstitute.hellbender.engine.datasources.VariantsSource
getVariantsList grabs the variants from local files (or perhaps eventually buckets).
getVariantsListAs(List<String>, Function<VariantContext, T>) - Static method in class org.broadinstitute.hellbender.engine.datasources.VariantsSource
getVariantsListAs grabs the variants from local files (or perhaps eventually buckets), applies the wrapper function to each object, and returns them as a list of objects of the type returned by the wrapper function
getVariantType() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
getVariantType() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.ConcordanceSummaryRecord
 
getVariantTypeFromOrdinal(int) - Static method in enum picard.util.VariantType
Gets the enum for a given ordinal
getVariationEvents(int) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResultSet
Returns a sorted set of variant events that best explain the haplotypes found by the assembly across kmerSizes.
getVc() - Method in class org.broadinstitute.hellbender.tools.walkers.ReferenceConfidenceVariantContextMerger.VCWithNewAlleles
 
getVCFAnnotationDescriptions() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotatorEngine
Returns the set of descriptions to be added to the VCFHeader line (for all annotations in this engine).
getVCFAnnotationDescriptions(boolean) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotatorEngine
Returns the set of descriptions to be added to the VCFHeader line (for all annotations in this engine).
getVCFHeaderLines() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReferenceConfidenceModel
getVcfKey() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.BaseQuality
 
getVcfKey() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.FragmentLength
 
getVcfKey() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.MappingQuality
 
getVcfKey() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.PerAlleleAnnotation
 
getVcfKey() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.ReadPosition
 
getVCsAtThisLocation(List<Haplotype>, int, List<VariantContext>) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerGenotypingEngine
 
getVersion() - Method in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
 
getVersion() - Method in class org.broadinstitute.hellbender.tools.copynumber.denoising.HDF5SVDReadCountPanelOfNormals
 
getVersion() - Method in interface org.broadinstitute.hellbender.tools.copynumber.denoising.SVDReadCountPanelOfNormals
Returns the PoN version.
getVersion() - Method in class org.broadinstitute.hellbender.tools.funcotator.DataSourceFuncotationFactory
 
getVersion() - Method in class org.broadinstitute.hellbender.tools.funcotator.Funcotator
 
getVersion() - Method in class org.broadinstitute.hellbender.utils.report.GATKReport
 
getVersion() - Method in class picard.cmdline.CommandLineProgram
 
getVertices() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.Path
Get the list of vertices in this path in order defined by the edges of the path
getWeight() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence
 
getWidth() - Method in class org.broadinstitute.hellbender.utils.report.GATKReportColumnFormat
 
getWindow() - Method in class org.broadinstitute.hellbender.engine.ReferenceContext
Get the full expanded window of bases spanned by this context, including any extra bases of requested context around the current interval.
getWordCount() - Method in class picard.util.AbstractInputParser
 
getWordStarts(String) - Static method in class org.broadinstitute.hellbender.utils.text.TextFormattingUtils
Returns the word starting positions within line, excluding the first position 0.
getWorkingDir(MiniDFSCluster) - Static method in class org.broadinstitute.hellbender.utils.test.MiniClusterUtils
 
getWrapped() - Method in class org.broadinstitute.hellbender.utils.UniqueIDWrapper
 
getWriter(File) - Static method in class org.broadinstitute.hellbender.tools.walkers.validation.ConcordanceSummaryRecord
 
getX() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
getX() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Pair
 
getX() - Method in class picard.illumina.parser.ClusterData
 
getX() - Method in interface picard.sam.util.PhysicalLocation
 
getX() - Method in class picard.sam.util.PhysicalLocationInt
 
getXCoordinate() - Method in class picard.illumina.parser.CbclData
 
getY() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
getY() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Pair
 
getY() - Method in class picard.illumina.parser.ClusterData
 
getY() - Method in interface picard.sam.util.PhysicalLocation
 
getY() - Method in class picard.sam.util.PhysicalLocationInt
 
getYCoordinate() - Method in class picard.illumina.parser.CbclData
 
getZ() - Method in class org.broadinstitute.hellbender.utils.MannWhitneyU.Result
 
getZeroBasedTileNumber() - Method in class picard.illumina.parser.TileIndex.TileIndexRecord
 
getZishScore(int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.LibraryStatistics
 
getZishScore(String, int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata
 
ggaExtension - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmerArgumentCollection
 
GibbsBuilder(S2, T2) - Constructor for class org.broadinstitute.hellbender.utils.mcmc.ParameterizedModel.GibbsBuilder
GibbsSampler<V extends java.lang.Enum<V> & ParameterEnum,S extends ParameterizedState<V>,T extends DataCollection> - Class in org.broadinstitute.hellbender.utils.mcmc
Implements Gibbs sampling of a multivariate probability density function.
GibbsSampler(int, ParameterizedModel<V, S, T>) - Constructor for class org.broadinstitute.hellbender.utils.mcmc.GibbsSampler
Constructs a GibbsSampler given the total number of samples (including burn-in) and a ParameterizedModel.
GLmodel - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.UnifiedArgumentCollection
 
GLOBAL_PSI_SCALE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineContigPloidyModelArgumentCollection
 
globalPriorIndel - Variable in class org.broadinstitute.hellbender.tools.walkers.variantutils.CalculateGenotypePosteriors
Prior indel pseudocounts for Dirichlet distribution of allele frequencies.
globalPriorSnp - Variable in class org.broadinstitute.hellbender.tools.walkers.variantutils.CalculateGenotypePosteriors
Prior SNP pseudocounts for Dirichlet distribution of allele frequencies.
globalQScorePrior - Variable in class org.broadinstitute.hellbender.tools.ApplyBQSRUniqueArgumentCollection
If specified, the value of this argument will be used as a flat prior for all mismatching quality scores instead of the reported quality score (assigned by the sequencer).
GMMFromTables(GATKReportTable, GATKReportTable, GATKReportTable, int, int) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantRecalibrator
Rebuild a Gaussian Mixture Model from gaussian means and co-variates stored in a GATKReportTables
GOOD_CIGAR - Static variable in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary
 
GoodAndBadMappings(List<AlignmentInterval>) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigAlignmentsConfigPicker.GoodAndBadMappings
 
GoodAndBadMappings(List<AlignmentInterval>, List<AlignmentInterval>, AlignmentInterval) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigAlignmentsConfigPicker.GoodAndBadMappings
 
GoodAndBadMappings(List<AlignmentInterval>, List<AlignmentInterval>) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigAlignmentsConfigPicker.GoodAndBadMappings
 
GoodCigarReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.GoodCigarReadFilter
 
goodLog10Probability(double) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Checks that the result is a well-formed log10 probability
goodLog10ProbVector(double[], int, boolean) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Check that the log10 prob vector vector is well formed
goodNonCanonicalMappingSATag - Variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SimpleChimera
 
goodProbability(double) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Checks that the result is a well-formed probability
GQ_MEAN_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
GQ_STDEV_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
grabCount() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.KmerAndCount
 
granularity - Variable in class org.broadinstitute.hellbender.tools.spark.CreateHadoopBamSplittingIndex
 
graph() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KBestHaplotype
Returns the original graph searched.
Graph() - Constructor for class picard.util.GraphUtils.Graph
 
graphEquals(BaseGraph<T, E>, BaseGraph<T, E>) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Semi-lenient comparison of two graphs, truing true if g1 and g2 have similar structure By similar this means that both graphs have the same number of vertices, where each vertex can find a vertex in the other graph that's seqEqual to it.
graphOutput - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadThreadingAssemblerArgumentCollection
This argument is meant for debugging and is not immediately useful for normal analysis use.
GraphUtils - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs
Utility functions used in the graphs package
GraphUtils - Class in picard.util
Created by farjoun on 11/2/16.
GraphUtils() - Constructor for class picard.util.GraphUtils
 
GraphUtils.Graph<Node extends java.lang.Comparable<Node>> - Class in picard.util
 
groupIntervalsByContig(List<SimpleInterval>) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Accepts a sorted List of intervals, and returns a List of Lists of intervals grouped by contig, one List per contig.
gunzip(File, File) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
Un-gzips the input file to the output file.
gunzipToTempIfNeeded(File) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
Un-gzips the input file to a output file but only if the file's name ends with '.gz'.
GVCF_FILE_EXTENSION - Static variable in class org.broadinstitute.hellbender.tools.IndexFeatureFile
 
GVCF_INPUT - Variable in class picard.vcf.CollectVariantCallingMetrics
 
GVCF_VALIDATE - Static variable in class org.broadinstitute.hellbender.tools.walkers.variantutils.ValidateVariants
 
GVCFGQBands - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerArgumentCollection
When HC is run in reference confidence mode with banding compression enabled (-ERC GVCF), homozygous-reference sites are compressed into bands of similar genotype quality (GQ) that are emitted as a single VCF record.
GvcfKeyIgnoringVCFRecordWriter(Path, VCFHeader, boolean, TaskAttemptContext) - Constructor for class org.broadinstitute.hellbender.engine.spark.datasources.VariantsSparkSink.GvcfKeyIgnoringVCFRecordWriter
 
GvcfKeyIgnoringVCFRecordWriter(OutputStream, VCFHeader, boolean, TaskAttemptContext) - Constructor for class org.broadinstitute.hellbender.engine.spark.datasources.VariantsSparkSink.GvcfKeyIgnoringVCFRecordWriter
 
GvcfMetricAccumulator - Class in picard.vcf
An accumulator for collecting metrics about a single-sample GVCF.
GvcfMetricAccumulator(DbSnpBitSetUtil.DbSnpBitSets) - Constructor for class picard.vcf.GvcfMetricAccumulator
 
gvcfToHeaderSampleMapFile - Variable in class org.broadinstitute.hellbender.tools.FixCallSetSampleOrdering
 
GVCFWriter - Class in org.broadinstitute.hellbender.utils.variant.writers
Genome-wide VCF writer
GVCFWriter(VariantContextWriter, List<Integer>, int) - Constructor for class org.broadinstitute.hellbender.utils.variant.writers.GVCFWriter
Create a new GVCF writer Should be a non-empty list of boundaries.

H

HALF_OF_DEFAULT_PCR_ERROR_QUAL - Static variable in class org.broadinstitute.hellbender.utils.fragments.FragmentUtils
 
handleAdditionalRecords(SAMRecord, Map<SAMReadGroupRecord, List<FastqWriter>>, SAMRecord, SAMRecord) - Method in class picard.sam.SamToFastq
 
handleAdditionalRecords(SAMRecord, Map<SAMReadGroupRecord, List<FastqWriter>>, SAMRecord, SAMRecord) - Method in class picard.sam.SamToFastqWithTags
 
handleItem(String) - Method in class picard.cmdline.ClassFinder
Checks an item to see if it is a class and is annotated with the specified annotation.
handleNonUserException(Exception) - Method in class org.broadinstitute.hellbender.Main
Handle any exception that does not come from the user.
handleResult(Object) - Method in class org.broadinstitute.hellbender.Main
Handle the result returned for a tool.
handleStorageException(StorageException) - Method in class org.broadinstitute.hellbender.Main
Handle any exception that does not come from the user.
handleUserException(Exception) - Method in class org.broadinstitute.hellbender.Main
Handle an exception that was likely caused by user error.
haplotype() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KBestHaplotype
Returns the solution haplotype.
Haplotype - Class in org.broadinstitute.hellbender.utils.haplotype
 
Haplotype(byte[], boolean) - Constructor for class org.broadinstitute.hellbender.utils.haplotype.Haplotype
Main constructor
Haplotype(byte[]) - Constructor for class org.broadinstitute.hellbender.utils.haplotype.Haplotype
Create a new non-ref haplotype
Haplotype(byte[], boolean, int, Cigar) - Constructor for class org.broadinstitute.hellbender.utils.haplotype.Haplotype
Create a new haplotype with bases Requires bases.length == cigar.getReadLength()
Haplotype(byte[], Locatable) - Constructor for class org.broadinstitute.hellbender.utils.haplotype.Haplotype
 
HAPLOTYPE_CALLER_PHASING_GT_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
HAPLOTYPE_CALLER_PHASING_ID_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
HAPLOTYPE_MAP - Variable in class picard.fingerprint.CheckFingerprint
 
HAPLOTYPE_MAP - Variable in class picard.fingerprint.CrosscheckFingerprints
 
HAPLOTYPE_MAP - Variable in class picard.fingerprint.IdentifyContaminant
 
HAPLOTYPE_SCORE_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
HAPLOTYPE_TAG - Static variable in class org.broadinstitute.hellbender.utils.read.AlignmentUtils
 
HaplotypeBAMDestination - Class in org.broadinstitute.hellbender.utils.haplotype
Utility class that allows easy creation of destinations for the HaplotypeBAMWriters
HaplotypeBAMDestination(SAMFileHeader, String) - Constructor for class org.broadinstitute.hellbender.utils.haplotype.HaplotypeBAMDestination
Create a new HaplotypeBAMDestination
HaplotypeBAMWriter - Class in org.broadinstitute.hellbender.utils.haplotype
A BAMWriter that aligns reads to haplotypes and emits their best alignments to a destination.
HaplotypeBAMWriter(HaplotypeBAMDestination) - Constructor for class org.broadinstitute.hellbender.utils.haplotype.HaplotypeBAMWriter
Create a new HaplotypeBAMWriter writing its output to the given destination
HaplotypeBAMWriter.WriterType - Enum in org.broadinstitute.hellbender.utils.haplotype
Possible modes for writing haplotypes to BAMs
HaplotypeBlock - Class in picard.fingerprint
Represents information about a group of SNPs that form a haplotype in perfect LD with one another.
HaplotypeBlock(double) - Constructor for class picard.fingerprint.HaplotypeBlock
Constructs a haplotype block with the provided minor allele frequency.
HaplotypeCaller - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
Call germline SNPs and indels via local re-assembly of haplotypes
HaplotypeCaller() - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCaller
 
HaplotypeCallerArgumentCollection - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
Set of arguments for the HaplotypeCallerEngine
HaplotypeCallerArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerArgumentCollection
 
HaplotypeCallerEngine - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
The core engine for the HaplotypeCaller that does all of the actual work of the tool.
HaplotypeCallerEngine(HaplotypeCallerArgumentCollection, boolean, boolean, SAMFileHeader, ReferenceSequenceFile, VariantAnnotatorEngine) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerEngine
Create and initialize a new HaplotypeCallerEngine given a collection of HaplotypeCaller arguments, a reads header, and a reference file
HaplotypeCallerGenotypingEngine - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
HaplotypeCaller's genotyping strategy implementation.
HaplotypeCallerGenotypingEngine(HaplotypeCallerArgumentCollection, SampleList, AFCalculatorProvider, boolean) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerGenotypingEngine
HaplotypeCallerSpark - Class in org.broadinstitute.hellbender.tools
******************************************************************************** * This tool DOES NOT match the output of HaplotypeCaller.
HaplotypeCallerSpark() - Constructor for class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark
 
HaplotypeCallerSpark.ReferenceMultiSourceAdapter - Class in org.broadinstitute.hellbender.tools
Adapter to allow a 2bit reference to be used in HaplotypeCallerEngine.
HaplotypeCallerSpark.ShardingArgumentCollection - Class in org.broadinstitute.hellbender.tools
 
HaplotypeMap - Class in picard.fingerprint
A collection of metadata about Haplotype Blocks including multiple in memory "indices" of the data to make it easy to query the correct HaplotypeBlock or Snp by snp names, positions etc.
HaplotypeMap(SAMFileHeader) - Constructor for class picard.fingerprint.HaplotypeMap
Constructs an empty HaplotypeMap using the provided SAMFileHeader's sequence dictionary.
HaplotypeMap(File) - Constructor for class picard.fingerprint.HaplotypeMap
 
HaplotypeProbabilities - Class in picard.fingerprint
Abstract class for storing and calculating various likelihoods and probabilities for haplotype alleles given evidence.
HaplotypeProbabilities(HaplotypeBlock) - Constructor for class picard.fingerprint.HaplotypeProbabilities
 
HaplotypeProbabilities.Genotype - Enum in picard.fingerprint
Log10(P(evidence| haplotype)) for the 3 different possible haplotypes {aa, ab, bb}
HaplotypeProbabilitiesFromContaminatorSequence - Class in picard.fingerprint
Represents the probability of the underlying haplotype of the contaminating sample given the data.
HaplotypeProbabilitiesFromContaminatorSequence(HaplotypeBlock, double) - Constructor for class picard.fingerprint.HaplotypeProbabilitiesFromContaminatorSequence
 
HaplotypeProbabilitiesFromGenotype - Class in picard.fingerprint
Represents a set of HaplotypeProbabilities that were derived from a single SNP genotype at a point in time.
HaplotypeProbabilitiesFromGenotype(Snp, HaplotypeBlock, double, double, double) - Constructor for class picard.fingerprint.HaplotypeProbabilitiesFromGenotype
 
HaplotypeProbabilitiesFromGenotypeLikelihoods - Class in picard.fingerprint
Represents the likelihood of the HaplotypeBlock given the GenotypeLikelihoods (GL field from a VCF, which is actually a log10-likelihood) for each of the SNPs in that block.
HaplotypeProbabilitiesFromGenotypeLikelihoods(HaplotypeBlock) - Constructor for class picard.fingerprint.HaplotypeProbabilitiesFromGenotypeLikelihoods
 
HaplotypeProbabilitiesFromSequence - Class in picard.fingerprint
Represents the probability of the underlying haplotype given the data.
HaplotypeProbabilitiesFromSequence(HaplotypeBlock) - Constructor for class picard.fingerprint.HaplotypeProbabilitiesFromSequence
 
HaplotypeProbabilityOfNormalGivenTumor - Class in picard.fingerprint
A wrapper class for any HaplotypeProbabilities instance that will assume that the given evidence is that of a tumor sample and provide an hp for the normal sample that tumor came from.
HaplotypeProbabilityOfNormalGivenTumor(HaplotypeProbabilities, double) - Constructor for class picard.fingerprint.HaplotypeProbabilityOfNormalGivenTumor
 
HAPLOTYPES_CONFIDENTLY_CHECKED - Variable in class picard.analysis.FingerprintingSummaryMetrics
The subset of genotyped haplotypes for which there was sufficient sequence data to confidently genotype the haplotype.
HAPLOTYPES_CONFIDENTLY_MATCHING - Variable in class picard.analysis.FingerprintingSummaryMetrics
The subset of confidently checked haplotypes that match the expected genotypes.
HAPLOTYPES_WITH_GENOTYPES - Variable in class picard.analysis.FingerprintingSummaryMetrics
The number of haplotypes that had expected genotypes to compare to.
hapStartIndex - Variable in class org.broadinstitute.hellbender.utils.pairhmm.PairHMM
 
hardClipAdaptorSequence(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.clipping.ReadClipper
 
hardClipBothEndsByReferenceCoordinates(GATKRead, int, int) - Static method in class org.broadinstitute.hellbender.utils.clipping.ReadClipper
 
hardClipByReadCoordinates(GATKRead, int, int) - Static method in class org.broadinstitute.hellbender.utils.clipping.ReadClipper
 
hardClipByReferenceCoordinates(int, int) - Method in class org.broadinstitute.hellbender.utils.clipping.ReadClipper
 
hardClipByReferenceCoordinatesLeftTail(GATKRead, int) - Static method in class org.broadinstitute.hellbender.utils.clipping.ReadClipper
 
hardClipByReferenceCoordinatesRightTail(GATKRead, int) - Static method in class org.broadinstitute.hellbender.utils.clipping.ReadClipper
 
hardClipLeadingInsertions(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.clipping.ReadClipper
 
hardClipLowQualEnds(GATKRead, byte) - Static method in class org.broadinstitute.hellbender.utils.clipping.ReadClipper
 
hardClipSoftClippedBases(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.clipping.ReadClipper
 
hardClipToRegion(GATKRead, int, int) - Static method in class org.broadinstitute.hellbender.utils.clipping.ReadClipper
Hard clip the read to the variable region (from refStart to refStop)
hardClipToRegionIncludingClippedBases(GATKRead, int, int) - Static method in class org.broadinstitute.hellbender.utils.clipping.ReadClipper
Hard clip the read to the variable region (from refStart to refStop) processing also the clipped bases
HardThresholdingOutputStream - Class in org.broadinstitute.hellbender.utils.io
An output stream which stops at the threshold instead of potentially triggering early.
HardThresholdingOutputStream(int) - Constructor for class org.broadinstitute.hellbender.utils.io.HardThresholdingOutputStream
 
HardwareFeatureException(String) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.HardwareFeatureException
 
HardwareFeatureException(String, Exception) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.HardwareFeatureException
 
HARDY_WEINBERG_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
HAS_MATCHING_BASES_AND_QUALS - Static variable in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary
 
HAS_READ_GROUP - Static variable in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary
 
hasAccession(String) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenReferenceTaxonProperties
 
hasAmbiguousSequence() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseVertex
Checks whether the vertex sequence is ambiguous or not.
hasAnnotation(String) - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedInterval
 
hasAttribute(Allele) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.ReducibleAnnotationData
 
hasAttribute(String) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Check whether this read has a particular attribute
hasAttribute(String) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
hasBackingDataSource() - Method in class org.broadinstitute.hellbender.engine.FeatureContext
Determines whether this FeatureContext has a backing source of Features.
hasBackingDataSource() - Method in class org.broadinstitute.hellbender.engine.ReadsContext
Does this context have a backing source of reads data?
hasBackingDataSource() - Method in class org.broadinstitute.hellbender.engine.ReferenceContext
Determines whether this ReferenceContext has a backing reference data source.
hasBAQTag(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.baq.BAQ
Returns true if the read has a BAQ tag, or false otherwise
hasBaseIndelQualities(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
hasBasesAlignedAgainstTheReference(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Checks whether the input read has some base aligned against the reference.
hasBeenOverhangClipped() - Method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.OverhangFixingManager.SplitRead
 
hasBothParents() - Method in class picard.pedigree.PedFile.PedTrio
True if this record has paternal and maternal ids, otherwise false.
hasCbcls(File, int) - Static method in class picard.illumina.parser.IlluminaFileUtil
 
hasChimericAlignments() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments
After fine tuning, a contig may have no, or only one, good alignment left.
hasColumn(String) - Method in class picard.util.DelimitedTextFileWithHeaderIterator
 
hasColumn(String) - Method in class picard.util.TabbedTextFileWithHeaderParser
 
hasCoverage() - Method in class picard.analysis.directed.TargetMetricsCollector.Coverage
Returns true if any base in the range has coverage of > 0
hasCRAMFileContents(Path) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Validate that a file has CRAM contents by checking that it has a valid CRAM file header (no matter what the extension).
hasCRAMFileContents(File) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Validate that a file has CRAM contents by checking that it has a valid CRAM file header (no matter what the extension).
hasCycles() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Checks for the presence of directed cycles in the graph.
hasDistalTargets(ReadMetadata, int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.DiscordantReadPairEvidence
 
hasDistalTargets(ReadMetadata, int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence
Returns true if this piece of evidence specifies a possible distal target for the breakpoint.
hasDistalTargets(ReadMetadata, int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.SplitRead
 
hasDuplicationAnnotation() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.NovelAdjacencyAndAltHaplotype
 
hasEquallyGoodAlnConfigurations() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments
 
hasEvidence() - Method in class picard.fingerprint.HaplotypeProbabilities
Returns true if evidence has been added, false if the probabilities are just the priors.
hasEvidence() - Method in class picard.fingerprint.HaplotypeProbabilitiesFromSequence
 
hasEvidence() - Method in class picard.fingerprint.HaplotypeProbabilityOfNormalGivenTumor
 
hasFeatures() - Method in class org.broadinstitute.hellbender.engine.GATKTool
Are sources of Features available?
hasFilledLikelihoods() - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Is this container expected to have the per-allele liklihoods calculations filled in.
hasFilledLikelihoods() - Method in class org.broadinstitute.hellbender.utils.genotyper.UnfilledReadsLikelihoods
Is this container expected to have the per-allele likelihoods calculations filled in.
hasFinalizedItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.Downsampler
Are there items that have survived the downsampling process waiting to be retrieved?
hasFinalizedItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.FractionalDownsampler
 
hasFinalizedItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.LevelingDownsampler
 
hasFinalizedItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.MutectDownsampler
 
hasFinalizedItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.PassThroughDownsampler
 
hasFinalizedItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.PositionalDownsampler
 
hasFinalizedItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.ReservoirDownsampler
 
hasFixedQual() - Method in class org.broadinstitute.hellbender.utils.recalibration.QualQuantizer.QualInterval
 
HasGenomeLocation - Interface in org.broadinstitute.hellbender.utils
Indicates that this object has a genomic location and provides a systematic interface to get it.
hashCode() - Method in class org.broadinstitute.hellbender.engine.FeatureInput
FeatureInputs will be hashed by the engine, so make an effort to produce a reasonable hash code
hashCode() - Method in class org.broadinstitute.hellbender.engine.ReadContextData
 
hashCode() - Method in class org.broadinstitute.hellbender.engine.ReferenceShard
 
hashCode() - Method in class org.broadinstitute.hellbender.engine.ShardBoundary
 
hashCode() - Method in class org.broadinstitute.hellbender.engine.VariantShard
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.collections.AbstractRecordCollection
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.metadata.SimpleLocatableMetadata
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.metadata.SimpleSampleLocatableMetadata
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.metadata.SimpleSampleMetadata
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AlleleFractionSegment
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AllelicCount
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AnnotatedInterval
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AnnotationSet
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CalledCopyRatioSegment
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CopyNumberPosteriorDistribution
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CopyRatio
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CopyRatioSegment
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CoveragePerContig
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.IntegerCopyNumberSegment
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.IntervalCopyNumberGenotypingData
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.MultidimensionalSegment
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.SimpleCount
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.copynumber.gcnv.IntegerCopyNumberState
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedInterval
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalCollection
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.FlagStat.FlagStatus
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.TableFuncotation
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerBloomFilter
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerSet
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTree
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTreeNode
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignedAssembly
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignedContig
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigAlignmentsConfigPicker.GoodAndBadMappings
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications.IntraChrStrandSwitchBreakpointComplications
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications.SmallDuplicationWithImpreciseDupRangeBreakpointComplications
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications.SmallDuplicationWithPreciseDupRangeBreakpointComplications
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.NovelAdjacencyAndAltHaplotype
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SimpleChimera
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SimpleNovelAdjacencyAndChimericAlignmentEvidence
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.EvidenceTargetLink
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.QNameAndInterval
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.PairedStrandedIntervals
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.StrandedInterval
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVInterval
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerLong
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerShort
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVLocation
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.TextMDCodec.MDElement
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchSet
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.utils.LargeLongHopscotchSet
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongBloomFilter
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongHopscotchSet
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.ExactACcounts
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.ExactACset
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeAlleleCounts
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseVertex
necessary to override here so that graph.containsVertex() works the same way as vertex.equals() as one might expect
hashCode() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KBestHaplotype
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.SeqVertex
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.Kmer
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.MultiDeBruijnVertex
 
hashCode() - Method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.OverhangFixingManager.Splice
 
hashCode() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfExonFeature
 
hashCode() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
hashCode() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.OptionalField
 
hashCode() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeatureBaseData
 
hashCode() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfGeneFeature
 
hashCode() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfTranscriptFeature
 
hashCode() - Method in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvTableFeature
 
hashCode() - Method in class org.broadinstitute.hellbender.utils.collections.IndexedSet
 
hashCode() - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
 
hashCode() - Method in class org.broadinstitute.hellbender.utils.haplotype.Haplotype
 
hashCode() - Method in class org.broadinstitute.hellbender.utils.IndexRange
 
hashCode() - Method in class org.broadinstitute.hellbender.utils.KV
 
hashCode() - Method in class org.broadinstitute.hellbender.utils.read.PrimaryAlignmentKey
 
hashCode() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
hashCode() - Method in class org.broadinstitute.hellbender.utils.reference.ReferenceBases
 
hashCode() - Method in class org.broadinstitute.hellbender.utils.samples.Sample
 
hashCode() - Method in class org.broadinstitute.hellbender.utils.SimpleInterval
 
hashCode() - Method in class org.broadinstitute.hellbender.utils.variant.MinimalVariant
 
hashCode() - Method in class org.broadinstitute.hellbender.utils.variant.VariantContextVariantAdapter
 
hashCode() - Method in class picard.annotation.Gene.Transcript
 
hashCode() - Method in class picard.fingerprint.FingerprintIdDetails
 
hashCode() - Method in class picard.fingerprint.HaplotypeBlock
 
hashCode() - Method in class picard.fingerprint.Snp
 
hashCode() - Method in class picard.illumina.parser.FourChannelIntensityData
 
hashCode() - Method in class picard.illumina.parser.Range
 
hashCode() - Method in class picard.illumina.parser.ReadDescriptor
 
hashCode() - Method in class picard.illumina.parser.readers.TileMetricsOutReader.IlluminaLaneTileCode
 
hashCode() - Method in class picard.illumina.parser.readers.TileMetricsOutReader.IlluminaTileMetrics
 
hashCode() - Method in class picard.illumina.parser.ReadStructure
 
hashCode() - Method in class picard.sam.markduplicates.util.PhysicalLocationForMateCigar
 
hashCode() - Method in class picard.vcf.GenotypeConcordanceStates.TruthAndCallStates
 
hasHeader() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
hashKeyForFragment(int, boolean, int, String) - Static method in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadsKey
Makes a hash key for the fragment.
hashKeyForPair(SAMFileHeader, GATKRead, GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadsKey
Makes a hash key for the paired reads.
hashKeyForRead(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadsKey
Makes a hash key for the read.
hashMapCapacity(int) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVUtils
return a good initialCapacity for a HashMap that will hold a given number of elements
hasIncompletePictureFromTwoAlignments(AlignmentInterval, AlignmentInterval) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments
This predicate tests if an assembly contig with two (picked) alignments has the full event, or breakpoint assembled.
hasInsertedSequence() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.NovelAdjacencyAndAltHaplotype
 
hasIntervals() - Method in class org.broadinstitute.hellbender.engine.GATKTool
Are sources of intervals available?
hasIntervals() - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
Are sources of intervals available?
hasLeftFlankingRegion() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmer.Result
Checks whether there is a non-empty left flanking non-variant trimmed out region.
hasLocation() - Method in interface picard.sam.util.PhysicalLocation
Default implementation of a method to check whether real location data has been set.
hasMultipleKmerSizes() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResultSet
Indicates whether there are more than one kmerSize in the set.
hasNext() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegionIterator
 
hasNext() - Method in class org.broadinstitute.hellbender.engine.spark.AddContextDataToReadSparkOptimized.SubdivideAndFillReadsIterator
 
hasNext() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointDensityFilter
 
hasNext() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.PairedStrandedIntervalTree.PairedStrandedIntervalTreeIterator
 
hasNext() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.PairedStrandedIntervalTree.PairedStrandedIntervalTreeOverlapperIterator
 
hasNext() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree.ValuesIterator
 
hasNext() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerizer
 
hasNext() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVUtils.IteratorFilter
 
hasNext() - Method in class org.broadinstitute.hellbender.tools.spark.utils.FlatMapGluer
 
hasNext() - Method in interface org.broadinstitute.hellbender.tools.spark.utils.LongIterator
 
hasNext() - Method in class org.broadinstitute.hellbender.utils.downsampling.ReadsDownsamplingIterator
 
hasNext() - Method in class org.broadinstitute.hellbender.utils.iterators.AllLocusIterator
 
hasNext() - Method in class org.broadinstitute.hellbender.utils.iterators.ByteArrayIterator
 
hasNext() - Method in class org.broadinstitute.hellbender.utils.iterators.IntervalLocusIterator
 
hasNext() - Method in class org.broadinstitute.hellbender.utils.iterators.IntervalOverlappingIterator
 
hasNext() - Method in class org.broadinstitute.hellbender.utils.iterators.ReadCachingIterator
 
hasNext() - Method in class org.broadinstitute.hellbender.utils.iterators.ReadFilteringIterator
 
hasNext() - Method in class org.broadinstitute.hellbender.utils.iterators.ReadTransformingIterator
 
hasNext() - Method in class org.broadinstitute.hellbender.utils.iterators.SamReaderQueryingIterator
 
hasNext() - Method in class org.broadinstitute.hellbender.utils.iterators.SAMRecordToReadIterator
 
hasNext() - Method in class org.broadinstitute.hellbender.utils.iterators.ShardedIntervalIterator
 
hasNext() - Method in class org.broadinstitute.hellbender.utils.locusiterator.IntervalAlignmentContextIterator
 
hasNext() - Method in class org.broadinstitute.hellbender.utils.locusiterator.LocusIteratorByState
Is there another pileup available?
hasNext() - Method in class org.broadinstitute.hellbender.utils.read.ArtificialReadIterator
 
hasNext() - Method in class org.broadinstitute.hellbender.utils.read.ArtificialReadQueryIterator
override the hasNext, to incorportate our limiting factor
hasNext() - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.MultiHitAlignedReadIterator
 
hasNext() - Method in class org.broadinstitute.hellbender.utils.text.XReadLines
 
hasNext() - Method in class picard.illumina.parser.IlluminaDataProvider
 
hasNext() - Method in class picard.illumina.parser.MultiTileParser
 
hasNext() - Method in class picard.illumina.parser.NewIlluminaDataProvider
 
hasNext() - Method in class picard.illumina.parser.PerTileParser
 
hasNext() - Method in class picard.illumina.parser.readers.AbstractIlluminaPositionFileReader
Return true if the file has more elements to return, false otherwise
hasNext() - Method in class picard.illumina.parser.readers.BarcodeFileReader
 
hasNext() - Method in class picard.illumina.parser.readers.BclReader
 
hasNext() - Method in class picard.illumina.parser.readers.CbclReader
 
hasNext() - Method in class picard.illumina.parser.readers.ClocsFileReader
 
hasNext() - Method in class picard.illumina.parser.readers.EmpiricalPhasingMetricsOutReader
 
hasNext() - Method in class picard.illumina.parser.readers.FilterFileReader
 
hasNext() - Method in class picard.illumina.parser.readers.LocsFileReader
 
hasNext() - Method in class picard.illumina.parser.readers.PosFileReader
 
hasNext() - Method in class picard.illumina.parser.readers.TileMetricsOutReader
 
hasNext() - Method in class picard.sam.markduplicates.MarkDuplicatesWithMateCigarIterator
 
hasNext() - Method in class picard.util.AsyncIterator
 
hasNext() - Method in class picard.util.DelimitedTextFileWithHeaderIterator
 
hasNext() - Method in class picard.vcf.ByIntervalListVariantContextIterator
 
hasNext() - Method in class picard.vcf.filter.FilterApplyingVariantIterator
 
hasNext() - Method in class picard.vcf.PairedVariantSubContextIterator
 
hasNext() - Method in class picard.vcf.processor.util.PredicateFilterDecoratingClosableIterator
 
hasNode(int) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTree
 
hasNonClippedBases(Cigar) - Static method in class org.broadinstitute.hellbender.utils.read.CigarUtils
Checks whether the cigar has any element that is not H or S
hasNonDiagonalElements() - Method in class org.broadinstitute.hellbender.tools.validation.CompareMatrix
 
hasOnly2GoodAlignments() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments
 
hasOverlapper(SVInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree
Check the tree against a probe interval to see if there's an overlapping interval.
hasPendingItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.Downsampler
Are there items stored in this downsampler that it doesn't yet know whether they will ultimately survive the downsampling process?
hasPendingItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.FractionalDownsampler
 
hasPendingItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.LevelingDownsampler
 
hasPendingItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.MutectDownsampler
 
hasPendingItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.PassThroughDownsampler
 
hasPendingItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.PositionalDownsampler
 
hasPendingItems() - Method in class org.broadinstitute.hellbender.utils.downsampling.ReservoirDownsampler
 
hasPileupBeenDownsampled() - Method in class org.broadinstitute.hellbender.engine.AlignmentContext
Returns true if any reads have been filtered out of the pileup due to excess DoC.
hasRateFactor() - Method in enum org.broadinstitute.hellbender.tools.walkers.haplotypecaller.PairHMMLikelihoodCalculationEngine.PCRErrorModel
 
HasReadGroupReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.HasReadGroupReadFilter
 
hasReads() - Method in class org.broadinstitute.hellbender.engine.GATKTool
Are sources of reads available?
hasReads() - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
Are sources of reads available?
hasReference() - Method in class org.broadinstitute.hellbender.engine.GATKTool
Is a source of reference data available?
hasReference() - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
Is a source of reference data available?
hasRightFlankingRegion() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmer.Result
Checks whether there is a non-empty right flanking non-variant trimmed out region.
hasSequenceInfo() - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
hasSupplementalHits() - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.HitsForInsert
True if either the first or second of pair has supplementary alignments, otherwise false.
hasTooManyAlternativeAlleles(VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
Checks whether the variant context has too many alternative alleles for progress to genotyping the site.
hasWebDocumentation(Class<?>) - Static method in class picard.cmdline.CommandLineProgram
Determine if a class has web documentation based on its package name
hasWellDefinedFragmentSize(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Can the adaptor sequence of read be reliably removed from the read based on the alignment of read and its mate?
hcArgs - Variable in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark
 
hcArgs - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.ReadsPipelineSpark
 
HDF5SimpleCountCollection - Class in org.broadinstitute.hellbender.tools.copynumber.formats.collections
Helper class for SimpleCountCollection used to read/write HDF5.
HDF5SVDReadCountPanelOfNormals - Class in org.broadinstitute.hellbender.tools.copynumber.denoising
Represents the SVD panel of normals to be created by CreateReadCountPanelOfNormals.
HDF5Utils - Class in org.broadinstitute.hellbender.tools.copynumber.utils
TODO move into hdf5-java-bindings
HDFS_PREFIX - Static variable in class org.broadinstitute.hellbender.utils.gcs.BucketUtils
 
head() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KBestHaplotype
The first vertex on the haplotype path.
header - Variable in class org.broadinstitute.hellbender.utils.codecs.table.TableCodec
 
header - Variable in class org.broadinstitute.hellbender.utils.read.ArtificialReadIterator
 
header - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.AbstractMarkDuplicatesCommandLineProgram.SamHeaderAndIterator
 
header - Variable in class picard.sam.markduplicates.util.AbstractMarkDuplicatesCommandLineProgram.SamHeaderAndIterator
 
HEADER - Variable in class picard.sam.ReplaceSamHeader
 
HEADER - Variable in class picard.vcf.FixVcfHeader
 
HEADER_DELIMITER - Static variable in class org.broadinstitute.hellbender.utils.codecs.table.TableCodec
 
HEADER_FIELD_EQUAL_CHR - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils
 
HEADER_FIELD_LIST_SEPARATOR_STR - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils
 
HEADER_FIELD_SEPARATOR_CHR - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils
 
HEADER_FIELD_SEPARATOR_REGEXP - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils
 
HEADER_LISTED_FIELD_DELIMITER - Static variable in class org.broadinstitute.hellbender.tools.funcotator.vcfOutput.VcfOutputRenderer
The delimiter in the header for the list of fields that each funcotation has.
HEADER_NAME_AND_DESCRIPTION_SEPARATOR - Static variable in class org.broadinstitute.hellbender.utils.reference.FastaReferenceWriter
Character used to separate the sequence name and the description if any.
HEADER_ONLY - Variable in class picard.sam.ViewSam
 
HEADER_PREFIX_CHR - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils
 
HEADER_START_CHAR - Static variable in class org.broadinstitute.hellbender.utils.reference.FastaReferenceWriter
Sequence header start character.
headerlessReadAdapter(SAMRecord) - Static method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
Produces a SAMRecordToGATKReadAdapter wrapping the provided SAMRecord, and nulls out the header in the encapsulated read.
HeaderlessSAMRecordCoordinateComparator - Class in org.broadinstitute.hellbender.utils.read
A comparator for headerless SAMRecords that exactly matches the ordering of the SAMRecordCoordinateComparator
HeaderlessSAMRecordCoordinateComparator(SAMFileHeader) - Constructor for class org.broadinstitute.hellbender.utils.read.HeaderlessSAMRecordCoordinateComparator
 
headerLines() - Method in class picard.vcf.filter.AlleleBalanceFilter
 
headerLines() - Method in class picard.vcf.filter.FisherStrandFilter
 
headerLines() - Method in class picard.vcf.filter.QdFilter
 
headerLines() - Method in interface picard.vcf.filter.VariantFilter
Return VCF header lines that define filters that may be applied by the VariantFilter.
HeaderMissingReadGroup(GATKRead) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.HeaderMissingReadGroup
 
headers - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
headerWarningFile - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
 
HelpConstants - Class in org.broadinstitute.hellbender.utils.help
 
HelpConstants - Class in picard.util.help
 
helpDebugAuthError() - Method in class org.broadinstitute.hellbender.utils.test.BaseTest
Print information to the console that helps understand which credentials are in use (are they the ones you meant to use?).
HET_ALLELIC_COUNTS_FILE_SUFFIX - Static variable in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
HET_AS_HOM - Variable in class picard.analysis.FingerprintingSummaryMetrics
num of hets, observed as homs with LOD > threshold
HET_GENOTYPE_FOR_PHASING - Static variable in class picard.fingerprint.HaplotypeMap
 
HET_HOMVAR_RATIO - Variable in class picard.vcf.CollectVariantCallingMetrics.VariantCallingDetailMetrics
(count of hets)/(count of homozygous non-ref) for this sample
HET_PPV - Variable in class picard.vcf.GenotypeConcordanceSummaryMetrics
The ppv (positive predictive value) for all heterozygous variants (PPV is the TP / (TP + FP))
HET_SENSITIVITY - Variable in class picard.vcf.GenotypeConcordanceSummaryMetrics
The sensitivity for all heterozygous variants (Sensitivity is TP / (TP + FN))
HET_SNP_Q - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The Phred Scaled Q Score of the theoretical HET SNP sensitivity.
HET_SNP_Q - Variable in class picard.analysis.directed.HsMetrics
The Phred Scaled Q Score of the theoretical HET SNP sensitivity.
HET_SNP_Q - Variable in class picard.analysis.directed.TargetedPcrMetrics
The Q Score of the theoretical HET SNP sensitivity.
HET_SNP_Q - Variable in class picard.analysis.directed.TargetMetrics
The Phred Scaled Q Score of the theoretical HET SNP sensitivity.
HET_SNP_SENSITIVITY - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The theoretical HET SNP sensitivity.
HET_SNP_SENSITIVITY - Variable in class picard.analysis.directed.HsMetrics
The theoretical HET SNP sensitivity.
HET_SNP_SENSITIVITY - Variable in class picard.analysis.directed.TargetedPcrMetrics
The theoretical HET SNP sensitivity.
HET_SNP_SENSITIVITY - Variable in class picard.analysis.directed.TargetMetrics
The theoretical HET SNP sensitivity.
HET_SPECIFICITY - Variable in class picard.vcf.GenotypeConcordanceSummaryMetrics
The specificity for all heterozygous variants cannot be calculated
hetAltDepthDistribution(int) - Static method in class picard.analysis.TheoreticalSensitivity
 
HeterogeneousPloidyModel - Class in org.broadinstitute.hellbender.tools.walkers.genotyper
General heterogeneous ploidy model.
HeterogeneousPloidyModel(SampleList, int[]) - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.HeterogeneousPloidyModel
 
HeterozygosityAFPriorProvider - Class in org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc
Allele frequency prior provider based on heterozygosity.
HeterozygosityAFPriorProvider(double) - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.HeterozygosityAFPriorProvider
Construct a new provider given the heterozygosity value.
HeterozygosityCalculator - Class in org.broadinstitute.hellbender.tools.walkers.annotator
A class containing utility methods used in the calculation of annotations related to cohort heterozygosity, e.g.
HeterozygosityCalculator(VariantContext) - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.HeterozygosityCalculator
Create a new HeterozygosityUtils -- a new class should be instantiated for each VariantContext to store data for that VC
heterozygosityStandardDeviation - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeCalculationArgumentCollection
The standard deviation of the distribution of alt allele fractions.
hetSNPSensitivity(double[], double[], int, double) - Static method in class picard.analysis.TheoreticalSensitivity
 
hetSNPSensitivity(double[], double[], int, double, boolean) - Static method in class picard.analysis.TheoreticalSensitivity
 
HG19_REFERENCE_VERSION_STRING - Static variable in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorArgumentDefinitions
 
HG38_REFERENCE_VERSION_STRING - Static variable in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorArgumentDefinitions
 
HI_CONF_DENOVO_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
hiddenStates() - Method in interface org.broadinstitute.hellbender.utils.hmm.HMM
Returns all hidden states.
hierarchicalBayesianQualityEstimate(double, RecalDatum, RecalDatum, RecalDatum...) - Static method in class org.broadinstitute.hellbender.transformers.BQSRReadTransformer
 
HIGH_COVERAGE_RATIO_THRESHOLD_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.contamination.CalculateContamination
 
highConfidenceRegion - Variable in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker
 
highCoverageIntervalsFile - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
highDepthCoverageFactor - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
highDepthCoveragePeakFactor - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
highQualityDepthHistogram - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
Count of sites with a given depth of coverage.
highQualityDepthHistogramArray - Variable in class picard.analysis.AbstractWgsMetricsCollector
Count of sites with a given depth of coverage.
Histogram - Class in org.broadinstitute.hellbender.utils
Class used for storing a list of doubles as a run length encoded histogram that compresses the data into bins spaced at defined intervals.
Histogram() - Constructor for class org.broadinstitute.hellbender.utils.Histogram
Create an empty histogram object with a default bin size of 0.1
Histogram(Double) - Constructor for class org.broadinstitute.hellbender.utils.Histogram
Create an empty histogram object with a with a specified bin size
Histogram_FILE - Variable in class picard.analysis.CollectInsertSizeMetrics
 
Histogram_R_SCRIPT - Static variable in class picard.analysis.CollectInsertSizeMetrics
 
HISTOGRAM_WIDTH - Variable in class picard.analysis.CollectInsertSizeMetrics
 
histogramPlotFile - Variable in class org.broadinstitute.hellbender.metrics.InsertSizeMetricsArgumentCollection
 
histogramWidth - Variable in class org.broadinstitute.hellbender.metrics.InsertSizeMetricsArgumentCollection
 
HITS_TAG - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScorer
 
HitsForInsert - Class in org.broadinstitute.hellbender.utils.read.mergealignment
Holds all the hits (alignments) for a read or read pair.
HitsForInsert() - Constructor for class org.broadinstitute.hellbender.utils.read.mergealignment.HitsForInsert
 
HitsForInsert.NumPrimaryAlignmentState - Enum in org.broadinstitute.hellbender.utils.read.mergealignment
 
HMM<D,T,S> - Interface in org.broadinstitute.hellbender.utils.hmm
Hidden Markov Model interface with hidden-state transition probabilities and data emission that might depends on the position.
hmm_glocal(byte[], byte[], int, int, byte[], int[], byte[]) - Method in class org.broadinstitute.hellbender.utils.baq.BAQ
 
HOM_AS_HET - Variable in class picard.analysis.FingerprintingSummaryMetrics
num of homs, observed as hets with LOD > threshold
HOM_AS_OTHER_HOM - Variable in class picard.analysis.FingerprintingSummaryMetrics
num of homs, observed as other homs with LOD > threshold
HomogeneousPloidyModel - Class in org.broadinstitute.hellbender.tools.walkers.genotyper
PloidyModel implementation tailored to work with a homogeneous constant ploidy across samples and positions.
HomogeneousPloidyModel(SampleList, int) - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.HomogeneousPloidyModel
Constructs a homogeneous ploidy model given the sample list and ploidy.
HOMOLOGY - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
HOMOLOGY_LENGTH - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
homologyForwardStrandRep - Variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications
'+' strand representations of micro-homology, inserted sequence and duplicated sequence on the reference.
HOMOPOLYMER_RUN_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
HomoSapiensConstants - Class in org.broadinstitute.hellbender.utils.variant
Homo sapiens genome constants.
homozygousAlleleList(Allele, int) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Returns a homozygous call allele list given the only allele and the ploidy.
HOMVAR_PPV - Variable in class picard.vcf.GenotypeConcordanceSummaryMetrics
The ppv (positive predictive value) for all homozygous variants (PPV is the TP / (TP + FP))
HOMVAR_SENSITIVITY - Variable in class picard.vcf.GenotypeConcordanceSummaryMetrics
The sensitivity for all homozygous variants (Sensitivity is TP / (TP + FN))
HOMVAR_SPECIFICITY - Variable in class picard.vcf.GenotypeConcordanceSummaryMetrics
The specificity for all homozygous variants cannot be calculated.
HOPSCOTCH_SET_EXTENSION - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerUtils
 
HopscotchCollection<T> - Class in org.broadinstitute.hellbender.tools.spark.utils
Multiset implementation that provides low memory overhead with a high load factor by using the hopscotch algorithm.
HopscotchCollection() - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.HopscotchCollection
make a small HopscotchCollection
HopscotchCollection(int) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.HopscotchCollection
make a HopscotchCollection for a specified capacity (or good guess)
HopscotchCollection(Collection<? extends T>) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.HopscotchCollection
make a HopscotchCollection from a collection
HopscotchCollection(Kryo, Input) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.HopscotchCollection
 
HopscotchCollection.Serializer<T> - Class in org.broadinstitute.hellbender.tools.spark.utils
 
HopscotchMap<K,V,T extends java.util.Map.Entry<K,V>> - Class in org.broadinstitute.hellbender.tools.spark.utils
A uniquely keyed map with O(1) operations.
HopscotchMap() - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.HopscotchMap
 
HopscotchMap(int) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.HopscotchMap
 
HopscotchMap(Collection<? extends T>) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.HopscotchMap
 
HopscotchMap(Kryo, Input) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.HopscotchMap
 
HopscotchMap.Serializer - Class in org.broadinstitute.hellbender.tools.spark.utils
 
HopscotchMultiMap<K,V,T extends java.util.Map.Entry<K,V>> - Class in org.broadinstitute.hellbender.tools.spark.utils
A map that can contain multiple values for a given key.
HopscotchMultiMap() - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.HopscotchMultiMap
 
HopscotchMultiMap(int) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.HopscotchMultiMap
 
HopscotchMultiMap(Collection<? extends T>) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.HopscotchMultiMap
 
HopscotchMultiMap(Kryo, Input) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.HopscotchMultiMap
 
HopscotchMultiMap.Serializer - Class in org.broadinstitute.hellbender.tools.spark.utils
 
HopscotchSet<T> - Class in org.broadinstitute.hellbender.tools.spark.utils
Implements Set by imposing a unique-element constraint on HopscotchCollection.
HopscotchSet() - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.HopscotchSet
 
HopscotchSet(int) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.HopscotchSet
 
HopscotchSet(Collection<? extends T>) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.HopscotchSet
 
HopscotchSet(Kryo, Input) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.HopscotchSet
 
HopscotchSet.Serializer - Class in org.broadinstitute.hellbender.tools.spark.utils
 
HopscotchUniqueMultiMap<K,V,T extends java.util.Map.Entry<K,V>> - Class in org.broadinstitute.hellbender.tools.spark.utils
A map that can contain multiple values for a given key, but distinct entries.
HopscotchUniqueMultiMap() - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.HopscotchUniqueMultiMap
 
HopscotchUniqueMultiMap(int) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.HopscotchUniqueMultiMap
 
HopscotchUniqueMultiMap(Collection<? extends T>) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.HopscotchUniqueMultiMap
 
HopscotchUniqueMultiMap(Kryo, Input) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.HopscotchUniqueMultiMap
 
HopscotchUniqueMultiMap.Serializer - Class in org.broadinstitute.hellbender.tools.spark.utils
 
HOST_KMER_COUNT_THRESHOLD_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
HOST_KMER_COUNT_THRESHOLD_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
HOST_MIN_IDENTITY_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
HOST_MIN_IDENTITY_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
HOST_READS_FILTERED - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterMetrics
The number of subtracted reads identified as host
HostAlignmentReadFilter - Class in org.broadinstitute.hellbender.tools.spark.pathseq
Filters out reads above a threshold identity (number of matches less deletions), given in bases.
HostAlignmentReadFilter(int) - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.HostAlignmentReadFilter
 
hostKmerThresh - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
Controls the stringency of read filtering based on host k-mer matching.
HQ_MAPPINGS - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
HS_LIBRARY_SIZE - Variable in class picard.analysis.directed.HsMetrics
The estimated number of unique molecules in the selected part of the library.
HS_PENALTY_100X - Variable in class picard.analysis.directed.HsMetrics
The "hybrid selection penalty" incurred to get 80% of target bases to 100X.
HS_PENALTY_10X - Variable in class picard.analysis.directed.HsMetrics
The "hybrid selection penalty" incurred to get 80% of target bases to 10X.
HS_PENALTY_20X - Variable in class picard.analysis.directed.HsMetrics
The "hybrid selection penalty" incurred to get 80% of target bases to 20X.
HS_PENALTY_30X - Variable in class picard.analysis.directed.HsMetrics
The "hybrid selection penalty" incurred to get 80% of target bases to 30X.
HS_PENALTY_40X - Variable in class picard.analysis.directed.HsMetrics
The "hybrid selection penalty" incurred to get 80% of target bases to 40X.
HS_PENALTY_50X - Variable in class picard.analysis.directed.HsMetrics
The "hybrid selection penalty" incurred to get 80% of target bases to 50X.
HsMetricCollector - Class in picard.analysis.directed
Calculates HS metrics for a given SAM or BAM file.
HsMetricCollector(Set<MetricAccumulationLevel>, List<SAMReadGroupRecord>, ReferenceSequenceFile, File, File, IntervalList, IntervalList, String, int, int, int, boolean, int, int) - Constructor for class picard.analysis.directed.HsMetricCollector
 
HsMetricCollector(Set<MetricAccumulationLevel>, List<SAMReadGroupRecord>, ReferenceSequenceFile, File, File, IntervalList, IntervalList, String, int, int, int, boolean, boolean, int, int) - Constructor for class picard.analysis.directed.HsMetricCollector
 
HsMetrics - Class in picard.analysis.directed
Metrics generated by CollectHsMetrics for the analysis of target-capture sequencing experiments.
HsMetrics() - Constructor for class picard.analysis.directed.HsMetrics
 
htsjdk.samtools - package htsjdk.samtools
 
HybridADVIArgumentCollection - Class in org.broadinstitute.hellbender.tools.copynumber.arguments
 
HybridADVIArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection
 
HybridADVIArgumentCollection.HybridADVIArgument - Enum in org.broadinstitute.hellbender.tools.copynumber.arguments
 

I

id() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.AggregatedSubHaplotypeFinder
 
ID_COLUMN_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.FalsePositiveRecord
 
idealSpan - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmer.Result
The ideal trimmer variant region span including the extension.
identifyContaminant(Path, double, int) - Method in class picard.fingerprint.FingerprintChecker
Generates a per-sample Fingerprint for the contaminant in the supplied SAM file.
IdentifyContaminant - Class in picard.fingerprint
Program to create a fingerprint for the contaminating sample when the level of contamination is both known and uniform in the genome.
IdentifyContaminant() - Constructor for class picard.fingerprint.IdentifyContaminant
 
identity() - Static method in interface org.broadinstitute.hellbender.transformers.ReadTransformer
 
IDENTITY_FUNCTION - Static variable in class org.broadinstitute.hellbender.engine.datasources.ReferenceWindowFunctions
A function for requesting only reference bases that directly overlap each read.
IDENTITY_MARGIN_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
 
IDENTITY_MARGIN_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
 
identityMargin - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
For reads having multiple alignments, the best hit is always counted as long as it is above the identity score threshold.
idx - Variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerizer
 
IGNORE - Variable in class picard.sam.ValidateSamFile
 
IGNORE_FILTER_STATUS - Variable in class picard.vcf.GenotypeConcordance
 
IGNORE_LANE_INFO - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.UnifiedArgumentCollection
 
IGNORE_MISSING_MATES - Variable in class picard.sam.FixMateInformation
 
IGNORE_READ_GROUPS - Variable in class picard.fingerprint.CheckFingerprint
 
IGNORE_SAFETY_CHECKS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.GatherVcfsCloud
 
IGNORE_SEQUENCE - Variable in class picard.analysis.CollectRnaSeqMetrics
 
IGNORE_SNP_ALLELES - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.UnifiedArgumentCollection
 
IGNORE_UNEXPECTED_BARCODES - Variable in class picard.illumina.IlluminaBasecallsToFastq
 
IGNORE_UNEXPECTED_BARCODES - Variable in class picard.illumina.IlluminaBasecallsToSam
 
IGNORE_VARIANTS_THAT_START_OUTSIDE_INTERVAL - Static variable in class org.broadinstitute.hellbender.engine.MultiVariantWalkerGroupedOnStart
 
IGNORE_WARNINGS - Variable in class picard.sam.ValidateSamFile
 
ignoreAlignment(SAMRecord) - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.AbstractAlignmentMerger
 
ignoreAlignment(SAMRecord) - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.SamAlignmentMerger
For now, we only ignore those alignments that have more than maxGaps insertions or deletions.
ignoreAlignment(SAMRecord) - Method in class picard.sam.AbstractAlignmentMerger
 
ignoreAlignment(SAMRecord) - Method in class picard.sam.SamAlignmentMerger
For now, we ignore only those alignments that have more than SamAlignmentMerger.maxGaps insertions or deletions.
ignoreCrossContigID(int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata
 
IGNORED_READS - Variable in class picard.analysis.RnaSeqMetrics
Number of primary alignments that are mapped to a sequence specified on command-line as IGNORED_SEQUENCE.
ignoreExceptions - Variable in class org.broadinstitute.hellbender.utils.runtime.ScriptExecutor
 
ignoreInputSamples - Variable in class org.broadinstitute.hellbender.tools.walkers.variantutils.CalculateGenotypePosteriors
When this flag is set, only the AC and AN calculated from external sources will be used, and the calculation will not use the discovered allele frequency in the callset whose posteriors are being calculated.
ignoreInputSamplesForMissingResources - Variable in class org.broadinstitute.hellbender.tools.walkers.variantutils.CalculateGenotypePosteriors
Don't add input sample ACs for variants not seen in the supporting panel.
ignoreLastModificationTime - Variable in class org.broadinstitute.hellbender.tools.walkers.bqsr.AnalyzeCovariates
If true, it won't show a warning if the last-modification time of the before and after input files suggest that they have been reversed.
ignoreOverlaps - Variable in class org.broadinstitute.hellbender.tools.walkers.qc.CheckPileup
 
ignoreSafetyChecks - Variable in class org.broadinstitute.hellbender.tools.GatherVcfsCloud
 
IGV_HEADER_DELIMITER - Static variable in class org.broadinstitute.hellbender.utils.codecs.table.TableCodec
 
IGVUtils - Class in org.broadinstitute.hellbender.utils
Utilities for interacting with IGV-specific formats.
ILLUMINA_ALLEGED_MINIMUM_QUALITY - Static variable in class picard.illumina.parser.readers.BclQualityEvaluationStrategy
 
IlluminaAdapterPair - Enum in org.broadinstitute.hellbender.utils.illumina
Describes adapters used on each pair of strands
IlluminaBasecallingMetrics - Class in picard.illumina
Metric for Illumina Basecalling that stores means and standard deviations on a per-barcode per-lane basis.
IlluminaBasecallingMetrics() - Constructor for class picard.illumina.IlluminaBasecallingMetrics
 
IlluminaBasecallsConverter<CLUSTER_OUTPUT_RECORD> - Class in picard.illumina
Manages the conversion of Illumina basecalls into some output format.
IlluminaBasecallsConverter(File, int, ReadStructure, Map<String, ? extends BasecallsConverter.ConvertedClusterDataWriter<CLUSTER_OUTPUT_RECORD>>, boolean, int, List<File>, int, boolean, Integer, Integer, Comparator<CLUSTER_OUTPUT_RECORD>, SortingCollection.Codec<CLUSTER_OUTPUT_RECORD>, Class<CLUSTER_OUTPUT_RECORD>, BclQualityEvaluationStrategy, boolean, boolean, boolean) - Constructor for class picard.illumina.IlluminaBasecallsConverter
 
IlluminaBasecallsConverter(File, File, int, ReadStructure, Map<String, ? extends BasecallsConverter.ConvertedClusterDataWriter<CLUSTER_OUTPUT_RECORD>>, boolean, int, List<File>, int, boolean, Integer, Integer, Comparator<CLUSTER_OUTPUT_RECORD>, SortingCollection.Codec<CLUSTER_OUTPUT_RECORD>, Class<CLUSTER_OUTPUT_RECORD>, BclQualityEvaluationStrategy, boolean, boolean, boolean) - Constructor for class picard.illumina.IlluminaBasecallsConverter
 
IlluminaBasecallsToFastq - Class in picard.illumina
 
IlluminaBasecallsToFastq() - Constructor for class picard.illumina.IlluminaBasecallsToFastq
 
IlluminaBasecallsToFastq.ReadNameFormat - Enum in picard.illumina
Simple switch to control the read name format to emit.
IlluminaBasecallsToSam - Class in picard.illumina
IlluminaBasecallsToSam transforms a lane of Illumina data file formats (bcl, locs, clocs, qseqs, etc.) into SAM or BAM file format.
IlluminaBasecallsToSam() - Constructor for class picard.illumina.IlluminaBasecallsToSam
 
IlluminaDataProvider - Class in picard.illumina.parser
Parse various formats and versions of Illumina Basecall files, and use them the to populate ClusterData objects.
IlluminaDataProviderFactory - Class in picard.illumina.parser
IlluminaDataProviderFactory accepts options for parsing Illumina data files for a lane and creates an IlluminaDataProvider, an iterator over the ClusterData for that lane, which utilizes these options.
IlluminaDataProviderFactory(File, int, ReadStructure, BclQualityEvaluationStrategy, IlluminaDataType...) - Constructor for class picard.illumina.parser.IlluminaDataProviderFactory
Create factory with the specified options, one that favors using QSeqs over all other files
IlluminaDataProviderFactory(File, File, int, ReadStructure, BclQualityEvaluationStrategy, IlluminaDataType...) - Constructor for class picard.illumina.parser.IlluminaDataProviderFactory
Create factory with the specified options, one that favors using QSeqs over all other files
IlluminaDataProviderFactory(File, File, int, ReadStructure, BclQualityEvaluationStrategy) - Constructor for class picard.illumina.parser.IlluminaDataProviderFactory
 
IlluminaDataType - Enum in picard.illumina.parser
List of data types of interest when parsing Illumina data.
IlluminaFileUtil - Class in picard.illumina.parser
General utils for dealing with IlluminaFiles as well as utils for specific, support formats.
IlluminaFileUtil(File, int) - Constructor for class picard.illumina.parser.IlluminaFileUtil
 
IlluminaFileUtil(File, File, int) - Constructor for class picard.illumina.parser.IlluminaFileUtil
 
IlluminaFileUtil.SupportedIlluminaFormat - Enum in picard.illumina.parser
 
IlluminaLaneMetrics - Class in picard.illumina
Embodies characteristics that describe a lane.
IlluminaLaneMetrics() - Constructor for class picard.illumina.IlluminaLaneMetrics
 
IlluminaLaneMetricsCollector() - Constructor for class picard.illumina.CollectIlluminaLaneMetrics.IlluminaLaneMetricsCollector
 
IlluminaLaneTileCode(int, int, int) - Constructor for class picard.illumina.parser.readers.TileMetricsOutReader.IlluminaLaneTileCode
 
IlluminaMetricsCode - Enum in picard.illumina.parser
Illumina's TileMetricsOut.bin file codes various metrics, both concrete (all density id's are code 100) or as a base code (e.g.
IlluminaPhasingMetrics - Class in picard.illumina
Metrics for Illumina Basecalling that stores median phasing and prephasing percentages on a per-template-read, per-lane basis.
IlluminaPhasingMetrics() - Constructor for class picard.illumina.IlluminaPhasingMetrics
 
IlluminaReadNameEncoder - Class in picard.fastq
A read name encoder following the encoding initially produced by picard fastq writers.
IlluminaReadNameEncoder(String) - Constructor for class picard.fastq.IlluminaReadNameEncoder
 
IlluminaTileMetrics(ByteBuffer, TileMetricsOutReader.TileMetricsVersion) - Constructor for class picard.illumina.parser.readers.TileMetricsOutReader.IlluminaTileMetrics
 
IlluminaTileMetrics(int, int, int, float) - Constructor for class picard.illumina.parser.readers.TileMetricsOutReader.IlluminaTileMetrics
 
IlluminaUtil - Class in picard.util
Misc utilities for working with Illumina specific files and data
IlluminaUtil() - Constructor for class picard.util.IlluminaUtil
 
IlluminaUtil.IlluminaAdapterPair - Enum in picard.util
Describes adapters used on each pair of strands
IMPRECISE - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
ImpreciseDeletion(EvidenceTargetLink, int, ReadMetadata) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.SimpleSVType.ImpreciseDeletion
 
impreciseDupAffectedRefRange - Variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications.SmallDuplicationWithImpreciseDupRangeBreakpointComplications
 
ImpreciseVariantDetector - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.inference
 
ImpreciseVariantDetector() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.ImpreciseVariantDetector
 
impreciseVariantEvidenceThreshold - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.DiscoverVariantsFromContigsAlignmentsSparkArgumentCollection
 
IMPUTE_ZEROS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.CreateReadCountPanelOfNormals
 
in - Variable in class picard.sam.markduplicates.util.ReadEndsForMarkDuplicatesCodec
 
in - Variable in class picard.sam.markduplicates.util.RepresentativeReadIndexerCodec
 
IN_PON_VCF_ATTRIBUTE - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
INBREEDING_COEFFICIENT_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
InbreedingCoeff - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Likelihood-based test for the consanguinuity among samples
InbreedingCoeff() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.InbreedingCoeff
 
InbreedingCoeff(Set<String>) - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.InbreedingCoeff
 
InbreedingCoeff(File) - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.InbreedingCoeff
 
incAll(int) - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
Increase (or decrease) all elements in the set by a number.
INCLUDE_BQ_HISTOGRAM - Variable in class picard.analysis.CollectWgsMetrics
 
INCLUDE_DUPLICATES - Variable in class picard.analysis.artifacts.CollectSequencingArtifactMetrics
 
INCLUDE_DUPLICATES - Variable in class picard.analysis.CollectInsertSizeMetrics
 
INCLUDE_FILTERED - Variable in class picard.util.IntervalListTools
 
INCLUDE_FILTERED - Variable in class picard.vcf.VcfToIntervalList
 
INCLUDE_FILTERED_SHORT_NAME - Static variable in class picard.vcf.VcfToIntervalList
 
INCLUDE_NO_CALLS - Variable in class picard.analysis.QualityScoreDistribution
 
INCLUDE_NON_PF_READS - Variable in class picard.analysis.artifacts.CollectSequencingArtifactMetrics
 
INCLUDE_NON_PF_READS - Variable in class picard.analysis.CollectOxoGMetrics
 
INCLUDE_NON_PF_READS - Variable in class picard.fastq.BamToBfq
 
INCLUDE_NON_PF_READS - Variable in class picard.illumina.IlluminaBasecallsToFastq
 
INCLUDE_NON_PF_READS - Variable in class picard.illumina.IlluminaBasecallsToSam
 
INCLUDE_NON_PF_READS - Variable in class picard.sam.SamToFastq
 
INCLUDE_NON_PRIMARY_ALIGNMENTS - Variable in class picard.sam.SamToFastq
 
INCLUDE_SECONDARY_ALIGNMENTS - Variable in class picard.analysis.CollectQualityYieldMetrics
 
INCLUDE_SECONDARY_ALIGNMENTS - Variable in class picard.sam.MergeBamAlignment
 
INCLUDE_SUPPLEMENTAL_ALIGNMENTS - Variable in class picard.analysis.CollectQualityYieldMetrics
 
INCLUDE_UNPAIRED - Variable in class picard.analysis.artifacts.CollectSequencingArtifactMetrics
 
INCLUDE_UNPAIRED - Variable in class picard.analysis.CollectMultipleMetrics
 
includeDeletions() - Method in class org.broadinstitute.hellbender.engine.LocusWalker
Does this tool require deletions in the AlignmentContext? Tools that don't should override to return false.
includeDeletions() - Method in class org.broadinstitute.hellbender.tools.walkers.qc.Pileup
 
includeMappingLocation - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
includeMatching(Collection<String>, Collection<String>, boolean) - Static method in class org.broadinstitute.hellbender.tools.walkers.variantutils.SelectVariants
Returns a new set of values including only values listed by filters/expressions

includeNoCalls - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.QualityScoreDistributionSpark
 
includeNs() - Method in class org.broadinstitute.hellbender.engine.LocusWalker
Does this tool require Ns in the AlignmentContext? Tools that do should override to return true.
includePluginClass(Class<?>) - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKAnnotationPluginDescriptor
 
includePluginClass(Class<?>) - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKReadFilterPluginDescriptor
 
includeReadsWithDeletionsInIsActivePileups() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
includeReadsWithDeletionsInIsActivePileups() - Method in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerSpark
subclasses can override this to control if reads with deletions should be included in isActive pileups
includeReadsWithDeletionsInIsActivePileups() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleAssemblyRegionWalker
 
includeReadsWithDeletionsInIsActivePileups() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleAssemblyRegionWalkerSpark
 
includeReadsWithDeletionsInIsActivePileups() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCaller
 
includeReadsWithDeletionsInIsActivePileups() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2
 
includeRefAllele() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.FragmentLength
 
includeRefAllele() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.PerAlleleAnnotation
 
includeSupplementalAlignments - Variable in class picard.analysis.CollectQualityYieldMetrics.QualityYieldMetricsCollector
 
incMultiplicity(int) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseEdge
Increase the multiplicity of this edge by incr
incMultiplicity(int) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.MultiSampleEdge
 
incNQClippedBases(int) - Method in class org.broadinstitute.hellbender.tools.ClipReads.ClippingData
 
incNRangeClippedBases(int) - Method in class org.broadinstitute.hellbender.tools.ClipReads.ClippingData
 
incomingEdgeOf(V) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Get the incoming edge of v.
incomingVerticesOf(V) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Get the set of vertices connected to v by incoming edges
IncompatibleRecalibrationTableParameters(String) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.IncompatibleRecalibrationTableParameters
 
IncompatibleSequenceDictionaries(String, String, SAMSequenceDictionary, String, SAMSequenceDictionary) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.IncompatibleSequenceDictionaries
 
INCORRECT_STRAND_READS - Variable in class picard.analysis.RnaSeqMetrics
Number of aligned reads that are mapped to the incorrect strand.
increase(int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeAlleleCounts
Increases the allele counts a number of times.
increase() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeAlleleCounts
Updates the genotype counts to match the next genotype.
increment(long, double) - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalDatum
 
increment(boolean) - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalDatum
 
increment(Object, String) - Method in class org.broadinstitute.hellbender.utils.report.GATKReportTable
Increment the value for a given position in the table.
increment(int) - Method in class picard.analysis.CounterManager.Counter
Increments value corresponding to reference sequence index
increment(GenotypeConcordanceStates.TruthAndCallStates) - Method in class picard.vcf.GenotypeConcordanceCounts
Increments a count for the truth/call state tuple.
increment(GenotypeConcordanceStates.TruthAndCallStates, double) - Method in class picard.vcf.GenotypeConcordanceCounts
 
incrementDatumOrPutIfNecessary2keys(NestedIntegerArray<RecalDatum>, byte, double, int, int) - Static method in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
Increments the RecalDatum at the specified position in the specified table, or put a new item there if there isn't already one.
incrementDatumOrPutIfNecessary3keys(NestedIntegerArray<RecalDatum>, byte, double, int, int, int) - Static method in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
Increments the RecalDatum at the specified position in the specified table, or put a new item there if there isn't already one.
incrementDatumOrPutIfNecessary4keys(NestedIntegerArray<RecalDatum>, byte, double, int, int, int, int) - Static method in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
Increments the RecalDatum at the specified position in the specified table, or put a new item there if there isn't already one.
incrementFalseNegative() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.FilterAnalysisRecord
 
incrementNumberOfDiscardedItems(int) - Method in class org.broadinstitute.hellbender.utils.downsampling.Downsampler
Increments the number of discarded items by the given value.
incrementNumMismatches(double) - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalDatum
 
incrementNumObservations(long) - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalDatum
 
incrementReadCount() - Method in class picard.analysis.directed.TargetMetricsCollector.Coverage
Increments the # of reads mapping to this target.
incrementTrueNegative() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.FilterAnalysisRecord
 
incrementUniqueFalseNegative() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.FilterAnalysisRecord
 
incrementUniqueTrueNegative() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.FilterAnalysisRecord
 
incSeqClippedBases(String, int) - Method in class org.broadinstitute.hellbender.tools.ClipReads.ClippingData
 
INDEL_COLUMN_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.FalsePositiveRecord
 
INDEL_CONTINUATION_QUAL - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2Engine
 
INDEL_FPR_COLUMN_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.FalsePositiveRecord
 
INDEL_GAP_CONTINUATION_PENALTY - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.UnifiedArgumentCollection
 
INDEL_GAP_OPEN_PENALTY - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.UnifiedArgumentCollection
 
INDEL_HAPLOTYPE_SIZE - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.UnifiedArgumentCollection
 
INDEL_HETEROZYGOSITY - Static variable in class org.broadinstitute.hellbender.utils.variant.HomoSapiensConstants
Standard heterozygous rate for INDEL variation.
INDEL_OUTPUT - Variable in class picard.vcf.SplitVcfs
 
INDEL_START_QUAL - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2Engine
 
INDEL_START_TOLERANCE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.FilterAlignmentArtifacts
 
indelCounter - Variable in class picard.vcf.GenotypeConcordance
 
indelHeterozygosity - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeCalculationArgumentCollection
This argument informs the prior probability of having an indel at a site.
indelHeterozygosity - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerGenotypingEngine
 
indelPadding - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmerArgumentCollection
Include at least this many bases around an event for calling it
indels - Variable in class org.broadinstitute.hellbender.utils.variant.DbSnpBitSetUtil.DbSnpBitSets
 
indels - Variable in class picard.util.DbSnpBitSetUtil.DbSnpBitSets
 
INDELS_CONTEXT_SIZE - Variable in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationArgumentCollection
The context covariate will use a context of this size to calculate its covariate value for base insertions and deletions.
indelSizeToEliminateInRefModel - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerArgumentCollection
This parameter determines the maximum size of an indel considered as potentially segregating in the reference model.
indelToMatch - Static variable in class org.broadinstitute.hellbender.utils.pairhmm.PairHMMModel
Position in the transition probability array for the Indel-to-Match transition.
IndependentAllelesDiploidExactAFCalculator - Class in org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc
Computes the conditional bi-allelic exact results Suppose vc contains 2 alt allele: A* with C and T.
IndependentReplicateMetric - Class in picard.analysis.replicates
A class to store information relevant for biological rate estimation
IndependentReplicateMetric() - Constructor for class picard.analysis.replicates.IndependentReplicateMetric
 
independentReplicationRateFromBiDups - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
independentReplicationRateFromTriDups - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
independentReplicationRateFromUmi - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
IndependentSampleGenotypesModel - Class in org.broadinstitute.hellbender.tools.walkers.genotyper
This class delegates genotyping to allele count- and ploidy-dependent GenotypeLikelihoodCalculators under the assumption that sample genotypes are independent conditional on their population frequencies.
IndependentSampleGenotypesModel() - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.IndependentSampleGenotypesModel
 
IndependentSampleGenotypesModel(int, int) - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.IndependentSampleGenotypesModel
Initialize model with given maximum allele count and ploidy for caching
index() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeAlleleCounts
Returns the index of this genotype allele count within all possible genotypes with the same ploidy.
index() - Method in enum org.broadinstitute.hellbender.utils.report.GATKReportTable.TableDataHeaderFields
 
index() - Method in enum org.broadinstitute.hellbender.utils.report.GATKReportTable.TableNameHeaderFields
 
INDEX_VALIDATION_STRINGENCY - Variable in class picard.sam.ValidateSamFile
 
indexByClass(Class<? extends Covariate>) - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.StandardCovariateList
Returns the index of the covariate by class name or -1 if not found.
IndexedAlleleList<A extends htsjdk.variant.variantcontext.Allele> - Class in org.broadinstitute.hellbender.utils.genotyper
Allele list implementation using and indexed-set.
IndexedAlleleList() - Constructor for class org.broadinstitute.hellbender.utils.genotyper.IndexedAlleleList
Constructs a new empty allele-list
IndexedAlleleList(A...) - Constructor for class org.broadinstitute.hellbender.utils.genotyper.IndexedAlleleList
Constructs a new allele-list from an array of alleles.
IndexedAlleleList(Collection<A>) - Constructor for class org.broadinstitute.hellbender.utils.genotyper.IndexedAlleleList
Constructs a new allele-list from a collection of alleles.
IndexedSampleList - Class in org.broadinstitute.hellbender.utils.genotyper
Simple implementation of a sample-list using an indexed-set.
IndexedSampleList() - Constructor for class org.broadinstitute.hellbender.utils.genotyper.IndexedSampleList
Constructs an empty sample-list.
IndexedSampleList(Collection<String>) - Constructor for class org.broadinstitute.hellbender.utils.genotyper.IndexedSampleList
Constructs a sample-list from a collection of samples.
IndexedSampleList(String...) - Constructor for class org.broadinstitute.hellbender.utils.genotyper.IndexedSampleList
Constructs a sample-list from an array of samples.
IndexedSet<E> - Class in org.broadinstitute.hellbender.utils.collections
Set where each element can be reference by a unique integer index that runs from 0 to the size of the set - 1.
IndexedSet(int) - Constructor for class org.broadinstitute.hellbender.utils.collections.IndexedSet
Creates an empty indexed set indicating the expected number of elements.
IndexedSet(Collection<E>) - Constructor for class org.broadinstitute.hellbender.utils.collections.IndexedSet
Creates a new sample list from a existing collection of elements.
IndexedSet(E...) - Constructor for class org.broadinstitute.hellbender.utils.collections.IndexedSet
Creates a new sample list from a existing array of elements.
IndexFeatureFile - Class in org.broadinstitute.hellbender.tools
This tool creates an index file for the various kinds of feature-containing files supported by GATK (such as VCF and BED files).
IndexFeatureFile() - Constructor for class org.broadinstitute.hellbender.tools.IndexFeatureFile
 
indexImageFile - Variable in class org.broadinstitute.hellbender.tools.spark.bwa.BwaArgumentCollection
The BWA-MEM index image file name that you've distributed to each executor.
indexImageFile - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
This file should be generated using BwaMemIndexImageCreator.
indexOf(Object) - Method in class org.broadinstitute.hellbender.utils.collections.IndexedSet
Returns the index of an object.
indexOf(String) - Method in class org.broadinstitute.hellbender.utils.tsv.TableColumnCollection
Returns the index of a column by its name.
indexOfAllele(A) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingData
 
indexOfAllele(A) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingLikelihoods
 
indexOfAllele(A) - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.SubsettedLikelihoodMatrix
 
indexOfAllele(A) - Method in class org.broadinstitute.hellbender.utils.genotyper.AlleleList.ActualPermutation
 
indexOfAllele(A) - Method in interface org.broadinstitute.hellbender.utils.genotyper.AlleleList
Returns the index of the given Allele in this AlleleList.
indexOfAllele(A) - Method in class org.broadinstitute.hellbender.utils.genotyper.AlleleList.NonPermutation
 
indexOfAllele(A) - Method in class org.broadinstitute.hellbender.utils.genotyper.IndexedAlleleList
 
indexOfAllele(A) - Method in interface org.broadinstitute.hellbender.utils.genotyper.LikelihoodMatrix
Queries the index of an allele in the matrix.
indexOfAllele(A) - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Returns the index of an allele within the likelihood collection.
indexOfAllele(VariantContext, Allele, boolean, boolean, boolean) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Returns the absolute 0-based index of an allele.
indexOfAltAllele(VariantContext, Allele, boolean) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Returns the relative 0-based index of an alternative allele.
indexOfMax(double[]) - Static method in class picard.util.MathUtil
Returns the index of the largest element in the array.
indexOfMax(long[]) - Static method in class picard.util.MathUtil
Returns the index of the largest element in the array.
indexOfMin(int[]) - Static method in class picard.util.MathUtil
Returns the index of the smallest element in the array.
indexOfMin(double[]) - Static method in class picard.util.MathUtil
Returns the index of the smallest element in the array.
indexOfRead(GATKRead) - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.SubsettedLikelihoodMatrix
 
indexOfRead(GATKRead) - Method in interface org.broadinstitute.hellbender.utils.genotyper.LikelihoodMatrix
Queries the index of a read in the matrix.
indexOfReference() - Method in interface org.broadinstitute.hellbender.utils.genotyper.AlleleList
Resolves the index of the reference allele in an allele-list.
indexOfSample(String) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingData
 
indexOfSample(String) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingLikelihoods
 
indexOfSample(String) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.HeterogeneousPloidyModel
 
indexOfSample(String) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.HomogeneousPloidyModel
 
indexOfSample(String) - Method in class org.broadinstitute.hellbender.utils.genotyper.IndexedSampleList
 
indexOfSample(String) - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Returns the index of a sample within the likelihood collection.
indexOfSample(String) - Method in interface org.broadinstitute.hellbender.utils.genotyper.SampleList
Returns the index of an object.
IndexRange - Class in org.broadinstitute.hellbender.utils
Represents 0-based integer index range.
IndexRange(int, int) - Constructor for class org.broadinstitute.hellbender.utils.IndexRange
Creates a new range given its from and to indices.
IndexUtils - Class in org.broadinstitute.hellbender.utils
 
indicatesRefSeqDuplicatedOnAlt() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications
To be overridden as appropriate.
indicatesRefSeqDuplicatedOnAlt() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications.IntraChrStrandSwitchBreakpointComplications
 
indicesAvailable() - Method in class org.broadinstitute.hellbender.engine.ReadsDataSource
Are indices available for all files?
inferArtifactName() - Method in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasSummaryMetrics
Label the artifacts corresponding to known error modes.
inferArtifactName() - Method in class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterSummaryMetrics
Label the artifacts corresponding to known error modes.
INFERRED_UMI_ENTROPY - Variable in class picard.sam.markduplicates.UmiMetrics
Entropy (in base 4) of the inferred UMI sequences, indicating the effective number of bases in the inferred UMIs.
INFERRED_UNIQUE_UMIS - Variable in class picard.sam.markduplicates.UmiMetrics
Number of different inferred UMI sequences derived
InfoFieldAnnotation - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Annotations relevant to the INFO field of the variant file (ie annotations for sites).
InfoFieldAnnotation() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.InfoFieldAnnotation
 
INFORMATIVE_THRESHOLD - Static variable in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods.BestAllele
 
INIT_ARD_REL_UNEXPLAINED_VARIANCE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineDenoisingModelArgumentCollection
 
INITIAL_TEMPERATURE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection
 
INITIAL_TUMOR_LOD_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
INITIAL_TUMOR_LOD_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
initialize(InsertSizeMetricsArgumentCollection, SAMFileHeader) - Method in class org.broadinstitute.hellbender.metrics.InsertSizeMetricsCollector
 
initialize(ExampleMultiMetricsArgumentCollection, SAMFileHeader, List<Header>) - Method in class org.broadinstitute.hellbender.tools.examples.metrics.multi.ExampleCollectMultiMetricsSpark
Initialize the collector with it's input arguments.
initialize(ExampleMultiMetricsArgumentCollection, SAMFileHeader) - Method in class org.broadinstitute.hellbender.tools.examples.metrics.multi.ExampleMultiMetricsCollector
 
initialize(ExampleMultiMetricsArgumentCollection, SAMFileHeader, List<Header>) - Method in class org.broadinstitute.hellbender.tools.examples.metrics.multi.ExampleMultiMetricsCollectorSpark
Initialize the collector with input arguments.
initialize(ExampleSingleMetricsArgumentCollection, SAMFileHeader, List<Header>) - Method in class org.broadinstitute.hellbender.tools.examples.metrics.single.ExampleCollectSingleMetricsSpark
Initialize the collector with it's input arguments.
initialize(ExampleSingleMetricsArgumentCollection, SAMFileHeader, List<Header>) - Method in class org.broadinstitute.hellbender.tools.examples.metrics.single.ExampleSingleMetricsCollectorSpark
Initialize the collector with input arguments;
initialize(InsertSizeMetricsArgumentCollection, SAMFileHeader, List<Header>) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectInsertSizeMetricsSpark
 
initialize(QualityYieldMetricsArgumentCollection, SAMFileHeader, List<Header>) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectQualityYieldMetricsSpark
 
initialize(InsertSizeMetricsArgumentCollection, SAMFileHeader, List<Header>) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.InsertSizeMetricsCollectorSpark
Initialize the collector with input arguments;
initialize(T, SAMFileHeader, List<Header>) - Method in interface org.broadinstitute.hellbender.tools.spark.pipelines.metrics.MetricsCollectorSpark
Give the collector's input arguments to the collector (if the collector is being driven by a standalone tool.
initialize(T, SAMFileHeader, List<Header>) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.MetricsCollectorSparkTool
 
initialize(QualityYieldMetricsArgumentCollection, SAMFileHeader, List<Header>) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.QualityYieldMetricsCollectorSpark
Initialize the collector with input arguments;
initialize(AssemblyRegionTrimmerArgumentCollection, SAMSequenceDictionary, boolean, boolean, boolean) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmer
Initializes the trimmer.
initialize(IndexedFastaSequenceFile) - Method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.OverhangFixingManager.Splice
 
initialize(int, int) - Method in class org.broadinstitute.hellbender.utils.pairhmm.Log10PairHMM
Initialize this PairHMM, making it suitable to run against a read and haplotype with given lengths Note: Do not worry about padding, just provide the true max length of the read and haplotype.
initialize(int, int) - Method in class org.broadinstitute.hellbender.utils.pairhmm.PairHMM
Initialize this PairHMM, making it suitable to run against a read and haplotype with given lengths Note: Do not worry about padding, just provide the true max length of the read and haplotype.
initialize(List<Haplotype>, Map<String, List<GATKRead>>, int, int) - Method in class org.broadinstitute.hellbender.utils.pairhmm.PairHMM
Initialize this PairHMM, making it suitable to run against a read and haplotype with given lengths This function is used by the JNI implementations to transfer all data once to the native code
initialize(List<Haplotype>, Map<String, List<GATKRead>>, int, int) - Method in class org.broadinstitute.hellbender.utils.pairhmm.VectorLoglessPairHMM
Initialize this PairHMM, making it suitable to run against a read and haplotype with given lengths This function is used by the JNI implementations to transfer all data once to the native code
initialize() - Method in class picard.illumina.parser.MultiTileBclParser
 
initialize() - Method in enum picard.nio.PathHelper.PathProviders
 
initializeAdditionalWriters() - Method in class picard.sam.SamToFastq
 
initializeAdditionalWriters() - Method in class picard.sam.SamToFastqWithTags
 
initializeAnnotationOverrides(LinkedHashMap<String, String>) - Method in class org.broadinstitute.hellbender.tools.funcotator.DataSourceFuncotationFactory
Set values in DataSourceFuncotationFactory.annotationOverrideMap based on the given annotation override values and whether or not this DataSourceFuncotationFactory supports those annotations.
initializeConfigurationsFromCommandLineArgs(String[], String) - Method in class org.broadinstitute.hellbender.utils.config.ConfigFactory
Get the configuration filename from the command-line (if it exists) and create a configuration for it.
initializeConfigurationsFromCommandLineArgs(String[], String, Class<? extends T>) - Method in class org.broadinstitute.hellbender.utils.config.ConfigFactory
Get the configuration from filename the command-line (if it exists) and create a configuration for it of the given type.
initialized - Variable in class org.broadinstitute.hellbender.utils.pairhmm.PairHMM
 
initializeDefaultMapWithKeys() - Method in class org.broadinstitute.hellbender.tools.funcotator.mafOutput.MafOutputRenderer
Initializes MafOutputRenderer.defaultMap with the default keys for the columns in a MAF file.
initializeDrivingVariants() - Method in class org.broadinstitute.hellbender.engine.MultiVariantWalker
 
initializeDrivingVariants() - Method in class org.broadinstitute.hellbender.engine.VariantWalker
 
initializeDrivingVariants() - Method in class org.broadinstitute.hellbender.engine.VariantWalkerBase
Process the feature inputs that represent the primary driving source(s) of variants for this tool, and perform any necessary header and sequence dictionary validation.
initializeLog10Priors(byte[], byte[], byte[], int) - Method in class org.broadinstitute.hellbender.utils.pairhmm.Log10PairHMM
Initializes the matrix that holds all the constants related to the editing distance between the read and the haplotype.
initializeLog10Probabilities(byte[], byte[], byte[]) - Method in class org.broadinstitute.hellbender.utils.pairhmm.Log10PairHMM
Initializes the matrix that holds all the constants related to quality scores.
initializeNewRawAnnotationData(List<Allele>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RankSumTest
Initializing a AlleleSpecificAnnotationData> object for annotateRawData() to be used for the per-read data generated by calculateRawData().
initialTumorLod - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
Only variants with estimated tumor LODs exceeding this threshold will be considered active.
initiateScheme() - Method in class picard.vcf.GA4GHScheme
 
initiateScheme() - Method in class picard.vcf.GA4GHSchemeWithMissingAsHomRef
 
initiateScheme() - Method in class picard.vcf.GenotypeConcordanceScheme
 
initilizeAll() - Static method in class picard.nio.PathHelper
calls PathProviders::initialize() for all PathProviders.
injectDefaultVerbosity(List<String>) - Method in interface org.broadinstitute.hellbender.utils.test.CommandLineProgramTester
Inject the verbosity parameter into the list.
injectSystemPropertiesFromConfig(T) - Method in class org.broadinstitute.hellbender.utils.config.ConfigFactory
Injects system properties from the given configuration file.
inPlaceCombine(RecalibrationTables, RecalibrationTables) - Static method in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationTables
Combines the right table into the left table, in-place (without making a copy)
input - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.CountVariantsSpark
 
INPUT - Variable in class org.broadinstitute.hellbender.tools.walkers.markduplicates.EstimateLibraryComplexityGATK
 
INPUT - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.AbstractMarkDuplicatesCommandLineProgram
 
INPUT - Variable in class picard.analysis.CollectJumpingLibraryMetrics
 
INPUT - Variable in class picard.analysis.CollectMultipleMetrics
 
INPUT - Variable in class picard.analysis.CollectOxoGMetrics
 
INPUT - Variable in class picard.analysis.CollectRrbsMetrics
 
INPUT - Variable in class picard.analysis.CollectWgsMetrics
 
INPUT - Variable in class picard.analysis.directed.CollectTargetedMetrics
 
INPUT - Variable in class picard.analysis.replicates.CollectIndependentReplicateMetrics
 
INPUT - Variable in class picard.analysis.SinglePassSamProgram
 
INPUT - Variable in class picard.fastq.BamToBfq
 
INPUT - Variable in class picard.fingerprint.CheckFingerprint
 
INPUT - Variable in class picard.fingerprint.ClusterCrosscheckMetrics
 
INPUT - Variable in class picard.fingerprint.CrosscheckFingerprints
 
INPUT - Variable in class picard.fingerprint.IdentifyContaminant
 
INPUT - Variable in class picard.illumina.CollectIlluminaBasecallingMetrics
 
INPUT - Variable in class picard.illumina.MarkIlluminaAdapters
 
INPUT - Variable in class picard.reference.NonNFastaSize
 
INPUT - Variable in class picard.reference.NormalizeFasta
 
INPUT - Variable in class picard.sam.AddCommentsToBam
 
INPUT - Variable in class picard.sam.AddOrReplaceReadGroups
 
INPUT - Variable in class picard.sam.BamIndexStats
 
INPUT - Variable in class picard.sam.BuildBamIndex
 
INPUT - Variable in class picard.sam.CalculateReadGroupChecksum
 
INPUT - Variable in class picard.sam.CheckTerminatorBlock
 
INPUT - Variable in class picard.sam.CleanSam
 
INPUT - Variable in class picard.sam.DownsampleSam
 
INPUT - Variable in class picard.sam.FilterSamReads
 
INPUT - Variable in class picard.sam.FixMateInformation
 
INPUT - Variable in class picard.sam.GatherBamFiles
 
INPUT - Variable in class picard.sam.markduplicates.EstimateLibraryComplexity
 
INPUT - Variable in class picard.sam.markduplicates.util.AbstractMarkDuplicatesCommandLineProgram
 
INPUT - Variable in class picard.sam.MergeSamFiles
 
INPUT - Variable in class picard.sam.PositionBasedDownsampleSam
 
INPUT - Variable in class picard.sam.ReorderSam
 
INPUT - Variable in class picard.sam.ReplaceSamHeader
 
INPUT - Variable in class picard.sam.RevertOriginalBaseQualitiesAndAddMateCigar
 
INPUT - Variable in class picard.sam.RevertSam
 
INPUT - Variable in class picard.sam.SamFormatConverter
 
INPUT - Variable in class picard.sam.SamToFastq
 
INPUT - Variable in class picard.sam.SetNmMdAndUqTags
 
INPUT - Variable in class picard.sam.SortSam
 
INPUT - Variable in class picard.sam.SplitSamByLibrary
 
INPUT - Variable in class picard.sam.SplitSamByNumberOfReads
 
INPUT - Variable in class picard.sam.ValidateSamFile
 
INPUT - Variable in class picard.sam.ViewSam
 
INPUT - Variable in class picard.util.BedToIntervalList
 
INPUT - Variable in class picard.util.IntervalListToBed
 
INPUT - Variable in class picard.util.IntervalListTools
 
INPUT - Variable in class picard.util.LiftOverIntervalList
 
INPUT - Variable in class picard.vcf.AccumulateVariantCallingMetrics
 
INPUT - Variable in class picard.vcf.CollectVariantCallingMetrics
 
INPUT - Variable in class picard.vcf.filter.FilterVcf
 
INPUT - Variable in class picard.vcf.FixVcfHeader
 
INPUT - Variable in class picard.vcf.GatherVcfs
 
INPUT - Variable in class picard.vcf.LiftoverVcf
 
INPUT - Variable in class picard.vcf.MakeSitesOnlyVcf
 
INPUT - Variable in class picard.vcf.MendelianViolations.FindMendelianViolations
 
INPUT - Variable in class picard.vcf.MergeVcfs
 
INPUT - Variable in class picard.vcf.RenameSampleInVcf
 
INPUT - Variable in class picard.vcf.SortVcf
 
INPUT - Variable in class picard.vcf.SplitVcfs
 
INPUT - Variable in class picard.vcf.UpdateVcfSequenceDictionary
 
INPUT - Variable in class picard.vcf.VcfFormatConverter
 
INPUT - Variable in class picard.vcf.VcfToIntervalList
 
input2 - Variable in class org.broadinstitute.hellbender.tools.spark.validation.CompareDuplicatesSpark
 
INPUT_2_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.validation.CompareDuplicatesSpark
 
INPUT_2_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.validation.CompareDuplicatesSpark
 
INPUT_BASE - Variable in class picard.analysis.artifacts.ConvertSequencingArtifactToOxoG
 
INPUT_CALL_HEADER - Static variable in class org.broadinstitute.hellbender.tools.copynumber.utils.TagGermlineEvents
 
INPUT_GCS_PATH_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.ParallelCopyGCSDirectoryIntoHDFSSpark
 
INPUT_GLOB - Static variable in class org.broadinstitute.hellbender.tools.spark.ParallelCopyGCSDirectoryIntoHDFSSpark
 
INPUT_GLOB_ALL_FILES - Static variable in class org.broadinstitute.hellbender.tools.spark.ParallelCopyGCSDirectoryIntoHDFSSpark
 
INPUT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
INPUT_MODEL_INTERVAL_FILE - Static variable in class org.broadinstitute.hellbender.tools.copynumber.GermlineCNVCaller
 
INPUT_SAMPLE_MAP - Variable in class picard.fingerprint.CrosscheckFingerprints
 
INPUT_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
INPUT_SHORT_NAME - Static variable in class picard.cmdline.StandardOptionDefinitions
 
INPUT_VCFS_LIST_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.CreateSomaticPanelOfNormals
 
INPUT_VCFS_LIST_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.CreateSomaticPanelOfNormals
 
inputBam - Variable in class org.broadinstitute.hellbender.tools.spark.CreateHadoopBamSplittingIndex
 
inputPaired - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBwaSpark
 
inputPrior - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeCalculationArgumentCollection
By default, the prior specified with the argument --heterozygosity/-hets is used for variant discovery at a particular locus, using an infinite sites model, see e.g.
inputReports - Variable in class org.broadinstitute.hellbender.tools.walkers.bqsr.GatherBQSRReports
 
inputReports - Variable in class org.broadinstitute.hellbender.tools.walkers.vqsr.GatherTranches
 
inputs - Variable in class org.broadinstitute.hellbender.tools.GatherVcfsCloud
 
InputStreamSettings - Class in org.broadinstitute.hellbender.utils.runtime
Settings that define text to write to the process stdin.
InputStreamSettings() - Constructor for class org.broadinstitute.hellbender.utils.runtime.InputStreamSettings
 
inputUnpaired - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBwaSpark
 
inRange(double, double, double, String) - Static method in class org.broadinstitute.hellbender.utils.param.ParamUtils
Checks that the input is within range and returns the same value or throws an IllegalArgumentException
inRange(long, double, double, String) - Static method in class org.broadinstitute.hellbender.utils.param.ParamUtils
Checks that the input is within range and returns the same value or throws an IllegalArgumentException
inRange(long, long, long, String) - Static method in class org.broadinstitute.hellbender.utils.param.ParamUtils
Checks that the input is within range and returns the same value or throws an IllegalArgumentException
inRange(int, int, int, String) - Static method in class org.broadinstitute.hellbender.utils.param.ParamUtils
Checks that the input int value is within range and returns the same value or throws an IllegalArgumentException
inRange(DoubleRange, double, String) - Static method in class org.broadinstitute.hellbender.utils.param.ParamUtils
Validates the value of a parameter.
inRange(IntRange, int, String) - Static method in class org.broadinstitute.hellbender.utils.param.ParamUtils
Validates the value of a parameter.
insertAllele(Allele, Allele, int, int) - Method in class org.broadinstitute.hellbender.utils.haplotype.Haplotype
 
INSERTED_SEQUENCE - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
INSERTED_SEQUENCE_LENGTH - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
INSERTED_SEQUENCE_MAPPINGS - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
insertedSequenceForwardStrandRep - Variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications
 
Insertion(NovelAdjacencyAndAltHaplotype, int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.SimpleSVType.Insertion
 
insertionMappings - Variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SimpleChimera
 
INSERTIONS_DEFAULT_QUALITY - Variable in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationArgumentCollection
A default base qualities to use as a prior (reported quality) in the insertion covariate model.
insertionToInsertion - Static variable in class org.broadinstitute.hellbender.utils.pairhmm.PairHMMModel
Position in the transition probability array for the Insertion-to-Insertion transition.
InsertSizeMetrics - Class in org.broadinstitute.hellbender.metrics
Metrics about the insert size distribution of a paired-end library, created by the CollectInsertSizeMetrics program and usually written to a file with the extension ".insertSizeMetrics".
InsertSizeMetrics() - Constructor for class org.broadinstitute.hellbender.metrics.InsertSizeMetrics
 
InsertSizeMetrics - Class in picard.analysis
Metrics about the insert size distribution of a paired-end library, created by the CollectInsertSizeMetrics program and usually written to a file with the extension ".insert_size_metrics".
InsertSizeMetrics() - Constructor for class picard.analysis.InsertSizeMetrics
 
InsertSizeMetricsArgumentCollection - Class in org.broadinstitute.hellbender.metrics
ArgumentCollection for InsertSizeMetrics collectors.
InsertSizeMetricsArgumentCollection() - Constructor for class org.broadinstitute.hellbender.metrics.InsertSizeMetricsArgumentCollection
 
InsertSizeMetricsCollector - Class in org.broadinstitute.hellbender.metrics
Collects InsertSizeMetrics on the specified accumulationLevels
InsertSizeMetricsCollector() - Constructor for class org.broadinstitute.hellbender.metrics.InsertSizeMetricsCollector
 
InsertSizeMetricsCollector - Class in picard.analysis.directed
Collects InsertSizeMetrics on the specified accumulationLevels using
InsertSizeMetricsCollector(Set<MetricAccumulationLevel>, List<SAMReadGroupRecord>, double, Integer, double, boolean) - Constructor for class picard.analysis.directed.InsertSizeMetricsCollector
 
InsertSizeMetricsCollector.PerUnitInsertSizeMetricsCollector - Class in picard.analysis.directed
A Collector for individual InsertSizeMetrics for a given SAMPLE or SAMPLE/LIBRARY or SAMPLE/LIBRARY/READ_GROUP (depending on aggregation levels)
InsertSizeMetricsCollectorSpark - Class in org.broadinstitute.hellbender.tools.spark.pipelines.metrics
Worker class to collect insert size metrics, add metrics to file, and provides accessors to stats of groups of different level.
InsertSizeMetricsCollectorSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.InsertSizeMetricsCollectorSpark
 
INSTANCE - Static variable in class org.broadinstitute.hellbender.tools.spark.transforms.markduplicates.MarkDuplicatesSparkUtils.PairedEndsCoordinateComparator
 
instanceMain(String[]) - Method in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
 
instanceMain(String[]) - Method in class org.broadinstitute.hellbender.cmdline.PicardCommandLineProgram
 
instanceMain(String[]) - Method in class org.broadinstitute.hellbender.cmdline.PicardCommandLineProgramExecutor
Entry point for Picard tools that are called from GATK.
instanceMain(String[], List<String>, List<Class<? extends CommandLineProgram>>, String) - Method in class org.broadinstitute.hellbender.Main
The main method.
instanceMain(String[]) - Method in class org.broadinstitute.hellbender.Main
This method is not intended to be used outside of the GATK framework and tests.
instanceMain(String[]) - Method in class picard.cmdline.CommandLineProgram
 
instanceMain(String[], List<String>, String) - Method in class picard.cmdline.PicardCommandLine
The main method.
instanceMain(String[]) - Method in class picard.cmdline.PicardCommandLine
For testing
instanceMainPostParseArgs() - Method in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
 
instanceMainWithExit(String[]) - Method in class picard.cmdline.CommandLineProgram
 
int1() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.FindBreakpointEvidenceSpark.IntPair
 
int2() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.FindBreakpointEvidenceSpark.IntPair
 
IntBiConsumer - Interface in org.broadinstitute.hellbender.utils.functional
Created by davidben on 8/19/16.
IntegerCopyNumberSegment - Class in org.broadinstitute.hellbender.tools.copynumber.formats.records
A genotyped integer copy-number segment.
IntegerCopyNumberSegment(SimpleInterval, IntegerCopyNumberState, IntegerCopyNumberState, int, double, double, double, double) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.records.IntegerCopyNumberSegment
 
IntegerCopyNumberSegmentCollection - Class in org.broadinstitute.hellbender.tools.copynumber.formats.collections
Represents a collection of IntegerCopyNumberSegment for a sample.
IntegerCopyNumberSegmentCollection(File) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.collections.IntegerCopyNumberSegmentCollection
 
IntegerCopyNumberSegmentCollection(SampleLocatableMetadata, List<IntegerCopyNumberSegment>) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.collections.IntegerCopyNumberSegmentCollection
 
IntegerCopyNumberState - Class in org.broadinstitute.hellbender.tools.copynumber.gcnv
This class represents integer copy number states.
IntegerCopyNumberState(int) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.gcnv.IntegerCopyNumberState
 
integrate(DoubleFunction<Double>, double, double, int) - Static method in class org.broadinstitute.hellbender.utils.IntegrationUtils
 
integrate2d(ToDoubleBiFunction<Double, Double>, double, double, int, double, double, int) - Static method in class org.broadinstitute.hellbender.utils.IntegrationUtils
 
IntegrationTestSpec - Class in org.broadinstitute.hellbender.utils.test
 
IntegrationTestSpec(String, List<String>) - Constructor for class org.broadinstitute.hellbender.utils.test.IntegrationTestSpec
 
IntegrationTestSpec(String, int, Class<?>) - Constructor for class org.broadinstitute.hellbender.utils.test.IntegrationTestSpec
 
IntegrationUtils - Class in org.broadinstitute.hellbender.utils
Created by tsato on 5/1/17.
IntegrationUtils() - Constructor for class org.broadinstitute.hellbender.utils.IntegrationUtils
 
IntensityChannel - Enum in picard.illumina.parser
The channels in a FourChannelIntensityData object, and the channels produced by a ClusterIntensityFileReader, for cases in which it is desirable to handle these abstractly rather than having the specific names in the source code.
INTERGENIC_BASES - Variable in class picard.analysis.RnaSeqMetrics
Number of bases in primary alignments that do not align to any gene.
INTERLEAVE - Variable in class picard.sam.SamToFastq
 
INTEROP_SUBDIRECTORY_NAME - Static variable in class picard.illumina.parser.TileMetricsUtil
The path to the directory containing the tile metrics file relative to the basecalling directory.
intersect(SVInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVInterval
 
intersect(GenomeLoc) - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
 
intersect(Locatable) - Method in class org.broadinstitute.hellbender.utils.SimpleInterval
Returns the intersection of the two intervals.
INTERSECT_INTERVALS - Variable in class picard.vcf.GenotypeConcordance
 
interval - Variable in class org.broadinstitute.hellbender.engine.ContextShard
 
INTERVAL_CONTIG_NAMES_SUB_PATH - Static variable in class org.broadinstitute.hellbender.tools.copynumber.utils.HDF5Utils
 
INTERVAL_EXCLUSION_PADDING_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.IntervalArgumentCollection
 
INTERVAL_FILE_EXTENSIONS - Static variable in class org.broadinstitute.hellbender.utils.IntervalUtils
Recognized extensions for interval files
INTERVAL_GC_CONTENT_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
INTERVAL_LIST - Variable in class picard.reference.ExtractSequences
 
INTERVAL_LIST - Variable in class picard.sam.FilterSamReads
 
INTERVAL_LIST - Variable in class picard.sam.ViewSam
 
INTERVAL_LIST_FILE_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.gcnv.GermlineCNVNamingConstants
 
INTERVAL_MATRIX_SUB_PATH - Static variable in class org.broadinstitute.hellbender.tools.copynumber.utils.HDF5Utils
 
INTERVAL_MERGING_RULE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.IntervalArgumentCollection
 
INTERVAL_PADDING_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.IntervalArgumentCollection
 
INTERVAL_PSI_SCALE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineDenoisingModelArgumentCollection
 
INTERVAL_SET_RULE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.IntervalArgumentCollection
 
INTERVAL_VARIANT_ID_FIELD_SEPARATOR - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
IntervalAlignmentContextIterator - Class in org.broadinstitute.hellbender.utils.locusiterator
For special cases where we want to emit AlignmentContexts regardless of whether we have an overlap with a given interval.
IntervalAlignmentContextIterator(Iterator<AlignmentContext>, IntervalLocusIterator, SAMSequenceDictionary) - Constructor for class org.broadinstitute.hellbender.utils.locusiterator.IntervalAlignmentContextIterator
Note: Typically, if you are calling this from a walker tool, you want to use AlignmentContextIteratorBuilder
IntervalArgumentCollection - Class in org.broadinstitute.hellbender.cmdline.argumentcollections
Intended to be used as an @ArgumentCollection for specifying intervals at the command line.
IntervalArgumentCollection() - Constructor for class org.broadinstitute.hellbender.cmdline.argumentcollections.IntervalArgumentCollection
 
intervalArgumentCollection - Variable in class org.broadinstitute.hellbender.engine.GATKTool
 
intervalArgumentCollection - Variable in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
 
intervalArgumentCollection - Variable in class org.broadinstitute.hellbender.tools.copynumber.GermlineCNVCaller
 
IntervalArgumentCollection - Interface in picard.cmdline.argumentcollections
Base interface for an interval argument collection.
intervalArugmentCollection - Variable in class picard.analysis.CollectWgsMetrics
 
IntervalCopyNumberGenotypingData - Class in org.broadinstitute.hellbender.tools.copynumber.formats.records
The bundle of integer copy-number posterior distribution and baseline integer copy-number state for an interval.
IntervalCopyNumberGenotypingData(SimpleInterval, CopyNumberPosteriorDistribution, IntegerCopyNumberState) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.records.IntervalCopyNumberGenotypingData
 
IntervalCoverageFinder - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
Class to find the coverage of the intervals.
IntervalCoverageFinder(ReadMetadata, List<SVInterval>, Iterator<GATKRead>, SVReadFilter) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.IntervalCoverageFinder
 
intervalExclusionPadding - Variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.IntervalArgumentCollection
Use this to add padding to the intervals specified using -XL.
intervalFile - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
intervalFileToList(GenomeLocParser, String) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Read a file of genome locations to process.
intervalIsOnDictionaryContig(SimpleInterval, SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Determines whether the provided interval is within the bounds of its assigned contig according to the provided dictionary
IntervalListScatterer - Class in picard.util
 
IntervalListScatterer(IntervalListScatterer.Mode) - Constructor for class picard.util.IntervalListScatterer
 
IntervalListScatterer.Mode - Enum in picard.util
 
IntervalListToBed - Class in picard.util
Trivially simple command line program to convert an IntervalList file to a BED file.
IntervalListToBed() - Constructor for class picard.util.IntervalListToBed
 
IntervalListTools - Class in picard.util
Performs various IntervalList manipulations.
IntervalListTools() - Constructor for class picard.util.IntervalListTools
 
IntervalListTools.Action - Enum in picard.util
 
IntervalLocusIterator - Class in org.broadinstitute.hellbender.utils.iterators
Returns a SimpleInterval for each locus in a set of intervals.
IntervalLocusIterator(Iterator<SimpleInterval>) - Constructor for class org.broadinstitute.hellbender.utils.iterators.IntervalLocusIterator
 
intervalMergingRule - Variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.IntervalArgumentCollection
By default, the program merges abutting intervals (i.e.
IntervalMergingRule - Enum in org.broadinstitute.hellbender.utils
a class we use to determine the merging rules for intervals passed to the GATK
intervalOnlyAssembly - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
IntervalOverlappingIterator<T extends htsjdk.samtools.util.Locatable> - Class in org.broadinstitute.hellbender.utils.iterators
Wraps an iterator of Locatable with a list of sorted intervals to return only the objects which overlaps with them
IntervalOverlappingIterator(Iterator<T>, List<SimpleInterval>, SAMSequenceDictionary) - Constructor for class org.broadinstitute.hellbender.utils.iterators.IntervalOverlappingIterator
Wraps an iterator to be filtered by a sorted list of intervals
intervalPadding - Variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.IntervalArgumentCollection
Use this to add padding to the intervals specified using -L.
intervals - Variable in class picard.analysis.AbstractWgsMetricsCollector
 
INTERVALS - Variable in class picard.analysis.artifacts.CollectSequencingArtifactMetrics
 
INTERVALS - Variable in class picard.analysis.CollectMultipleMetrics
 
INTERVALS - Variable in class picard.analysis.CollectOxoGMetrics
 
INTERVALS - Variable in class picard.analysis.CollectWgsMetrics.CollectWgsMetricsIntervalArgumentCollection
 
INTERVALS - Variable in class picard.analysis.CollectWgsMetrics
 
intervals - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The intervals over which this metric was computed.
INTERVALS - Variable in class picard.reference.NonNFastaSize
 
INTERVALS - Variable in class picard.sam.MergeSamFiles
 
INTERVALS - Variable in class picard.vcf.GenotypeConcordance
 
INTERVALS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
INTERVALS_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
intervalSetRule - Variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.IntervalArgumentCollection
By default, the program will take the UNION of all intervals specified using -L and/or -XL.
IntervalSetRule - Enum in org.broadinstitute.hellbender.utils
set operators for combining lists of intervals
intervalShardPadding - Variable in class org.broadinstitute.hellbender.engine.spark.IntervalWalkerSpark
 
intervalSize(List<GenomeLoc>) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
 
IntervalsManipulationProgramGroup - Class in picard.cmdline.programgroups
Tools that process genomic intervals in various formats.
IntervalsManipulationProgramGroup() - Constructor for class picard.cmdline.programgroups.IntervalsManipulationProgramGroup
 
IntervalsSkipList<T extends htsjdk.samtools.util.Locatable> - Class in org.broadinstitute.hellbender.utils.collections
Holds many intervals in memory, with an efficient operation to get intervals that overlap a given query interval.
IntervalsSkipList(Iterable<T>) - Constructor for class org.broadinstitute.hellbender.utils.collections.IntervalsSkipList
Creates an IntervalsSkipList that holds a copy of the given intervals, sorted and indexed.
IntervalsSkipListOneContig<T extends htsjdk.samtools.util.Locatable> - Class in org.broadinstitute.hellbender.utils.collections
Holds many intervals in memory, with an efficient operation to get intervals that overlap a given query interval.
IntervalsSkipListOneContig(Iterable<T>) - Constructor for class org.broadinstitute.hellbender.utils.collections.IntervalsSkipListOneContig
Creates an IntervalsSkipList that holds a copy of the given intervals, sorted and indexed.
intervalsSpecified() - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.IntervalArgumentCollection
Have any intervals been specified for inclusion or exclusion
intervalStrings - Variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.OptionalIntervalArgumentCollection
 
intervalStrings - Variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.RequiredIntervalArgumentCollection
 
IntervalUtils - Class in org.broadinstitute.hellbender.utils
Parse text representations of interval strings that can appear in GATK-based applications.
IntervalUtils() - Constructor for class org.broadinstitute.hellbender.utils.IntervalUtils
 
IntervalUtils.IntervalBreakpointType - Enum in org.broadinstitute.hellbender.utils
An enum to classify breakpoints whether the breakpoint is the start or end of a region.
IntervalWalker - Class in org.broadinstitute.hellbender.engine
An IntervalWalker is a tool that processes a single interval at a time, with the ability to query optional overlapping sources of reads, reference data, and/or variants/features.
IntervalWalker() - Constructor for class org.broadinstitute.hellbender.engine.IntervalWalker
 
IntervalWalkerContext - Class in org.broadinstitute.hellbender.engine.spark
Encapsulates a SimpleInterval with the reads that overlap it (the ReadsContext and its ReferenceContext and FeatureContext.
IntervalWalkerContext(SimpleInterval, ReadsContext, ReferenceContext, FeatureContext) - Constructor for class org.broadinstitute.hellbender.engine.spark.IntervalWalkerContext
 
IntervalWalkerSpark - Class in org.broadinstitute.hellbender.engine.spark
A Spark version of IntervalWalker.
IntervalWalkerSpark() - Constructor for class org.broadinstitute.hellbender.engine.spark.IntervalWalkerSpark
 
IntHistogram - Class in org.broadinstitute.hellbender.tools.spark.utils
Histogram of observations on a compact set of non-negative integer values.
IntHistogram(int) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.IntHistogram
 
IntHistogram.CDF - Class in org.broadinstitute.hellbender.tools.spark.utils
 
IntHistogram.CDF.Serializer - Class in org.broadinstitute.hellbender.tools.spark.utils
 
IntHistogram.Serializer - Class in org.broadinstitute.hellbender.tools.spark.utils
 
IntPair(int, int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.FindBreakpointEvidenceSpark.IntPair
 
INTRONIC_BASES - Variable in class picard.analysis.RnaSeqMetrics
Number of bases in primary alignments that align to an intronic base for some gene, and not a coding or UTR base.
IntToDoubleBiFunction - Interface in org.broadinstitute.hellbender.utils.functional
Created by davidben on 8/19/16.
INV33 - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
INV33_BND - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.BreakEndVariantType.InvSuspectBND
 
INV55 - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
INV55_BND - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.BreakEndVariantType.InvSuspectBND
 
INV_LOG_10 - Static variable in class org.broadinstitute.hellbender.utils.MathUtils
 
INV_LOG_2 - Static variable in class org.broadinstitute.hellbender.utils.MathUtils
 
INV_LOG_2 - Static variable in class org.broadinstitute.hellbender.utils.param.ParamUtils
 
INV_SQRT_2_PI - Static variable in class org.broadinstitute.hellbender.utils.MathUtils
 
INVALID_ELEMENT_FROM_READ - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.RankSumTest
 
INVALID_TABLE_NAME_REGEX - Static variable in class org.broadinstitute.hellbender.utils.report.GATKReportTable
REGEX that matches any table with an invalid name
INVALIDATE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
 
Inversion(NovelAdjacencyAndAltHaplotype, int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.SimpleSVType.Inversion
 
INVERT - Variable in class picard.util.IntervalListTools
 
INVERT_GT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
 
INVERT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
 
invertCigar(Cigar) - Static method in class org.broadinstitute.hellbender.utils.read.CigarUtils
Inverts the order of the operators in the cigar.
invertFilterExpression - Variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
Invert the selection criteria for --filter-expression
invertGenotypeFilterExpression - Variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
Invert the selection criteria for --genotype-filter-expression
IO_SIZE - Variable in class picard.util.FifoBuffer
 
IOUtils - Class in org.broadinstitute.hellbender.utils.io
 
IOUtils() - Constructor for class org.broadinstitute.hellbender.utils.io.IOUtils
 
IS_BISULFITE_SEQUENCE - Variable in class picard.sam.MergeBamAlignment
 
IS_BISULFITE_SEQUENCE - Variable in class picard.sam.SetNmMdAndUqTags
 
IS_BISULFITE_SEQUENCED - Variable in class picard.analysis.CollectAlignmentSummaryMetrics
 
IS_BISULFITE_SEQUENCED - Variable in class picard.analysis.CollectGcBiasMetrics
 
IS_BISULFITE_SEQUENCED - Variable in class picard.sam.ValidateSamFile
 
IS_ENOUGH_VALIDATION_COVERAGE - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
IS_HOST_ALIGNED_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
IS_HOST_ALIGNED_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
IS_NOT_NOISE - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
IS_NOVASEQ - Variable in class picard.illumina.CollectIlluminaLaneMetrics
 
IS_ORIENTATION_BIAS_ARTIFACT_MODE - Static variable in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasFilterConstants
 
IS_ORIENTATION_BIAS_CUT - Static variable in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasFilterConstants
 
IS_ORIENTATION_BIAS_RC_ARTIFACT_MODE - Static variable in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasFilterConstants
 
isAbleToValidateGenotype(Genotype, Allele) - Static method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.BasicSomaticShortMutationValidator
 
isAcceptableFeatureType(Class<? extends Feature>) - Method in class org.broadinstitute.hellbender.engine.FeatureWalker
Returns whether the given class of features is acceptable for this walker.
isAcceptableFeatureType(Class<? extends Feature>) - Method in class org.broadinstitute.hellbender.tools.examples.ExampleFeatureWalker
 
isActive() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
Does this region represent an active region (all isActiveProbs above threshold) or an inactive region (all isActiveProbs below threshold)?
isActive(AlignmentContext, ReferenceContext, FeatureContext) - Method in interface org.broadinstitute.hellbender.engine.AssemblyRegionEvaluator
Given a pileup over a single locus, returns an ActivityProfileState containing the probability (0.0 to 1.0) that the locus is an "active" site.
isActive(AlignmentContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerEngine
Given a pileup, returns an ActivityProfileState containing the probability (0.0 to 1.0) that it's an "active" site.
isActive(AlignmentContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2Engine
 
isActiveProb() - Method in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfileState
 
isAdapterSequence(byte[]) - Method in class picard.analysis.AdapterUtility
Checks the first ADAPTER_MATCH_LENGTH bases of the read against known adapter sequences and returns true if the read matches an adapter sequence with MAX_ADAPTER_ERRORS mismsatches or fewer.
isAdditionalCovariateTable(NestedIntegerArray<RecalDatum>) - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationTables
 
isAfter(Locatable, Locatable, SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Tests whether the first Locatable starts after the end of the second Locatable
isAfterDeletionEnd() - Method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Is the current element immediately after a deletion, but itself not a deletion? Suppose we are aligning a read with cigar 1M2D3M.
isAfterInsertion() - Method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Does an insertion occur immediately before the current position on the genome?
isAfterSoftClip() - Method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Does a soft-clipping event occur immediately before the current position on the genome?
isAllRegularBases(byte[]) - Static method in class org.broadinstitute.hellbender.utils.BaseUtils
Returns true iff all bases are 'regular' BaseUtils.isRegularBase(byte).
isAntiTraining - Variable in class org.broadinstitute.hellbender.tools.walkers.vqsr.TrainingSet
 
isAppendFile() - Method in class org.broadinstitute.hellbender.utils.runtime.OutputStreamSettings
 
isAvailable() - Method in enum picard.nio.PathHelper.PathProviders
 
isBamFileName(String) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
Returns true if the file's extension is BAM.
isBaseInsideAdaptor(GATKRead, long) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
is this base inside the adaptor of the read? There are two cases to treat here: 1) Read is in the negative strand => Adaptor boundary is on the left tail 2) Read is in the positive strand => Adaptor boundary is on the right tail Note: We return false to all reads that are UNMAPPED or have an weird big insert size (probably due to mismapping or bigger event)
isBefore(GenomeLoc) - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
Tests whether this contig is completely before contig 'that'.
isBefore(Locatable, Locatable, SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Tests whether the first Locatable ends before the start of the second Locatable
isBeforeDeletionStart() - Method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Is the current element immediately before a deletion, but itself not a deletion? Suppose we are aligning a read with cigar 3M2D1M.
isBeforeInsertion() - Method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Does an insertion occur immediately after the current position on the genome?
isBeforeSoftClip() - Method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Does a soft-clipping event occur immediately after the current position on the genome?
isBetaFeature() - Method in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
 
isBetween(GenomeLoc, GenomeLoc) - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
 
isBlank(byte[]) - Method in class picard.util.AbstractInputParser
Determines whether a given line is a comment
isBlockGzipped(File) - Static method in class picard.illumina.parser.readers.BclReader
 
isBreakEndOnly() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.BreakEndVariantType
 
isBreakEndOnly() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SimpleSVType
 
isBreakEndOnly() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvType
 
isBufferTruncated() - Method in class org.broadinstitute.hellbender.utils.runtime.CapturedStreamOutput
 
isBufferTruncated() - Method in class org.broadinstitute.hellbender.utils.runtime.StreamOutput
Returns true if the buffer was truncated.
isCalledAlt(double) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.VariantCallContext
 
isCalledRef(double) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.VariantCallContext
 
isChimeric(SAMRecord, int, Set<SamPairUtil.PairOrientation>) - Static method in class picard.analysis.ChimeraUtil
Checks whether the given read is part of a chimeric pair.
isChimeric(SAMRecord, SAMRecord, int, Set<SamPairUtil.PairOrientation>) - Static method in class picard.analysis.ChimeraUtil
Checks whether the given read is part of a chimeric pair.
isClipOverlappingReads() - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.AbstractAlignmentMerger
 
isClipOverlappingReads() - Method in class picard.sam.AbstractAlignmentMerger
 
isClosed() - Method in class picard.util.CircularByteBuffer
Returns true if the buffer is closed, false otherwise.
isCloudStorageUrl(String) - Static method in class org.broadinstitute.hellbender.utils.gcs.BucketUtils
 
isCloudStorageUrl(Path) - Static method in class org.broadinstitute.hellbender.utils.gcs.BucketUtils
 
isClusterRecord() - Method in class picard.illumina.parser.readers.TileMetricsOutReader.IlluminaTileMetrics
 
isComment(byte[]) - Method in class picard.util.AbstractInputParser
Determines whether a given line is a comment
isCommentLine(String[]) - Method in class org.broadinstitute.hellbender.utils.tsv.TableReader
Checks whether a line is a comment line or not.
isCompatibleWithSparkBroadcast() - Method in class org.broadinstitute.hellbender.engine.datasources.ReferenceMultiSource
Returns whether this reference source can be used with Spark broadcast.
isCompatibleWithSparkBroadcast() - Method in interface org.broadinstitute.hellbender.engine.datasources.ReferenceSource
Returns whether this reference source can be used with Spark broadcast.
isComplexIndel(Allele, Allele) - Static method in class org.broadinstitute.hellbender.utils.GATKProtectedVariantContextUtils
This method should only be run on variants that are known to be indels.
isConcrete() - Method in enum org.broadinstitute.hellbender.utils.Nucleotide
Checks whether the nucleotide refer to a concrete (rather than ambiguous) base.
isConsensus - Variable in class org.broadinstitute.hellbender.tools.walkers.vqsr.TrainingSet
 
isContaminant(HitsForInsert) - Method in class picard.sam.AbstractAlignmentMerger
 
isContaminant(HitsForInsert) - Method in class picard.sam.SamAlignmentMerger
Criteria for contaminant reads: 1.
isCramFile(File) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
Returns true if the file's extension is CRAM.
isCramFile(Path) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
Returns true if the file's extension is CRAM.
isCramFileName(String) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
Returns true if the file's extension is CRAM.
isDbSnpSite(String, int) - Method in class org.broadinstitute.hellbender.utils.variant.DbSnpBitSetUtil
Returns true if there is a dbSnp entry at pos in sequenceName, otherwise false
isDbSnpSite(String, int) - Method in class picard.util.DbSnpBitSetUtil
Returns true if there is a dbSnp entry at pos in sequenceName, otherwise false
isDebug() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingAssembler
 
isDebugGraphTransformations() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingAssembler
 
isDeletion() - Method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Is this element a deletion w.r.t.
isDeletion(String, String) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Determines whether the given reference and alternate alleles constitute a deletion mutation.
isDeletion(Allele, Allele) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Determines whether the given reference and alternate alleles constitute a deletion mutation.
isDelimiter(byte) - Method in class picard.util.AbstractInputParser
Determines whether a given character is a delimiter
isDelimiter(byte) - Method in class picard.util.CsvInputParser
Determines whether a given character is a delimiter
isDelimiter(byte) - Method in class picard.util.TabbedInputParser
Determines whether a given character is a delimiter
isDependentArgumentAllowed(Class<?>) - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKAnnotationPluginDescriptor
 
isDependentArgumentAllowed(Class<?>) - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKReadFilterPluginDescriptor
 
isDifferentByKSStatistic(IntHistogram, float) - Method in class org.broadinstitute.hellbender.tools.spark.utils.IntHistogram.CDF
Using the Kolmogorov-Smirnov statistic for two samples: Is the specified histogram significantly different from the CDF? This is what we use in production code: It minimizes the number of comparisons, and quits as soon as it finds a significant K-S stat (rather than finding the max).
isDiploidWithLikelihoods(Genotype) - Static method in class org.broadinstitute.hellbender.utils.GenotypeUtils
Returns true of the genotype is a called diploid genotype with likelihoods.
isDisabledFilter(String) - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKReadFilterPluginDescriptor
Determine if a particular ReadFilter was disabled on the command line, either directly of by disabling all tool defaults.
isDisjointFrom(SVInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVInterval
 
isDoingExactLog10Calculations() - Method in class org.broadinstitute.hellbender.utils.pairhmm.Log10PairHMM
Is this HMM using exact log calculations?
isDone(LineIterator) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfCodec
 
isDone(B) - Method in class org.broadinstitute.hellbender.utils.codecs.ProgressReportingDelegatingCodec
 
isDuplicate() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
isDuplicate() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
isEmitEmptyLoci() - Method in class org.broadinstitute.hellbender.utils.locusiterator.AlignmentContextIteratorBuilder
 
isEmpty() - Method in class org.broadinstitute.hellbender.engine.FeatureManager
Does this manager have no sources of Features to query?
isEmpty() - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchCollection
 
isEmpty() - Method in class org.broadinstitute.hellbender.tools.spark.utils.LargeLongHopscotchSet
 
isEmpty() - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongBloomFilter
 
isEmpty() - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongHopscotchSet
 
isEmpty() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseVertex
Does this vertex have an empty sequence? That is, is it a dummy node that's only present for structural reasons but doesn't actually contribute to the sequence of the graph?
isEmpty() - Method in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfile
Is this profile empty? (ie., does it contain no ActivityProfileStates?)
isEmpty() - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
 
isEmpty() - Method in class org.broadinstitute.hellbender.utils.CompressedDataList
 
isEmpty() - Method in class org.broadinstitute.hellbender.utils.GenomeLocSortedSet
determine if the collection is empty
isEmpty() - Method in class org.broadinstitute.hellbender.utils.Histogram
 
isEmpty() - Method in class org.broadinstitute.hellbender.utils.pileup.ReadPileup
 
isEmpty() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
isEmpty(SAMRecord) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
isEmpty() - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationReport
 
isEmpty() - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationTables
 
isEmpty() - Method in class picard.illumina.parser.ReadStructure.Substructure
 
isEmpty() - Method in class picard.sam.markduplicates.util.MarkQueue
 
isEnoughValidationReads() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.BasicValidationResult
 
isEvidence(GATKRead) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.SVReadFilter
 
isEvidenceUpstreamOfBreakpoint() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence
If true: the evidence suggests a breakpoint at a reference location upstream of the interval's start coordinate If false: the evidence suggests a breakpoint downstream of the interval's end coordinate
isEvidenceUpstreamOfBreakpoint() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.ReadEvidence
 
isExpected() - Method in enum picard.fingerprint.CrosscheckMetric.FingerprintResult
 
isExperimentalFeature() - Method in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
 
isF2R1(GATKRead) - Static method in class org.broadinstitute.hellbender.tools.walkers.annotator.OxoGReadCounts
 
isFeatureFile(Path) - Static method in class org.broadinstitute.hellbender.engine.FeatureManager
 
isFileUrl(String) - Static method in class org.broadinstitute.hellbender.utils.gcs.BucketUtils
 
isFinalized() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
 
isFinite(double, String) - Static method in class org.broadinstitute.hellbender.utils.param.ParamUtils
Checks that the input is not infinity nor NaN or throws an IllegalArgumentException
isFirstOfPair() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
isFirstOfPair() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
isForwardStrand() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils.Mapping
 
isFrameshift(Allele, Allele) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Determines whether the given reference and alternate alleles constitute a frameshift mutation.
isFrameshift(String, String) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Determines whether the given reference and alternate alleles constitute a frameshift mutation.
isFrameshift(int, int, int) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Determines whether the given reference and alternate alleles constitute a frameshift mutation.
isFuncotationInTranscriptList(GencodeFuncotation, Set<String>) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Determines whether the given funcotation has a transcript ID that is in the given acceptableTranscripts.
isGenomicsDBPath(String) - Static method in class org.broadinstitute.hellbender.engine.FeatureDataSource
 
isGenotypeInTransition(Genotype, Transition) - Static method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasUtils
Complement of the artifact mode is NOT considered.
isGenotypeInTransitionsWithComplement(Genotype, Collection<Transition>) - Static method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasUtils
Is this genotype in any of the specified artifact modes (or complements) See OrientationBiasUtils.isGenotypeInTransitionWithComplement(Genotype, Transition)
isGenotypeInTransitionWithComplement(Genotype, Transition) - Static method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasUtils
isGood() - Method in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.RealignmentEngine.RealignmentResult
 
isGood(Cigar) - Static method in class org.broadinstitute.hellbender.utils.read.CigarUtils
A good Cigar object obeys the following rules: - is valid as per SAM spec Cigar.isValid(String, long).
isGzipped(File) - Static method in class picard.illumina.parser.readers.BclReader
 
isHadoopUrl(String) - Static method in class org.broadinstitute.hellbender.utils.gcs.BucketUtils
Returns true if the given path is a HDFS (Hadoop filesystem) URL.
isHeaderLine(String[]) - Method in class org.broadinstitute.hellbender.utils.tsv.TableReader
Determines whether a line is a repetition of the header.
isHet() - Method in enum org.broadinstitute.hellbender.utils.genotyper.DiploidGenotype
 
isHeterozygous() - Method in enum picard.fingerprint.DiploidGenotype
 
isHetRef(byte) - Method in enum org.broadinstitute.hellbender.utils.genotyper.DiploidGenotype
 
isHom() - Method in enum org.broadinstitute.hellbender.utils.genotyper.DiploidGenotype
 
isHomogeneous() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.HeterogeneousPloidyModel
 
isHomogeneous() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.HomogeneousPloidyModel
 
isHomogeneous() - Method in interface org.broadinstitute.hellbender.tools.walkers.genotyper.PloidyModel
Checks whether the ploidy is homogeneous across all samples.
isHomomozygous() - Method in enum picard.fingerprint.DiploidGenotype
 
isHomRef(byte) - Method in enum org.broadinstitute.hellbender.utils.genotyper.DiploidGenotype
 
isHomVar(byte) - Method in enum org.broadinstitute.hellbender.utils.genotyper.DiploidGenotype
 
isImpreciseDeletion() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.EvidenceTargetLink
 
isIncludeDeletions() - Method in class org.broadinstitute.hellbender.utils.locusiterator.AlignmentContextIteratorBuilder
 
isIncludeNs() - Method in class org.broadinstitute.hellbender.utils.locusiterator.AlignmentContextIteratorBuilder
 
isIndel() - Method in interface org.broadinstitute.hellbender.utils.variant.GATKVariant
 
isIndel(String, String) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Determines whether the given reference and alternate alleles constitute an insertion or deletion mutation.
isIndel(Allele, Allele) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Determines whether the given reference and alternate alleles constitute an insertion or deletion mutation.
isIndel() - Method in class org.broadinstitute.hellbender.utils.variant.MinimalVariant
 
isIndel() - Method in class org.broadinstitute.hellbender.utils.variant.VariantContextVariantAdapter
 
isIndexed() - Method in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark.ReferenceMultiSourceAdapter
 
isInformative() - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods.BestAllele
 
isInformative(double[]) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
 
isInFrameWithEndOfRegion(int, int) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Calculates whether the given startPosition (1-based, inclusive) is in frame relative to the end of the region.
isInsertion(Allele, Allele) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Determines whether the given reference and alternate alleles constitute an insertion mutation.
isInsertion(String, String) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Determines whether the given reference and alternate alleles constitute an insertion mutation.
isInsideDeletion(Cigar, int) - Static method in class org.broadinstitute.hellbender.utils.read.AlignmentUtils
Is the offset inside a deletion?
isInsideRead(GATKRead, int) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Is a base inside a read?
isIntervalFile(String) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Check if string argument was intended as a file Accepted file extensions: .bed .list, .picard, .interval_list, .intervals.
isIntervalFile(String, boolean) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Check if string argument was intended as a file Accepted file extensions are defined in IntervalUtils.INTERVAL_FILE_EXTENSIONS
isKeepAlignerProperPairFlags() - Method in class picard.sam.AbstractAlignmentMerger
 
isKeepUniqueReadListInLibs() - Method in class org.broadinstitute.hellbender.utils.locusiterator.AlignmentContextIteratorBuilder
 
isKept(int) - Method in interface org.broadinstitute.hellbender.utils.collections.Permutation
Given an index of the original list, return whether this index is found at any position of the permuted list.
isKept(int) - Method in class org.broadinstitute.hellbender.utils.genotyper.AlleleList.ActualPermutation
 
isKept(int) - Method in class org.broadinstitute.hellbender.utils.genotyper.AlleleList.NonPermutation
 
isKnown - Variable in class org.broadinstitute.hellbender.tools.walkers.vqsr.TrainingSet
 
isKnown(String) - Static method in enum org.broadinstitute.hellbender.utils.NGSPlatform
checks whether or not the requested platform is listed in the set (and is not unknown)
isLeftEdge() - Method in class org.broadinstitute.hellbender.utils.locusiterator.AlignmentStateMachine
Is this the left edge state? I.e., one that is before or after the current read?
isLeftOverhang(GenomeLoc, GenomeLoc) - Static method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.OverhangFixingManager
Is this a proper overhang on the left side of the read?
isLowComplexity() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingGraph
Does the graph not have enough complexity? We define low complexity as a situation where the number of non-unique kmers is more than 20% of the total number of kmers.
isMapped(GATKRead) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.SVReadFilter
 
isMapped() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils.Mapping
 
isMappedPrimary(GATKRead) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.SVReadFilter
 
isMappedToPrimaryContig(GATKRead, ReadMetadata) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.SVReadFilter
 
isMatch() - Method in enum picard.fingerprint.CrosscheckMetric.FingerprintResult
 
isMatched() - Method in class picard.illumina.ExtractIlluminaBarcodes.PerTileBarcodeExtractor.BarcodeMatch
 
isMissing(GenotypeConcordanceStates.TruthState, GenotypeConcordanceStates.CallState) - Method in class picard.vcf.GenotypeConcordanceCounts
Returns true if EITHER the truth or call state is MISSING.
isNBase(byte) - Static method in class org.broadinstitute.hellbender.utils.BaseUtils
 
isNegativeOrZero(double, String) - Static method in class org.broadinstitute.hellbender.utils.param.ParamUtils
Checks that the input is positive or zero and returns the same value or throws an IllegalArgumentException
isNeitherIncompleteNorSimpleTranslocation() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SimpleChimera
 
isNextToSoftClip() - Method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Does a soft-clipping event occur immediately before or after the current position on the genome?
isNonEmpty(Collection<?>) - Static method in class org.broadinstitute.hellbender.utils.Utils
Checks that a Collection is not null and that it is not empty.
isNonPermuted() - Method in interface org.broadinstitute.hellbender.utils.collections.Permutation
Checks whether this is a trivial permutation where the resulting element list is the same as original.
isNonPermuted() - Method in class org.broadinstitute.hellbender.utils.genotyper.AlleleList.ActualPermutation
 
isNonPermuted() - Method in class org.broadinstitute.hellbender.utils.genotyper.AlleleList.NonPermutation
 
isNonPrimary(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
isNotFailure() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.AlignedAssemblyOrExcuse
 
isOpen() - Method in class org.broadinstitute.hellbender.utils.nio.SeekableByteChannelPrefetcher
Tells whether or not this channel is open.
isOpen() - Method in class org.broadinstitute.hellbender.utils.test.XorWrapper
 
isOpticalDuplicate - Variable in class picard.sam.markduplicates.util.ReadEnds
A *transient* flag marking this read end as being an optical duplicate.
isOutOfNoiseFloor() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.BasicValidationResult
 
isOutputAvailable() - Method in class org.broadinstitute.hellbender.utils.python.StreamingPythonScriptExecutor
See if any output is currently available.
isOutputAvailable() - Method in class org.broadinstitute.hellbender.utils.runtime.StreamingProcessController
Non-blocking call to see if output is available.
isPaired() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
isPaired() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
isPaired() - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.HitsForInsert
 
isPaired() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
isPaired() - Method in class picard.sam.markduplicates.util.ReadEnds
 
isPaired() - Method in class picard.sam.markduplicates.util.ReadEndsForMateCigar
 
isPartial() - Method in interface org.broadinstitute.hellbender.utils.collections.Permutation
Checks whether this permutation is a partial one of the original list.
isPartial() - Method in class org.broadinstitute.hellbender.utils.genotyper.AlleleList.ActualPermutation
 
isPartial() - Method in class org.broadinstitute.hellbender.utils.genotyper.AlleleList.NonPermutation
 
isPast(GenomeLoc) - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
Tests whether this contig is completely after contig 'that'.
isPerformDownsampling() - Method in class org.broadinstitute.hellbender.utils.locusiterator.LIBSDownsamplingInfo
 
isPf() - Method in class picard.illumina.parser.CbclData
 
isPf() - Method in class picard.illumina.parser.ClusterData
 
isPhasing(IlluminaMetricsCode) - Static method in enum picard.illumina.parser.IlluminaMetricsCode
 
isPolymorphic(Allele, double) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculationResult
Are we sufficiently confident in being non-ref that the site is considered polymorphic? We are non-ref if the probability of being non-ref > the emit confidence (often an argument).
isPolymorphicPhredScaledQual(Allele, double) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculationResult
Same as #isPolymorphic but takes a phred-scaled quality score as input
isPopulatePaTag() - Method in enum picard.sam.AbstractAlignmentMerger.UnmappingReadStrategy
 
isPositionInFrame(int) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Gets whether the given position is in-frame.
isPositive(long, String) - Static method in class org.broadinstitute.hellbender.utils.param.ParamUtils
Checks that the input is greater than zero and returns the same value or throws an IllegalArgumentException
isPositive(int, String) - Static method in class org.broadinstitute.hellbender.utils.param.ParamUtils
Checks that the input int value is greater than zero and returns the same value or throws an IllegalArgumentException
isPositive(double, String) - Static method in class org.broadinstitute.hellbender.utils.param.ParamUtils
Checks that the input is greater than zero and returns the same value or throws an IllegalArgumentException
isPositiveOrZero(double, String) - Static method in class org.broadinstitute.hellbender.utils.param.ParamUtils
Checks that the input is positive or zero and returns the same value or throws an IllegalArgumentException
isPositiveOrZero(long, String) - Static method in class org.broadinstitute.hellbender.utils.param.ParamUtils
Checks that the input is positive or zero and returns the same value or throws an IllegalArgumentException
isPositiveOrZero(int, String) - Static method in class org.broadinstitute.hellbender.utils.param.ParamUtils
Checks that the input is positive or zero and returns the same value or throws an IllegalArgumentException
isPreservingCase() - Method in class org.broadinstitute.hellbender.utils.fasta.CachingIndexedFastaSequenceFile
Is this CachingIndexedFastaReader keeping the original case of bases in the fasta, or is everything being made upper case?
isPrimaryLine(GATKRead) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.SVReadFilter
 
isProperlyPaired() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
isProperlyPaired() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
isQualityScoreTable(NestedIntegerArray<RecalDatum>) - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationTables
 
isRead1ReverseStrand() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.EmptyFragment
 
isRead1ReverseStrand() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Fragment
 
isRead1ReverseStrand() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Pair
 
isRead1ReverseStrand() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.PairedEnds
 
isReadGroupTable(NestedIntegerArray<RecalDatum>) - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationTables
 
isReadNameGroupedBam(SAMFileHeader) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Interrogates the header to determine if the bam is expected to be sorted such that reads with the same name appear in order.
isReadsRequired() - Method in enum org.broadinstitute.hellbender.tools.walkers.vqsr.TensorType
 
isRecoverDanglingBranches() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingAssembler
 
isRedirectErrorStream() - Method in class org.broadinstitute.hellbender.utils.runtime.ProcessSettings
 
isRef() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseEdge
Does this edge indicate a path through the reference graph?
isReference() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.AggregatedSubHaplotypeFinder
 
isReference() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KBestHaplotype
Indicates whether this result is the reference haplotype.
isReferenceNode(V) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
 
isRefSink(V) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
 
isRefSource(V) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
 
isRegularBase(byte) - Static method in class org.broadinstitute.hellbender.utils.BaseUtils
Returns true iff the base represented by the byte is a 'regular' base (ACGT or *).
isRemoteStorageUrl(String) - Static method in class org.broadinstitute.hellbender.utils.gcs.BucketUtils
Returns true if the given path is a GCS or HDFS (Hadoop filesystem) URL.
isRepeatAllele(Allele, Allele, String) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Helper function for isTandemRepeat that checks that allele matches somewhere on the reference
isRequestedReducibleRawKey(String) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotatorEngine
Method which checks if a key is a raw key of the requested reducible annotations
isReservedTag(String) - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.AbstractAlignmentMerger
 
isReservedTag(String) - Method in class picard.sam.AbstractAlignmentMerger
 
isResetMappingInformation() - Method in enum picard.sam.AbstractAlignmentMerger.UnmappingReadStrategy
 
isReverseStrand() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
isReverseStrand() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
isRightAlign(String) - Static method in class org.broadinstitute.hellbender.utils.report.GATKReportColumn
Check if the value can be right aligned.
isRightEdge() - Method in class org.broadinstitute.hellbender.utils.locusiterator.AlignmentStateMachine
Are we on the right edge? I.e., is the current state off the right of the alignment?
isRightOverhang(GenomeLoc, GenomeLoc) - Static method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.OverhangFixingManager
Is this a proper overhang on the right side of the read?
isSameBlock(GATKRead) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.KSWindowFinder
 
isSameDictionary(SAMSequenceDictionary, SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.tools.copynumber.arguments.CopyNumberArgumentValidationUtils
Compares two non-null sequence dictionaries using sequence index, name, and length only.
isSameFormat(GATKReport) - Method in class org.broadinstitute.hellbender.utils.report.GATKReport
Returns whether or not the two reports have the same format, from columns, to tables, to reports, and everything in between.
isSameFormat(GATKReportTable) - Method in class org.broadinstitute.hellbender.utils.report.GATKReportTable
Returns whether or not the two tables have the same format including columns and everything in between.
isSampleContaminationPresent() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.StandardCallerArgumentCollection
Returns true if there is some sample contamination present, false otherwise.
isSecondaryAlignment() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
isSecondaryAlignment() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
isSecondOfPair() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
isSecondOfPair() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
isSequenceDictionaryFromIndex(SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.utils.IndexUtils
Determine if sequenceDictionary has the form of a dictionary created from an index file by IndexUtils.createSequenceDictionaryFromFeatureIndex(java.io.File)).
isSequenceDictionaryUsingB37Reference(SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils
Returns if the given SAMSequenceDictionary is for the B37 Human Genome Reference.
isSink(V) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
 
isSkipBlankLines() - Method in class picard.util.AbstractInputParser
 
isSnp() - Method in interface org.broadinstitute.hellbender.utils.variant.GATKVariant
 
isSnp() - Method in class org.broadinstitute.hellbender.utils.variant.MinimalVariant
 
isSnp() - Method in class org.broadinstitute.hellbender.utils.variant.VariantContextVariantAdapter
 
isSoloTranscript() - Method in class picard.annotation.Gene.Transcript
 
isSource(V) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
 
isSpanningDeletion(Allele) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
isSpecialFile(File) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
Returns true if the file is a special file.
isStop() - Method in enum org.broadinstitute.hellbender.tools.funcotator.AminoAcid
 
isSupplementaryAlignment() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
isSupplementaryAlignment() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
isSupportConnected() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.BetaBinomialDistribution
 
isTandemRepeat(VariantContext, byte[]) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Returns true iff VC is an non-complex indel where every allele represents an expansion or contraction of a series of identical bases in the reference.
isTemplateLenTestable(GATKRead) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.SVReadFilter
 
isTestable(GATKRead) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.KSWindowFinder
 
isTheUpstreamMate - Variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.BreakEndVariantType
Technically, a BND-formatted variant should have two VCF records, for mates, hence we also have this field.
isTheUpstreamMate() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.BreakEndVariantType
 
isTraining - Variable in class org.broadinstitute.hellbender.tools.walkers.vqsr.TrainingSet
 
isTransition(byte, byte) - Static method in class org.broadinstitute.hellbender.utils.BaseUtils
 
isTransition(VariantContext) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
If this is a BiAllelic SNP, is it a transition?
isTreatGroupedDelimitersAsOne() - Method in class picard.util.AbstractInputParser
 
isTruth - Variable in class org.broadinstitute.hellbender.tools.walkers.vqsr.TrainingSet
 
isTwoBit(String) - Static method in class org.broadinstitute.hellbender.engine.spark.datasources.ReferenceTwoBitSource
 
isUnmapped() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignedContig
 
isUnmapped(GenomeLoc) - Static method in class org.broadinstitute.hellbender.utils.GenomeLoc
 
isUnmapped() - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
Return true if this GenomeLoc represents the UNMAPPED location
isUnmapped() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
isUnmapped() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
isUnmappedGenomeLocString(String) - Static method in class org.broadinstitute.hellbender.utils.GenomeLocParser
 
isUpstreamOf(SVInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVInterval
 
isUsableBaseForAnnotation(PileupElement) - Static method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
Can the base in this pileup element be used in comparative tests?
isUsableRead(GATKRead, int) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_ReadPosRankSumTest
 
isUsableRead(GATKRead) - Static method in class org.broadinstitute.hellbender.tools.walkers.annotator.OxoGReadCounts
 
isUsableRead(GATKRead, int) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.RankSumTest
Can the read be used in comparative tests between ref / alt bases?
isUsableRead(GATKRead, int) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.ReadPosRankSumTest
 
isValid(String, int, int) - Static method in class org.broadinstitute.hellbender.utils.SimpleInterval
Test that these are valid values for constructing a SimpleInterval: contig cannot be null start must be >= 1 end must be >= start
isValidated() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence
 
isValidBase(byte) - Static method in enum picard.fingerprint.DiploidGenotype
 
isValidDirectory(Path) - Static method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
 
isValidGenomeLoc(String, int, int, boolean) - Method in class org.broadinstitute.hellbender.utils.GenomeLocParser
Would a genome loc created with the given parameters be valid w.r.t.
isValidGenomeLoc(String, int, int) - Method in class org.broadinstitute.hellbender.utils.GenomeLocParser
 
isValidLength(int) - Method in class org.broadinstitute.hellbender.utils.IndexRange
Checks whether this range is valid for a collection or array of a given size.
isVar(GenotypeConcordanceStates.TruthState, GenotypeConcordanceStates.CallState) - Method in class picard.vcf.GenotypeConcordanceCounts
Returns true if EITHER the truth or call state is a VAR.
isVariantFile(File) - Static method in class picard.vcf.VcfUtils
Checks if the suffix is one of those that are allowed for the various formats that contain variants (currently vcf and bcf)
isVariationPresent() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmer.Result
Checks whether there is any variation present in the target region.
isVariationPresent() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResultSet
Checks whether there is any variation present in the assembly result set.
isViolation(Sample, Sample, Sample, VariantContext) - Method in class org.broadinstitute.hellbender.utils.samples.MendelianViolation
 
isViolation(Genotype, Genotype, Genotype) - Static method in class org.broadinstitute.hellbender.utils.samples.MendelianViolation
Evaluate the genotypes of mom, dad, and child to detect Mendelian violations
isWithinInterval(Locatable) - Method in class org.broadinstitute.hellbender.engine.MultiVariantWalkerGroupedOnStart
 
isXnp(Allele, Allele) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Determines whether the given reference and alternate alleles constitute a polymorphism in one or more nucleotides (XNP).
isXnp(String, String) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Determines whether the given reference and alternate alleles constitute a polymorphism in one or more nucleotides (XNP).
iterator() - Method in class org.broadinstitute.hellbender.engine.FeatureDataSource
Gets an iterator over all Features in this data source, restricting traversal to Features overlapping our intervals if intervals were provided via FeatureDataSource.setIntervalsForTraversal(List) Calling this method invalidates (closes) any previous iterator obtained from this method.
iterator() - Method in class org.broadinstitute.hellbender.engine.MultiIntervalLocalReadShard
 
iterator() - Method in class org.broadinstitute.hellbender.engine.MultiVariantDataSource
Gets an iterator over all variants in this data source, restricting traversal to variants overlapping our intervals if intervals were provided via MultiVariantDataSource.setIntervalsForTraversal(List) Calling this method invalidates (closes) any previous iterator obtained from this method.
iterator() - Method in class org.broadinstitute.hellbender.engine.ReadsContext
Get an iterator over the reads in this context.
iterator(SimpleInterval) - Method in class org.broadinstitute.hellbender.engine.ReadsContext
Get an iterator over the reads of the backing data source over a given interval.
iterator() - Method in class org.broadinstitute.hellbender.engine.ReadsDataSource
Iterate over all reads in this data source.
iterator() - Method in class org.broadinstitute.hellbender.engine.ReferenceContext
Get an iterator over the reference bases in this context.
iterator() - Method in class org.broadinstitute.hellbender.engine.ReferenceFileSource
Start an iteration over the entire reference.
iterator() - Method in class org.broadinstitute.hellbender.engine.ReferenceMemorySource
Start an iteration over the entire reference.
iterator() - Method in class org.broadinstitute.hellbender.engine.ShardBoundaryShard
 
iterator() - Method in class org.broadinstitute.hellbender.engine.ShardToMultiIntervalShardAdapter
 
iterator() - Method in class org.broadinstitute.hellbender.tools.DownsampleableSparkReadShard
 
iterator() - Method in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark.ReferenceMultiSourceAdapter
 
iterator() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerSet
 
iterator() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.IntervalCoverageFinder
 
iterator() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.KmerCleaner
 
iterator() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadsForQNamesFinder
 
iterator() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.PairedStrandedIntervalTree
 
iterator() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree
Return an iterator over the entire tree.
iterator(SVInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree
Return an iterator over all intervals greater than or equal to the specified interval.
iterator() - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchCollection
 
iterator() - Method in class org.broadinstitute.hellbender.tools.spark.utils.LargeLongHopscotchSet
 
iterator() - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongHopscotchSet
 
iterator() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KBestHaplotypeFinder
 
iterator(int) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KBestHaplotypeFinder
Returns an iterator on the first k best haplotypes.
iterator() - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
 
iterator() - Method in class org.broadinstitute.hellbender.utils.collections.IndexedSet
 
iterator() - Method in class org.broadinstitute.hellbender.utils.CompressedDataList
 
iterator() - Method in class org.broadinstitute.hellbender.utils.downsampling.ReadsDownsamplingIterator
 
iterator() - Method in class org.broadinstitute.hellbender.utils.GenomeLocSortedSet
get an iterator over this collection
iterator() - Method in class org.broadinstitute.hellbender.utils.iterators.ReadFilteringIterator
 
iterator() - Method in class org.broadinstitute.hellbender.utils.iterators.ReadTransformingIterator
 
iterator() - Method in class org.broadinstitute.hellbender.utils.iterators.SamReaderQueryingIterator
 
iterator() - Method in class org.broadinstitute.hellbender.utils.iterators.SAMRecordToReadIterator
 
iterator() - Method in class org.broadinstitute.hellbender.utils.nio.PathLineIterator
 
iterator() - Method in class org.broadinstitute.hellbender.utils.nio.ReadsIterable
 
iterator() - Method in class org.broadinstitute.hellbender.utils.pileup.ReadPileup
The best way to access PileupElements where you only care about the bases and quals in the pileup.
iterator() - Method in class org.broadinstitute.hellbender.utils.read.ArtificialReadIterator
return this iterator, for the iterable interface
iterator - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.AbstractMarkDuplicatesCommandLineProgram.SamHeaderAndIterator
 
iterator() - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.StandardCovariateList
Returns a new iterator over all covariates in this list.
iterator() - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationTables
 
iterator() - Method in class org.broadinstitute.hellbender.utils.text.XReadLines
I'm an iterator too...
iterator() - Method in class org.broadinstitute.hellbender.utils.tsv.TableReader
Returns an iterator on the remaining records in the input.
iterator() - Method in class picard.annotation.Gene
 
iterator() - Method in class picard.illumina.parser.BaseIlluminaDataProvider
 
iterator() - Method in class picard.illumina.parser.ReadStructure.Substructure
 
iterator() - Method in class picard.illumina.parser.TileIndex
 
iterator - Variable in class picard.sam.markduplicates.util.AbstractMarkDuplicatesCommandLineProgram.SamHeaderAndIterator
 
iterator() - Method in class picard.util.AbstractInputParser
 
iterator() - Method in class picard.util.TabbedTextFileWithHeaderParser
Creates the iterator object.
IteratorFilter(Iterator<T>, Predicate<T>) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVUtils.IteratorFilter
 
Iterators - Class in picard.util
 
Iterators() - Constructor for class picard.util.Iterators
 
iterators() - Method in class picard.vcf.processor.VariantIteratorProducer
Renders the embodied regions of the VCF files in the form of CloseableIterators over VariantContexts.
iteratorSize(Iterator<T>) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVUtils
count the number of items available from an iterator
iteratorSize(LongIterator) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVUtils
 

J

JAVA_DEFAULT_HASH_LOAD_FACTOR - Static variable in class org.broadinstitute.hellbender.utils.Utils
 
JAVASCRIPT_FILE - Variable in class picard.sam.FilterSamReads
 
JAVASCRIPT_FILE - Variable in class picard.vcf.filter.FilterVcf
 
join(JavaRDD<GATKRead>, JavaRDD<GATKVariant>) - Static method in class org.broadinstitute.hellbender.engine.spark.BroadcastJoinReadsWithVariants
Joins each read of an RDD with overlapping variants from an RDD of GATKVariants.
join(JavaRDD<GATKRead>, List<String>) - Static method in class org.broadinstitute.hellbender.engine.spark.BroadcastJoinReadsWithVariants
Joins each read of an RDD with overlapping variants from an RDD of GATKVariants.
join(JavaRDD<GATKRead>, JavaRDD<GATKVariant>) - Static method in class org.broadinstitute.hellbender.engine.spark.ShuffleJoinReadsWithVariants
 
join(SVInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVInterval
 
join(String, Object...) - Static method in class org.broadinstitute.hellbender.utils.Utils
Returns a string of the values in an Object array joined by a separator.
join(String, int[]) - Static method in class org.broadinstitute.hellbender.utils.Utils
Returns a string of the values in ints joined by separator, such as A,B,C
join(String, double[]) - Static method in class org.broadinstitute.hellbender.utils.Utils
Returns a string of the values in joined by separator, such as A,B,C
join(String, Collection<T>) - Static method in class org.broadinstitute.hellbender.utils.Utils
Returns a string of the form elt1.toString() [sep elt2.toString() ...
JoinStrategy - Enum in org.broadinstitute.hellbender.engine.spark
Possible join strategies when using Spark
JOINT_LIKELIHOOD_TAG_NAME - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
JOINT_POSTERIOR_TAG_NAME - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
JsonSerializer<T> - Class in org.broadinstitute.hellbender.engine.spark
This is a simple JsonSerializer for use with Kryo.
JsonSerializer() - Constructor for class org.broadinstitute.hellbender.engine.spark.JsonSerializer
 
JUMP_DUPLICATE_PAIRS - Variable in class picard.analysis.JumpingLibraryMetrics
The number of outward-facing pairs that are duplicates
JUMP_DUPLICATE_PCT - Variable in class picard.analysis.JumpingLibraryMetrics
The fraction of outward-facing pairs that are marked as duplicates
JUMP_LIBRARY_SIZE - Variable in class picard.analysis.JumpingLibraryMetrics
The estimated library size for outward-facing pairs
JUMP_MEAN_INSERT_SIZE - Variable in class picard.analysis.JumpingLibraryMetrics
The mean insert size for outward-facing pairs
JUMP_PAIRS - Variable in class picard.analysis.JumpingLibraryMetrics
The number of outward-facing pairs in the SAM file
JUMP_SIZE - Variable in class picard.sam.MergeBamAlignment
Deprecated.
JUMP_STDEV_INSERT_SIZE - Variable in class picard.analysis.JumpingLibraryMetrics
The standard deviation on the insert size for outward-facing pairs
JumpingLibraryMetrics - Class in picard.analysis
High level metrics about the presence of outward- and inward-facing pairs within a SAM file generated with a jumping library, produced by the CollectJumpingLibraryMetrics program and usually stored in a file with the extension ".jump_metrics".
JumpingLibraryMetrics() - Constructor for class picard.analysis.JumpingLibraryMetrics
 
justDetermineActiveRegions - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerArgumentCollection
This argument is intended for benchmarking and scalability testing.

K

kAdvance - Variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerizer
 
KBestHaplotype - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs
Represents a result from a K-best haplotype search.
KBestHaplotype() - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KBestHaplotype
 
KBestHaplotypeFinder - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs
Efficient algorithm to obtain the list of best haplotypes given the instace.
KBestHaplotypeFinder(SeqGraph, Set<SeqVertex>, Set<SeqVertex>) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KBestHaplotypeFinder
Constructs a new best haplotypes finder.
KBestHaplotypeFinder(SeqGraph, SeqVertex, SeqVertex) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KBestHaplotypeFinder
Constructs a new best haplotypes finder.
KBestHaplotypeFinder(SeqGraph) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KBestHaplotypeFinder
Constructs a new best haplotype finder.
KEEP_FIRST_DUPLICATE - Variable in class picard.sam.RevertSam
 
KEEP_READ_GROUP_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ReadFilterArgumentDefinitions
 
KEEP_REVERSE_STRAND_ONLY_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ReadFilterArgumentDefinitions
 
keepOnlyReverse - Variable in class org.broadinstitute.hellbender.engine.filters.ReadStrandFilter
 
keepRG - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerArgumentCollection
 
keepUniqueReadListInLibs() - Method in class org.broadinstitute.hellbender.engine.LocusWalker
Should the LIBS keep unique reads? Tools that do should override to return true.
KERNEL_APPROXIMATION_DIMENSION_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
KERNEL_SCALING_ALLELE_FRACTION_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
KERNEL_VARIANCE_ALLELE_FRACTION_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
KERNEL_VARIANCE_COPY_RATIO_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
KernelSegmenter<DATA> - Class in org.broadinstitute.hellbender.tools.copynumber.utils.segmentation
Segments data (i.e., finds multiple changepoints) using a method based on the kernel-segmentation algorithm described in https://hal.inria.fr/hal-01413230/document, which gives a framework to quickly calculate the cost of a segment given a low-rank approximation to a specified kernel.
KernelSegmenter(List<DATA>) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.utils.segmentation.KernelSegmenter
 
KernelSegmenter.ChangepointSortOrder - Enum in org.broadinstitute.hellbender.tools.copynumber.utils.segmentation
 
KEY - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.BaseQuality
 
KEY - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.FragmentLength
 
KEY - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.MappingQuality
 
KEY - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.ReadPosition
 
key - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.EmptyFragment
 
key() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.EmptyFragment
 
key - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Fragment
 
key() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Fragment
 
key() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.MarkDuplicatesSparkRecord
 
key - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Pair
 
key() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Pair
 
key() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Passthrough
 
keyForRead(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadsKey
Makes a unique key for the read.
keyFromContext(String) - Static method in class org.broadinstitute.hellbender.utils.recalibration.covariates.ContextCovariate
 
keyFromCycle(int, int) - Static method in class org.broadinstitute.hellbender.utils.recalibration.covariates.CycleCovariate
Encodes the cycle number as a key.
keyFromValue(Object) - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.ContextCovariate
 
keyFromValue(Object) - Method in interface org.broadinstitute.hellbender.utils.recalibration.covariates.Covariate
Converts an Object key into a long key using only the lowest numberOfBits() bits Only necessary for on-the-fly recalibration when you have the object, but need to store it in memory in long format.
keyFromValue(Object) - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.CycleCovariate
 
keyFromValue(Object) - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.QualityScoreCovariate
 
keyFromValue(Object) - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.ReadGroupCovariate
 
keyNames - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.ChromosomeCounts
 
keys - Variable in class org.broadinstitute.hellbender.utils.collections.NestedIntegerArray.Leaf
 
keySet() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.TableFuncotation
 
keySet() - Method in class org.broadinstitute.hellbender.utils.mcmc.ParameterizedState
Returns a Set of the keys of the Parameter objects that are held internally as values of the parameter map.
Kmer - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
Fast wrapper for byte[] kmers This objects has several important features that make it better than using a raw byte[] for a kmer: -- Can create kmer from a range of a larger byte[], allowing us to avoid Array.copyOfRange -- Fast equals and hashcode methods -- can get actual byte[] of the kmer, even if it's from a larger byte[], and this operation only does the work of that operation once, updating its internal state
Kmer(byte[]) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.Kmer
Create a new kmer using all bases in kmer
Kmer(String) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.Kmer
Create a new kmer based on the string kmer This is not a good method to use for performance
Kmer(byte[], int, int) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.Kmer
Create a new kmer backed by the bases in bases, spanning start -> start + length Under no circumstances can bases be modified anywhere in the client code.
KMER_FILE_PATH_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
KMER_FILE_PATH_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
KMER_MASK_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildKmers
 
KMER_MASK_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildKmers
 
KMER_SIZE - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
KMER_SIZE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildKmers
 
KMER_SIZE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildKmers
 
KMER_SPACING_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildKmers
 
KMER_SPACING_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildKmers
 
KmerAndCount - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
A pair.
KmerAndCount(SVKmerLong) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.KmerAndCount
 
KmerAndCount(SVKmerLong, int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.KmerAndCount
 
KmerAndCount.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
KmerAndInterval - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
A pair.
KmerAndInterval(SVKmer, int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.KmerAndInterval
 
KmerAndInterval.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
KmerCleaner - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
Eliminates dups, and removes over-represented kmers.
KmerCleaner(Iterator<Tuple2<KmerAndInterval, Integer>>, int, int, int, int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.KmerCleaner
 
KmerCounter - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
Iterates over reads, kmerizing them, and counting up just the kmers that appear in a passed-in set.
KmerCounter(int, int, HopscotchUniqueMultiMap<SVKmer, Integer, KmerAndInterval>) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.KmerCounter
 
KMerCounter - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
generic utility class that counts kmers Basically you add kmers to the counter, and it tells you how many occurrences of each kmer it's seen.
KMerCounter(int) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.KMerCounter
Create a new kmer counter
kmerFile - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
kmerFilePath - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
kmerLengthForReadErrorCorrection - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadThreadingAssemblerArgumentCollection
Enabling this argument may cause fundamental problems with the assembly graph itself.
kmerMaskString - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildKmers
K-mer masking allows mismatches to occur at one or more specified positions.
KmerSearchableGraph<V extends BaseVertex,E extends BaseEdge> - Interface in org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs
Common interface for those graphs that implement vertex by kmer look-up.
kmerSize - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildKmers
Reducing the k-mer length will increase the number of host reads subtracted in the filtering phase of the pipeline, but it may also increase the number of non-host (i.e.
kmerSize() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerBloomFilter
 
kmerSize() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerSet
 
kmerSize - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
 
kmerSizes - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadThreadingAssemblerArgumentCollection
Multiple kmer sizes can be specified, using e.g.
kmerSpacing - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildKmers
The k-mer set size can be reduced by only storing k-mers starting at every n bases in the reference.
kmersToIgnoreFile - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
This is a path to a file of kmers that appear too frequently in the reference to be usable as probes to localize reads.
KNOWN_SITES_ARG_FULL_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.bqsr.BaseRecalibrator
 
knownPlatformsString() - Static method in enum org.broadinstitute.hellbender.utils.NGSPlatform
Get a human-readable list of platform names
knownSubInterfaces(Class<?>) - Static method in class org.broadinstitute.hellbender.utils.ClassUtils
Finds all subinterfaces of the given interface (in the same package).
knownSubInterfaceSimpleNames(Class<?>) - Static method in class org.broadinstitute.hellbender.utils.ClassUtils
Finds sub-interfaces of the given interface (in the same package) and returns their simple names.
KS_SIGNIFICANCE - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.evidence.KSWindowFinder
 
kSize - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
kSize - Variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerizer
 
KSWindowFinder - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
KSWindowFinder(ReadMetadata, SVReadFilter) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.KSWindowFinder
 
KV<K,V> - Class in org.broadinstitute.hellbender.utils
replacement for dataflow Key-Value class, don't use this anywhere new

L

label() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.AggregatedSubHaplotypeFinder
 
LABELS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.utils.CombineSegmentBreakpoints
 
LANE - Variable in class picard.fastq.BamToBfq
 
LANE - Variable in class picard.illumina.CollectIlluminaBasecallingMetrics
 
LANE - Variable in class picard.illumina.ExtractIlluminaBarcodes
 
LANE - Variable in class picard.illumina.IlluminaBasecallingMetrics
The lane for which the metrics were calculated.
LANE - Variable in class picard.illumina.IlluminaBasecallsToFastq
 
LANE - Variable in class picard.illumina.IlluminaBasecallsToSam
 
LANE - Variable in class picard.illumina.IlluminaLaneMetrics
This lane's number.
LANE - Variable in class picard.illumina.IlluminaPhasingMetrics
Illumina flowcell lane number
lane - Variable in class picard.illumina.parser.BaseIlluminaDataProvider
 
lane - Variable in class picard.illumina.parser.ParameterizedFileUtil
 
lane - Variable in class picard.illumina.parser.readers.AbstractIlluminaPositionFileReader.PositionInfo
The lane, which is determined from the file name
LANE - Variable in class picard.illumina.quality.CollectHiSeqXPfFailMetrics
 
LANE_SHORT_NAME - Static variable in class picard.cmdline.StandardOptionDefinitions
 
laneIsSet() - Method in class picard.illumina.parser.ClusterData
 
LanePhasingMetricsCollector - Class in picard.illumina
Helper class used to transform tile data for a lane into a collection of IlluminaPhasingMetrics
LanePhasingMetricsCollector(Collection<Tile>, boolean) - Constructor for class picard.illumina.LanePhasingMetricsCollector
Constructor takes a lane's collection of Tiles and calculates the median phasing/prephasing for the first and second (if available) reads
LANES - Variable in class picard.illumina.CheckIlluminaDirectory
 
laneTileCode - Variable in class picard.illumina.parser.readers.EmpiricalPhasingMetricsOutReader.IlluminaPhasingMetrics
 
LARGE_RUNTIME_RESOURCES_PATH - Static variable in class org.broadinstitute.hellbender.utils.io.Resource
Path to the directory for large runtime system resources
LargeLongHopscotchSet - Class in org.broadinstitute.hellbender.tools.spark.utils
Set of longs that is larger than the max Java array size ( ~ 2^31 ~ 2 billion) and therefore cannot fit into a single LongHopscotchSet.
LargeLongHopscotchSet(long) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.LargeLongHopscotchSet
 
LargeLongHopscotchSet(Kryo, Input) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.LargeLongHopscotchSet
 
LargeLongHopscotchSet.Serializer - Class in org.broadinstitute.hellbender.tools.spark.utils
 
lastBase() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmer
 
lastBase() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerLong
 
lastBase() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerShort
 
lastIndexOf(byte[], byte[]) - Static method in class org.broadinstitute.hellbender.utils.Utils
Find the last occurrence of the query sequence in the reference sequence Returns the index of the last occurrence or -1 if the query sequence is not found
lastTrimer() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmer
 
lastTrimer() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerLong
 
lastTrimer() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerShort
 
LATEST_REPORT_VERSION - Static variable in class org.broadinstitute.hellbender.utils.report.GATKReport
 
launchProcess(ProcessSettings) - Method in class org.broadinstitute.hellbender.utils.runtime.ProcessControllerBase
Executes a command line program with the settings and waits for it to return, processing the output on a background thread.
Leaf(int[], T) - Constructor for class org.broadinstitute.hellbender.utils.collections.NestedIntegerArray.Leaf
 
LEARNING_RATE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection
 
LEFT_FILE - Variable in class picard.fingerprint.CrosscheckMetric
 
LEFT_GROUP_VALUE - Variable in class picard.fingerprint.CrosscheckMetric
 
LEFT_LANE - Variable in class picard.fingerprint.CrosscheckMetric
 
LEFT_LIBRARY - Variable in class picard.fingerprint.CrosscheckMetric
 
LEFT_MOLECULAR_BARCODE_SEQUENCE - Variable in class picard.fingerprint.CrosscheckMetric
 
LEFT_PRIMER - Variable in class picard.util.BaitDesigner
 
LEFT_RUN_BARCODE - Variable in class picard.fingerprint.CrosscheckMetric
 
LEFT_SAMPLE - Variable in class picard.fingerprint.CrosscheckMetric
 
leftAlignCigarSequentially(Cigar, byte[], byte[], int, int) - Static method in class org.broadinstitute.hellbender.utils.read.CigarUtils
Left align the given cigar sequentially.
leftAlignIndel(Cigar, byte[], byte[], int, int, boolean) - Static method in class org.broadinstitute.hellbender.utils.read.AlignmentUtils
Takes the alignment of the read sequence readSeq to the reference sequence refSeq starting at 0-based position refIndex on the refSeq and specified by its cigar.
LeftAlignIndels - Class in org.broadinstitute.hellbender.tools
Left-aligns indels in read data
LeftAlignIndels() - Constructor for class org.broadinstitute.hellbender.tools.LeftAlignIndels
 
leftAlignSingleIndel(Cigar, byte[], byte[], int, int, boolean) - Static method in class org.broadinstitute.hellbender.utils.read.AlignmentUtils
See the documentation for AlignmentUtils.leftAlignIndel() for more details.
leftAlignVariant(VariantContextBuilder, int, int, List<Allele>, ReferenceSequence) - Static method in class picard.util.LiftoverUtils
Normalizes and left aligns a VariantContextBuilder.
leftMedianDeviation(int) - Method in class org.broadinstitute.hellbender.tools.spark.utils.IntHistogram.CDF
 
leftVariantContext - Variable in class picard.vcf.PairedVariantSubContextIterator.VcfTuple
 
LEGACY_PAIRHMM_BASE_QUALITY_SCORE_THRESHOLD - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.ReadPosRankSumTest
 
LEGACY_SEG_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
LEGACY_SEG_FILE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
legalSizes - Static variable in class org.broadinstitute.hellbender.tools.spark.utils.SetSizeUtils
Largest prime numbers less than each half power of 2 from 2^8 to 2^31 Note the last size is the greatest prime that is an allowable Java array size (<=2^31-3)
length() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerizer.ASCIICharSequence
 
length() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseVertex
Get the length of this sequence
length() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.Path
Length of the path in edges.
length() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.Kmer
The length of this kmer
length() - Method in class org.broadinstitute.hellbender.utils.nio.ChannelAsSeekableStream
 
length() - Method in class picard.annotation.Gene.Transcript
 
length - Variable in class picard.illumina.parser.Range
 
length - Variable in class picard.illumina.parser.ReadDescriptor
 
length() - Method in class picard.illumina.parser.ReadStructure.Substructure
 
LENIENT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
LENIENT_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
lenientVCFProcessing - Variable in class org.broadinstitute.hellbender.engine.GATKTool
 
LevelingDownsampler<T extends java.util.List<E>,E> - Class in org.broadinstitute.hellbender.utils.downsampling
Leveling Downsampler: Given a set of Lists of arbitrary items and a target size, removes items from the Lists in an even fashion until the total size of all Lists is <= the target size.
LevelingDownsampler(long) - Constructor for class org.broadinstitute.hellbender.utils.downsampling.LevelingDownsampler
Construct a LevelingDownsampler Uses the default minElementsPerStack of 1
LevelingDownsampler(long, int) - Constructor for class org.broadinstitute.hellbender.utils.downsampling.LevelingDownsampler
Construct a LevelingDownsampler
levelToLog4jLevel(Log.LogLevel) - Static method in class org.broadinstitute.hellbender.utils.LoggingUtils
Converts a picard log level to a log4j log level.
LEXICOGRAPHICAL_ORDER_COMPARATOR - Static variable in class org.broadinstitute.hellbender.utils.IntervalUtils
Lexicographical (contig) order comparator.
LexicographicallySortedSequenceDictionary(String, SAMSequenceDictionary) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.LexicographicallySortedSequenceDictionary
 
lhs - Variable in class org.broadinstitute.hellbender.engine.filters.ReadFilter.ReadFilterBinOp
 
LIBRARY - Variable in class org.broadinstitute.hellbender.metrics.MultiLevelMetrics
The library to which these metrics apply.
LIBRARY - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasDetailMetrics
The name of the library being assayed.
LIBRARY - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasSummaryMetrics
The name of the library being assayed.
LIBRARY - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterDetailMetrics
The name of the library being assayed.
LIBRARY - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterSummaryMetrics
The name of the library being assayed.
LIBRARY - Variable in class picard.analysis.CollectOxoGMetrics.CpcgMetrics
The name of the library being assayed.
LIBRARY - Variable in class picard.metrics.MultilevelMetrics
The library to which these metrics apply.
LIBRARY - Variable in class picard.sam.DuplicationMetrics
The library on which the duplicate marking was performed.
LIBRARY_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ReadFilterArgumentDefinitions
 
LIBRARY_NAME - Variable in class org.broadinstitute.hellbender.tools.SplitReads
 
LIBRARY_NAME - Variable in class picard.illumina.ExtractIlluminaBarcodes.BarcodeMetric
The name of the library
LIBRARY_NAME - Variable in class picard.illumina.IlluminaBasecallsToSam
 
LIBRARY_NAME - Variable in class picard.sam.FastqToSam
 
LIBRARY_NAME - Variable in class picard.sam.RevertSam
 
LIBRARY_NAME_COLUMN - Static variable in class picard.illumina.ExtractIlluminaBarcodes
Column header for the library name.
LIBRARY_NAME_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.SplitReads
 
LIBRARY_NAME_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.SplitReads
 
LIBRARY_NAME_SHORT_NAME - Static variable in class picard.cmdline.StandardOptionDefinitions
 
LIBRARY_PARAMS - Variable in class picard.illumina.IlluminaBasecallsToSam
 
libraryId - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
libraryId - Variable in class picard.sam.markduplicates.util.ReadEnds
 
LibraryIdGenerator - Class in org.broadinstitute.hellbender.utils.read.markduplicates
A class to generate library Ids and keep duplication metrics by library IDs.
LibraryIdGenerator(SAMFileHeader) - Constructor for class org.broadinstitute.hellbender.utils.read.markduplicates.LibraryIdGenerator
 
libraryIdGenerator - Variable in class picard.sam.markduplicates.MarkDuplicates
 
LibraryIdGenerator - Class in picard.sam.markduplicates.util
A class to generate library Ids and keep duplication metrics by library IDs.
LibraryIdGenerator(SAMFileHeader) - Constructor for class picard.sam.markduplicates.util.LibraryIdGenerator
 
LibraryNameSplitter - Class in org.broadinstitute.hellbender.tools.readersplitters
Splits readers by library name.
LibraryNameSplitter() - Constructor for class org.broadinstitute.hellbender.tools.readersplitters.LibraryNameSplitter
 
LibraryRawStatistics(int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.LibraryRawStatistics
 
LibraryReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Keep only reads from the specified library.
LibraryReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.LibraryReadFilter
 
LibraryReadFilter(SAMFileHeader) - Constructor for class org.broadinstitute.hellbender.engine.filters.LibraryReadFilter
 
LibraryStatistics - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
statistics of fragment length distributions
LibraryStatistics(IntHistogram.CDF, long, long, long, long) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.LibraryStatistics
 
LibraryStatistics.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
libraryToHistoPairMap - Variable in class org.broadinstitute.hellbender.tools.spark.sv.evidence.KSWindowFinder
 
libraryToKeep - Variable in class org.broadinstitute.hellbender.engine.filters.LibraryReadFilter
 
LIBSDownsamplingInfo - Class in org.broadinstitute.hellbender.utils.locusiterator
Simple wrapper about the information LIBS needs about downsampling
LIBSDownsamplingInfo(boolean, int) - Constructor for class org.broadinstitute.hellbender.utils.locusiterator.LIBSDownsamplingInfo
 
LIFTOVER_MIN_MATCH - Variable in class picard.vcf.LiftoverVcf
 
LiftOverIntervalList - Class in picard.util
This tool adjusts the coordinates in an interval list on one reference to its homologous interval list on another reference, based on a chain file that describes the correspondence between the two references.
LiftOverIntervalList() - Constructor for class picard.util.LiftOverIntervalList
 
LiftoverUtils - Class in picard.util
 
LiftoverUtils() - Constructor for class picard.util.LiftoverUtils
 
LiftoverVcf - Class in picard.vcf
Summary
LiftoverVcf() - Constructor for class picard.vcf.LiftoverVcf
 
liftSimpleVariantContext(VariantContext, Interval) - Static method in class picard.util.LiftoverUtils
 
liftVariant(VariantContext, Interval, ReferenceSequence, boolean) - Static method in class picard.util.LiftoverUtils
This will take an input VariantContext and lift to the provided interval.
likelihood - Variable in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods.BestAllele
If allele != null, the indicates the likelihood of the read.
LIKELIHOOD_RANK_SUM_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
likelihoodArgs - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerArgumentCollection
 
LikelihoodEngineArgumentCollection - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
Set of arguments related to ReadLikelihoodCalculationEngine implementations
LikelihoodEngineArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.LikelihoodEngineArgumentCollection
 
likelihoodEngineImplementation - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.LikelihoodEngineArgumentCollection
 
LikelihoodMatrix<A extends htsjdk.variant.variantcontext.Allele> - Interface in org.broadinstitute.hellbender.utils.genotyper
Likelihood matrix between a set of alleles and reads.
LikelihoodRankSumTest - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Rank Sum Test of per-read likelihoods of REF versus ALT reads
LikelihoodRankSumTest() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.LikelihoodRankSumTest
 
LIKELIHOODS_FILENAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.PairHMMLikelihoodCalculationEngine
 
limitingProcessedRegionsTo(IntervalList) - Method in class picard.vcf.processor.VariantProcessor.Builder
 
LINE_LENGTH - Variable in class picard.reference.ExtractSequences
 
LINE_LENGTH - Variable in class picard.reference.NormalizeFasta
 
LineIteratorReader - Class in org.broadinstitute.hellbender.utils.codecs
A reader wrapper around a LineIterator.
LineIteratorReader(LineIterator) - Constructor for class org.broadinstitute.hellbender.utils.codecs.LineIteratorReader
 
LINK - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
LINK_LOCS - Variable in class picard.illumina.CheckIlluminaDirectory
Deprecated.
It is no longer necessary to create locs file symlinks.
listFromPrimitives(int[]) - Static method in class org.broadinstitute.hellbender.utils.Utils
Simple wrapper for sticking elements of a int[] array into a List
LL_EXPECTED_SAMPLE - Variable in class picard.analysis.FingerprintingSummaryMetrics
The Log Likelihood of the sequence data given the expected sample's genotypes.
LL_RANDOM_SAMPLE - Variable in class picard.analysis.FingerprintingSummaryMetrics
The Log Likelihood of the sequence data given a random sample from the human population.
LO_CONF_DENOVO_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
loadBQSRScriptResource() - Static method in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
Retrieve the BQSR.R script
loadCNVCalls(String, SAMFileHeader) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.CNVInputReader
Loads an external cnv call list and returns the results in an SVIntervalTree.
loadContaminationFile(File, double, Set<String>, Logger) - Static method in class org.broadinstitute.hellbender.utils.downsampling.AlleleBiasedDownsamplingUtils
Create sample-contamination maps from file.
loadFastaDictionary(File) - Static method in class org.broadinstitute.hellbender.utils.reference.ReferenceUtils
Given a fasta dictionary file, returns its sequence dictionary
loadFastaDictionary(InputStream) - Static method in class org.broadinstitute.hellbender.utils.reference.ReferenceUtils
Given an InputStream connected to a fasta dictionary, returns its sequence dictionary Note: does not close the InputStream it's passed
loadFingerprints(Path, String) - Method in class picard.fingerprint.FingerprintChecker
Loads genotypes from the supplied file into one or more Fingerprint objects and returns them in a Map of Sample->Fingerprint.
loadFingerprintsFromIndexedVcf(Path, String) - Method in class picard.fingerprint.FingerprintChecker
Loads genotypes from the supplied file into one or more Fingerprint objects and returns them in a Map of Sample->Fingerprint.
loadFingerprintsFromNonIndexedVcf(Path, String) - Method in class picard.fingerprint.FingerprintChecker
Loads genotypes from the supplied file into one or more Fingerprint objects and returns them in a Map of Sample->Fingerprint.
loadFingerprintsFromQueriableReader(VCFFileReader, String, Path) - Method in class picard.fingerprint.FingerprintChecker
Loads genotypes from the supplied reader into one or more Fingerprint objects and returns them in a Map of Sample->Fingerprint.
loadFingerprintsFromVariantContexts(Iterable<VariantContext>, String, Path) - Method in class picard.fingerprint.FingerprintChecker
Loads genotypes from the supplied file into one or more Fingerprint objects and returns them in a Map of Sample->Fingerprint.
loadIndex(File) - Static method in class org.broadinstitute.hellbender.utils.IndexUtils
Loads and returns the index of the feature file or null if there is no index.
loadIntervals(List<String>, IntervalSetRule, IntervalMergingRule, int, GenomeLocParser) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
 
loadLibraryFromClasspath(String) - Static method in class org.broadinstitute.hellbender.utils.NativeUtils
Loads a native library stored on our classpath by extracting it to a temporary location and invoking System.load(java.lang.String) on it
loadPropertiesFile(String, Class<?>) - Static method in class picard.util.PropertyUtils
Attempt to load a Properties object from an on-disk properties file.
loadRefFlat(File, SAMSequenceDictionary) - Static method in class picard.annotation.GeneAnnotationReader
 
loadSampleNameMapFile(Path) - Static method in class org.broadinstitute.hellbender.tools.genomicsdb.GenomicsDBImport
load a tab delimited new line separated file of sample name to URI mapping: this maintains the keys in the same order that they appeared in the file this tool should only call GenomicsDBImport.loadSampleNameMapFileInSortedOrder(Path), this version is exposed for the benefit of FixCallSetSampleOrdering ex: Sample1\tpathToSample1.vcf\n Sample2\tpathTosample2.vcf\n ...
loadSampleNameMapFileInSortedOrder(Path) - Static method in class org.broadinstitute.hellbender.tools.genomicsdb.GenomicsDBImport
load a tab delimited new line separated file of sample name to URI mapping: ex: Sample1\tpathToSample1.vcf\n Sample2\tpathTosample2.vcf\n ...
loadTabixIndex(File) - Static method in class org.broadinstitute.hellbender.utils.IndexUtils
Try to load the tabix index from disk, checking for out of date indexes and old versions
loadTribbleIndex(File) - Static method in class org.broadinstitute.hellbender.utils.IndexUtils
Load a Tribble .idx index from disk, checking for out of date indexes and old versions
loc - Variable in class org.broadinstitute.hellbender.tools.walkers.rnaseq.OverhangFixingManager.Splice
 
LocatableMetadata - Interface in org.broadinstitute.hellbender.tools.copynumber.formats.metadata
Interface for marking objects that contain metadata associated with a collection of locatables.
locatableToString(Locatable) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
 
LocatableXsvFuncotationFactory - Class in org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv
Factory for creating TableFuncotations by handling `Separated Value` files with arbitrary delimiters (e.g.
LocatableXsvFuncotationFactory() - Constructor for class org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv.LocatableXsvFuncotationFactory
 
LocatableXsvFuncotationFactory(String, String) - Constructor for class org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv.LocatableXsvFuncotationFactory
 
LocatableXsvFuncotationFactory(String, String, LinkedHashMap<String, String>) - Constructor for class org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv.LocatableXsvFuncotationFactory
 
LocsFileFaker - Class in picard.illumina.parser.fakers
Created by jcarey on 3/13/14.
LocsFileFaker() - Constructor for class picard.illumina.parser.fakers.LocsFileFaker
 
LocsFileReader - Class in picard.illumina.parser.readers
The locs file format is one 3 Illumina formats(pos, locs, and clocs) that stores position data exclusively.
LocsFileReader(File) - Constructor for class picard.illumina.parser.readers.LocsFileReader
 
LocsFileReader(File, int, int) - Constructor for class picard.illumina.parser.readers.LocsFileReader
 
locToReadsPileup(List<GATKRead>, Locatable) - Static method in class org.broadinstitute.hellbender.utils.pileup.ReadPileup
Helper routine for converting reads and a single offset to a PileupElement list.
LOCUS_ACCUMULATION_CAP - Variable in class picard.analysis.CollectWgsMetrics
 
LOCUS_MAX_READS - Variable in class picard.fingerprint.IdentifyContaminant
 
LocusFunction - Enum in picard.annotation
Describes the behavior of a locus relative to a gene.
LocusIteratorByState - Class in org.broadinstitute.hellbender.utils.locusiterator
Iterator that traverses a SAM File, accumulating information on a per-locus basis Produces AlignmentContext objects, that contain ReadPileups of PileupElements.
LocusIteratorByState(Iterator<GATKRead>, DownsamplingMethod, boolean, Collection<String>, SAMFileHeader, boolean) - Constructor for class org.broadinstitute.hellbender.utils.locusiterator.LocusIteratorByState
Create a new LocusIteratorByState
LocusIteratorByState(Iterator<GATKRead>, DownsamplingMethod, boolean, Collection<String>, SAMFileHeader, boolean, boolean) - Constructor for class org.broadinstitute.hellbender.utils.locusiterator.LocusIteratorByState
Create a new LocusIteratorByState
LocusIteratorByState(Iterator<GATKRead>, LIBSDownsamplingInfo, boolean, Collection<String>, SAMFileHeader, boolean) - Constructor for class org.broadinstitute.hellbender.utils.locusiterator.LocusIteratorByState
Create a new LocusIteratorByState
LocusIteratorByState(Iterator<GATKRead>, LIBSDownsamplingInfo, boolean, Collection<String>, SAMFileHeader, boolean, boolean) - Constructor for class org.broadinstitute.hellbender.utils.locusiterator.LocusIteratorByState
Create a new LocusIteratorByState
locusLevel - Variable in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeatureBaseData
 
LocusWalker - Class in org.broadinstitute.hellbender.engine
A LocusWalker is a tool that processes reads that overlap a single position in a reference at a time from one or multiple sources of reads, with optional contextual information from a reference and/or sets of variants/Features.
LocusWalker() - Constructor for class org.broadinstitute.hellbender.engine.LocusWalker
 
LocusWalkerContext - Class in org.broadinstitute.hellbender.engine.spark
Encapsulates an AlignmentContext with its ReferenceContext and FeatureContext.
LocusWalkerContext(AlignmentContext, ReferenceContext, FeatureContext) - Constructor for class org.broadinstitute.hellbender.engine.spark.LocusWalkerContext
 
LocusWalkerSpark - Class in org.broadinstitute.hellbender.engine.spark
A Spark version of LocusWalker.
LocusWalkerSpark() - Constructor for class org.broadinstitute.hellbender.engine.spark.LocusWalkerSpark
 
LOD - Variable in class picard.analysis.FingerprintingDetailMetrics
The LOD score for OBSERVED_GENOTYPE vs.
LOD_EXPECTED_SAMPLE - Variable in class picard.analysis.FingerprintingSummaryMetrics
The LOD for Expected Sample vs.
LOD_SCORE - Variable in class picard.fingerprint.CrosscheckMetric
 
LOD_SCORE_NORMAL_TUMOR - Variable in class picard.fingerprint.CrosscheckMetric
 
LOD_SCORE_TUMOR_NORMAL - Variable in class picard.fingerprint.CrosscheckMetric
 
LOD_THRESHOLD - Variable in class picard.fingerprint.ClusterCrosscheckMetrics
 
LOD_THRESHOLD - Variable in class picard.fingerprint.CrosscheckFingerprints
 
LOG - Static variable in class org.broadinstitute.hellbender.utils.read.markduplicates.AbstractOpticalDuplicateFinderCommandLineProgram
 
log(String...) - Method in class org.broadinstitute.hellbender.utils.runtime.ProgressLogger
Log a message to whatever logger is being used
log(String) - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest
Log this message so that it shows up inline during output as well as in html reports
LOG - Static variable in class picard.sam.markduplicates.util.AbstractOpticalDuplicateFinderCommandLineProgram
 
log - Static variable in class picard.util.LiftoverUtils
 
LOG - Static variable in class picard.vcf.VcfFormatConverter
 
LOG - Static variable in class picard.vcf.VcfToIntervalList
 
log10(int) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
log10_1p(double) - Static method in class picard.util.MathUtil
this function mimics the behavior of log_1p but resulting in log _base 10_ of (1+x) instead of natural log of 1+x
LOG10_OF_E - Static variable in class org.broadinstitute.hellbender.utils.MathUtils
Log10 of the e constant.
LOG10_ONE_HALF - Static variable in class org.broadinstitute.hellbender.utils.MathUtils
 
LOG10_ONE_THIRD - Static variable in class org.broadinstitute.hellbender.utils.MathUtils
 
LOG10_P_OF_ZERO - Static variable in class org.broadinstitute.hellbender.utils.MathUtils
The smallest log10 value we'll emit from normalizeFromLog10 and other functions where the real-space value is 0.0.
log10BinomialCoefficient(int, int) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
log10BinomialProbability(int, int, double) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
binomial Probability(int, int, double) with log applied to result
log10BinomialProbability(int, int) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
log10CombinationCount() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeAlleleCounts
Gets the log10 combination count, computing it if uninitialized.
log10DirichletNormalization(double[]) - Static method in class org.broadinstitute.hellbender.tools.walkers.mutect.SomaticLikelihoodsEngine
 
log10Evidence(RealMatrix, double[]) - Static method in class org.broadinstitute.hellbender.tools.walkers.mutect.SomaticLikelihoodsEngine
 
log10Evidence(RealMatrix) - Static method in class org.broadinstitute.hellbender.tools.walkers.mutect.SomaticLikelihoodsEngine
 
log10Factorial(int) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
log10Gamma(double) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Calculates the log10 of the gamma function for x.
log10MeanWeights() - Method in class org.broadinstitute.hellbender.utils.Dirichlet
 
log10MultinomialCoefficient(int, int[]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Calculates the log10 of the multinomial coefficient.
log10OneMinusPow10(double) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Calculates log10(1-10^a) without losing precision.
log10OneMinusX(double) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Compute in a numerically correct way the quantity log10(1-x) Uses the approximation log10(1-x) = log10(1/x - 1) + log10(x) to avoid very quick underflow in 1-x when x is very small
Log10PairHMM - Class in org.broadinstitute.hellbender.utils.pairhmm
Util class for performing the pair HMM for local alignment.
Log10PairHMM(boolean) - Constructor for class org.broadinstitute.hellbender.utils.pairhmm.Log10PairHMM
Create an uninitialized PairHMM
log10PosteriorProbabilityOfGermlineVariant(double, double, double, double, double) - Static method in class org.broadinstitute.hellbender.tools.walkers.mutect.GermlineProbabilityCalculator
 
log10PriorProbOfSomaticEvent - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
Prior log-10 probability that any given site has a somatic allele.
log10QempLikelihood(double, long, long) - Static method in class org.broadinstitute.hellbender.utils.recalibration.RecalDatum
 
log10QempPrior(double, double) - Static method in class org.broadinstitute.hellbender.utils.recalibration.RecalDatum
 
log10sumLog10(double[]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
log10sumLog10(double[], int) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
log10sumLog10(double[], int, int) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
log10SumLog10(double[], int) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
log10SumLog10(double[]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
log10SumLog10(double[], int, int) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
log10SumLog10(double, double) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
log10ToLog(double) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
log1mexp(double) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Calculates log(1-exp(a)) without losing precision.
log2(double) - Static method in class org.broadinstitute.hellbender.utils.param.ParamUtils
log the value in base 2
LOG2_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
LOG2_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
LOG_10_MATH - Static variable in class picard.util.MathUtil
 
LOG_2_MATH - Static variable in class picard.util.MathUtil
 
LOG_4_BASE_E - Static variable in class picard.util.MathUtil
Constant to convert between the natural base e and 4.0.
LOG_EMISSION_SAMPLES_PER_ROUND_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection
 
LOG_EMISSION_SAMPLING_MEDIAN_REL_ERROR_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection
 
LOG_EMISSION_SAMPLING_ROUNDS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection
 
LOG_FAILED_INTERVALS - Variable in class picard.vcf.LiftoverVcf
 
LOG_MEAN_BIAS_STANDARD_DEVIATION_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineDenoisingModelArgumentCollection
 
LOG_ONE_HALF - Static variable in class org.broadinstitute.hellbender.utils.MathUtils
 
LOG_PROB_TO_PHRED_MULTIPLIER - Static variable in class org.broadinstitute.hellbender.utils.QualityUtils
 
LOG_SOMATIC_PRIOR_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
logb(double, double) - Static method in class org.broadinstitute.hellbender.utils.param.ParamUtils
log the value in base b
logBackwardProbability(int, S) - Method in interface org.broadinstitute.hellbender.utils.hmm.ForwardBackwardAlgorithm.Result
Returns the backward probability of the hidden state at certain position.
logBackwardProbability(T, S) - Method in interface org.broadinstitute.hellbender.utils.hmm.ForwardBackwardAlgorithm.Result
Returns the backward probability of the hidden state at certain position.
logChainPosteriorProbability() - Method in interface org.broadinstitute.hellbender.utils.hmm.ForwardBackwardAlgorithm.Result
Returns the posterior probability of the hidden chain, defined as: \log \pi_i E[z_{i,0}] + \log T_{t, t+1}^{i, j} E[z_{i,t} z_{j,t+1}] This quantity is the logDataLikelihood excluding the emission probability
logConfigFields(T) - Static method in class org.broadinstitute.hellbender.utils.config.ConfigFactory
Logs all the parameters in the given Config object at Level.DEBUG
logConfigFields(T, Log.LogLevel) - Static method in class org.broadinstitute.hellbender.utils.config.ConfigFactory
Logs all the parameters in the given Config object at the given Log.LogLevel
logConstrainedProbability(int, List<Set<S>>) - Method in interface org.broadinstitute.hellbender.utils.hmm.ForwardBackwardAlgorithm.Result
Return the posterior probability of a sequence of hidden state constraints.
logConstrainedProbability(T, List<Set<S>>) - Method in interface org.broadinstitute.hellbender.utils.hmm.ForwardBackwardAlgorithm.Result
Return the posterior probability of a sequence of hidden state constraints.
logCovariatesUsed() - Method in class org.broadinstitute.hellbender.utils.recalibration.BaseRecalibrationEngine
 
logDataLikelihood() - Method in interface org.broadinstitute.hellbender.utils.hmm.ForwardBackwardAlgorithm.Result
Returns the likelihood of the original data given the model.
logDataLikelihood(int) - Method in interface org.broadinstitute.hellbender.utils.hmm.ForwardBackwardAlgorithm.Result
Returns the likelihood of the original data given the model as evaluated at a particular position.
logDataLikelihood(T) - Method in interface org.broadinstitute.hellbender.utils.hmm.ForwardBackwardAlgorithm.Result
Returns the likelihood of the original data given the model as evaluated at a particular position.
logDotProduct(ProbabilityVector) - Method in class org.broadinstitute.hellbender.utils.genotyper.ProbabilityVector
 
logEmissionProbability(D, S, T) - Method in interface org.broadinstitute.hellbender.utils.hmm.HMM
Returns the emission probability of the data given hidden state and position in the sequence.
logFinalPairedReads(JavaRDD<GATKRead>) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterEmptyLogger
 
logFinalPairedReads(JavaRDD<GATKRead>) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterFileLogger
 
logFinalPairedReads(JavaRDD<GATKRead>) - Method in interface org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterLogger
 
logForwardProbability(int, S) - Method in interface org.broadinstitute.hellbender.utils.hmm.ForwardBackwardAlgorithm.Result
Returns the forward probability of the hidden state at certain position.
logForwardProbability(T, S) - Method in interface org.broadinstitute.hellbender.utils.hmm.ForwardBackwardAlgorithm.Result
Returns the forward probability of the hidden state at certain position.
logger - Variable in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
 
logger - Variable in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKAnnotationPluginDescriptor
 
logger - Variable in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKReadFilterPluginDescriptor
 
logger - Static variable in class org.broadinstitute.hellbender.engine.ProgressMeter
 
logger - Static variable in class org.broadinstitute.hellbender.engine.ReadsDataSource
 
logger - Static variable in class org.broadinstitute.hellbender.tools.funcotator.DataSourceFuncotationFactory
Standard Logger.
logger - Static variable in class org.broadinstitute.hellbender.tools.funcotator.dataSources.cosmic.CosmicFuncotationFactory
Standard Logger.
logger - Static variable in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationFactory
Standard Logger.
logger - Static variable in class org.broadinstitute.hellbender.tools.funcotator.dataSources.vcf.VcfFuncotationFactory
Standard Logger.
logger - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.ContainsKmerReadFilter
 
logger - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBuildReferenceTaxonomyUtils
 
logger - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPairedUnpairedSplitterSpark
 
logger - Static variable in class org.broadinstitute.hellbender.tools.walkers.bqsr.BaseRecalibrator
 
logger - Static variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculator
 
logger - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
 
logger - Static variable in class org.broadinstitute.hellbender.tools.walkers.rnaseq.OverhangFixingManager
 
logger - Variable in class org.broadinstitute.hellbender.tools.walkers.vqsr.TrainingSet
 
logger - Static variable in class org.broadinstitute.hellbender.tools.walkers.vqsr.TrancheManager
 
logger - Static variable in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
 
logger - Static variable in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantRecalibratorEngine
 
logger - Static variable in class org.broadinstitute.hellbender.utils.fasta.CachingIndexedFastaSequenceFile
 
logger - Static variable in class org.broadinstitute.hellbender.utils.gcs.BucketUtils
 
logger - Static variable in class org.broadinstitute.hellbender.utils.iterators.SamReaderQueryingIterator
 
logger - Static variable in class org.broadinstitute.hellbender.utils.locusiterator.AlignmentContextIteratorBuilder
 
logger - Static variable in class org.broadinstitute.hellbender.utils.MannWhitneyU
 
logger - Static variable in class org.broadinstitute.hellbender.utils.nio.NioBam
 
logger - Static variable in class org.broadinstitute.hellbender.utils.pairhmm.PairHMM
 
logger - Static variable in class org.broadinstitute.hellbender.utils.recalibration.BaseRecalibrationEngine
 
logger - Static variable in interface org.broadinstitute.hellbender.utils.smithwaterman.SmithWatermanAligner
 
logger - Static variable in class org.broadinstitute.hellbender.utils.test.BaseTest
 
LoggingUtils - Class in org.broadinstitute.hellbender.utils
Logging utilities.
LoggingUtils() - Constructor for class org.broadinstitute.hellbender.utils.LoggingUtils
 
logItemizedWarning(Logger, Collection<?>, String) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSUtils
Prints warning message followed by a list of relevant items
logJointProbability(int, int, S, S) - Method in interface org.broadinstitute.hellbender.utils.hmm.ForwardBackwardAlgorithm.Result
Return the posterior joint probability of going from one state to another in a specified interval
LoglessPairHMM - Class in org.broadinstitute.hellbender.utils.pairhmm
 
LoglessPairHMM() - Constructor for class org.broadinstitute.hellbender.utils.pairhmm.LoglessPairHMM
 
logLikelihoodsToProbs(double[]) - Static method in class picard.util.MathUtil
Deprecated.
logMemoryStats(Log) - Method in class picard.sam.markduplicates.MarkDuplicatesWithMateCigarIterator
 
logPrimaryReads(JavaRDD<GATKRead>) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterEmptyLogger
 
logPrimaryReads(JavaRDD<GATKRead>) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterFileLogger
 
logPrimaryReads(JavaRDD<GATKRead>) - Method in interface org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterLogger
 
logPriorProbability(S, T) - Method in interface org.broadinstitute.hellbender.utils.hmm.HMM
Returns the prior probability of an state.
logProbability(int, S) - Method in interface org.broadinstitute.hellbender.utils.hmm.ForwardBackwardAlgorithm.Result
Returns the posterior probability of the hidden state at certain position.
logProbability(T, S) - Method in interface org.broadinstitute.hellbender.utils.hmm.ForwardBackwardAlgorithm.Result
Returns the posterior probability of the hidden state at certain position.
logProbability(List<S>) - Method in interface org.broadinstitute.hellbender.utils.hmm.ForwardBackwardAlgorithm.Result
Returns the posterior probability of a full sequence of hidden states given the original data and position sequences.
logProbability(int, int, S) - Method in interface org.broadinstitute.hellbender.utils.hmm.ForwardBackwardAlgorithm.Result
Returns the posterior probability that the hidden state takes on a constant value along a position interval.
logProbability(int, List<S>) - Method in interface org.broadinstitute.hellbender.utils.hmm.ForwardBackwardAlgorithm.Result
Returns the posterior probability of a sequence of hidden states starting at a particular position.
logProbability(T, List<S>) - Method in interface org.broadinstitute.hellbender.utils.hmm.ForwardBackwardAlgorithm.Result
Returns the posterior probability of a sequence of hidden states starting at a particular position.
logProbComplement(double) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Calculates the complement of a log probability.
logProbToPhred(double) - Static method in class org.broadinstitute.hellbender.utils.QualityUtils
Convert a log-probability to a phred-scaled value ( log(0.001) => 30 )
logProbToPhredScore(double, boolean, double, double, double) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Transform a log scaled probability (x) into the Phred scaled equivalent or its complement (1-x) Phred scaled equivalent.
logReadCounts(JavaRDD<GATKRead>) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSScoreFileLogger
 
logReadCounts(JavaRDD<GATKRead>) - Method in interface org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSScoreLogger
 
logReadsAfterDeduplication(JavaRDD<GATKRead>) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterEmptyLogger
 
logReadsAfterDeduplication(JavaRDD<GATKRead>) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterFileLogger
 
logReadsAfterDeduplication(JavaRDD<GATKRead>) - Method in interface org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterLogger
 
logReadsAfterHostFilter(JavaRDD<GATKRead>) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterEmptyLogger
 
logReadsAfterHostFilter(JavaRDD<GATKRead>) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterFileLogger
 
logReadsAfterHostFilter(JavaRDD<GATKRead>) - Method in interface org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterLogger
 
logReadsAfterPrealignedHostFilter(JavaRDD<GATKRead>) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterEmptyLogger
 
logReadsAfterPrealignedHostFilter(JavaRDD<GATKRead>) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterFileLogger
 
logReadsAfterPrealignedHostFilter(JavaRDD<GATKRead>) - Method in interface org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterLogger
 
logReadsAfterQualityFilter(JavaRDD<GATKRead>) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterEmptyLogger
 
logReadsAfterQualityFilter(JavaRDD<GATKRead>) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterFileLogger
 
logReadsAfterQualityFilter(JavaRDD<GATKRead>) - Method in interface org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterLogger
 
logSumExp(double...) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Computes $\log(\sum_i e^{a_i})$ trying to avoid underflow issues by using the log-sum-exp trick.
logSumExp(Collection<Double>) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
logSumLog(double, double) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
logToLog10(double) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Converts LN to LOG10
logTransitionProbability(S, T, S, T) - Method in interface org.broadinstitute.hellbender.utils.hmm.HMM
Returns the transition probability from one state to another.
longArrayCollectionSize(Collection<long[]>) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerUtils
Returns the total number of longs in the Collection
longArrayCollectionToBloomFilter(Collection<long[]>, long, double) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerUtils
Converts a Collection of Lists of Longs's into a Bloom filter
longArrayCollectionToSet(Collection<long[]>, long) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerUtils
Converts a Collection of Lists of Longs's into a Hopscotch set
LongBloomFilter - Class in org.broadinstitute.hellbender.tools.spark.utils
Bloom filter for primitive longs.
LongBloomFilter(long, double) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.LongBloomFilter
 
LongBloomFilter(Kryo, Input) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.LongBloomFilter
 
LongBloomFilter.Serializer - Class in org.broadinstitute.hellbender.tools.spark.utils
 
longHash(long) - Static method in class org.broadinstitute.hellbender.tools.spark.utils.LongHopscotchSet
 
LongHopscotchSet - Class in org.broadinstitute.hellbender.tools.spark.utils
This class is based on the HopscotchCollection and HopscotchSet classes for storing Objects.
LongHopscotchSet() - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.LongHopscotchSet
make a small LongHopscotchSet
LongHopscotchSet(int) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.LongHopscotchSet
make a LongHopscotchSet for a specified minimum capacity
LongHopscotchSet(long[]) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.LongHopscotchSet
make a LongHopscotchSet containing an initial array of values
LongHopscotchSet(Kryo, Input) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.LongHopscotchSet
 
LongHopscotchSet.Serializer - Class in org.broadinstitute.hellbender.tools.spark.utils
 
LongIterator - Interface in org.broadinstitute.hellbender.tools.spark.utils
Iterator-like interface for collections of primitive long's
longLaneStr(int) - Static method in class picard.illumina.parser.IlluminaFileUtil
 
LOOKAHEAD_CACHE_IN_BP_DEFAULT_VALUE - Static variable in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorArgumentDefinitions
 
LOOKAHEAD_CACHE_IN_BP_NAME - Static variable in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorArgumentDefinitions
 
lookaheadFeatureCachingInBp - Variable in class org.broadinstitute.hellbender.tools.funcotator.Funcotator
 
LOSS_OF_HET_RATE - Variable in class picard.fingerprint.CrosscheckFingerprints
 
LOW_COVERAGE_LOCI - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
LOW_COVERAGE_RATIO_THRESHOLD_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.contamination.CalculateContamination
 
LOW_MQ_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
LOW_QUAL_FILTER_NAME - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
LOW_QUAL_TAIL - Variable in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationArgumentCollection
Reads with low quality bases on either tail (beginning or end) will not be considered in the context.
LOW_QUALITY_OR_LOW_COMPLEXITY_READS_FILTERED - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterMetrics
The number of reads filtered because they were low-quality or low-complexity
LOW_VQSLOD_FILTER_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.vqsr.ApplyVQSR
 
LowWeightChainPruner<V extends BaseVertex,E extends BaseEdge> - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs
Prune all chains from this graph where all edges in the path have multiplicity < pruneFactor Unlike pruneGraph, this function will remove only linear chains in the graph where all edges have weight < pruneFactor.
LowWeightChainPruner(int) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.LowWeightChainPruner
 
LRUCache<K,V> - Class in org.broadinstitute.hellbender.utils
An LRU cache implemented as an extension to LinkedHashMap
LRUCache(int) - Constructor for class org.broadinstitute.hellbender.utils.LRUCache
 

M

M2ArgumentCollection - Class in org.broadinstitute.hellbender.tools.walkers.mutect
 
M2ArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
M2FiltersArgumentCollection - Class in org.broadinstitute.hellbender.tools.walkers.mutect
 
M2FiltersArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
MACHINE_NAME - Variable in class picard.illumina.IlluminaBasecallsToFastq
 
MAD_COVERAGE - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The median absolute deviation of coverage of the genome after all filters are applied.
MafOutputRenderer - Class in org.broadinstitute.hellbender.tools.funcotator.mafOutput
A Funcotator output renderer for writing to MAF files.
MafOutputRenderer(Path, List<DataSourceFuncotationFactory>, VCFHeader, LinkedHashMap<String, String>, LinkedHashMap<String, String>, Set<String>) - Constructor for class org.broadinstitute.hellbender.tools.funcotator.mafOutput.MafOutputRenderer
Main - Class in org.broadinstitute.hellbender
This is the main class of Hellbender and is the way of executing individual command line programs.
Main() - Constructor for class org.broadinstitute.hellbender.Main
 
main(String[]) - Static method in class org.broadinstitute.hellbender.Main
The entry point to GATK from commandline.
main(String[]) - Static method in class picard.analysis.CollectAlignmentSummaryMetrics
Required main method implementation.
main(String[]) - Static method in class picard.analysis.CollectBaseDistributionByCycle
 
main(String[]) - Static method in class picard.analysis.CollectGcBiasMetrics
 
main(String[]) - Static method in class picard.analysis.CollectInsertSizeMetrics
Required main method implementation.
main(String[]) - Static method in class picard.analysis.CollectJumpingLibraryMetrics
Stock main method.
main(String[]) - Static method in class picard.analysis.CollectMultipleMetrics
 
main(String[]) - Static method in class picard.analysis.CollectRnaSeqMetrics
Required main method implementation.
main(String[]) - Static method in class picard.analysis.CollectRrbsMetrics
 
main(String[]) - Static method in class picard.analysis.CollectWgsMetrics
 
main(String[]) - Static method in class picard.analysis.CollectWgsMetricsWithNonZeroCoverage
 
main(String[]) - Static method in class picard.analysis.CompareMetrics
 
main(String[]) - Static method in class picard.analysis.directed.CollectHsMetrics
Stock main method.
main(String[]) - Static method in class picard.analysis.directed.CollectTargetedPcrMetrics
Stock main method.
main(String[]) - Static method in class picard.analysis.MeanQualityByCycle
Required main method.
main(String[]) - Static method in class picard.analysis.QualityScoreDistribution
Required main method.
main(String[]) - Static method in class picard.cmdline.PicardCommandLine
Override this if you want to include different java packages to search for classes that extend CommandLineProgram.
main(String[]) - Static method in class picard.fastq.BamToBfq
 
main(String[]) - Static method in class picard.illumina.CheckIlluminaDirectory
Required main method implementation.
main(String[]) - Static method in class picard.illumina.CollectIlluminaBasecallingMetrics
 
main(String[]) - Static method in class picard.illumina.CollectIlluminaLaneMetrics
 
main(String[]) - Static method in class picard.illumina.ExtractIlluminaBarcodes
 
main(String[]) - Static method in class picard.illumina.IlluminaBasecallsToFastq
 
main(String[]) - Static method in class picard.illumina.IlluminaBasecallsToSam
 
main(String[]) - Static method in class picard.illumina.MarkIlluminaAdapters
 
main(String[]) - Static method in class picard.illumina.quality.CollectHiSeqXPfFailMetrics
Stock main method.
main(String[]) - Static method in class picard.reference.ExtractSequences
 
main(String[]) - Static method in class picard.reference.NonNFastaSize
 
main(String[]) - Static method in class picard.reference.NormalizeFasta
 
main(String[]) - Static method in class picard.sam.AddCommentsToBam
 
main(String[]) - Static method in class picard.sam.BamIndexStats
Stock main method for a command line program.
main(String[]) - Static method in class picard.sam.BuildBamIndex
Stock main method for a command line program.
main(String[]) - Static method in class picard.sam.CalculateReadGroupChecksum
 
main(String[]) - Static method in class picard.sam.CheckTerminatorBlock
 
main(String[]) - Static method in class picard.sam.CleanSam
 
main(String[]) - Static method in class picard.sam.CompareSAMs
 
main(String[]) - Static method in class picard.sam.CreateSequenceDictionary
 
main(String[]) - Static method in class picard.sam.DuplicationMetrics
 
main(String[]) - Static method in class picard.sam.FastqToSam
Stock main method.
main(String[]) - Static method in class picard.sam.FixMateInformation
 
main(String[]) - Static method in class picard.sam.GatherBamFiles
 
main(String[]) - Static method in class picard.sam.markduplicates.EstimateLibraryComplexity
Stock main method.
main(String[]) - Static method in class picard.sam.markduplicates.MarkDuplicates
Stock main method.
main(String[]) - Static method in class picard.sam.markduplicates.MarkDuplicatesWithMateCigar
Stock main method.
main(String[]) - Static method in class picard.sam.markduplicates.SimpleMarkDuplicatesWithMateCigar
Stock main method.
main(String[]) - Static method in class picard.sam.MergeSamFiles
Required main method implementation.
main(String[]) - Static method in class picard.sam.ReplaceSamHeader
 
main(String[]) - Static method in class picard.sam.RevertOriginalBaseQualitiesAndAddMateCigar
Default main method impl.
main(String[]) - Static method in class picard.sam.SamFormatConverter
 
main(String[]) - Static method in class picard.sam.SamToFastq
 
main(String[]) - Static method in class picard.sam.SetNmMdAndUqTags
 
main(String[]) - Static method in class picard.sam.SplitSamByLibrary
 
main(String[]) - Static method in class picard.sam.ValidateSamFile
 
main(String[]) - Static method in class picard.sam.ViewSam
 
main(String[]) - Static method in class picard.Test
 
main(String[]) - Static method in class picard.util.BaitDesigner
Stock main method.
main(String[]) - Static method in class picard.util.BedToIntervalList
 
main(String[]) - Static method in class picard.util.FifoBuffer
 
main(String[]) - Static method in class picard.util.ScatterIntervalsByNs
 
main(String[]) - Static method in class picard.vcf.CollectVariantCallingMetrics
 
main(String[]) - Static method in class picard.vcf.filter.FilterVcf
 
main(String[]) - Static method in class picard.vcf.FixVcfHeader
 
main(String[]) - Static method in class picard.vcf.GatherVcfs
 
main(String[]) - Static method in class picard.vcf.GenotypeConcordance
 
main(String[]) - Static method in class picard.vcf.MakeSitesOnlyVcf
 
main(String[]) - Static method in class picard.vcf.MergeVcfs
 
main(String[]) - Static method in class picard.vcf.RenameSampleInVcf
 
main(String[]) - Static method in class picard.vcf.SortVcf
 
main(String[]) - Static method in class picard.vcf.SplitVcfs
 
main(String[]) - Static method in class picard.vcf.UpdateVcfSequenceDictionary
 
main(String[]) - Static method in class picard.vcf.VcfFormatConverter
 
main(String[]) - Static method in class picard.vcf.VcfToIntervalList
 
mainEntry(String[]) - Method in class org.broadinstitute.hellbender.Main
The entry point to the toolkit from commandline: it uses Main.instanceMain(String[]) to run the command line program and handle the returned object with Main.handleResult(Object), and exit with 0.
makeAllReadCollector() - Method in class org.broadinstitute.hellbender.metrics.MultiLevelCollector
 
makeAllReadCollector() - Method in class org.broadinstitute.hellbender.metrics.MultiLevelReducibleCollector
These are exposed here (rather than being encapsulated in the Distributor subclasses below in order to provide subclasses with an explicit point to add initialization (specific to accumulation level) for a PerUnitMetricCollector it is creating.
makeAllReadCollector() - Method in class picard.analysis.directed.TargetMetricsCollector
 
makeAllReadCollector() - Method in class picard.metrics.MultiLevelCollector
 
makeAnnotatedCall(byte[], SimpleInterval, FeatureContext, SAMFileHeader, VariantContext, ReadLikelihoods<Allele>, VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerGenotypingEngine
 
makeArg(SAMRecord, ReferenceSequence) - Method in class org.broadinstitute.hellbender.metrics.InsertSizeMetricsCollector
 
makeArg(SAMRecord, ReferenceSequence) - Method in class org.broadinstitute.hellbender.metrics.MultiLevelCollector
 
makeArg(SAMRecord, ReferenceSequence) - Method in class org.broadinstitute.hellbender.metrics.MultiLevelReducibleCollector
Convert the current SAMRecord and the ReferenceSequence for that record into an ARGTYPE object.
makeArg(SAMRecord, ReferenceSequence) - Method in class org.broadinstitute.hellbender.metrics.SAMRecordAndReferenceMultiLevelCollector
 
makeArg(SAMRecord, ReferenceSequence) - Method in class org.broadinstitute.hellbender.metrics.SAMRecordMultiLevelCollector
 
makeArg(SAMRecord, ReferenceSequence) - Method in class org.broadinstitute.hellbender.tools.examples.metrics.multi.ExampleMultiMetricsCollector
Process the record and create a collector args object to hold the results of any calculation for re-use across multiple levels.
makeArg(SAMRecord, ReferenceSequence) - Method in class picard.analysis.directed.InsertSizeMetricsCollector
 
makeArg(SAMRecord, ReferenceSequence) - Method in class picard.analysis.GcBiasMetricsCollector
 
makeArg(SAMRecord, ReferenceSequence) - Method in class picard.metrics.MultiLevelCollector
 
makeArg(SAMRecord, ReferenceSequence) - Method in class picard.metrics.SAMRecordAndReferenceMultiLevelCollector
 
makeArg(SAMRecord, ReferenceSequence) - Method in class picard.metrics.SAMRecordMultiLevelCollector
 
makeBAMFile(File) - Method in class org.broadinstitute.hellbender.utils.read.ArtificialBAMBuilder
Write the reads from this builder to output, creating an index as well
makeBarcodeRegex(int) - Static method in class picard.illumina.parser.ParameterizedFileUtil
 
makeBlock(VariantContext, VariantContext) - Method in class org.broadinstitute.hellbender.utils.haplotype.EventMap
Create a block substitution out of two variant contexts that start at the same position vc1 can be SNP, and vc2 can then be either a insertion or deletion.
makeCalls() - Method in class org.broadinstitute.hellbender.tools.copynumber.caller.SimpleCopyRatioCaller
 
makeChildCollector(String, String, String) - Method in class org.broadinstitute.hellbender.metrics.InsertSizeMetricsCollector
 
makeChildCollector(String, String, String) - Method in class org.broadinstitute.hellbender.metrics.MultiLevelCollector
Construct a PerUnitMetricCollector with the given arguments.
makeChildCollector(String, String, String) - Method in class org.broadinstitute.hellbender.metrics.MultiLevelReducibleCollector
Construct a PerUnitMetricCollector with the given arguments.
makeChildCollector(String, String, String) - Method in class org.broadinstitute.hellbender.tools.examples.metrics.multi.ExampleMultiMetricsCollector
Make an PerUnitExampleMultiMetricsCollector with the given arguments
makeChildCollector(String, String, String) - Method in class picard.analysis.AlignmentSummaryMetricsCollector
 
makeChildCollector(String, String, String) - Method in class picard.analysis.directed.InsertSizeMetricsCollector
Make an InsertSizeCollector with the given arguments
makeChildCollector(String, String, String) - Method in class picard.analysis.directed.RnaSeqMetricsCollector
 
makeChildCollector(String, String, String) - Method in class picard.analysis.directed.TargetMetricsCollector
 
makeChildCollector(String, String, String) - Method in class picard.analysis.GcBiasMetricsCollector
 
makeChildCollector(String, String, String) - Method in class picard.analysis.RrbsMetricsCollector
 
makeChildCollector(String, String, String) - Method in class picard.metrics.MultiLevelCollector
Construct a PerUnitMetricCollector with the given arguments.
makeCollector(Set<MetricAccumulationLevel>, List<SAMReadGroupRecord>, ReferenceSequenceFile, File, File, IntervalList, IntervalList, String, int) - Method in class picard.analysis.directed.CollectHsMetrics
 
makeCollector(Set<MetricAccumulationLevel>, List<SAMReadGroupRecord>, ReferenceSequenceFile, File, File, IntervalList, IntervalList, String, int) - Method in class picard.analysis.directed.CollectTargetedMetrics
A factory method for the TargetMetricsCollector to use this time.
makeCollector(Set<MetricAccumulationLevel>, List<SAMReadGroupRecord>, ReferenceSequenceFile, File, File, IntervalList, IntervalList, String, int) - Method in class picard.analysis.directed.CollectTargetedPcrMetrics
 
makeCombinedAnnotationString(List<Allele>, Map<Allele, Histogram>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RankSumTest
 
makeCommandLineArgs(List<String>) - Method in interface org.broadinstitute.hellbender.utils.test.CommandLineProgramTester
For testing support.
makeCommandLineArgs(List<String>, String) - Method in interface org.broadinstitute.hellbender.utils.test.CommandLineProgramTester
For testing support.
makeCycleFileParser(List<File>, PerTileCycleParser.CycleFilesParser<BclData>) - Method in class picard.illumina.parser.MultiTileBclParser
 
makeCycleFileParser(List<File>) - Method in class picard.illumina.parser.MultiTileBclParser
 
makeDataProvider(List<File>, List<AbstractIlluminaPositionFileReader.PositionInfo>, File[], int, File) - Method in class picard.illumina.parser.IlluminaDataProviderFactory
Call this method to create a ClusterData iterator over all clusters for a given tile.
makeDataProvider() - Method in class picard.illumina.parser.IlluminaDataProviderFactory
 
makeDataProvider(List<Integer>) - Method in class picard.illumina.parser.IlluminaDataProviderFactory
Call this method to create a ClusterData iterator over the specified tiles.
makeEvalVariantFilter() - Method in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker
 
makeExceptionMsg() - Method in class picard.illumina.parser.readers.AbstractIlluminaPositionFileReader
Create a string that will be included in any NoSuchElementException thrown by the next() method
makeExceptionMsg() - Method in class picard.illumina.parser.readers.ClocsFileReader
 
makeExceptionMsg() - Method in class picard.illumina.parser.readers.LocsFileReader
 
makeExceptionMsg() - Method in class picard.illumina.parser.readers.PosFileReader
 
makeFilePathAbsolute(String) - Static method in class org.broadinstitute.hellbender.utils.gcs.BucketUtils
Changes relative local file paths to be absolute file paths.
makeFilteredPileup(Predicate<PileupElement>) - Method in class org.broadinstitute.hellbender.utils.pileup.ReadPileup
Make a new pileup consisting of elements of this pileup that satisfy the predicate.
makeFinalizedAnnotationString(int, Map<Allele, Double>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.RMSMappingQuality
 
makeFromAlleles(String, String, int, List<String>) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
For testing purposes only.
makeGenomicsDBUri(File) - Static method in class org.broadinstitute.hellbender.utils.test.GenomicsDBTestUtils
 
makeGenotypeCall(int, GenotypeBuilder, GenotypeAssignmentMethod, double[], List<Allele>) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Add the genotype call (GT) field to GenotypeBuilder using the requested GenotypeAssignmentMethod
makeIgnoredSequenceIndicesSet(SAMFileHeader, Set<String>) - Static method in class picard.analysis.directed.RnaSeqMetricsCollector
 
makeIndexableSourceFromStream(InputStream) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfCodec
 
makeIndexableSourceFromStream(InputStream) - Method in class org.broadinstitute.hellbender.utils.codecs.ProgressReportingDelegatingCodec
 
makeInstance(String, String, File, File, Set<MetricAccumulationLevel>, File, File, boolean) - Method in interface picard.analysis.CollectMultipleMetrics.ProgramInterface
By default, this method calls the CollectMultipleMetrics.ProgramInterface.makeInstance(String, String, File, File, Set, File, File) method without 'includeUnpaired' parameter.
makeInstance(String, String, File, File, Set<MetricAccumulationLevel>, File, File) - Method in interface picard.analysis.CollectMultipleMetrics.ProgramInterface
 
makeInstancesOfSubclasses(Class<? extends T>, Package) - Static method in class org.broadinstitute.hellbender.utils.ClassUtils
Finds and creates objects of all concrete subclasses of the given class in the package.
makeInterpretation(JavaRDD<AssemblyContigWithFineTunedAlignments>, SvDiscoveryInputMetaData) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.CpxVariantInterpreter
 
makeInterpretation(JavaRDD<AssemblyContigWithFineTunedAlignments>, SvDiscoveryInputMetaData) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SimpleNovelAdjacencyInterpreter
 
makeIntervalArgumentCollection() - Method in class picard.analysis.CollectWgsMetrics
 
makeItSo(File, File, boolean, long, Collection<SinglePassSamProgram>) - Static method in class picard.analysis.SinglePassSamProgram
 
makeItSo(FastqReader, FastqReader, SAMFileWriter) - Method in class picard.sam.FastqToSam
Handles the FastqToSam execution on the FastqReader(s).
makeKernel(int, double) - Static method in class org.broadinstitute.hellbender.utils.activityprofile.BandPassActivityProfile
 
makeLaneTileRegex(String, int) - Static method in class picard.illumina.parser.ParameterizedFileUtil
Return a regex string for finding Lane and Tile given a file extension pattern
makeLibraryCollector(SAMReadGroupRecord) - Method in class org.broadinstitute.hellbender.metrics.MultiLevelCollector
 
makeLibraryCollector(SAMReadGroupRecord) - Method in class org.broadinstitute.hellbender.metrics.MultiLevelReducibleCollector
 
makeLibraryCollector(SAMReadGroupRecord) - Method in class picard.metrics.MultiLevelCollector
 
makeMergedVariantContext(List<VariantContext>) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerUtils
 
makeNewHMM(PairHMMNativeArguments) - Method in enum org.broadinstitute.hellbender.utils.pairhmm.PairHMM.Implementation
 
makeOREdge(Collection<BaseEdge>, int) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseEdge
Create a new BaseEdge with the given multiplicity.
makeOverlapDetector(File, SAMFileHeader, File, Log) - Static method in class picard.analysis.directed.RnaSeqMetricsCollector
 
makePermutations(List<T>, int, boolean) - Static method in class org.broadinstitute.hellbender.utils.Utils
Make all combinations of N size of objects if objects = [A, B, C] if N = 1 => [[A], [B], [C]] if N = 2 => [[A, A], [B, A], [C, A], [A, B], [B, B], [C, B], [A, C], [B, C], [C, C]]
makePhredBinaryFromSolexaQualityAscii_1_3(String) - Static method in class picard.util.IlluminaUtil
Convert from Solexa-scaled ASCII qualities to Phred-scaled binary.
makePhredBinaryFromSolexaQualityAscii_1_3(String, int, int) - Static method in class picard.util.IlluminaUtil
Convert from Solexa-scaled ASCII qualities to Phred-scaled binary.
makePileupElement() - Method in class org.broadinstitute.hellbender.utils.locusiterator.AlignmentStateMachine
Create a new PileupElement based on the current state of this element Must not be a left or right edge
makePostReadFilterTransformer() - Method in class org.broadinstitute.hellbender.engine.GATKTool
Returns the post-filter read transformer (simple or composite) that will be applied to the reads after filtering.
makePostReadFilterTransformer() - Method in class org.broadinstitute.hellbender.tools.walkers.bqsr.ApplyBQSR
Returns the BQSR post-transformer.
makePostReadFilterTransformer() - Method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.SplitNCigarReads
 
makePreReadFilterTransformer() - Method in class org.broadinstitute.hellbender.engine.GATKTool
Returns the pre-filter read transformer (simple or composite) that will be applied to the reads before filtering.
makePreReadFilterTransformer() - Method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.SplitNCigarReads
 
makePrintStreamMaybeGzipped(File) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
Makes a print stream for a file, gzipping on the fly if the file's name ends with '.gz'.
makeQualityScoreTable() - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationTables
Allocate a new quality score table, based on requested parameters in this set of tables, without any data in it.
makeRawAnnotationString(List<Allele>, Map<Allele, Double>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RankSumTest
 
makeRawAnnotationString(List<Allele>, Map<Allele, List<Integer>>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_StrandBiasTest
 
makeRawAnnotationString(List<Allele>, Map<Allele, Number>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.RMSMappingQuality
 
makeRead(String, KV<Integer, Integer>, int, Class<?>) - Static method in class org.broadinstitute.hellbender.utils.test.ReadsPreprocessingPipelineTestData
makeRead creates a read backed by either SAMRecord or Google model Read.
makeRead(String, int, int, int, Class<?>) - Static method in class org.broadinstitute.hellbender.utils.test.ReadsPreprocessingPipelineTestData
makeRead creates a read backed by either SAMRecord or Google model Read.
makeReaderMaybeGzipped(File) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
Makes a reader for a file, unzipping if the file's name ends with '.gz'.
makeReaderMaybeGzipped(InputStream, boolean) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
makes a reader for an inputStream wrapping it in an appropriate unzipper if necessary
makeReadFilter() - Method in class org.broadinstitute.hellbender.engine.GATKTool
Returns a read filter (simple or composite) that can be applied to reads.
makeReadFilter() - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
Returns a read filter (simple or composite) that can be applied to the reads returned from GATKSparkTool.getReads().
makeReadFilter(SAMFileHeader) - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
Like GATKSparkTool.makeReadFilter() but with the ability to pass a different SAMFileHeader.
makeReadFromCigar(String) - Static method in class org.broadinstitute.hellbender.utils.test.ReadClipperTestUtils
Make a read from the CIGAR string
makeReadFromCigar(Cigar) - Static method in class org.broadinstitute.hellbender.utils.test.ReadClipperTestUtils
Make a read from the CIGAR.
makeReadFromCigar(String, int) - Static method in class org.broadinstitute.hellbender.utils.test.ReadClipperTestUtils
Make a read from the CIGAR
makeReadGroupCollector(SAMReadGroupRecord) - Method in class org.broadinstitute.hellbender.metrics.MultiLevelCollector
 
makeReadGroupCollector(SAMReadGroupRecord) - Method in class org.broadinstitute.hellbender.metrics.MultiLevelReducibleCollector
 
makeReadGroupCollector(SAMReadGroupRecord) - Method in class picard.metrics.MultiLevelCollector
 
makeReads() - Method in class org.broadinstitute.hellbender.utils.read.ArtificialBAMBuilder
Create a read stream based on the parameters.
makeReducedAnnotationString(VariantContext, Map<Allele, Double>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_StrandBiasTest
 
makeReferenceArgumentCollection() - Method in class picard.analysis.CollectAlignmentSummaryMetrics
 
makeReferenceArgumentCollection() - Method in class picard.analysis.CollectRrbsMetrics
 
makeReferenceArgumentCollection() - Method in class picard.cmdline.CommandLineProgram
 
makeReferenceArgumentCollection() - Method in class picard.sam.CreateSequenceDictionary
 
makeReferenceArgumentCollection() - Method in class picard.sam.DownsampleSam
 
makeReferenceArgumentCollection() - Method in class picard.sam.ReorderSam
 
makeReferenceArgumentCollection() - Method in class picard.util.ScatterIntervalsByNs
 
makeReferenceArgumentCollection() - Method in class picard.vcf.LiftoverVcf
 
makeReferenceShardBoundaryReads(int, int, Class<?>) - Static method in class org.broadinstitute.hellbender.utils.test.ReadsPreprocessingPipelineTestData
Generates a List of artificial reads located in significant positions relative to reference shard boundaries.
makeSampleCollector(SAMReadGroupRecord) - Method in class org.broadinstitute.hellbender.metrics.MultiLevelCollector
 
makeSampleCollector(SAMReadGroupRecord) - Method in class org.broadinstitute.hellbender.metrics.MultiLevelReducibleCollector
 
makeSampleCollector(SAMReadGroupRecord) - Method in class picard.metrics.MultiLevelCollector
 
makeSeekable(List<File>, BclQualityEvaluationStrategy, int[]) - Static method in class picard.illumina.parser.readers.BclReader
 
makeSequenceDictionary(File) - Method in class picard.sam.CreateSequenceDictionary
Deprecated.
MakeSitesOnlyVcf - Class in picard.vcf
Creates a VCF that contains all the site-level information for all records in the input VCF but no genotype information.
MakeSitesOnlyVcf() - Constructor for class picard.vcf.MakeSitesOnlyVcf
 
makeSourceFromStream(InputStream) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfCodec
 
makeSourceFromStream(InputStream) - Method in class org.broadinstitute.hellbender.utils.codecs.ProgressReportingDelegatingCodec
 
makeStandardHCReadFilters() - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerEngine
 
makeStandardMutect2ReadFilters() - Static method in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2Engine
 
makeTemporaryBAMFile() - Method in class org.broadinstitute.hellbender.utils.read.ArtificialBAMBuilder
Make an indexed BAM file contains the reads in the builder, marking it for deleteOnExit()
makeTileIterator(File) - Method in class picard.illumina.parser.PerTileParser
Factory method for the iterator of each tile
makeTileIterator(File) - Method in class picard.illumina.parser.PosParser
Make an CloseableIterator based on the given file and fileType specified at construction.
makeTruthVariantFilter() - Method in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker
 
makeTruthVariantFilter() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.Concordance
 
makeValueObjectForAnnotation(int[][]) - Static method in class org.broadinstitute.hellbender.tools.walkers.annotator.FisherStrand
 
makeValueObjectForAnnotation(double) - Static method in class org.broadinstitute.hellbender.tools.walkers.annotator.FisherStrand
 
makeVariantAnnotations() - Method in class org.broadinstitute.hellbender.engine.GATKTool
Returns a list of annotations that can be applied to VariantContexts.
makeVariantAnnotations() - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
 
makeVariantAnnotations() - Method in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark
 
makeVariantAnnotations() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.ReadsPipelineSpark
 
makeVariantAnnotations() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCaller
If we are in reference confidence mode we want to filter the annotations as there are certain annotations in the standard HaplotypeCaller set which are no longer relevant, thus we filter them out before constructing the VariantAnnotationEngine because the user args will have been parsed by that point.
makeVariantFilter() - Method in class org.broadinstitute.hellbender.engine.spark.VariantWalkerSpark
Returns the variant filter (simple or composite) that will be applied to the variants before calling VariantWalkerSpark.getVariants(org.apache.spark.api.java.JavaSparkContext).
makeVariantFilter() - Method in class org.broadinstitute.hellbender.engine.VariantWalkerBase
makeVariantFilter() - Method in class org.broadinstitute.hellbender.tools.walkers.variantutils.SelectVariants
Create filters for variant types, ids, and genomic intervals.
makeVariantFilter() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.CNNScoreVariants
 
makeVCFHeader(SAMSequenceDictionary, Set<VCFHeaderLine>) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerEngine
Create a VCF header.
makeVCFWriter(String, SAMSequenceDictionary, boolean, boolean, boolean) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerEngine
Create a VCF or GVCF writer as appropriate, given our arguments
makeVectorTable(String, String, List<String>, double[], String, String) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantRecalibrator
 
makeZippedInputStream(InputStream) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
creates an input stream from a zipped stream
MALE_CHROMS - Variable in class picard.vcf.MendelianViolations.FindMendelianViolations
 
MalformedBAM(GATKRead, String) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.MalformedBAM
 
MalformedBAM(File, String) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.MalformedBAM
 
MalformedBAM(String, String) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.MalformedBAM
 
MalformedFile(String) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.MalformedFile
 
MalformedFile(File, String) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.MalformedFile
 
MalformedFile(File, String, Exception) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.MalformedFile
 
MalformedFile(Path, String) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.MalformedFile
 
MalformedFile(Path, String, Exception) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.MalformedFile
 
MalformedGenomeLoc(String) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.MalformedGenomeLoc
 
MalformedGenomeLoc(String, Exception) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.MalformedGenomeLoc
 
MalformedRead(GATKRead, String) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.MalformedRead
 
MalformedRead(String, String) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.MalformedRead
 
MANDATORY_PROPERTIES - Static variable in class org.broadinstitute.hellbender.engine.spark.SparkContextFactory
GATK will not run without these properties They will always be set unless explicitly overridden with StandardArgumentDefinitions.SPARK_PROPERTY_NAME
MannWhitneyU - Class in org.broadinstitute.hellbender.utils
Imported with changes from Picard private.
MannWhitneyU() - Constructor for class org.broadinstitute.hellbender.utils.MannWhitneyU
 
MannWhitneyU.RankedData - Class in org.broadinstitute.hellbender.utils
The ranked data in one list and a list of the number of ties.
MannWhitneyU.Result - Class in org.broadinstitute.hellbender.utils
The results of performing a rank sum test.
MannWhitneyU.TestStatistic - Class in org.broadinstitute.hellbender.utils
The values of U1, U2 and the transformed number of ties needed for the calculation of sigma in the normal approximation.
MannWhitneyU.TestType - Enum in org.broadinstitute.hellbender.utils
A variable that indicates if the test is one sided or two sided and if it's one sided which group is the dominator in the null hypothesis.
manualAnnotations - Variable in class org.broadinstitute.hellbender.tools.funcotator.OutputRenderer
LinkedHashMap of manually specified annotations to add to each output in addition to annotations provided to OutputRenderer.write(VariantContext, List).
manualAnnotationSerializedString - Variable in class org.broadinstitute.hellbender.tools.funcotator.OutputRenderer
String representation of OutputRenderer.manualAnnotations serialized to the output format of this OutputRenderer.
MAP_ALLELE_FRACTIONS_KEY - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.StrandArtifact
 
MAP_NAME_VALUE_DELIMITER - Static variable in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorArgumentDefinitions
 
MAP_QUAL_RANK_SUM_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
MAPPED - Static variable in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary
 
MAPPED_READS - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSScoreMetrics
The number of non-host reads mapped to a pathogen
mappedAndUnmappedReadIterator(int, int, int, int) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
create an iterator containing the specified read piles
MappedReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.MappedReadFilter
 
mappedReadIterator(int, int, int) - Static method in class org.broadinstitute.hellbender.utils.read.ArtificialReadUtils
create an iterator containing the specified read piles
Mapping(String) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils.Mapping
 
Mapping(GATKRead) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils.Mapping
 
MAPPING_ERROR_RATE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineContigPloidyModelArgumentCollection
 
MAPPING_ERROR_RATE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineDenoisingModelArgumentCollection
 
MAPPING_QUALITIES - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
MAPPING_QUALITY_AVAILABLE - Static variable in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary
 
MAPPING_QUALITY_NOT_ZERO - Static variable in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary
 
MAPPING_QUALITY_UNAVAILABLE - Static variable in class org.broadinstitute.hellbender.utils.QualityUtils
 
MAPPING_QUALITY_ZERO_BY_SAMPLE_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
MappingQuality - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Median mapping quality of reads supporting each alt allele.
MappingQuality() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.MappingQuality
 
MappingQualityAvailableReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.MappingQualityAvailableReadFilter
 
MappingQualityNotZeroReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.MappingQualityNotZeroReadFilter
 
MappingQualityRankSumTest - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Rank Sum Test for mapping qualities of REF versus ALT reads
MappingQualityRankSumTest() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.MappingQualityRankSumTest
 
MappingQualityReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Keep only reads with mapping qualities within a specified range.
MappingQualityReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.MappingQualityReadFilter
 
MappingQualityReadFilter(int) - Constructor for class org.broadinstitute.hellbender.engine.filters.MappingQualityReadFilter
 
MappingQualityReadFilter(int, Integer) - Constructor for class org.broadinstitute.hellbender.engine.filters.MappingQualityReadFilter
 
MappingQualityReadTransformer - Class in org.broadinstitute.hellbender.transformers
A read transformer to modify the mapping quality of reads with MQ=255 to reads with MQ=60
MappingQualityReadTransformer(int, int) - Constructor for class org.broadinstitute.hellbender.transformers.MappingQualityReadTransformer
 
MappingQualityZero - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Count of all reads with MAPQ = 0 across all samples
MappingQualityZero() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.MappingQualityZero
 
mapQual - Variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
Mapping quality, SAMRecord.NO_MAPPING_QUALITY if unspecified.
mapQualTieBreaker - Static variable in class org.broadinstitute.hellbender.utils.pileup.ReadPileup
 
mapToDouble(IntToDoubleFunction) - Method in class org.broadinstitute.hellbender.utils.IndexRange
Apply an int -> double function to this range, producing a double[]
mapToInteger(IntUnaryOperator) - Method in class org.broadinstitute.hellbender.utils.IndexRange
Apply an int -> int function to this range, producing an int[]
margin - Static variable in class org.broadinstitute.hellbender.engine.spark.AddContextDataToReadSparkOptimized
 
marginalize(Map<B, List<A>>) - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Perform marginalization from an allele set to another (smaller one) taking the maximum value for each read in the original allele subset.
marginalize(Map<B, List<A>>, Locatable) - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Perform marginalization from an allele set to another (smaller one) taking the maximum value for each read in the original allele subset.
mark(JavaRDD<GATKRead>, SAMFileHeader, MarkDuplicatesScoringStrategy, OpticalDuplicateFinder, int, boolean) - Static method in class org.broadinstitute.hellbender.tools.spark.transforms.markduplicates.MarkDuplicatesSpark
Main method for marking duplicates, takes an JavaRDD of GATKRead and an associated SAMFileHeader with corresponding sorting information and returns a new JavaRDD\ in which all read templates have been marked as duplicates NOTE: This method expects the incoming reads to be grouped by read name (queryname sorted/querygrouped) and for this to be explicitly be set in the the provided header.
MarkDuplicates - Class in picard.sam.markduplicates
A better duplication marking algorithm that handles all cases including clipped and gapped alignments.
MarkDuplicates() - Constructor for class picard.sam.markduplicates.MarkDuplicates
 
MarkDuplicates.DuplicateTaggingPolicy - Enum in picard.sam.markduplicates
Enum used to control how duplicates are flagged in the DT optional tag on each read.
MarkDuplicates.DuplicateType - Enum in picard.sam.markduplicates
Enum for the possible values that a duplicate read can be tagged with in the DT attribute.
MarkDuplicatesGATK - Class in org.broadinstitute.hellbender.tools.walkers.markduplicates
A better duplication marking algorithm that handles all cases including clipped and gapped alignments.
MarkDuplicatesGATK() - Constructor for class org.broadinstitute.hellbender.tools.walkers.markduplicates.MarkDuplicatesGATK
 
MarkDuplicatesScoringStrategy - Enum in org.broadinstitute.hellbender.utils.read.markduplicates
This class helps us compute and compare duplicate scores, which are used for selecting the non-duplicate during duplicate marking (see MarkDuplicatesGATK).
MarkDuplicatesSpark - Class in org.broadinstitute.hellbender.tools.spark.transforms.markduplicates
 
MarkDuplicatesSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.transforms.markduplicates.MarkDuplicatesSpark
 
MarkDuplicatesSparkArgumentCollection - Class in org.broadinstitute.hellbender.cmdline.argumentcollections
An argument collection for use with tools that mark optical duplicates.
MarkDuplicatesSparkArgumentCollection() - Constructor for class org.broadinstitute.hellbender.cmdline.argumentcollections.MarkDuplicatesSparkArgumentCollection
 
markDuplicatesSparkArgumentCollection - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.BwaAndMarkDuplicatesPipelineSpark
 
markDuplicatesSparkArgumentCollection - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.ReadsPipelineSpark
 
markDuplicatesSparkArgumentCollection - Variable in class org.broadinstitute.hellbender.tools.spark.transforms.markduplicates.MarkDuplicatesSpark
 
MarkDuplicatesSparkRecord - Class in org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords
A common interface for the data types that represent reads for mark duplicates spark.
MarkDuplicatesSparkRecord.Type - Enum in org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords
 
MarkDuplicatesSparkUtils - Class in org.broadinstitute.hellbender.tools.spark.transforms.markduplicates
Utility classes and functions for Mark Duplicates.
MarkDuplicatesSparkUtils() - Constructor for class org.broadinstitute.hellbender.tools.spark.transforms.markduplicates.MarkDuplicatesSparkUtils
 
MarkDuplicatesSparkUtils.IndexPair<T> - Class in org.broadinstitute.hellbender.tools.spark.transforms.markduplicates
Wrapper object used for storing an object and some type of index information.
MarkDuplicatesSparkUtils.PairedEndsCoordinateComparator - Class in org.broadinstitute.hellbender.tools.spark.transforms.markduplicates
Comparator for sorting Reads by coordinate.
MarkDuplicatesWithMateCigar - Class in picard.sam.markduplicates
An even better duplication marking algorithm that handles all cases including clipped and gapped alignments.
MarkDuplicatesWithMateCigar() - Constructor for class picard.sam.markduplicates.MarkDuplicatesWithMateCigar
 
MarkDuplicatesWithMateCigarIterator - Class in picard.sam.markduplicates
This will iterate through a coordinate sorted SAM file (iterator) and either mark or remove duplicates as appropriate.
MarkDuplicatesWithMateCigarIterator(SAMFileHeader, CloseableIterator<SAMRecord>, OpticalDuplicateFinder, DuplicateScoringStrategy.ScoringStrategy, int, boolean, boolean, int, int, List<File>) - Constructor for class picard.sam.markduplicates.MarkDuplicatesWithMateCigarIterator
Initializes the mark duplicates iterator.
MarkedOpticalDuplicateReadFilter - Class in org.broadinstitute.hellbender.tools.spark.pathseq
 
MarkedOpticalDuplicateReadFilter() - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.MarkedOpticalDuplicateReadFilter
 
MarkIlluminaAdapters - Class in picard.illumina
Command line program to mark the location of adapter sequences.
MarkIlluminaAdapters() - Constructor for class picard.illumina.MarkIlluminaAdapters
 
MarkQueue - Class in picard.sam.markduplicates.util
This is the mark queue.
MarkQueue(DuplicateScoringStrategy.ScoringStrategy) - Constructor for class picard.sam.markduplicates.util.MarkQueue
 
mask(SVKmerShort) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerShort
 
mask - Variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
Any variant which overlaps entries from the provided mask file will be filtered.
MASK_EXTENSION_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
 
MASK_NAME_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
 
maskExtension - Variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
 
maskName - Variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
When using the -mask argument, the maskName will be annotated in the variant record.
MATCHED_NORMAL_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.contamination.CalculateContamination
 
MATCHED_NORMAL_SEGMENT_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.utils.TagGermlineEvents
 
MATCHED_NORMAL_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.contamination.CalculateContamination
 
matches(GATKRead) - Method in class org.broadinstitute.hellbender.utils.read.ArtificialReadQueryIterator
given a read and the query type, check if it matches our regions
matches(int, String) - Method in class org.broadinstitute.hellbender.utils.tsv.TableColumnCollection
Checks a column names matches given one.
matchesAll(int, String...) - Method in class org.broadinstitute.hellbender.utils.tsv.TableColumnCollection
Checks an array of column matches the column names starting from a given index.
matchesExactly(String...) - Method in class org.broadinstitute.hellbender.utils.tsv.TableColumnCollection
Checks whether columns contain all the names in an array and no other and in the very same order.
MATCHING_DICTIONARY_TAGS - Variable in class picard.sam.MergeBamAlignment
 
MatchingBasesAndQualsReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.MatchingBasesAndQualsReadFilter
 
matchingRef() - Method in enum org.broadinstitute.hellbender.utils.artifacts.Transition
Return the ref:ref transition corresponding to this ref:alt transition.
MatchMDElement(int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.TextMDCodec.MatchMDElement
 
matchPattern - Variable in class picard.illumina.parser.ParameterizedFileUtil
A pattern that will match files of this type for this lane
MatchResults - Class in picard.fingerprint
Represents the results of a fingerprint comparison between one dataset and a specific fingerprint file.
matchToDeletion - Static variable in class org.broadinstitute.hellbender.utils.pairhmm.PairHMMModel
Position in the transition probability array for the Match-to-Deletion transition.
matchToInsertion - Static variable in class org.broadinstitute.hellbender.utils.pairhmm.PairHMMModel
Position in the transition probability array for the Match-to-Insertion transition.
matchToMatch - Static variable in class org.broadinstitute.hellbender.utils.pairhmm.PairHMMModel
Position in the transition probability array for the Match-to-Match transition.
matchToMatchProb(byte, byte) - Static method in class org.broadinstitute.hellbender.utils.pairhmm.PairHMMModel
Returns the probability that neither of two event takes place.
matchToMatchProb(int, int) - Static method in class org.broadinstitute.hellbender.utils.pairhmm.PairHMMModel
Returns the probability that neither of two events, insertion and deletion, takes place.
matchToMatchProbLog10(byte, byte) - Static method in class org.broadinstitute.hellbender.utils.pairhmm.PairHMMModel
Returns the log10 probability that neither of two events, insertion and deletion, takes place.
matchToMatchProbLog10(int, int) - Static method in class org.broadinstitute.hellbender.utils.pairhmm.PairHMMModel
Returns the log-probability that neither of two events takes place.
MATE_ALIGNMENT_LENGTH_UNCERTAINTY - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.DiscordantReadPairEvidence
 
MATE_DIFFERENT_STRAND - Static variable in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary
 
MATE_ON_SAME_CONTIG_OR_NO_MAPPED_MATE - Static variable in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary
 
MateDifferentStrandReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.MateDifferentStrandReadFilter
 
mateIsReverseStrand() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
mateIsReverseStrand() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
mateIsUnmapped() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
 
mateIsUnmapped() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
MateOnSameContigOrNoMappedMateReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.MateOnSameContigOrNoMappedMateReadFilter
 
MathUtil - Class in picard.util
General math utilities
MathUtil.LogMath - Class in picard.util
A collection of common math operations that work with log values.
MathUtils - Class in org.broadinstitute.hellbender.utils
MathUtils is a static class (no instantiation allowed!) with some useful math methods.
MathUtils.IntToDoubleArrayFunction - Interface in org.broadinstitute.hellbender.utils
 
MathUtils.RunningAverage - Class in org.broadinstitute.hellbender.utils
A utility class that computes on the fly average and standard deviation for a stream of numbers.
MATRIX_OUTPUT - Variable in class picard.analysis.replicates.CollectIndependentReplicateMetrics
 
MATRIX_OUTPUT - Variable in class picard.fingerprint.CrosscheckFingerprints
 
MatrixSummaryUtils - Class in org.broadinstitute.hellbender.utils
Static class for implementing some matrix summary stats that are not in Apache, Spark, etc
max() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree
Find the greatest interval in the tree.
max(SVInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree
Find the latest interval in the tree less than or equal to the specified interval.
max() - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
Returns the largest integer value in the set.
max(GenomeLoc) - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
Returns the maximum GenomeLoc of this and other
max(double[]) - Static method in class picard.util.MathUtil
Returns the largest value stored in the array.
max(long[]) - Static method in class picard.util.MathUtil
Returns the largest value stored in the array.
MAX_ADAPTER_MISMATCHES_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
MAX_ADAPTER_MISMATCHES_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
MAX_ADVI_ITER_FIRST_EPOCH_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection
 
MAX_ADVI_ITER_SUBSEQUENT_EPOCHS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection
 
MAX_ALIGN_LENGTH - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
MAX_ALT_ALLELE_COUNT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
MAX_ALT_FRACTION_IN_NORMAL - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2Engine
 
MAX_ALT_HITS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBwaArgumentCollection
 
MAX_ALT_HITS_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBwaArgumentCollection
 
MAX_ALTERNATE_ALLELES - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeCalculationArgumentCollection
If there are more than this number of alternate alleles presented to the genotyper (either through discovery or GENOTYPE_GIVEN ALLELES), then only this many alleles will be used.
MAX_APPARENT_BASES_PER_WINDOW - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.evidence.KSWindowFinder
 
MAX_ASSEMBLY_LONG_NAME - Static variable in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
max_attempts - Variable in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantRecalibrator
The statistical model being built by this tool may fail due to simple statistical sampling issues.
MAX_BASE_SCORE - Static variable in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.PreAdapterOrientationScorer
Defined by convention that the Phred quality score is 100.0, so this value ensures that the Phred calculation will be 100.0.
MAX_BIAS_FACTORS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineDenoisingModelArgumentCollection
 
MAX_CALLING_ITERS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection
 
MAX_CONTAMINATION_PROBABILITY_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
MAX_COPY_NUMBER_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineCallingArgumentCollection
 
MAX_DELETION_FRACTION - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.UnifiedArgumentCollection
If the fraction of reads with deletions spanning a locus is greater than this value, the site will not be considered callable and will be skipped.
MAX_DIFF_RATE - Variable in class org.broadinstitute.hellbender.tools.walkers.markduplicates.EstimateLibraryComplexityGATK
 
MAX_DIFF_RATE - Variable in class picard.sam.markduplicates.EstimateLibraryComplexity
 
MAX_DISCARD_FRACTION - Variable in class picard.sam.RevertSam
 
MAX_DUST_SCORE - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
MAX_EDIT_DISTANCE_TO_JOIN - Variable in class picard.sam.markduplicates.UmiAwareMarkDuplicatesWithMateCigar
 
MAX_ERROR_RATE - Static variable in class picard.util.ClippingUtility
The default value used for the maximum error rate when matching read bases to clippable sequence.
MAX_ERROR_RATE_PE - Variable in class picard.illumina.MarkIlluminaAdapters
 
MAX_ERROR_RATE_SE - Variable in class picard.illumina.MarkIlluminaAdapters
 
MAX_EVENTS_IN_REGION_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
MAX_FAILED_REALIGNMENTS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.FilterAlignmentArtifacts
 
MAX_FILE_HANDLES_FOR_READ_ENDS_MAP - Variable in class org.broadinstitute.hellbender.tools.walkers.markduplicates.MarkDuplicatesGATK
 
MAX_FILE_HANDLES_FOR_READ_ENDS_MAP - Variable in class picard.sam.markduplicates.MarkDuplicates
 
MAX_FILTER_SIZE - Static variable in class org.broadinstitute.hellbender.utils.activityprofile.BandPassActivityProfile
 
MAX_FRAGMENT_LENGTH_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ReadFilterArgumentDefinitions
 
MAX_FS - Variable in class picard.vcf.filter.FilterVcf
 
MAX_GATK_USABLE_Q_SCORE - Static variable in class org.broadinstitute.hellbender.utils.recalibration.RecalDatum
Quals above this value should be capped down to this value (because they are too high) in the base quality score recalibrator
MAX_GENOTYPE_COUNT - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeCalculationArgumentCollection
If there are more than this number of genotypes at a locus presented to the genotyper, then only this many genotypes will be used.
MAX_GERMLINE_POSTERIOR_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
MAX_GROUP_RATIO - Variable in class org.broadinstitute.hellbender.tools.walkers.markduplicates.EstimateLibraryComplexityGATK
 
MAX_GROUP_RATIO - Variable in class picard.sam.markduplicates.EstimateLibraryComplexity
 
MAX_INSERT_SIZE - Variable in class org.broadinstitute.hellbender.metrics.InsertSizeMetrics
The maximum measure insert size by alignment.
MAX_INSERT_SIZE - Variable in class picard.analysis.CollectAlignmentSummaryMetrics
 
MAX_INSERT_SIZE - Variable in class picard.analysis.InsertSizeMetrics
The maximum measure insert size by alignment.
MAX_INSERTIONS_OR_DELETIONS - Variable in class picard.sam.MergeBamAlignment
 
MAX_KMER_FREQ - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.evidence.FindBadGenomicKmersSpark
 
MAX_MASKED_BASES_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
MAX_MASKED_BASES_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
MAX_MEDIAN_FRAGMENT_LENGTH_DIFFERENCE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
MAX_MISMATCH_RATE - Variable in class picard.analysis.CollectRrbsMetrics
 
MAX_MISMATCHES - Variable in class picard.illumina.ExtractIlluminaBarcodes
 
MAX_MNP_DISTANCE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerArgumentCollection
 
MAX_MNP_DISTANCE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
MAX_MNP_DISTANCE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerArgumentCollection
 
MAX_MNP_DISTANCE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
MAX_N_INDEL_INFORMATIVE_READS - Static variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReferenceConfidenceModel
 
MAX_NO_CALLS - Variable in class picard.illumina.ExtractIlluminaBarcodes
 
MAX_NORMAL_QUAL_SUM - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2Engine
 
MAX_NUMBER_OF_VALUES_PER_HDF5_MATRIX - Static variable in class org.broadinstitute.hellbender.tools.copynumber.utils.HDF5Utils
 
MAX_OPEN_TEMP_FILES - Variable in class picard.sam.ValidateSamFile
 
MAX_OPTICAL_DUPLICATE_SET_SIZE - Variable in class picard.sam.markduplicates.util.AbstractOpticalDuplicateFinderCommandLineProgram
 
MAX_OUTPUT - Variable in class picard.sam.ValidateSamFile
 
MAX_PE_ERROR_RATE - Static variable in class picard.util.ClippingUtility
The default value used for the maximum error rate when matching paired end read bases to clippable sequence.
MAX_POPULATION_AF_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
MAX_POPULATION_AF_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
MAX_POS - Static variable in class picard.illumina.parser.readers.AbstractIlluminaPositionFileReader
 
MAX_PROB_BELOW_ONE - Static variable in class picard.util.MathUtil
The double value closest to 1 while still being less than 1.
MAX_Q - Variable in class picard.sam.FastqToSam
 
MAX_QUAL - Static variable in class org.broadinstitute.hellbender.utils.QualityUtils
Maximum sense quality value.
MAX_READ_LENGTH - Variable in class picard.sam.markduplicates.EstimateLibraryComplexity
 
MAX_READ_LENGTH_ARG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ReadFilterArgumentDefinitions
 
MAX_READS_IN_RAM_PER_TILE - Variable in class picard.illumina.IlluminaBasecallsToFastq
 
MAX_READS_IN_RAM_PER_TILE - Variable in class picard.illumina.IlluminaBasecallsToSam
 
MAX_REASONABLE_Q_SCORE - Static variable in class org.broadinstitute.hellbender.utils.QualityUtils
bams containing quals above this value are extremely suspicious and we should warn the user
MAX_RECALIBRATED_Q_SCORE - Static variable in class org.broadinstitute.hellbender.utils.recalibration.RecalDatum
 
MAX_RECORDS_IN_RAM - Variable in class org.broadinstitute.hellbender.cmdline.PicardCommandLineProgram
 
MAX_RECORDS_IN_RAM - Static variable in class org.broadinstitute.hellbender.utils.read.mergealignment.AbstractAlignmentMerger
 
MAX_RECORDS_IN_RAM - Variable in class picard.cmdline.CommandLineProgram
 
MAX_RECORDS_IN_RAM - Static variable in class picard.sam.AbstractAlignmentMerger
 
MAX_RECORDS_TO_EXAMINE - Variable in class picard.sam.RevertOriginalBaseQualitiesAndAddMateCigar
 
MAX_SAM_QUAL_SCORE - Static variable in class org.broadinstitute.hellbender.utils.QualityUtils
Maximum quality score that can be encoded in a SAM/BAM file
MAX_SEQUENCES_FOR_DISK_READ_ENDS_MAP - Variable in class org.broadinstitute.hellbender.tools.walkers.markduplicates.MarkDuplicatesGATK
If more than this many sequences in SAM file, don't spill to disk because there will not be enough file handles.
MAX_SEQUENCES_FOR_DISK_READ_ENDS_MAP - Variable in class picard.sam.markduplicates.MarkDuplicates
If more than this many sequences in SAM file, don't spill to disk because there will not be enough file handles.
MAX_SITE_AF_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.contamination.GetPileupSummaries
 
MAX_SITE_AF_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.contamination.GetPileupSummaries
 
MAX_SPLICES_TO_KEEP - Static variable in class org.broadinstitute.hellbender.tools.walkers.rnaseq.OverhangFixingManager
 
MAX_STARTS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
MAX_STRAND_ARTIFACT_PROBABILITY_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
MAX_SUSPICIOUS_READS_PER_ALIGNMENT_START_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
MAX_TARGET_COVERAGE - Variable in class picard.analysis.directed.HsMetrics
The maximum coverage of reads that mapped to target regions of an experiment.
MAX_TARGET_COVERAGE - Variable in class picard.analysis.directed.TargetedPcrMetrics
The maximum coverage of reads that mapped to target regions of an experiment.
MAX_TARGET_COVERAGE - Variable in class picard.analysis.directed.TargetMetrics
The maximum coverage of reads that mapped to target regions of an experiment.
MAX_TO_MERGE - Variable in class picard.util.ScatterIntervalsByNs
 
MAX_TRAINING_EPOCHS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection
 
maxAdapterMismatches - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
maxAlternateHits - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBwaArgumentCollection
The maximum number of alternate alignments for each read, i.e.
maxAmbiguousBaseFraction - Variable in class org.broadinstitute.hellbender.engine.filters.AmbiguousBaseReadFilter
 
maxAmbiguousBases - Variable in class org.broadinstitute.hellbender.engine.filters.AmbiguousBaseReadFilter
 
maxAmbiguousBases - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
This is the threshold for filtering reads based on the number of 'N' values present in the sequence.
maxAssemblyRegionSize - Variable in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
maxAssemblyRegionSize - Variable in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerSpark
 
maxAssemblyRegionSize - Variable in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark.ShardingArgumentCollection
 
maxCallableImpreciseVariantDeletionSize - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.DiscoverVariantsFromContigsAlignmentsSparkArgumentCollection
 
maxContaminationProbability - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
maxDepthPerSample - Variable in class org.broadinstitute.hellbender.engine.LocusWalker
 
maxDepthPerSample - Variable in class org.broadinstitute.hellbender.engine.spark.LocusWalkerSpark
 
maxDifference(List<Double>, List<Double>) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Find the maximum difference between entries of two arrays.
maxDUSTScore - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
maxElementIndex(double[]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
maxElementIndex(double[], int, int) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
maxElementIndex(double[], int) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
maxEnd() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree
Return the interval having the largest ending value.
maxEventsInRegion - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
maxFASTQSize - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
maxFragmentLength - Variable in class org.broadinstitute.hellbender.engine.filters.FragmentLengthReadFilter
 
maxGermlinePosterior - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
maxHaplotypeLength - Variable in class org.broadinstitute.hellbender.utils.pairhmm.PairHMM
 
MAXIMUM_CHUNK_SIZE - Static variable in class org.broadinstitute.hellbender.tools.copynumber.CreateReadCountPanelOfNormals
 
MAXIMUM_CYCLE_VALUE - Variable in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationArgumentCollection
The cycle covariate will generate an error if it encounters a cycle greater than this value.
MAXIMUM_INSERT_SIZE - Variable in class picard.analysis.artifacts.CollectSequencingArtifactMetrics
 
MAXIMUM_INSERT_SIZE - Variable in class picard.analysis.CollectOxoGMetrics
 
MAXIMUM_MAPPING_QUALITY_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ReadFilterArgumentDefinitions
 
MAXIMUM_NUMBER_OF_SEGMENTS_PER_CHROMOSOME_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
MAXIMUM_NUMBER_OF_SMOOTHING_ITERATIONS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
MAXIMUM_STRONG_REF_GENOTYPE_PER_PLOIDY - Static variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeLikelihoodCalculators
Maximum possible number of genotypes that this calculator can handle.
MAXIMUM_ZEROS_IN_INTERVAL_PERCENTAGE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.CreateReadCountPanelOfNormals
 
MAXIMUM_ZEROS_IN_SAMPLE_PERCENTAGE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.CreateReadCountPanelOfNormals
 
maximumAlleleIndex() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeAlleleCounts
Returns the largest allele index present in the genotype.
maximumKeyValue() - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.ContextCovariate
 
maximumKeyValue() - Method in interface org.broadinstitute.hellbender.utils.recalibration.covariates.Covariate
Returns the maximum value possible for any key representing this covariate
maximumKeyValue() - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.CycleCovariate
 
maximumKeyValue() - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.QualityScoreCovariate
 
maximumKeyValue() - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.ReadGroupCovariate
 
maximumSpan - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmer.Result
Maximum available range for the trimmed variant region.
maxMADTolerance - Variable in class org.broadinstitute.hellbender.metrics.InsertSizeMetricsArgumentCollection
 
maxMappingQualityScore - Variable in class org.broadinstitute.hellbender.engine.filters.MappingQualityReadFilter
 
maxMedianFragmentLengthDifference - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
maxMnpDistance - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerArgumentCollection
Two or more phased substitutions separated by this distance or less are merged into MNPs.
maxMnpDistance - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
Two or more phased substitutions separated by this distance or less are merged into MNPs.
maxNumHaplotypesInPopulation - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadThreadingAssemblerArgumentCollection
The assembly graph can be quite complex, and could imply a very large number of possible haplotypes.
maxPopulationAlleleFrequency - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
In tumor-only mode, we discard variants with population allele frequencies greater than this threshold.
maxProbPropagationDistance - Variable in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
maxProbPropagationDistance - Variable in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerSpark
 
maxProbPropagationDistance - Variable in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark.ShardingArgumentCollection
 
maxProbPropagationDistance - Variable in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfile
 
maxQualityScore - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.UnifiedArgumentCollection
 
maxReadLength - Variable in class org.broadinstitute.hellbender.engine.filters.ReadLengthReadFilter
 
maxReadLength - Variable in class org.broadinstitute.hellbender.utils.pairhmm.PairHMM
 
maxReadsPerAlignmentStart - Variable in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
maxReadsPerAlignmentStart - Variable in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerSpark
 
maxReadsPerAlignmentStart - Variable in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark.ShardingArgumentCollection
 
maxReasonableFragmentLength - Variable in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.RealignmentArgumentCollection
Maximum fragment length to be considered a reasonable pair alignment
maxSuspiciousReadsPerAlignmentStart - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
Maximum number of suspicious reads (mediocre mapping quality or too many substitutions) allowed in a downsampling stride.
maxTrackedFragmentLength - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
maybeAdvance() - Method in class picard.illumina.parser.PerTileParser
 
MDElement(int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.TextMDCodec.MDElement
 
mean(int, boolean) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
 
mean(double...) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
mean(double[], int, int) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Calculate the mean of an array of doubles.
mean() - Method in class org.broadinstitute.hellbender.utils.MathUtils.RunningAverage
 
mean(double...) - Method in class picard.util.MathUtil.LogMath
Computes the mean of the provided log values.
mean(double[], int, int) - Static method in class picard.util.MathUtil
Calculated the mean of an array of doubles.
MEAN_AMPLICON_COVERAGE - Variable in class picard.analysis.directed.TargetedPcrMetrics
The mean read coverage of all amplicon regions in the experiment.
MEAN_BAIT_COVERAGE - Variable in class picard.analysis.directed.HsMetrics
The mean coverage of all baits in the experiment.
MEAN_BASE_QUALITY - Variable in class picard.analysis.GcBiasDetailMetrics
The mean quality (determined via the error rate) of all bases of all reads that are assigned to windows of this GC.
MEAN_BIAS_STANDARD_DEVIATION_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineContigPloidyModelArgumentCollection
 
MEAN_CLUSTERS_PER_TILE - Variable in class picard.illumina.IlluminaBasecallingMetrics
The mean number of clusters per tile.
MEAN_COVERAGE - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The mean coverage in bases of the genome territory, after all filters are applied.
MEAN_CPG_COVERAGE - Variable in class picard.analysis.RrbsSummaryMetrics
Mean coverage of CpG sites
MEAN_INSERT_SIZE - Variable in class org.broadinstitute.hellbender.metrics.InsertSizeMetrics
The mean insert size of the "core" of the distribution.
MEAN_INSERT_SIZE - Variable in class picard.analysis.InsertSizeMetrics
The mean insert size of the "core" of the distribution.
MEAN_PCT_PF_CLUSTERS_PER_TILE - Variable in class picard.illumina.IlluminaBasecallingMetrics
The mean percentage of pf clusters per tile.
MEAN_PF_CLUSTERS_PER_TILE - Variable in class picard.illumina.IlluminaBasecallingMetrics
The mean number of pf clusters per tile.
MEAN_PROBE_COVERAGE - Variable in class picard.analysis.directed.TargetMetrics
The mean coverage of all probes in the experiment, ON_PROBE_BASES/PROBE_TERRITORY.
MEAN_READ_LENGTH - Variable in class picard.analysis.AlignmentSummaryMetrics
The mean read length of the set of reads examined.
MEAN_TARGET_COVERAGE - Variable in class picard.analysis.directed.HsMetrics
The mean coverage of a target region.
MEAN_TARGET_COVERAGE - Variable in class picard.analysis.directed.TargetedPcrMetrics
The mean read coverage of all target regions in an experiment.
MEAN_TARGET_COVERAGE - Variable in class picard.analysis.directed.TargetMetrics
The mean coverage of targets.
MEAN_UMI_LENGTH - Variable in class picard.sam.markduplicates.UmiMetrics
Number of bases in each UMI
MeanQualityByCycle - Class in picard.analysis
Program to generate a data table and chart of mean quality by cycle from a BAM file.
MeanQualityByCycle() - Constructor for class picard.analysis.MeanQualityByCycle
 
MeanQualityByCycleSpark - Class in org.broadinstitute.hellbender.tools.spark.pipelines.metrics
Program to generate a data table and chart of mean quality by cycle from a BAM file.
MeanQualityByCycleSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.MeanQualityByCycleSpark
 
meanWeights() - Method in class org.broadinstitute.hellbender.utils.Dirichlet
 
median() - Method in class org.broadinstitute.hellbender.tools.spark.utils.IntHistogram.CDF
 
median() - Method in class org.broadinstitute.hellbender.utils.Histogram
 
median(double[]) - Method in class org.broadinstitute.hellbender.utils.MannWhitneyU
Finds or calculates the median value of a sorted array of double.
median(int[]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
median(Collection<T>) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Compute the median of a list of numbers If values.length is even, this will be the middle value when the elements are sorted If values.length is odd then it will be the mean of the two values closest to the middle.
median(double...) - Static method in class picard.util.MathUtil
Calculate the median of an array of doubles.
MEDIAN_3PRIME_BIAS - Variable in class picard.analysis.RnaSeqMetrics
The median 3 prime bias of the 1000 most highly expressed transcripts, where 3 prime bias is calculated per transcript as: mean coverage of the 3 prime-most 100 bases divided by the mean coverage of the whole transcript.
MEDIAN_5PRIME_BIAS - Variable in class picard.analysis.RnaSeqMetrics
The median 5 prime bias of the 1000 most highly expressed transcripts.
MEDIAN_5PRIME_TO_3PRIME_BIAS - Variable in class picard.analysis.RnaSeqMetrics
The ratio of coverage at the 5 prime end to the 3 prime end based on the 1000 most highly expressed transcripts.
MEDIAN_ABSOLUTE_DEVIATION - Variable in class org.broadinstitute.hellbender.metrics.InsertSizeMetrics
The median absolute deviation of the distribution.
MEDIAN_ABSOLUTE_DEVIATION - Variable in class picard.analysis.InsertSizeMetrics
The median absolute deviation of the distribution.
MEDIAN_BASE_QUALITY_FILTER_NAME - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
MEDIAN_COVERAGE - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The median coverage in bases of the genome territory, after all filters are applied.
MEDIAN_CPG_COVERAGE - Variable in class picard.analysis.RrbsSummaryMetrics
Median coverage of CpG sites
MEDIAN_CV_COVERAGE - Variable in class picard.analysis.RnaSeqMetrics
The median coefficient of variation (CV) or stdev/mean for coverage values of the 1000 most highly expressed transcripts.
MEDIAN_FRAGMENT_LENGTH_DIFFERENCE_FILTER_NAME - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
MEDIAN_INSERT_SIZE - Variable in class org.broadinstitute.hellbender.metrics.InsertSizeMetrics
The MEDIAN insert size of all paired end reads where both ends mapped to the same chromosome.
MEDIAN_INSERT_SIZE - Variable in class picard.analysis.InsertSizeMetrics
The MEDIAN insert size of all paired end reads where both ends mapped to the same chromosome.
MEDIAN_MAPPING_QUALITY_FILTER_NAME - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
MEDIAN_TARGET_COVERAGE - Variable in class picard.analysis.directed.HsMetrics
The median coverage of a target region.
MEDIAN_TARGET_COVERAGE - Variable in class picard.analysis.directed.TargetedPcrMetrics
The median coverage of reads that mapped to target regions of an experiment.
MEDIAN_TARGET_COVERAGE - Variable in class picard.analysis.directed.TargetMetrics
The median coverage of targets.
meetsMinMergableSequenceForEitherPrefixOrSuffix(int) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.SharedVertexSequenceSplitter
Does either the common suffix or prefix have at least minCommonSequence bases in it?
meetsMinMergableSequenceForPrefix(int) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.SharedVertexSequenceSplitter
Does the common prefix have at least minCommonSequence bases in it?
meetsMinMergableSequenceForSuffix(int) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.SharedVertexSequenceSplitter
Does the common suffix have at least minCommonSequence bases in it?
MENDEL_VIOLATION_LR_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
MendelianViolation - Class in org.broadinstitute.hellbender.utils.samples
Class for the identification and tracking of mendelian violation.
MendelianViolation(double) - Constructor for class org.broadinstitute.hellbender.utils.samples.MendelianViolation
 
MendelianViolation(double, boolean, boolean) - Constructor for class org.broadinstitute.hellbender.utils.samples.MendelianViolation
 
MendelianViolationMetrics - Class in picard.vcf.MendelianViolations
Describes the type and number of mendelian violations found within a Trio.
MendelianViolationMetrics() - Constructor for class picard.vcf.MendelianViolations.MendelianViolationMetrics
 
MendelianViolationsByFamily - Class in picard.vcf.MendelianViolations
Created by farjoun on 6/25/16.
MendelianViolationsByFamily() - Constructor for class picard.vcf.MendelianViolations.MendelianViolationsByFamily
 
merge(FlagStat.FlagStatus) - Method in class org.broadinstitute.hellbender.tools.FlagStat.FlagStatus
 
merge(SeqGraph, SeqVertex) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.SharedSequenceMerger
Attempt to merge the incoming vertices of v
merge(List<VariantContext>, Locatable, Byte, boolean, boolean) - Method in class org.broadinstitute.hellbender.tools.walkers.ReferenceConfidenceVariantContextMerger
Merges VariantContexts from gVCFs into a single hybrid.
merge(GenomeLoc) - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
Returns a new GenomeLoc that represents the entire span of this and that.
merge(T, T) - Static method in class org.broadinstitute.hellbender.utils.GenomeLoc
Merges 2 *contiguous* locs into 1
merge(SortedSet<T>) - Static method in class org.broadinstitute.hellbender.utils.GenomeLoc
Merges a list of *sorted* *contiguous* locs into 1
merge(MathUtils.RunningAverage) - Method in class org.broadinstitute.hellbender.utils.MathUtils.RunningAverage
 
merge(QualQuantizer.QualInterval) - Method in class org.broadinstitute.hellbender.utils.recalibration.QualQuantizer.QualInterval
Create a interval representing the merge of this interval and toMerge Errors and observations are combined Subintervals updated in order of left to right (determined by qStart) Level is 1 + highest level of this and toMerge Order must be updated elsewhere
merge(MergeableMetricBase) - Method in class picard.analysis.CollectWgsMetrics.WgsMetrics
Merges the various PCT_EXC_* metrics.
merge(Collection<? extends MergeableMetricBase>) - Method in class picard.analysis.MergeableMetricBase
for a collection of MergeableMetricBase, merge them all into "this" one.
merge(MergeableMetricBase) - Method in class picard.analysis.MergeableMetricBase
Merge another metric into this one
merge(Fingerprint) - Method in class picard.fingerprint.Fingerprint
Merges the likelihoods from the supplied Fingerprint into the likelihoods for this fingerprint.
merge(FingerprintIdDetails) - Method in class picard.fingerprint.FingerprintIdDetails
 
merge(HaplotypeProbabilities) - Method in class picard.fingerprint.HaplotypeProbabilities
Merges in the likelihood information from the supplied haplotype probabilities object.
merge(HaplotypeProbabilities) - Method in class picard.fingerprint.HaplotypeProbabilitiesFromContaminatorSequence
 
merge(HaplotypeProbabilities) - Method in class picard.fingerprint.HaplotypeProbabilitiesFromGenotype
 
merge(HaplotypeProbabilities) - Method in class picard.fingerprint.HaplotypeProbabilitiesFromSequence
Merges information from another haplotype probabilities object for the same haplotype into this object.
merge(HaplotypeProbabilities) - Method in class picard.fingerprint.HaplotypeProbabilityOfNormalGivenTumor
 
merge(ExtractIlluminaBarcodes.BarcodeMetric) - Method in class picard.illumina.ExtractIlluminaBarcodes.BarcodeMetric
Adds the non-calculated
merge(CollectHiSeqXPfFailMetrics.PFFailSummaryMetric) - Method in class picard.illumina.quality.CollectHiSeqXPfFailMetrics.PFFailSummaryMetric
Adds the non-calculated fields from the other metric to this one.
merge(Collection<CallingMetricAccumulator.Result>) - Static method in class picard.vcf.CallingMetricAccumulator.Result
 
merge(Collection<RESULT>) - Method in interface picard.vcf.processor.VariantProcessor.ResultMerger
 
MERGE_FILTER_IN_ALL - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
 
MERGE_FILTER_PREFIX - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
 
MERGE_INTERSECTION - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
 
MERGE_NEARBY_TARGETS - Variable in class picard.util.BaitDesigner
 
MERGE_REF_IN_ALL - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
 
MERGE_SEQUENCE_DICTIONARIES - Variable in class picard.sam.MergeSamFiles
 
MergeableMetricBase - Class in picard.analysis
An extension of MetricBase that knows how to merge-by-adding fields that are appropriately annotated.
MergeableMetricBase() - Constructor for class picard.analysis.MergeableMetricBase
 
MergeableMetricBase.MergeByAdding - Annotation Type in picard.analysis
Metrics whose values can be merged by adding.
MergeableMetricBase.MergeByAssertEquals - Annotation Type in picard.analysis
Metrics whose values should be equal when merging.
MergeableMetricBase.MergingIsManual - Annotation Type in picard.analysis
Metrics that are merged manually in the MergeableMetricBase.merge(MergeableMetricBase) ()}.
MergeableMetricBase.NoMergingIsDerived - Annotation Type in picard.analysis
Metrics that are not merged, but are subsequently derived from other metrics, for example by MergeableMetricBase.calculateDerivedFields().
MergeableMetricBase.NoMergingKeepsValue - Annotation Type in picard.analysis
Metrics that are not merged.
mergeAlignment(File) - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.AbstractAlignmentMerger
/** Merges the alignment data with the non-aligned records from the source BAM file.
mergeAlignment(File) - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.SamAlignmentMerger
Merges the alignment from the map file with the non-aligned records from the source BAM file.
mergeAlignment(File) - Method in class picard.sam.AbstractAlignmentMerger
Merges the alignment data with the non-aligned records from the source BAM file.
mergeAlignment(File) - Method in class picard.sam.SamAlignmentMerger
Merges the alignment from the map file with the non-aligned records from the source BAM file.
mergeAndConvertTranches(TreeMap<Double, List<VQSLODTranche>>, List<Double>, VariantRecalibratorArgumentCollection.Mode) - Static method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VQSLODTranche
 
mergeAndConvertTranches(List<VQSLODTranche>, VariantRecalibratorArgumentCollection.Mode) - Static method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VQSLODTranche
 
MergeAnnotatedRegions - Class in org.broadinstitute.hellbender.tools.copynumber.utils
 
MergeAnnotatedRegions() - Constructor for class org.broadinstitute.hellbender.tools.copynumber.utils.MergeAnnotatedRegions
 
MergeBamAlignment - Class in picard.sam
Summary
MergeBamAlignment() - Constructor for class picard.sam.MergeBamAlignment
 
mergedSampleName(String, String, boolean) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
 
mergeFingerprintsBy(Map<FingerprintIdDetails, Fingerprint>, Function<FingerprintIdDetails, String>) - Static method in class picard.fingerprint.CrosscheckFingerprints
 
mergeIfCan(MergeableMetricBase) - Method in class picard.analysis.MergeableMetricBase
Merges another MergableMetricBase if possible
mergeIntervalLocations(List<GenomeLoc>, IntervalMergingRule) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
merge a list of genome locs that may be overlapping, returning the list of unique genomic locations
mergeListsBySetOperator(List<GenomeLoc>, List<GenomeLoc>, IntervalSetRule) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
merge two interval lists, using an interval set rule
mergeRegions(List<AnnotatedInterval>, SAMSequenceDictionary, String, Consumer<Locatable>) - Static method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalUtils
Merge AnnotatedIntervals by whether the regions overlap.
MergeSamFiles - Class in picard.sam
This tool is used for combining SAM and/or BAM files from different runs or read groups into a single file, similar to the \"merge\" function of Samtools (http://www.htslib.org/doc/samtools.html).
MergeSamFiles() - Constructor for class picard.sam.MergeSamFiles
 
MergeVcfs - Class in picard.vcf
Combines multiple variant files into a single variant file.
MergeVcfs() - Constructor for class picard.vcf.MergeVcfs
 
mergeWithContiguous(Locatable) - Method in class org.broadinstitute.hellbender.utils.SimpleInterval
Returns a new SimpleInterval that represents the entire span of this and that.
mergeWithNewVCs(List<VariantContext>, ReferenceContext) - Method in class org.broadinstitute.hellbender.tools.walkers.CombineGVCFs
Method which calls endPreviousStates at the appropriate places on the given a new startingStates object and an OverallState object corresponding to the currently accumulated reads.
Metadata - Interface in org.broadinstitute.hellbender.tools.copynumber.formats.metadata
Interface for marking objects that contain metadata that can be represented as a SAMFileHeader.
metadata - Variable in class org.broadinstitute.hellbender.tools.spark.PileupSpark
This enables annotating the pileup to show overlaps with metadata from a Feature file(s).
metadata - Variable in class org.broadinstitute.hellbender.tools.walkers.qc.Pileup
This enables annotating the pileup to show overlaps with metadata from a Feature file(s).
Metadata.Type - Enum in org.broadinstitute.hellbender.tools.copynumber.formats.metadata
 
metadataFile - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
MetadataUtils - Class in org.broadinstitute.hellbender.tools.copynumber.formats.metadata
 
MetagenomicsProgramGroup - Class in org.broadinstitute.hellbender.cmdline.programgroups
Tools that perform metagenomic analysis, e.g.
MetagenomicsProgramGroup() - Constructor for class org.broadinstitute.hellbender.cmdline.programgroups.MetagenomicsProgramGroup
 
METRIC_ACCUMULATION_LEVEL - Variable in class picard.analysis.CollectAlignmentSummaryMetrics
 
METRIC_ACCUMULATION_LEVEL - Variable in class picard.analysis.CollectGcBiasMetrics
 
METRIC_ACCUMULATION_LEVEL - Variable in class picard.analysis.CollectInsertSizeMetrics
 
METRIC_ACCUMULATION_LEVEL - Variable in class picard.analysis.CollectMultipleMetrics
 
METRIC_ACCUMULATION_LEVEL - Variable in class picard.analysis.CollectRnaSeqMetrics
 
METRIC_ACCUMULATION_LEVEL - Variable in class picard.analysis.CollectRrbsMetrics
 
METRIC_ACCUMULATION_LEVEL - Variable in class picard.analysis.directed.CollectTargetedMetrics
 
METRIC_ACCUMULATION_LEVEL_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
METRIC_ACCUMULATION_LEVEL_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
metricAccumulationLevel - Variable in class org.broadinstitute.hellbender.metrics.InsertSizeMetricsArgumentCollection
 
MetricAccumulationLevel - Enum in org.broadinstitute.hellbender.metrics
For use with Picard metrics programs that may output metrics for multiple levels of aggregation with an analysis.
MetricAccumulationLevel - Enum in picard.analysis
For use with Picard metrics programs that may output metrics for multiple levels of aggregation with an analysis.
MetricAccumulationLevelArgumentCollection - Class in org.broadinstitute.hellbender.cmdline.argumentcollections
 
MetricAccumulationLevelArgumentCollection() - Constructor for class org.broadinstitute.hellbender.cmdline.argumentcollections.MetricAccumulationLevelArgumentCollection
 
metrics - Variable in class picard.analysis.directed.RnaSeqMetricsCollector.PerUnitRnaSeqMetricsCollector
 
METRICS - Variable in class picard.illumina.MarkIlluminaAdapters
 
METRICS_FILE - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.AbstractMarkDuplicatesCommandLineProgram
 
METRICS_FILE - Variable in class picard.illumina.ExtractIlluminaBarcodes
 
METRICS_FILE - Variable in class picard.sam.DownsampleSam
 
METRICS_FILE - Variable in class picard.sam.markduplicates.util.AbstractMarkDuplicatesCommandLineProgram
 
METRICS_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
METRICS_FILE_PREFIX - Variable in class picard.analysis.CollectRrbsMetrics
 
METRICS_FILE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
METRICS_FILE_SHORT_NAME - Static variable in class picard.cmdline.StandardOptionDefinitions
 
MetricsArgumentCollection - Class in org.broadinstitute.hellbender.metrics
Base class for defining a set of metrics collector arguments.
MetricsArgumentCollection() - Constructor for class org.broadinstitute.hellbender.metrics.MetricsArgumentCollection
 
MetricsCollectorSpark<T extends MetricsArgumentCollection> - Interface in org.broadinstitute.hellbender.tools.spark.pipelines.metrics
Each metrics collector has to be able to run from 4 different contexts: - a standalone walker tool - the org.broadinstitute.hellbender.metrics.analysis.CollectMultipleMetrics walker tool - a standalone Spark tool - the CollectMultipleMetricsSpark tool In order to allow a single collector implementation to be shared across all of these contexts (standalone and CollectMultiple, Spark and non-Spark), collectors should be factored into the following classes, where X in the class names represents the specific type of metrics being collected: XMetrics extends MetricBase: defines the aggregate metrics that we're trying to collect XMetricsArgumentCollection: defines parameters for XMetrics, extends MetricsArgumentCollection XMetricsCollector: processes a single read, and has a reduce/combiner For multi level collectors, XMetricsCollector is composed of several classes: XMetricsCollector extends MultiLevelReducibleCollector< XMetrics, HISTOGRAM_KEY, XMetricsCollectorArgs, XMetricsPerUnitCollector> XMetricsPerUnitCollector: per level collector, implements PerUnitMetricCollector (requires a combiner) XMetricsCollectorArgs per-record argument (type argument for MultiLevelReducibleCollector) XMetricsCollectorSpark: adapter/bridge between RDD and the (read-based) XMetricsCollector, implements MetricsCollectorSpark CollectXMetrics extends org.broadinstitute.hellbender.metrics.analysis.SinglePassSamProgram CollectXMetricsSpark extends MetricsCollectorSparkTool The following schematic shows the general relationships of these collector component classes in the context of various tools, with the arrows indicating a "delegates to" relationship via composition or inheritance: CollectXMetrics CollectMultipleMetrics \ / \ / v v _______________________________________ | XMetricsCollector =========|=========> MultiLevelReducibleCollector | | | | | V | | | XMetrics | V | XMetricsCollectorArgumentCollection | PerUnitXMetricCollector --------------------------------------- ^ | | XMetricsCollectorSpark ^ ^ / \ / \ CollectXMetricsSpark CollectMultipleMetricsSpark The general lifecycle of a Spark collector (XMetricsCollectorSpark in the diagram above) looks like this: CollectorType collector = new CollectorType() CollectorArgType args = // get metric-specific input arguments // NOTE: getDefaultReadFilters is called before the collector's initialize // method is called, so the read filters cannot access argument values ReadFilter filter == collector.getDefaultReadFilters(); // pass the input arguments to the collector for initialization collector.initialize(args, defaultMetricsHeaders); collector.collectMetrics( getReads().filter(filter), samFileHeader ); collector.saveMetrics(getReadSourceName());
MetricsCollectorSparkTool<T extends MetricsArgumentCollection> - Class in org.broadinstitute.hellbender.tools.spark.pipelines.metrics
Base class for standalone Spark metrics collector tools.
MetricsCollectorSparkTool() - Constructor for class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.MetricsCollectorSparkTool
 
metricsFile - Variable in class org.broadinstitute.hellbender.tools.spark.transforms.markduplicates.MarkDuplicatesSpark
 
metricsFiles - Variable in class picard.analysis.CompareMetrics
 
MetricsReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Filter out reads that: Fail platform/vendor quality checks (0x200) Are unmapped (0x4) Represent secondary/supplementary alignments (0x100 or 0x800)
MetricsReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.MetricsReadFilter
 
MetricsReadFilter(boolean, boolean) - Constructor for class org.broadinstitute.hellbender.engine.filters.MetricsReadFilter
 
MetricsUtils - Class in org.broadinstitute.hellbender.metrics
Utility methods for dealing with MetricsFile and related classes.
MICROBE_BWA_IMAGE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBwaArgumentCollection
 
MICROBE_BWA_IMAGE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBwaArgumentCollection
 
MICROBE_FASTA_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBwaArgumentCollection
 
MICROBE_FASTA_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBwaArgumentCollection
 
MICROBE_MIN_SEED_LENGTH_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBwaArgumentCollection
 
MICROBE_MIN_SEED_LENGTH_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBwaArgumentCollection
 
midpoint() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVInterval
 
MILLISECONDS_PER_MINUTE - Static variable in class org.broadinstitute.hellbender.engine.ProgressMeter
Number of milliseconds in a minute
MILLISECONDS_PER_SECOND - Static variable in class org.broadinstitute.hellbender.engine.ProgressMeter
Number of milliseconds in a second
min() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree
Find the least interval in the tree.
min(SVInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree
Find the earliest interval in the tree greater than or equal to the specified interval.
min() - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
Returns the smallest integer value in the set.
min(double[]) - Static method in class picard.util.MathUtil
Returns the smallest value stored in the array.
min(int[]) - Static method in class picard.util.MathUtil
Returns the smallest value stored in the array.
min(short[]) - Static method in class picard.util.MathUtil
Returns the smallest value stored in the array.
min(byte[]) - Static method in class picard.util.MathUtil
Returns the smallest value stored in the array.
MIN_AB - Variable in class picard.vcf.filter.FilterVcf
 
MIN_ACCEPTABLE_LOD_SCORE - Static variable in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantRecalibratorEngine
 
MIN_ADAPTER_LENGTH_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
MIN_ADAPTER_LENGTH_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
MIN_ALLELE_FRACTION_FOR_GERMLINE_HOM_ALT - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2FilteringEngine
 
MIN_ASSEMBLY_LONG_NAME - Static variable in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
MIN_BASE_QUAL - Static variable in enum org.broadinstitute.hellbender.utils.read.markduplicates.MarkDuplicatesScoringStrategy
 
MIN_BASE_QUALITY_DEFAULT_CUTOFF - Static variable in class org.broadinstitute.hellbender.tools.AnnotatePairOrientation
 
MIN_BASE_QUALITY_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
MIN_BASE_QUALITY_SCORE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerArgumentCollection
 
MIN_BASE_QUALITY_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
MIN_BASE_QUALTY_SCORE - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.UnifiedArgumentCollection
The minimum confidence needed in a given base for it to be used in variant calling.
MIN_BASES_TO_SUSPECT_PCR_SLIPPAGE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
MIN_CLIPPED_READ_LENGTH_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
MIN_CLIPPED_READ_LENGTH_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
MIN_COUNT - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_StrandBiasTest
 
MIN_DP - Variable in class picard.vcf.filter.FilterVcf
 
MIN_DP - Variable in class picard.vcf.GenotypeConcordance
 
MIN_DP - Variable in class picard.vcf.MendelianViolations.FindMendelianViolations
 
MIN_DP_FORMAT_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
MIN_GQ - Variable in class picard.vcf.filter.FilterVcf
 
MIN_GQ - Variable in class picard.vcf.GenotypeConcordance
 
MIN_GQ - Variable in class picard.vcf.MendelianViolations.FindMendelianViolations
 
MIN_GROUP_COUNT - Variable in class picard.sam.markduplicates.EstimateLibraryComplexity
 
MIN_HET_FRACTION - Variable in class picard.vcf.MendelianViolations.FindMendelianViolations
 
MIN_IDENTICAL_BASES - Variable in class org.broadinstitute.hellbender.tools.walkers.markduplicates.EstimateLibraryComplexityGATK
 
MIN_IDENTICAL_BASES - Variable in class picard.sam.markduplicates.EstimateLibraryComplexity
 
MIN_INDEL_COUNT_FOR_GENOTYPING - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.UnifiedArgumentCollection
A candidate indel is genotyped (and potentially called) if there are this number of reads with a consensus indel at a site.
MIN_INDEL_FRACTION_PER_SAMPLE - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.UnifiedArgumentCollection
Complementary argument to minIndelCnt.
MIN_INDEL_SPACING_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.RemoveNearbyIndels
 
MIN_INSERT_SIZE - Variable in class org.broadinstitute.hellbender.metrics.InsertSizeMetrics
The minimum measured insert size.
MIN_INSERT_SIZE - Variable in class picard.analysis.InsertSizeMetrics
The minimum measured insert size.
MIN_LIFTOVER_PCT - Variable in class picard.util.LiftOverIntervalList
 
MIN_MAPPING_QUALITY_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.contamination.GetPileupSummaries
 
MIN_MAPPING_QUALITY_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.contamination.GetPileupSummaries
 
MIN_MATCH_BASES - Static variable in class picard.util.ClippingUtility
The default value used for the minimum number of contiguous bases to match against.
MIN_MATCH_BASES_PE - Variable in class picard.illumina.MarkIlluminaAdapters
 
MIN_MATCH_BASES_SE - Variable in class picard.illumina.MarkIlluminaAdapters
 
MIN_MATCH_PE_BASES - Static variable in class picard.util.ClippingUtility
The default value used for the minimum number of contiguous bases to match against in a paired end read
MIN_MEAN_QUALITY - Variable in class org.broadinstitute.hellbender.tools.walkers.markduplicates.EstimateLibraryComplexityGATK
 
MIN_MEAN_QUALITY - Variable in class picard.sam.markduplicates.EstimateLibraryComplexity
 
MIN_MEDIAN_BASE_QUALITY_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
MIN_MEDIAN_MAPPING_QUALITY_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
MIN_MEDIAN_READ_POSITION_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
MIN_MISMATCH_DELTA - Variable in class picard.illumina.ExtractIlluminaBarcodes
 
MIN_NON_VIRUS_CONTIG_LENGTH_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildReferenceTaxonomy
 
MIN_NON_VIRUS_CONTIG_LENGTH_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildReferenceTaxonomy
 
MIN_NUMBER_OF_EVENTS_TO_COMBINE_INTO_BLOCK_SUBSTITUTION - Static variable in class org.broadinstitute.hellbender.utils.haplotype.EventMap
 
MIN_PHRED_SCALED_QUAL - Static variable in class org.broadinstitute.hellbender.utils.QualityUtils
 
MIN_POS - Static variable in class picard.illumina.parser.readers.AbstractIlluminaPositionFileReader
At least one NextSeq run produced a small negative value for y coordinate (-5), so allow small negative values and see what happens.
MIN_PVALUE - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_StrandBiasTest
 
MIN_Q - Variable in class picard.sam.FastqToSam
 
MIN_QD - Variable in class picard.vcf.filter.FilterVcf
 
MIN_READ_LENGTH_ARG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ReadFilterArgumentDefinitions
 
MIN_SAMPLE_COUNT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.CreateSomaticPanelOfNormals
 
MIN_SAMPLES - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_InbreedingCoeff
 
MIN_SCORE_IDENTITY_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
 
MIN_SCORE_IDENTITY_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
 
MIN_SITE_AF_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.contamination.GetPileupSummaries
 
MIN_SITE_AF_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.contamination.GetPileupSummaries
 
MIN_STRAND_ARTIFACT_ALLELE_FRACTION_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
MIN_TAIL_QUALITY_WITH_ERROR_CORRECTION - Static variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerEngine
 
MIN_TRAINING_EPOCHS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection
 
MIN_UNCLIPPED_BASES - Variable in class picard.sam.MergeBamAlignment
 
MIN_USABLE_Q_SCORE - Static variable in class org.broadinstitute.hellbender.utils.QualityUtils
The lowest quality score for a base that is considered reasonable for statistical analysis.
MIN_VAL_COUNT - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
minAdapterLength - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
Adapter trimming will require a match of at least this length to a known adapter.
minAlignerScoreDifference - Variable in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.RealignmentArgumentCollection
Minimum difference between best and second-best alignment for a read to be considered well-mapped
minAlignLength - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.DiscoverVariantsFromContigsAlignmentsSparkArgumentCollection
 
minAssemblyRegionSize - Variable in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
minAssemblyRegionSize - Variable in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerSpark
 
minAssemblyRegionSize - Variable in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark.ShardingArgumentCollection
 
minBaseQuality - Variable in class org.broadinstitute.hellbender.tools.walkers.rnaseq.ASEReadCounter
If this argument is enabled, bases with quality scores lower than this threshold will not be counted.
minBaseQualityScore - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerArgumentCollection
Bases with a quality below this threshold will not be used for calling.
minBaseQualityToUseInAssembly - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingAssembler
 
minBqCutoff - Variable in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
minCoherentEvidenceWeight - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
minDanglingBranchLength - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadThreadingAssemblerArgumentCollection
When constructing the assembly graph we are often left with "dangling" branches.
minDepthOfNonFilteredBases - Variable in class org.broadinstitute.hellbender.tools.walkers.rnaseq.ASEReadCounter
If this argument is enabled, loci with total depth lower than this threshold after all filters have been applied will be skipped.
minDistance(GenomeLoc) - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
Return the minimum distance between any pair of bases in this and that GenomeLocs:
minEvidenceMapQ - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
minEvidenceMatchLength - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
minEvidenceWeight - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
MiniClusterUtils - Class in org.broadinstitute.hellbender.utils.test
Utilities to help manage a MiniDFSCluster for use in tests.
MiniClusterUtils() - Constructor for class org.broadinstitute.hellbender.utils.test.MiniClusterUtils
 
MiniClusterUtils.MiniClusterTest - Interface in org.broadinstitute.hellbender.utils.test
An interface for writing tests that run on a minicluster.
minIdentity - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
Controls the stringency of read filtering based on alignment to the host reference.
minIdentity - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
This parameter controls the stringency of the microbe alignment.
MinimalGenotypingEngine - Class in org.broadinstitute.hellbender.tools.walkers.genotyper
A stripped-down version of the former UnifiedGenotyper's genotyping strategy implementation, used only by the HaplotypeCaller for its isActive() determination.
MinimalGenotypingEngine(UnifiedArgumentCollection, SampleList, AFCalculatorProvider) - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.MinimalGenotypingEngine
Creates a new unified genotyping given the UG configuration parameters and the targeted set of samples
MinimalGenotypingEngine(UnifiedArgumentCollection, SampleList, AFCalculatorProvider, boolean) - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.MinimalGenotypingEngine
Creates a new unified genotyping given the UG configuration parameters and the targeted set of samples
MinimalVariant - Class in org.broadinstitute.hellbender.utils.variant
MinimalVariant is a minimal implementation of the GATKVariant interface.
MinimalVariant(SimpleInterval, boolean, boolean) - Constructor for class org.broadinstitute.hellbender.utils.variant.MinimalVariant
 
MINIMUM_BAITS_PER_TARGET - Variable in class picard.util.BaitDesigner
 
MINIMUM_BARCODE_BQ - Variable in class picard.analysis.replicates.CollectIndependentReplicateMetrics
 
MINIMUM_BASE_QUALITY - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2Engine
 
MINIMUM_BASE_QUALITY - Variable in class picard.analysis.CollectWgsMetrics
 
MINIMUM_BASE_QUALITY - Variable in class picard.analysis.directed.CollectTargetedMetrics
 
MINIMUM_BASE_QUALITY - Variable in class picard.illumina.ExtractIlluminaBarcodes
 
MINIMUM_BASE_QUALITY_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.CollectAllelicCounts
 
MINIMUM_BQ - Variable in class picard.analysis.replicates.CollectIndependentReplicateMetrics
 
MINIMUM_DISTANCE - Variable in class picard.sam.markduplicates.MarkDuplicatesWithMateCigar
 
MINIMUM_GENOME_FRACTION - Variable in class picard.analysis.CollectGcBiasMetrics
 
MINIMUM_GQ - Variable in class picard.analysis.replicates.CollectIndependentReplicateMetrics
 
MINIMUM_INSERT_SIZE - Variable in class picard.analysis.artifacts.CollectSequencingArtifactMetrics
 
MINIMUM_INSERT_SIZE - Variable in class picard.analysis.CollectOxoGMetrics
 
MINIMUM_INTERVAL_MEDIAN_PERCENTILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.CreateReadCountPanelOfNormals
 
MINIMUM_LENGTH - Variable in class picard.analysis.CollectRnaSeqMetrics
 
MINIMUM_LOD_SHORT_NAME - Static variable in class picard.cmdline.StandardOptionDefinitions
 
MINIMUM_MAPPING_QUALITY - Variable in class picard.analysis.artifacts.CollectSequencingArtifactMetrics
 
MINIMUM_MAPPING_QUALITY - Variable in class picard.analysis.CollectJumpingLibraryMetrics
 
MINIMUM_MAPPING_QUALITY - Variable in class picard.analysis.CollectOxoGMetrics
 
MINIMUM_MAPPING_QUALITY - Variable in class picard.analysis.CollectWgsMetrics
 
MINIMUM_MAPPING_QUALITY - Variable in class picard.analysis.directed.CollectTargetedMetrics
 
MINIMUM_MAPPING_QUALITY_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ReadFilterArgumentDefinitions
 
MINIMUM_MAPPING_QUALITY_SHORT_NAME - Static variable in class picard.cmdline.StandardOptionDefinitions
 
MINIMUM_MQ - Variable in class picard.analysis.replicates.CollectIndependentReplicateMetrics
 
MINIMUM_NUM_READS_FOR_SIGNAL_COUNT - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.PowerCalculationUtils
 
MINIMUM_PCT - Variable in class picard.analysis.CollectInsertSizeMetrics
 
MINIMUM_QUALITY - Variable in class picard.illumina.ExtractIlluminaBarcodes
 
MINIMUM_QUALITY - Variable in class picard.illumina.IlluminaBasecallsToFastq
 
MINIMUM_QUALITY - Variable in class picard.illumina.IlluminaBasecallsToSam
 
MINIMUM_QUALITY_SCORE - Variable in class picard.analysis.artifacts.CollectSequencingArtifactMetrics
 
MINIMUM_QUALITY_SCORE - Variable in class picard.analysis.CollectOxoGMetrics
 
MINIMUM_READ_LENGTH - Variable in class picard.analysis.CollectRrbsMetrics
 
MINIMUM_TOTAL_ALLELE_COUNT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
minimumAlleleIndex() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeAlleleCounts
Returns the smallest allele index present in the genotype.
minimumPct - Variable in class org.broadinstitute.hellbender.metrics.InsertSizeMetricsArgumentCollection
 
minimumSequenceLength - Variable in class org.broadinstitute.hellbender.engine.filters.OverclippedReadFilter
 
minIndex(int...) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
minKmerLength(Collection<byte[]>) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.GraphUtils
Get the minimum length of a collection of byte[]
minKmersPerInterval - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
minMappingQuality - Variable in class org.broadinstitute.hellbender.tools.walkers.rnaseq.ASEReadCounter
If this argument is enabled, reads with mapping quality values lower than this threshold will not be counted.
minMappingQualityScore - Variable in class org.broadinstitute.hellbender.engine.filters.MappingQualityReadFilter
 
minMedianBaseQuality - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
minMedianMappingQuality - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
minMedianReadPosition - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
minNonVirusContigLength - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildReferenceTaxonomy
Sequences from non-virus organisms less than this length will be filtered out such that any reads aligning to them will be ignored.
minObservationsForKmerToBeSolid - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadThreadingAssemblerArgumentCollection
 
MINOR_ALLELE_FRACTION_PRIOR_ALPHA_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
MINOR_ALLELE_FRACTION_STEP_SIZE - Static variable in class org.broadinstitute.hellbender.tools.walkers.contamination.CalculateContamination
 
MinorAlleleFractionRecord - Class in org.broadinstitute.hellbender.tools.walkers.contamination
Created by David Benjamin on 2/13/17.
MinorAlleleFractionRecord(SimpleInterval, double) - Constructor for class org.broadinstitute.hellbender.tools.walkers.contamination.MinorAlleleFractionRecord
 
minOverlapper(SVInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree
Find the earliest interval in the tree that overlaps the specified interval.
minPcrSlippageBases - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
minPower - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.UnifiedArgumentCollection
 
minPruneFactor - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadThreadingAssemblerArgumentCollection
Paths with fewer supporting kmers than the specified threshold will be pruned from the graph.
minQualityScore - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.UnifiedArgumentCollection
The following argument are for debug-only tweaks when running generalized ploidy with a reference sample
minReadLength - Variable in class org.broadinstitute.hellbender.engine.filters.ReadLengthReadFilter
 
minReadLength - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
Reads are trimmed based on base call quality and low-complexity content.
minSeedLength - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
Controls the sensitivity of BWA alignment to the host reference.
minSeedLength - Variable in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.RealignmentArgumentCollection
BWA-mem minimum seed length
MisencodedBaseQualityReadTransformer - Class in org.broadinstitute.hellbender.transformers
Checks for and errors out (or fixes if requested) when it detects reads with base qualities that are not encoded with phred-scaled quality scores.
MisencodedBaseQualityReadTransformer() - Constructor for class org.broadinstitute.hellbender.transformers.MisencodedBaseQualityReadTransformer
 
MisencodedQualityScoresRead(GATKRead, String) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.MisencodedQualityScoresRead
 
MismatchCount() - Constructor for class org.broadinstitute.hellbender.utils.read.AlignmentUtils.MismatchCount
 
mismatches - Variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
Number of mismatches, AlignmentInterval.NO_NM if unknown or unspecified.
MISMATCHES_CONTEXT_SIZE - Variable in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationArgumentCollection
The context covariate will use a context of this size to calculate its covariate value for base mismatches.
MISMATCHES_DEFAULT_QUALITY - Variable in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationArgumentCollection
A default base qualities to use as a prior (reported quality) in the mismatch covariate model.
MismatchMDElement() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.TextMDCodec.MismatchMDElement
 
mismatchQualities - Variable in class org.broadinstitute.hellbender.utils.read.AlignmentUtils.MismatchCount
 
MISSING_SITES_HOM_REF - Variable in class picard.vcf.GenotypeConcordance
 
MISSING_VAL_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
 
MissingContigInSequenceDictionary(String, SAMSequenceDictionary) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.MissingContigInSequenceDictionary
 
MissingIndex(String, String) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.MissingIndex
 
MissingReadField(String) - Constructor for exception org.broadinstitute.hellbender.exceptions.GATKException.MissingReadField
 
MissingReadField(String, String) - Constructor for exception org.broadinstitute.hellbender.exceptions.GATKException.MissingReadField
 
MissingReadField(String, GATKRead) - Constructor for exception org.broadinstitute.hellbender.exceptions.GATKException.MissingReadField
 
MissingReference(String) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.MissingReference
 
MissingReferenceDictFile(Path, Path) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.MissingReferenceDictFile
 
MissingReferenceDictFile(String) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.MissingReferenceDictFile
 
MissingReferenceFaiFile(Path, Path) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.MissingReferenceFaiFile
 
MIXING_FRACTIONS_TABLE_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.AnnotateVcfWithExpectedAlleleFraction
 
MixingFraction - Class in org.broadinstitute.hellbender.tools.walkers.validation
Simple class for storing a sample and its mixing fraction within a pooled bam.
MixingFraction(String, double) - Constructor for class org.broadinstitute.hellbender.tools.walkers.validation.MixingFraction
 
MLE_ALLELE_COUNT_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
MLE_ALLELE_FREQUENCY_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
MLE_PER_SAMPLE_ALLELE_COUNT_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
MLE_PER_SAMPLE_ALLELE_FRACTION_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
mLogLikelihoodArray - Variable in class org.broadinstitute.hellbender.utils.pairhmm.PairHMM
 
MMapBackedIteratorFactory - Class in picard.illumina.parser.readers
MMapBackedIteratorFactory a file reader that takes a header size and a binary file, maps the file to a read-only byte buffer and provides methods to retrieve the header as it's own bytebuffer and create iterators of different data types over the values of file (starting after the end of the header).
MMapBackedIteratorFactory() - Constructor for class picard.illumina.parser.readers.MMapBackedIteratorFactory
 
MODE - Variable in class org.broadinstitute.hellbender.tools.walkers.vqsr.GatherTranches
Use either SNP for recalibrating only SNPs (emitting indels untouched in the output VCF) or INDEL for indels (emitting SNPs untouched in the output VCF).
MODE - Variable in class picard.sam.ValidateSamFile
 
MODE_INSERT_SIZE - Variable in class picard.analysis.InsertSizeMetrics
The MODE insert size of all paired end reads where both ends mapped to the same chromosome.
model() - Method in interface org.broadinstitute.hellbender.utils.hmm.ForwardBackwardAlgorithm.Result
Returns the model passed to the forward-backward algorithm.
MODEL_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.CopyNumberStandardArgument
 
MODEL_PATH_SUFFIX - Static variable in class org.broadinstitute.hellbender.tools.copynumber.DetermineGermlineContigPloidy
 
MODEL_PATH_SUFFIX - Static variable in class org.broadinstitute.hellbender.tools.copynumber.GermlineCNVCaller
 
MODEL_SHARD_PATH_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.PostprocessGermlineCNVCalls
 
ModeledSegment - Class in org.broadinstitute.hellbender.tools.copynumber.formats.records
 
ModeledSegment(SimpleInterval, int, int, ModeledSegment.SimplePosteriorSummary, ModeledSegment.SimplePosteriorSummary) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.records.ModeledSegment
 
ModeledSegment.SimplePosteriorSummary - Class in org.broadinstitute.hellbender.tools.copynumber.formats.records
 
ModeledSegmentCollection - Class in org.broadinstitute.hellbender.tools.copynumber.formats.collections
 
ModeledSegmentCollection(File) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.collections.ModeledSegmentCollection
 
ModeledSegmentCollection(SampleLocatableMetadata, List<ModeledSegment>) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.collections.ModeledSegmentCollection
 
ModelSegments - Class in org.broadinstitute.hellbender.tools.copynumber
Models segmented copy ratios from denoised read counts and segmented minor-allele fractions from allelic counts.
ModelSegments() - Constructor for class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
MOLECULAR_BARCODE_NAME - Variable in class picard.illumina.IlluminaBasecallingMetrics
The barcode name for which the metrics were calculated.
MOLECULAR_BARCODE_SEQUENCE_1 - Variable in class picard.illumina.IlluminaBasecallingMetrics
The barcode sequence for which the metrics were calculated.
MOLECULAR_INDEX_BASE_QUALITY_TAG - Variable in class picard.illumina.IlluminaBasecallsToSam
 
MOLECULAR_INDEX_TAG - Variable in class picard.illumina.IlluminaBasecallsToSam
 
molecularBarcode - Variable in class picard.illumina.parser.ReadStructure
 
MolecularIndex - Static variable in enum picard.illumina.parser.ReadType
 
MostDistantPrimaryAlignmentSelectionStrategy - Class in org.broadinstitute.hellbender.utils.read.mergealignment
For a paired-end aligner that aligns each end independently, select the pair of alignments that result in the largest insert size.
MostDistantPrimaryAlignmentSelectionStrategy() - Constructor for class org.broadinstitute.hellbender.utils.read.mergealignment.MostDistantPrimaryAlignmentSelectionStrategy
 
MostDistantPrimaryAlignmentSelectionStrategy - Class in picard.sam
For a paired-end aligner that aligns each end independently, select the pair of alignments that result in the largest insert size.
MostDistantPrimaryAlignmentSelectionStrategy() - Constructor for class picard.sam.MostDistantPrimaryAlignmentSelectionStrategy
 
MOTHER - Variable in class picard.vcf.MendelianViolations.MendelianViolationMetrics
The ID of the mother within the trio.
mpileup - Variable in class org.broadinstitute.hellbender.tools.walkers.qc.CheckPileup
This is the existing mpileup against which we'll compare GATK's internal pileup at each genome position in the desired interval.
msBetweenCallsToRead - Variable in class org.broadinstitute.hellbender.utils.nio.SeekableByteChannelPrefetcher
 
msCopyingData - Variable in class org.broadinstitute.hellbender.utils.nio.SeekableByteChannelPrefetcher
 
msWaitingForData - Variable in class org.broadinstitute.hellbender.utils.nio.SeekableByteChannelPrefetcher
 
MTAC - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2
 
MTFAC - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.FilterMutectCalls
 
MULTIALLELIC_FILTER_NAME - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
MultiDeBruijnVertex - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading
A DeBruijnVertex that supports multiple copies of the same kmer
MultiDeBruijnVertex(byte[], boolean) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.MultiDeBruijnVertex
Create a new MultiDeBruijnVertex with kmer sequence
MultiDeBruijnVertex(byte[]) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.MultiDeBruijnVertex
Create a new MultiDeBruijnVertex with kmer sequence
MultidimensionalKernelSegmenter - Class in org.broadinstitute.hellbender.tools.copynumber.segmentation
Segments copy-ratio and alternate-allele-fraction data using kernel segmentation.
MultidimensionalKernelSegmenter(CopyRatioCollection, AllelicCountCollection) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.segmentation.MultidimensionalKernelSegmenter
 
MultidimensionalModeller - Class in org.broadinstitute.hellbender.tools.copynumber.models
Represents a segmented model for copy ratio and allele fraction.
MultidimensionalModeller(MultidimensionalSegmentCollection, CopyRatioCollection, AllelicCountCollection, AlleleFractionPrior, int, int, int, int) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.models.MultidimensionalModeller
Constructs a copy-ratio and allele-fraction modeller, specifying number of total samples and number of burn-in samples for Markov-Chain Monte Carlo model fitting.
MultidimensionalSegment - Class in org.broadinstitute.hellbender.tools.copynumber.formats.records
 
MultidimensionalSegment(SimpleInterval, int, int, double) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.records.MultidimensionalSegment
 
MultidimensionalSegment(SimpleInterval, List<CopyRatio>, List<AllelicCount>) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.records.MultidimensionalSegment
 
MultidimensionalSegment(SimpleInterval, Comparator<Locatable>, OverlapDetector<CopyRatio>, OverlapDetector<AllelicCount>) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.records.MultidimensionalSegment
 
MultidimensionalSegmentCollection - Class in org.broadinstitute.hellbender.tools.copynumber.formats.collections
 
MultidimensionalSegmentCollection(File) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.collections.MultidimensionalSegmentCollection
 
MultidimensionalSegmentCollection(SampleLocatableMetadata, List<MultidimensionalSegment>) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.collections.MultidimensionalSegmentCollection
 
MultiHitAlignedReadIterator - Class in org.broadinstitute.hellbender.utils.read.mergealignment
Iterate over queryname-sorted SAM, and return each group of reads with the same queryname.
MultiIntervalLocalReadShard - Class in org.broadinstitute.hellbender.engine
A class to represent shards of read data spanning multiple intervals.
MultiIntervalLocalReadShard(List<SimpleInterval>, int, ReadsDataSource) - Constructor for class org.broadinstitute.hellbender.engine.MultiIntervalLocalReadShard
Create a new MultiIntervalLocalReadShard spanning the given intervals, with each interval expanded on both sides by the specified number of padding bases.
MultiIntervalLocalReadShard(List<SimpleInterval>, ReadsDataSource) - Constructor for class org.broadinstitute.hellbender.engine.MultiIntervalLocalReadShard
Create a new MultiIntervalLocalReadShard spanning the given intervals, with no padding around intervals.
MultiIntervalShard<T> - Interface in org.broadinstitute.hellbender.engine
An interface to represent shards of arbitrary data spanning multiple intervals.
MultiLevelCollector<METRIC_TYPE extends htsjdk.samtools.metrics.MetricBase,HISTOGRAM_KEY extends java.lang.Comparable<HISTOGRAM_KEY>,ARGTYPE> - Class in org.broadinstitute.hellbender.metrics
MultiLevelCollector handles accumulating Metrics at different MetricAccumulationLevels(ALL_READS, SAMPLE, LIBRARY, READ_GROUP).
MultiLevelCollector() - Constructor for class org.broadinstitute.hellbender.metrics.MultiLevelCollector
 
MultiLevelCollector<METRIC_TYPE extends htsjdk.samtools.metrics.MetricBase,Histogram_KEY extends java.lang.Comparable,ARGTYPE> - Class in picard.metrics
MultiLevelCollector handles accumulating Metrics at different MetricAccumulationLevels(ALL_READS, SAMPLE, LIBRARY, READ_GROUP).
MultiLevelCollector() - Constructor for class picard.metrics.MultiLevelCollector
 
MultiLevelMetrics - Class in org.broadinstitute.hellbender.metrics
 
MultiLevelMetrics() - Constructor for class org.broadinstitute.hellbender.metrics.MultiLevelMetrics
 
MultilevelMetrics - Class in picard.metrics
 
MultilevelMetrics() - Constructor for class picard.metrics.MultilevelMetrics
 
MultiLevelReducibleCollector<METRIC_TYPE extends htsjdk.samtools.metrics.MetricBase,HISTOGRAM_KEY extends java.lang.Comparable<HISTOGRAM_KEY>,ARGTYPE,UNIT_COLLECTOR extends PerUnitMetricCollector<METRIC_TYPE,HISTOGRAM_KEY,ARGTYPE>> - Class in org.broadinstitute.hellbender.metrics
Abstract base class for reducible multi-level metrics collectors.
MultiLevelReducibleCollector() - Constructor for class org.broadinstitute.hellbender.metrics.MultiLevelReducibleCollector
 
multipleAtWhichToBreakBands - Variable in class org.broadinstitute.hellbender.tools.walkers.CombineGVCFs
To reduce file sizes our gVCFs group similar reference positions into bands.
MULTIPLEX_PARAMS - Variable in class picard.illumina.IlluminaBasecallsToFastq
 
multiply(double[], double[]) - Static method in class picard.util.MathUtil
Calculates the product of two arrays of the same length.
MultiSampleEdge - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs
Edge class for connecting nodes in the graph that tracks some per-sample information.
MultiSampleEdge(boolean, int, int) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.MultiSampleEdge
Create a new MultiSampleEdge with weight multiplicity and, if isRef == true, indicates a path through the reference
MultiThreadedChunkBased(int, VariantIteratorProducer, VariantProcessor.AccumulatorGenerator<A, R>) - Constructor for class picard.vcf.processor.VariantAccumulatorExecutor.MultiThreadedChunkBased
 
multithreadingBy(int) - Method in class picard.vcf.processor.VariantProcessor.Builder
 
MultiTileBclFileFaker - Class in picard.illumina.parser.fakers
Created by jcarey on 3/13/14.
MultiTileBclFileFaker() - Constructor for class picard.illumina.parser.fakers.MultiTileBclFileFaker
 
MultiTileBclFileUtil - Class in picard.illumina.parser
NextSeq-style bcl's have all tiles for a cycle in a single file.
MultiTileBclParser - Class in picard.illumina.parser
Parse .bcl.bgzf files that contain multiple tiles in a single file.
MultiTileBclParser(File, int, CycleIlluminaFileMap, OutputMapping, boolean, BclQualityEvaluationStrategy, TileIndex) - Constructor for class picard.illumina.parser.MultiTileBclParser
 
MultiTileFileUtil<OUTPUT_RECORD extends picard.illumina.parser.IlluminaData> - Class in picard.illumina.parser
For file types for which there is one file per lane, with fixed record size, and all the tiles in it, so the s_.bci file can be used to figure out where each tile starts and ends.
MultiTileFilterParser - Class in picard.illumina.parser
Read filter file that contains multiple tiles in a single file.
MultiTileFilterParser(TileIndex, List<Integer>, File) - Constructor for class picard.illumina.parser.MultiTileFilterParser
 
MultiTileLocsFileFaker - Class in picard.illumina.parser.fakers
Created by jcarey on 3/13/14.
MultiTileLocsFileFaker() - Constructor for class picard.illumina.parser.fakers.MultiTileLocsFileFaker
 
MultiTileLocsParser - Class in picard.illumina.parser
Read locs file that contains multiple tiles in a single file.
MultiTileLocsParser(TileIndex, List<Integer>, File, int) - Constructor for class picard.illumina.parser.MultiTileLocsParser
 
MultiTileParser<OUTPUT_RECORD extends picard.illumina.parser.IlluminaData> - Class in picard.illumina.parser
Abstract class for files with fixed-length records for multiple tiles, e.g.
MultiTileParser(TileIndex, List<Integer>, Set<IlluminaDataType>) - Constructor for class picard.illumina.parser.MultiTileParser
 
MultiVariantDataSource - Class in org.broadinstitute.hellbender.engine
MultiVariantDataSource aggregates multiple FeatureDataSources of variants, and enables traversals and queries over those sources through a single interface.
MultiVariantDataSource(List<FeatureInput<VariantContext>>, int) - Constructor for class org.broadinstitute.hellbender.engine.MultiVariantDataSource
Creates a MultiVariantDataSource backed by the provided FeatureInputs.
MultiVariantDataSource(List<FeatureInput<VariantContext>>, int, int, int, Path) - Constructor for class org.broadinstitute.hellbender.engine.MultiVariantDataSource
Creates a MultiVariantDataSource backed by the provided FeatureInputs.
MultiVariantWalker - Class in org.broadinstitute.hellbender.engine
A MultiVariantWalker is a tool that processes one variant at a time, in position order, from multiple sources of variants, with optional contextual information from a reference, sets of reads, and/or supplementary sources of Features.
MultiVariantWalker() - Constructor for class org.broadinstitute.hellbender.engine.MultiVariantWalker
 
MultiVariantWalkerGroupedOnStart - Class in org.broadinstitute.hellbender.engine
A MultiVariantWalker that walks over multiple variant context sources in reference order and emits to client tools groups of all input variant contexts by their start position.
MultiVariantWalkerGroupedOnStart() - Constructor for class org.broadinstitute.hellbender.engine.MultiVariantWalkerGroupedOnStart
 
Mutect2 - Class in org.broadinstitute.hellbender.tools.walkers.mutect
Call somatic short variants via local assembly of haplotypes.
Mutect2() - Constructor for class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2
 
Mutect2Engine - Class in org.broadinstitute.hellbender.tools.walkers.mutect
Created by davidben on 9/15/16.
Mutect2Engine(M2ArgumentCollection, boolean, boolean, SAMFileHeader, String, VariantAnnotatorEngine) - Constructor for class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2Engine
Create and initialize a new HaplotypeCallerEngine given a collection of HaplotypeCaller arguments, a reads header, and a reference file
Mutect2FilteringEngine - Class in org.broadinstitute.hellbender.tools.walkers.mutect
Created by David Benjamin on 9/15/16.
Mutect2FilteringEngine(M2FiltersArgumentCollection, String) - Constructor for class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2FilteringEngine
 
MUTECT_FILTER_NAMES - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
MutectDownsampler - Class in org.broadinstitute.hellbender.utils.downsampling
 
MutectDownsampler(int, int, int) - Constructor for class org.broadinstitute.hellbender.utils.downsampling.MutectDownsampler
 

N

N_BASE_COUNT_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
N_CYCLES - Variable in class picard.illumina.quality.CollectHiSeqXPfFailMetrics
 
NA - Static variable in class picard.vcf.GenotypeConcordanceScheme
These are convenience variables for defining a scheme.
nAlternateAllelesBiDups - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
nAlternateAllelesTriDups - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
nAlternateReads - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
name - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.MarkDuplicatesSparkRecord
 
name - Variable in class org.broadinstitute.hellbender.utils.test.BaseTest.TestDataProvider
 
name - Variable in class picard.annotation.Gene.Transcript
 
NAME - Variable in class picard.util.FifoBuffer
 
nameAt(int) - Method in class org.broadinstitute.hellbender.utils.tsv.TableColumnCollection
Returns the name of a column by its index.
names() - Method in class org.broadinstitute.hellbender.utils.tsv.TableColumnCollection
Returns the column names ordered by column index.
nameSuffix() - Method in enum org.broadinstitute.hellbender.tools.spark.sv.evidence.TemplateFragmentOrdinal
 
NativeUtils - Class in org.broadinstitute.hellbender.utils
Utilities to provide architecture-dependent native functions
NATURAL_LOG_MATH - Static variable in class picard.util.MathUtil
 
nBadBarcodes - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
nbGoingBack - Variable in class org.broadinstitute.hellbender.utils.nio.SeekableByteChannelPrefetcher
 
nbHit - Variable in class org.broadinstitute.hellbender.utils.nio.SeekableByteChannelPrefetcher
 
nbMiss - Variable in class org.broadinstitute.hellbender.utils.nio.SeekableByteChannelPrefetcher
 
nbNearHit - Variable in class org.broadinstitute.hellbender.utils.nio.SeekableByteChannelPrefetcher
 
nbReadsPastEnd - Variable in class org.broadinstitute.hellbender.utils.nio.SeekableByteChannelPrefetcher
 
nClippedBases - Variable in class org.broadinstitute.hellbender.tools.ClipReads.ClippingData
 
nClippedReads - Variable in class org.broadinstitute.hellbender.tools.ClipReads.ClippingData
 
nDifferentAllelesBiDups - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
nDifferentAllelesTriDups - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
NDNCigarReadTransformer - Class in org.broadinstitute.hellbender.transformers
A read transformer that refactors NDN cigar elements to one N element.
NDNCigarReadTransformer() - Constructor for class org.broadinstitute.hellbender.transformers.NDNCigarReadTransformer
 
nDuplicateSets - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
NEAR_AMPLICON_BASES - Variable in class picard.analysis.directed.TargetedPcrMetrics
The number of PF_BASES_ALIGNED that mapped to within a fixed interval of an amplified region, but not on a baited region.
NEAR_BAIT_BASES - Variable in class picard.analysis.directed.HsMetrics
The number of PF_BASES_ALIGNED that are mapped to within a fixed interval containing a baited region, but not within the baited section per se.
NEAR_DISTANCE - Variable in class picard.analysis.directed.CollectTargetedMetrics
 
NEAR_PROBE_BASES - Variable in class picard.analysis.directed.TargetMetrics
The number of PF aligned bases that mapped to within a fixed interval of a probed region, but not on a baited region.
NEAR_PROBE_DISTANCE_DEFAULT - Static variable in class picard.analysis.directed.TargetMetricsCollector
Default distance for a read to be considered "selected".
nearestNeighborUniform1DInterpolate(double[], int) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Shrinks or expands a double array uniformly to a given length >= 2 (newLength) using nearest neighbor interpolation.
needsReferenceSequence() - Method in interface picard.analysis.CollectMultipleMetrics.ProgramInterface
 
needsRemapping() - Method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils.AlleleMapper
 
needsTrimming - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmer.Result
Indicates whether trimming is required per data and user request.
needsTrimming() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmer.Result
Checks whether the active region needs trimming.
negate() - Method in class org.broadinstitute.hellbender.engine.filters.CountingReadFilter
Specialization of negate so that the resulting object is still a CountingReadFilter
negate() - Method in class org.broadinstitute.hellbender.engine.filters.CountingVariantFilter
Specialization of negate so that the resulting object is still a CountingVariantFilter
negate() - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilter
Specialization of negate so that the resulting object is still a ReadFilter
negate() - Method in interface org.broadinstitute.hellbender.engine.filters.VariantFilter
 
NEGATIVE_LABEL_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
neighboringVerticesOf(V) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Get the set of vertices connected to v by incoming or outgoing edges
NestedIntegerArray<T extends java.io.Serializable> - Class in org.broadinstitute.hellbender.utils.collections
 
NestedIntegerArray(int...) - Constructor for class org.broadinstitute.hellbender.utils.collections.NestedIntegerArray
 
NestedIntegerArray.Leaf<T> - Class in org.broadinstitute.hellbender.utils.collections
 
NEUTRAL_SEGMENT_COPY_RATIO_LOWER_BOUND_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.CallCopyRatioSegments
 
NEUTRAL_SEGMENT_COPY_RATIO_UPPER_BOUND_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.CallCopyRatioSegments
 
NEW_SAMPLE_NAME - Variable in class picard.vcf.RenameSampleInVcf
 
NEW_SW_PARAMETERS - Static variable in class org.broadinstitute.hellbender.utils.read.CigarUtils
 
newAFCalculator - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
 
newCounter() - Method in class picard.analysis.CounterManager
Creates a new Counter object and adds it to the list of managed Counters.
newEmptyFragment(GATKRead, SAMFileHeader) - Static method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.MarkDuplicatesSparkRecord
 
newFragment(GATKRead, SAMFileHeader, int, MarkDuplicatesScoringStrategy) - Static method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.MarkDuplicatesSparkRecord
 
NewIlluminaBasecallsConverter<CLUSTER_OUTPUT_RECORD> - Class in picard.illumina
 
NewIlluminaBasecallsConverter(File, File, int, ReadStructure, Map<String, ? extends BasecallsConverter.ConvertedClusterDataWriter<CLUSTER_OUTPUT_RECORD>>, boolean, int, List<File>, int, Integer, Integer, Comparator<CLUSTER_OUTPUT_RECORD>, SortingCollection.Codec<CLUSTER_OUTPUT_RECORD>, Class<CLUSTER_OUTPUT_RECORD>, BclQualityEvaluationStrategy, boolean) - Constructor for class picard.illumina.NewIlluminaBasecallsConverter
 
NewIlluminaDataProvider - Class in picard.illumina.parser
Parse cbcls Illumina Basecall files, and use them the to populate ClusterData objects.
newInstance() - Method in enum org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculatorImplementation
 
newInstance(AlleleListPermutation<A>) - Static method in interface org.broadinstitute.hellbender.tools.walkers.genotyper.AlleleLikelihoodMatrixMapper
Instantiates a new mapper given an allele-list permutation.
newPair(GATKRead, GATKRead, SAMFileHeader, int, MarkDuplicatesScoringStrategy) - Static method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.MarkDuplicatesSparkRecord
 
newSimpleReport(String, GATKReportTable.Sorting, String...) - Static method in class org.broadinstitute.hellbender.utils.report.GATKReport
The constructor for a simplified GATK Report.
newSimpleReportWithDescription(String, String, GATKReportTable.Sorting, String...) - Static method in class org.broadinstitute.hellbender.utils.report.GATKReport
 
nExactlyDouble - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
nExactlyTriple - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
next() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegionIterator
 
next() - Method in class org.broadinstitute.hellbender.engine.spark.AddContextDataToReadSparkOptimized.SubdivideAndFillReadsIterator
 
next() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointDensityFilter
 
next() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.PairedStrandedIntervalTree.PairedStrandedIntervalTreeIterator
 
next() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.PairedStrandedIntervalTree.PairedStrandedIntervalTreeOverlapperIterator
 
next() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree.FwdIterator
 
next() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree.OverlapIterator
 
next() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree.RevIterator
 
next() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree.ValuesIterator
 
next() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerizer
 
next() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVUtils.IteratorFilter
 
next() - Method in class org.broadinstitute.hellbender.tools.spark.utils.FlatMapGluer
 
next() - Method in interface org.broadinstitute.hellbender.tools.spark.utils.LongIterator
 
next() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeAlleleCounts
Calculates the next genotype in likelihood indexing order.
next() - Method in class org.broadinstitute.hellbender.utils.downsampling.ReadsDownsamplingIterator
 
next() - Method in class org.broadinstitute.hellbender.utils.iterators.AllLocusIterator
 
next() - Method in class org.broadinstitute.hellbender.utils.iterators.ByteArrayIterator
 
next() - Method in class org.broadinstitute.hellbender.utils.iterators.IntervalLocusIterator
 
next() - Method in class org.broadinstitute.hellbender.utils.iterators.IntervalOverlappingIterator
 
next() - Method in class org.broadinstitute.hellbender.utils.iterators.ReadCachingIterator
 
next() - Method in class org.broadinstitute.hellbender.utils.iterators.ReadFilteringIterator
 
next() - Method in class org.broadinstitute.hellbender.utils.iterators.ReadTransformingIterator
 
next() - Method in class org.broadinstitute.hellbender.utils.iterators.SamReaderQueryingIterator
 
next() - Method in class org.broadinstitute.hellbender.utils.iterators.SAMRecordToReadIterator
 
next() - Method in class org.broadinstitute.hellbender.utils.iterators.ShardedIntervalIterator
 
next() - Method in class org.broadinstitute.hellbender.utils.locusiterator.IntervalAlignmentContextIterator
 
next() - Method in class org.broadinstitute.hellbender.utils.locusiterator.LocusIteratorByState
Get the next AlignmentContext available from the reads.
next - Variable in class org.broadinstitute.hellbender.utils.read.ArtificialReadIterator
 
next() - Method in class org.broadinstitute.hellbender.utils.read.ArtificialReadIterator
 
next() - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.MultiHitAlignedReadIterator
 
next() - Method in class org.broadinstitute.hellbender.utils.text.XReadLines
Returns the next line (optionally minus whitespace)
next() - Method in class picard.illumina.parser.IlluminaDataProvider
 
next() - Method in class picard.illumina.parser.MultiTileParser
 
next() - Method in class picard.illumina.parser.NewIlluminaDataProvider
 
next() - Method in class picard.illumina.parser.PerTileParser
 
next() - Method in class picard.illumina.parser.readers.AbstractIlluminaPositionFileReader
Return the next set of coordinates in a given file.
next() - Method in class picard.illumina.parser.readers.BarcodeFileReader
 
next() - Method in class picard.illumina.parser.readers.BclReader
 
next() - Method in class picard.illumina.parser.readers.CbclReader
 
next() - Method in class picard.illumina.parser.readers.EmpiricalPhasingMetricsOutReader
 
next() - Method in class picard.illumina.parser.readers.FilterFileReader
 
next() - Method in class picard.illumina.parser.readers.TileMetricsOutReader
 
next() - Method in class picard.sam.markduplicates.MarkDuplicatesWithMateCigarIterator
 
next() - Method in class picard.util.AsyncIterator
 
next() - Method in interface picard.util.AtomicIterator
Produces the next element from the iterator, if there is one; otherwise, produces Optional.EMPTY
next() - Method in class picard.util.DelimitedTextFileWithHeaderIterator
 
next() - Method in class picard.vcf.ByIntervalListVariantContextIterator
 
next() - Method in class picard.vcf.filter.FilterApplyingVariantIterator
Provides the next record from the underlying iterator after applying filter strings generated by the set of filters in use by the iterator.
next() - Method in class picard.vcf.PairedVariantSubContextIterator
 
next() - Method in class picard.vcf.processor.util.PredicateFilterDecoratingClosableIterator
 
NEXT_BASE_QUALITY_THRESHOLD - Variable in class picard.analysis.CollectRrbsMetrics
 
nextKmer(SVKmer, int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVDUSTFilteredKmerizer
 
nextKmer - Variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerizer
 
nextKmer(SVKmer, int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerizer
 
nextSequence() - Method in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark.ReferenceMultiSourceAdapter
 
nGoodBarcodes - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
NGSPlatform - Enum in org.broadinstitute.hellbender.utils
A canonical, master list of the standard NGS platforms.
NIO_MAX_REOPENS - Variable in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
 
NIO_MAX_REOPENS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
NIO_MAX_REOPENS_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
NioBam - Class in org.broadinstitute.hellbender.utils.nio
NioBam holds a reference to a BAM file on Google Cloud Storage, and can give you an RDD with the reads inside of it.
NioBam(String, String) - Constructor for class org.broadinstitute.hellbender.utils.nio.NioBam
Checks the files exists, then stores them.
NioBam(String) - Constructor for class org.broadinstitute.hellbender.utils.nio.NioBam
Finds the index file, then calls NioBam(bam, index).
nMatchingUMIsInDiffBiDups - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
nMatchingUMIsInSameBiDups - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
nMismatchingAllelesBiDups - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
nMismatchingAllelesTriDups - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
nMismatchingUMIsInContraOrientedBiDups - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
nMismatchingUMIsInCoOrientedBiDups - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
nMismatchingUMIsInDiffBiDups - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
nMismatchingUMIsInSameBiDups - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
NO_AS - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
Indicates that no AS (alignment score) annotation is present.
NO_CALL_ALLELES - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Deprecated.
you should use GATKVariantContextUtils.noCallAlleles(int) instead. It indicates the presence of a hardcoded diploid assumption which is bad.
NO_CALL_GTS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
 
NO_DOWNSAMPLING - Static variable in class org.broadinstitute.hellbender.utils.locusiterator.LocusIteratorByState
Indicates that we shouldn't do any downsampling
NO_EXON_NUMBER - Static variable in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
NO_FEATURE_ORDER - Static variable in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
NO_FILTER - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.SingleSequenceReferenceAligner
 
NO_GOOD_MAPPING_TO_NON_CANONICAL_CHROMOSOME - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments
NO_JOINT_VALUE - Variable in class org.broadinstitute.hellbender.tools.walkers.variantutils.FamilyLikelihoods
 
NO_LENGTH - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVContext
Indicates that the variant does not have a length or this could not be determined, e.g.
NO_LIBRARIES_SPECIFIED_IN_HEADER - Static variable in class picard.sam.SplitSamByLibrary
 
NO_LINE_NUMBER - Static variable in class org.broadinstitute.hellbender.utils.tsv.DataLine
Constant to indicate that a data-line has no line number assigned.
NO_MAPPING_QUALITY - Static variable in class org.broadinstitute.hellbender.utils.read.ReadConstants
Value used to represent the absence of a mapping quality in a read
NO_MATCH - Static variable in class picard.util.ClippingUtility
The value returned by methods returning int when no match is found.
NO_NM - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
Indicates that no NM (number of mismatches) annotation is present.
NO_PHENO - Static variable in class picard.pedigree.PedFile
 
NO_VALUE - Static variable in interface picard.sam.util.PhysicalLocation
 
NO_VALUE_STR - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
Represents the lack of a value for a field in a string representation.
NOCALL_CHROM_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
noCallAlleles(int) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Returns a NO_CALL allele list provided the ploidy.
noExtraAttributes - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvType
 
NON_CPG_BASES - Variable in class picard.analysis.RrbsSummaryMetrics
Number of times a non-CpG cytosine was encountered
NON_CPG_CONVERTED_BASES - Variable in class picard.analysis.RrbsSummaryMetrics
Number of times a non-CpG cytosine was converted (C->T for +, G->A for -)
NON_DIPLOID_RATIO_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
NON_REF_GENOTYPE_CONCORDANCE - Variable in class picard.vcf.GenotypeConcordanceSummaryMetrics
The non-ref genotype concordance, ie for all var states only.
NON_REF_SYMBOLIC_ALLELE_NAME - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
NON_ZERO_REFERENCE_LENGTH_ALIGNMENT - Static variable in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary
 
nonCanonicalChromosomeNamesFile - Variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.CpxVariantReInterpreterSpark
 
NonChecksumLocalFileSystem - Class in org.broadinstitute.hellbender.engine.spark
An extension of Hadoop's LocalFileSystem that doesn't write (or verify) .crc files.
NonChecksumLocalFileSystem() - Constructor for class org.broadinstitute.hellbender.engine.spark.NonChecksumLocalFileSystem
 
NONE - Static variable in class org.broadinstitute.hellbender.utils.downsampling.DownsamplingMethod
Expresses no downsampling applied at all.
nonEmpty(T, String) - Static method in class org.broadinstitute.hellbender.utils.Utils
Checks that a Collection is not null and that it is not empty.
nonEmpty(String, String) - Static method in class org.broadinstitute.hellbender.utils.Utils
Checks that a String is not null and that it is not empty.
nonEmpty(String) - Static method in class org.broadinstitute.hellbender.utils.Utils
Checks that a String is not null and that it is not empty.
nonEmpty(T) - Static method in class org.broadinstitute.hellbender.utils.Utils
Checks that a Collection is not null and that it is not empty.
NONJUMP_DUPLICATE_PAIRS - Variable in class picard.analysis.JumpingLibraryMetrics
The number of inward-facing pais that are duplicates
NONJUMP_DUPLICATE_PCT - Variable in class picard.analysis.JumpingLibraryMetrics
The fraction of inward-facing pairs that are marked as duplicates
NONJUMP_LIBRARY_SIZE - Variable in class picard.analysis.JumpingLibraryMetrics
The estimated library size for inward-facing pairs
NONJUMP_MEAN_INSERT_SIZE - Variable in class picard.analysis.JumpingLibraryMetrics
The mean insert size for inward-facing pairs
NONJUMP_PAIRS - Variable in class picard.analysis.JumpingLibraryMetrics
The number of inward-facing pairs in the SAM file
NONJUMP_STDEV_INSERT_SIZE - Variable in class picard.analysis.JumpingLibraryMetrics
The standard deviation on the insert size for inward-facing pairs
NonNFastaSize - Class in picard.reference
A tool to count the number of non-N bases in a fasta file
NonNFastaSize() - Constructor for class picard.reference.NonNFastaSize
 
nonNull(T) - Static method in class org.broadinstitute.hellbender.utils.Utils
Checks that an Object object is not null and returns the same object or throws an IllegalArgumentException
nonNull(T, String) - Static method in class org.broadinstitute.hellbender.utils.Utils
Checks that an Object is not null and returns the same object or throws an IllegalArgumentException
nonNull(T, Supplier<String>) - Static method in class org.broadinstitute.hellbender.utils.Utils
Checks that an Object is not null and returns the same object or throws an IllegalArgumentException
NonPermutation(AlleleList<A>) - Constructor for class org.broadinstitute.hellbender.utils.genotyper.AlleleList.NonPermutation
 
nonSkips - Variable in class picard.illumina.parser.ReadStructure
 
nonVariantFlanks - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmer.Result
Holds the flanking spans that do not contain the callable variants.
nonVariantLeftFlankRegion() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmer.Result
Returns the trimmed out left non-variant region.
nonVariantRightFlankRegion() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmer.Result
Returns the trimmed out right non-variant region.
NONZERO_FRAGMENT_LENGTH_READ_FILTER - Static variable in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary
 
NonZeroFragmentLengthReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.NonZeroFragmentLengthReadFilter
 
NonZeroReferenceLengthAlignmentReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.NonZeroReferenceLengthAlignmentReadFilter
 
noQuantization() - Method in class org.broadinstitute.hellbender.utils.recalibration.QuantizationInfo
 
NORMAL_ALLELIC_COUNTS_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
NORMAL_ALLELIC_COUNTS_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.CopyNumberStandardArgument
 
NORMAL_ALLELIC_COUNTS_FILE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
NORMAL_ARTIFACT_LOD_ATTRIBUTE - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
NORMAL_ARTIFACT_LOD_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
NORMAL_ARTIFACT_LOD_THRESHOLD - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
This is a measure of the minimum evidence to support that a variant observed in the tumor is not also present in the normal as an artifact i.e.
NORMAL_BAM_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
NORMAL_BAM_FILE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
NORMAL_HET_ALLELIC_COUNTS_FILE_SUFFIX - Static variable in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
NORMAL_LOD_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
NORMAL_LOD_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
NORMAL_SAMPLE_KEY_IN_VCF_HEADER - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2Engine
 
NORMAL_SAMPLE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
NORMAL_SAMPLE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
normalDistribution(double, double, double) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Calculate f(x) = Normal(x | mu = mean, sigma = sd)
normalDistributionLog10(double, double, double) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Calculate f(x) = log10 ( Normal(x | mu = mean, sigma = sd) )
normalizeAlleles(VariantContext, String, VariantContext, String, Boolean) - Static method in class picard.vcf.GenotypeConcordance
Gets the alleles for the truth and call genotypes.
NORMALIZED_COVERAGE - Variable in class picard.analysis.GcBiasDetailMetrics
The ratio of "coverage" in this GC bin vs.
normalizeData(boolean) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
 
NormalizeFasta - Class in picard.reference
Little program to "normalize" a fasta file to ensure that all line of sequence are the same length, and are a reasonable length!
NormalizeFasta() - Constructor for class picard.reference.NormalizeFasta
 
normalizeFromLog10ToLinearSpace(double[]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
normalizes the log-probability array in-place.
normalizeFromRealSpace(double[]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
normalizes the real-space probability array.
normalizeHistogram(Histogram<Integer>) - Static method in class picard.analysis.TheoreticalSensitivity
 
normalizeLikelihoods(boolean, double) - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Adjusts likelihoods so that for each read, the best allele likelihood is 0 and caps the minimum likelihood of any allele for each read based on the maximum alternative allele likelihood.
normalizeLog10(double[]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
normalizes the log-probability array in-place.
normalizeLog10(double[], boolean, boolean) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
See #normalizeFromLog but with the additional option to use an approximation that keeps the calculation always in log-space
normalizeLog10DeleteMePlease(double[], boolean) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
normalizePLs(int[]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
normalLod - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
This is a measure of the minimum evidence to support that a variant observed in the tumor is not also present in the normal.
normalSample - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
NoSuitableCodecs(Path) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.NoSuitableCodecs
 
NOT_DUPLICATE - Static variable in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary
 
NOT_NORMALIZED_BY_KINGDOM_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
 
NOT_NORMALIZED_BY_KINGDOM_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
 
NOT_SECONDARY_ALIGNMENT - Static variable in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary
 
NOT_SUPPLEMENTARY_ALIGNMENT - Static variable in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary
 
NOT_SV_OR_SYMBOLIC - Static variable in class org.broadinstitute.hellbender.engine.filters.VariantFilterLibrary
 
NotDuplicateReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.NotDuplicateReadFilter
 
notJunk(GATKRead) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.SVReadFilter
 
notNormalizedByKingdom - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
Comparmentalizes the normalized abundance scores by kingdom.
NotOpticalDuplicateReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Filters out reads marked as duplicates.
NotOpticalDuplicateReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.NotOpticalDuplicateReadFilter
 
noTrimming(boolean, AssemblyRegion, int, int, List<VariantContext>) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmer.Result
Creates a result indicating that there was no trimming to be done.
NotSecondaryAlignmentReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.NotSecondaryAlignmentReadFilter
 
NotSupplementaryAlignmentReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.NotSupplementaryAlignmentReadFilter
 
NoValidationCollection() - Constructor for class org.broadinstitute.hellbender.cmdline.argumentcollections.SequenceDictionaryValidationArgumentCollection.NoValidationCollection
 
noVariation(boolean, AssemblyRegion, int, int) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmer.Result
Creates a result indicating that no variation was found.
NOVEL_INDELS - Variable in class picard.vcf.CollectVariantCallingMetrics.VariantCallingSummaryMetrics
The number of passing indels called that were not found in dbSNP
NOVEL_INS_DEL_RATIO - Variable in class picard.vcf.CollectVariantCallingMetrics.VariantCallingSummaryMetrics
The Insertion/Deletion ratio of the indel calls made at non-dbSNP sites
NOVEL_SNPS - Variable in class picard.vcf.CollectVariantCallingMetrics.VariantCallingSummaryMetrics
The number of passing bi-allelic SNPS called that were not found in dbSNP
NOVEL_TITV - Variable in class picard.vcf.CollectVariantCallingMetrics.VariantCallingSummaryMetrics
The Transition/Transversion ratio of the passing bi-allelic SNP calls made at non-dbSNP sites
NovelAdjacencyAndAltHaplotype - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.inference
This class represents a pair of inferred genomic locations on the reference whose novel adjacency is generated due to an SV event (in other words, a simple rearrangement between two genomic locations) that is suggested by the input SimpleChimera, and complications as enclosed in BreakpointComplications in pinning down the locations to exact base pair resolution.
NovelAdjacencyAndAltHaplotype(SimpleChimera, byte[], SAMSequenceDictionary) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.NovelAdjacencyAndAltHaplotype
 
NovelAdjacencyAndAltHaplotype(Kryo, Input) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.NovelAdjacencyAndAltHaplotype
 
NovelAdjacencyAndAltHaplotype.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.inference
 
nQClippedBases - Variable in class org.broadinstitute.hellbender.tools.ClipReads.ClippingData
 
nRangeClippedBases - Variable in class org.broadinstitute.hellbender.tools.ClipReads.ClippingData
 
nReadsInBigSets - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
nReferenceAllelesBiDups - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
nReferenceAllelesTriDups - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
nReferenceReads - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
nSeqClippedBases - Variable in class org.broadinstitute.hellbender.tools.ClipReads.ClippingData
 
nSites - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
nThreeAllelesSites - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
nTotalBases - Variable in class org.broadinstitute.hellbender.tools.ClipReads.ClippingData
 
nTotalReads - Variable in class org.broadinstitute.hellbender.tools.ClipReads.ClippingData
 
nTotalReads - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
Nucleotide - Enum in org.broadinstitute.hellbender.utils
Represents the nucleotide alphabet.
Nucleotide.Counter - Class in org.broadinstitute.hellbender.utils
Helper class to count the number of occurrences of each nucleotide in a sequence.
NULL_NODE - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTree
 
NULL_SEQUENCE_STRING - Static variable in class org.broadinstitute.hellbender.utils.read.ReadConstants
Value used for String representation of a non-existent sequence
NUM_ADAPTERS_TO_KEEP - Variable in class picard.illumina.MarkIlluminaAdapters
 
NUM_BASES_ON_EITHER_SIDE - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.ReferenceBases
 
NUM_BURN_IN_ALLELE_FRACTION_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
NUM_CHANNELS - Static variable in enum picard.illumina.parser.IntensityChannel
 
NUM_DIPLOID_DENOVO - Variable in class picard.vcf.MendelianViolations.MendelianViolationMetrics
The number of diploid sites at which a potential de-novo mutation was observed (i.e.
NUM_GC_BINS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineDenoisingModelArgumentCollection
 
NUM_HAPLOID_DENOVO - Variable in class picard.vcf.MendelianViolations.MendelianViolationMetrics
The number of sites at which the offspring is haploid, the parent is homozygous reference and the offspring is non-reference.
NUM_HAPLOID_OTHER - Variable in class picard.vcf.MendelianViolations.MendelianViolationMetrics
The number of sites at which the offspring is haploid and exhibits a reference allele that is not present in the parent.
NUM_HOM_HET_HOM - Variable in class picard.vcf.MendelianViolations.MendelianViolationMetrics
The number of sites at which one parent is homozygous, the other is heterozygous and the offspring is the alternative homozygote.
NUM_HOMREF_HOMVAR_HOM - Variable in class picard.vcf.MendelianViolations.MendelianViolationMetrics
The number of sites at which the one parent is homozygous reference, the other homozygous variant and the offspring is homozygous.
NUM_HOMVAR_HOMVAR_HET - Variable in class picard.vcf.MendelianViolations.MendelianViolationMetrics
The number of sites at which both parents are homozygous for a non-reference allele and the offspring is heterozygous.
NUM_IN_DB_SNP - Variable in class picard.vcf.CollectVariantCallingMetrics.VariantCallingSummaryMetrics
The number of passing bi-allelic SNPs found in dbSNP
NUM_IN_DB_SNP_COMPLEX_INDELS - Variable in class picard.vcf.CollectVariantCallingMetrics.VariantCallingSummaryMetrics
The number of passing complex indels found in dbSNP
NUM_IN_DB_SNP_INDELS - Variable in class picard.vcf.CollectVariantCallingMetrics.VariantCallingSummaryMetrics
The number of passing indels found in dbSNP
NUM_IN_DB_SNP_MULTIALLELIC - Variable in class picard.vcf.CollectVariantCallingMetrics.VariantCallingSummaryMetrics
The number of passing multi-allelic SNPs found in dbSNP
NUM_N - Variable in class picard.illumina.quality.CollectHiSeqXPfFailMetrics.PFFailDetailedMetric
The number of Ns found in this read
NUM_OF_STRANDS - Static variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.AlleleSubsettingUtils
 
NUM_OTHER - Variable in class picard.vcf.MendelianViolations.MendelianViolationMetrics
The number of otherwise unclassified events.
NUM_PROCESSORS - Variable in class picard.illumina.ExtractIlluminaBarcodes
 
NUM_PROCESSORS - Variable in class picard.illumina.IlluminaBasecallsToFastq
 
NUM_PROCESSORS - Variable in class picard.illumina.IlluminaBasecallsToSam
 
NUM_PROCESSORS - Variable in class picard.illumina.quality.CollectHiSeqXPfFailMetrics
 
NUM_Q_GT_TWO - Variable in class picard.illumina.quality.CollectHiSeqXPfFailMetrics.PFFailDetailedMetric
The number of Quality scores greater than 2 found in this read
NUM_R1_TRANSCRIPT_STRAND_READS - Variable in class picard.analysis.RnaSeqMetrics
The number of reads that support the model where R1 is on the strand of transcription and R2 is on the opposite strand.
NUM_R2_TRANSCRIPT_STRAND_READS - Variable in class picard.analysis.RnaSeqMetrics
The fraction of reads that support the model where R2 is on the strand of transcription and R1 is on the opposite strand.
NUM_REDUCERS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
 
NUM_REF_SAMPLES_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeCalculationArgumentCollection
 
NUM_REF_SAMPLES_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.variantutils.CalculateGenotypePosteriors
 
NUM_SAMPLES_ALLELE_FRACTION_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
NUM_SEQUENCES - Variable in class picard.sam.CreateSequenceDictionary
 
NUM_SINGLETONS - Variable in class picard.vcf.CollectVariantCallingMetrics.VariantCallingSummaryMetrics
For summary metrics, the number of variants that appear in only one sample.
NUM_THERMAL_ADVI_ITERS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection
 
NUM_THREADS - Variable in class picard.fingerprint.CrosscheckFingerprints
 
NUM_UNEXPLAINED_READS - Variable in class picard.analysis.RnaSeqMetrics
The fraction of reads for which the transcription strand model could not be inferred.
NUM_VARIANT_SITES - Variable in class picard.vcf.MendelianViolations.MendelianViolationMetrics
The number of biallelic, SNP sites at which all relevant samples exceeded the minimum genotype quality and depth and at least one of the samples was variant.
numAltAllelesThreshold - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
NUMBER_ERRORS_COLUMN_NAME - Static variable in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
 
NUMBER_ERRORS_DECIMAL_PLACES - Static variable in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
 
NUMBER_OBSERVATIONS_COLUMN_NAME - Static variable in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
 
NUMBER_OF_BURN_IN_SAMPLES_COPY_RATIO_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
NUMBER_OF_CHANGEPOINTS_PENALTY_FACTOR_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
NUMBER_OF_CHUNKS_SUB_PATH - Static variable in class org.broadinstitute.hellbender.tools.copynumber.utils.HDF5Utils
 
NUMBER_OF_COLUMNS_SUB_PATH - Static variable in class org.broadinstitute.hellbender.tools.copynumber.utils.HDF5Utils
 
NUMBER_OF_DISCOVERED_ALLELES_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
NUMBER_OF_EIGENSAMPLES_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.CopyNumberStandardArgument
 
NUMBER_OF_ROWS_SUB_PATH - Static variable in class org.broadinstitute.hellbender.tools.copynumber.utils.HDF5Utils
 
NUMBER_OF_SAMPLES_COPY_RATIO_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
NUMBER_OF_SMOOTHING_ITERATIONS_PER_FIT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
numberOfAlleles() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingData
 
numberOfAlleles() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingLikelihoods
 
numberOfAlleles() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.SubsettedLikelihoodMatrix
 
numberOfAlleles() - Method in class org.broadinstitute.hellbender.utils.genotyper.AlleleList.ActualPermutation
 
numberOfAlleles() - Method in class org.broadinstitute.hellbender.utils.genotyper.AlleleList.NonPermutation
 
numberOfAlleles() - Method in interface org.broadinstitute.hellbender.utils.genotyper.AlleleList
Returns the number of alleles in this AlleleList.
numberOfAlleles() - Method in class org.broadinstitute.hellbender.utils.genotyper.IndexedAlleleList
 
numberOfAlleles() - Method in interface org.broadinstitute.hellbender.utils.genotyper.LikelihoodMatrix
Number of allele in the matrix.
numberOfAlleles() - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Returns number of alleles in the collection.
numberOfGenomes - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
 
numberOfReads() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.SubsettedLikelihoodMatrix
 
numberOfReads() - Method in interface org.broadinstitute.hellbender.utils.genotyper.LikelihoodMatrix
Number of reads in the matrix.
numberOfSamples() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingData
 
numberOfSamples() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingLikelihoods
 
numberOfSamples() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.HeterogeneousPloidyModel
 
numberOfSamples() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.HomogeneousPloidyModel
 
numberOfSamples() - Method in class org.broadinstitute.hellbender.utils.genotyper.IndexedSampleList
 
numberOfSamples() - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Number of samples included in the likelihood collection.
numberOfSamples() - Method in interface org.broadinstitute.hellbender.utils.genotyper.SampleList
Returns number of elements in the list.
numberOfSpecialCovariates() - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.StandardCovariateList
Returns 2.
numCigarElements() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
The number of cigar elements in this read.
numCigarElements() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
This implementation saves time by not making an unmodifiable view of the list of elements but returns the length of the list directly (or 0 if there's no cigar).
numClusters - Variable in class picard.illumina.parser.readers.FilterFileReader
The number of cluster's pf values stored in this file
numDimensions - Variable in class org.broadinstitute.hellbender.utils.collections.NestedIntegerArray
 
numHits() - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.HitsForInsert
Note that a single alignment for each end of a read pair is counted as a single hit.
numMates - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenAlignmentHit
 
numMismatches - Variable in class org.broadinstitute.hellbender.utils.read.AlignmentUtils.MismatchCount
 
numOutputReads() - Method in class picard.illumina.parser.OutputMapping
 
numPartitions() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.ComplexityPartitioner
 
numPruningSamples - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadThreadingAssemblerArgumentCollection
If fewer samples than the specified number pass the minPruning threshold for a given path, that path will be eliminated from the graph.
NUMREADS - Variable in class org.broadinstitute.hellbender.tools.examples.metrics.multi.ExampleMultiMetrics
 
NUMREADS - Variable in class org.broadinstitute.hellbender.tools.examples.metrics.single.ExampleSingleMetrics
 
numReducers - Variable in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
 
numRefIfMissing - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeCalculationArgumentCollection
When a variant is not seen in any panel, this argument controls whether to infer (and with what effective strength) that only reference alleles were observed at that site.
numRefIfMissing - Variable in class org.broadinstitute.hellbender.tools.walkers.variantutils.CalculateGenotypePosteriors
When a variant is not seen in a panel, this argument controls whether to infer (and with what effective strength) that only reference alleles were observed at that site.
numRegularContigs - Variable in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.RealignmentArgumentCollection
Number of regular i.e.
numTables() - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationTables
 
numWindowLeadingBases() - Method in class org.broadinstitute.hellbender.engine.ReferenceContext
Get the number of extra bases of context before the start of our interval, as configured by a call to ReferenceContext.setWindow(int, int) or at construction time.
numWindowTrailingBases() - Method in class org.broadinstitute.hellbender.engine.ReferenceContext
Get the number of extra bases of context after the end of our interval, as configured by a call to ReferenceContext.setWindow(int, int) or at construction time.

O

OBS_A - Variable in class picard.analysis.FingerprintingDetailMetrics
The number of observations of the first, or A, allele of the SNP in the sequencing data.
OBS_B - Variable in class picard.analysis.FingerprintingDetailMetrics
The number of observations of the second, or B, allele of the SNP in the sequencing data.
obsAllele1 - Variable in class picard.fingerprint.HaplotypeProbabilitiesFromSequence
 
obsAllele2 - Variable in class picard.fingerprint.HaplotypeProbabilitiesFromSequence
 
obsAlleleOther - Variable in class picard.fingerprint.HaplotypeProbabilitiesFromSequence
 
observationCount() - Method in class org.broadinstitute.hellbender.utils.MathUtils.RunningAverage
 
OBSERVED_BASE_ERRORS - Variable in class picard.sam.markduplicates.UmiMetrics
Number of errors inferred by comparing the observed and inferred UMIs
OBSERVED_GENOTYPE - Variable in class picard.analysis.FingerprintingDetailMetrics
The most likely genotype given the observed evidence at the SNP locus in the sequencing data.
OBSERVED_SAMPLE_ALIAS - Variable in class picard.fingerprint.CheckFingerprint
 
OBSERVED_UMI_ENTROPY - Variable in class picard.sam.markduplicates.UmiMetrics
Entropy (in base 4) of the observed UMI sequences, indicating the effective number of bases in the UMIs.
OBSERVED_UNIQUE_UMIS - Variable in class picard.sam.markduplicates.UmiMetrics
Number of different UMI sequences observed
of(Path) - Static method in interface org.broadinstitute.hellbender.engine.ReferenceDataSource
Initialize this data source using a fasta file.
of(Path, boolean) - Static method in interface org.broadinstitute.hellbender.engine.ReferenceDataSource
Initialize this data source using a fasta file.
of(ReferenceBases, SAMSequenceDictionary) - Static method in interface org.broadinstitute.hellbender.engine.ReferenceDataSource
Initialize this data source using ReferenceBases and corresponding sequence dictionary.
of(VariantContext) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVContext
Returns an instance given a plain VariantContext instance.
of(K, V) - Static method in class org.broadinstitute.hellbender.utils.KV
 
of(boolean) - Static method in enum org.broadinstitute.hellbender.utils.Trilean
 
OFF_AMPLICON_BASES - Variable in class picard.analysis.directed.TargetedPcrMetrics
The number of PF_BASES_ALIGNED that mapped neither on or near an amplicon.
OFF_BAIT_BASES - Variable in class picard.analysis.directed.HsMetrics
The number of PF_BASES_ALIGNED that are mapped away from any baited region.
OFF_PROBE_BASES - Variable in class picard.analysis.directed.TargetMetrics
The number of PF aligned bases that mapped to neither on or near a probe.
OFFSPRING - Variable in class picard.vcf.MendelianViolations.MendelianViolationMetrics
The ID of the offspring within the trio.
OFFSPRING_SEX - Variable in class picard.vcf.MendelianViolations.MendelianViolationMetrics
The sex of the offspring.
OjAlgoSingularValueDecomposer - Class in org.broadinstitute.hellbender.utils.svd
SVD using the ojAlgo library.
OjAlgoSingularValueDecomposer() - Constructor for class org.broadinstitute.hellbender.utils.svd.OjAlgoSingularValueDecomposer
 
OLD_SAMPLE_NAME - Variable in class picard.vcf.RenameSampleInVcf
 
ON_AMPLICON_BASES - Variable in class picard.analysis.directed.TargetedPcrMetrics
The number of PF_BASES_ALIGNED that mapped to an amplified region of the genome.
ON_AMPLICON_VS_SELECTED - Variable in class picard.analysis.directed.TargetedPcrMetrics
The fraction of bases mapping to regions on or near amplicons, which mapped directly to but not near amplicons, ON_AMPLICON_BASES/(NEAR_AMPLICON_BASES + ON_AMPLICON_BASES)
ON_BAIT_BASES - Variable in class picard.analysis.directed.HsMetrics
The number of PF_BASES_ALIGNED that are mapped to the baited regions of the genome.
ON_BAIT_VS_SELECTED - Variable in class picard.analysis.directed.HsMetrics
The fraction of bases on or near baits that are covered by baits, ON_BAIT_BASES/(ON_BAIT_BASES + NEAR_BAIT_BASES).
ON_PROBE_BASES - Variable in class picard.analysis.directed.TargetMetrics
The number of PF aligned probed bases that mapped to a baited region of the genome.
ON_PROBE_VS_SELECTED - Variable in class picard.analysis.directed.TargetMetrics
The fraction of on+near probe bases that are on as opposed to near, ON_PROBE_BASES/(ON_PROBE_BASES + NEAR_PROBE_BASES).
ON_TARGET_BASES - Variable in class picard.analysis.directed.HsMetrics
The number of PF_BASES_ALIGNED that are mapped to a targeted region of the genome.
ON_TARGET_BASES - Variable in class picard.analysis.directed.TargetedPcrMetrics
The number of PF_BASES_ALIGNED that mapped to a targeted region of the genome.
ON_TARGET_BASES - Variable in class picard.analysis.directed.TargetMetrics
The number of PF aligned bases that mapped to a targeted region of the genome.
ON_TARGET_FROM_PAIR_BASES - Variable in class picard.analysis.directed.TargetedPcrMetrics
The number of bases from PF_SELECTED_UNIQUE_PAIRS that mapped to a targeted region of the genome.
ON_TARGET_FROM_PAIR_BASES - Variable in class picard.analysis.directed.TargetMetrics
The number of PF aligned bases that are mapped in pair to a targeted region of the genome.
onBoundary(SVInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.PartitionCrossingChecker
 
ONE_MISMATCH_MATCHES - Variable in class picard.illumina.ExtractIlluminaBarcodes.BarcodeMetric
The number of all reads matching this barcode that matched with 1 error or no-call.
oneShotAnnotationLogger - Variable in class org.broadinstitute.hellbender.tools.walkers.ReferenceConfidenceVariantContextMerger
 
oneShotHeaderLineLogger - Variable in class org.broadinstitute.hellbender.tools.walkers.ReferenceConfidenceVariantContextMerger
 
OneShotLogger - Class in org.broadinstitute.hellbender.utils.logging
A logger wrapper class which only outputs the first warning provided to it
OneShotLogger(Class<?>) - Constructor for class org.broadinstitute.hellbender.utils.logging.OneShotLogger
 
OneShotLogger(Logger) - Constructor for class org.broadinstitute.hellbender.utils.logging.OneShotLogger
 
onLeadingBoundary(SVInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.PartitionCrossingChecker
 
ONLY_OUTPUT_CALLS_STARTING_IN_INTERVALS_FULL_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.GenotypeGVCFs
 
onSameContig(GenomeLoc) - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
 
onShutdown() - Method in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
Perform cleanup after doWork() is finished.
onShutdown() - Method in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker
 
onShutdown() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
Shutdown data sources.
onShutdown() - Method in class org.broadinstitute.hellbender.engine.FeatureWalker
Close the reads and reference data sources.
onShutdown() - Method in class org.broadinstitute.hellbender.engine.GATKTool
Close all data sources on shutdown.
onShutdown() - Method in class org.broadinstitute.hellbender.engine.IntervalWalker
Close data sources.
onShutdown() - Method in class org.broadinstitute.hellbender.engine.LocusWalker
Marked final so that tool authors don't override it.
onShutdown() - Method in class org.broadinstitute.hellbender.engine.MultiVariantWalker
Close all data sources.
onShutdown() - Method in class org.broadinstitute.hellbender.engine.ReadWalker
Shutdown data sources.
onShutdown() - Method in class org.broadinstitute.hellbender.engine.VariantWalker
Close all data sources.
onShutdown() - Method in class org.broadinstitute.hellbender.tools.genomicsdb.GenomicsDBImport
 
onStartup() - Method in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
Perform initialization/setup after command-line argument parsing but before doWork() is invoked.
onStartup() - Method in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker
 
onStartup() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
Initialize data sources for traversal.
onStartup() - Method in class org.broadinstitute.hellbender.engine.FeatureWalker
Set the intervals for traversal in the driving features.
onStartup() - Method in class org.broadinstitute.hellbender.engine.GATKTool
Initialize our data sources, make sure that all tool requirements for input data have been satisfied and start the progress meter.
onStartup() - Method in class org.broadinstitute.hellbender.engine.IntervalWalker
Initialize data sources.
onStartup() - Method in class org.broadinstitute.hellbender.engine.LocusWalker
Marked final so that tool authors don't override it.
onStartup() - Method in class org.broadinstitute.hellbender.engine.MultiVariantWalker
Marked final so that tool authors don't override it.
onStartup() - Method in class org.broadinstitute.hellbender.engine.ReadWalker
Initialize data sources for traversal.
onStartup() - Method in class org.broadinstitute.hellbender.engine.VariantWalker
Marked final so that tool authors don't override it.
onStartup() - Method in class org.broadinstitute.hellbender.tools.copynumber.DetermineGermlineContigPloidy
 
onStartup() - Method in class org.broadinstitute.hellbender.tools.copynumber.GermlineCNVCaller
 
onStartup() - Method in class org.broadinstitute.hellbender.tools.copynumber.PostprocessGermlineCNVCalls
 
onStartup() - Method in class org.broadinstitute.hellbender.tools.genomicsdb.GenomicsDBImport
Before traversal starts, create the feature readers for all the input GVCFs, create the merged header and initialize the interval
onStartup() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.CNNVariantTrain
 
onStartup() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.CNNVariantWriteTensors
 
onStartup() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.FilterVariantTranches
 
onTrailingBoundary(SVInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.PartitionCrossingChecker
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.engine.GATKTool
Operations performed just prior to the start of traversal.
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.AnnotatePairOrientation
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.ClipReads
The initialize function.
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.copynumber.AnnotateIntervals
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.copynumber.CollectAllelicCounts
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.copynumber.CollectReadCounts
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.copynumber.PostprocessGermlineCNVCalls
Performs various validations on input arguments.
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.copynumber.PreprocessIntervals
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleAssemblyRegionWalker
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleFeatureWalker
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleIntervalWalker
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleLocusWalker
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.examples.ExamplePostTraversalPythonExecutor
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleReadWalkerWithReference
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleReadWalkerWithVariants
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleStreamingPythonExecutor
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleTwoPassVariantWalker
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleVariantWalker
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.exome.FilterByOrientationBias
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.FixCallSetSampleOrdering
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.FixMisencodedBaseQualityReads
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.funcotator.Funcotator
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.genomicsdb.GenomicsDBImport
Before traversal, fix configuration parameters and initialize GenomicsDB.
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.GetSampleName
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.LeftAlignIndels
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.PrintReads
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.SplitReads
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotator
Prepare the output file and the list of available features.
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.bqsr.ApplyBQSR
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.bqsr.BaseRecalibrator
Parse the -cov arguments and create a list of covariates to be used here Based on the covariates' estimates for initial capacity allocate the data hashmap
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.CombineGVCFs
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.contamination.GetPileupSummaries
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.GenotypeGVCFs
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCaller
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.FilterMutectCalls
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.qc.CheckPileup
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.qc.Pileup
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.FilterAlignmentArtifacts
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.RevertBaseQualityScores
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.ASEReadCounter
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.SplitNCigarReads
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.SplitIntervals
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.UnmarkDuplicates
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.AnnotateVcfWithBamDepth
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.AnnotateVcfWithExpectedAlleleFraction
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.CalculateMixingFractions
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.Concordance
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.CountFalsePositives
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.RemoveNearbyIndels
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.variantutils.CalculateGenotypePosteriors
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.variantutils.SelectVariants
Set up the VCF writer, the sample expressions and regexs, filters inputs, and the JEXL matcher
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.variantutils.UpdateVCFSequenceDictionary
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.variantutils.ValidateVariants
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.variantutils.VariantsToTable
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.ApplyVQSR
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.CNNScoreVariants
 
onTraversalStart() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantRecalibrator
 
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.engine.GATKTool
Operations performed immediately after a successful traversal (ie when no uncaught exceptions were thrown during the traversal).
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.ClipReads
 
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.copynumber.AnnotateIntervals
 
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.copynumber.CollectAllelicCounts
 
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.copynumber.CollectReadCounts
 
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.CountBases
 
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.CountReads
 
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.examples.ExamplePostTraversalPythonExecutor
 
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleStreamingPythonExecutor
On traversal success, write the remaining batch.
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.exome.FilterByOrientationBias
 
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.FlagStat
 
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.funcotator.Funcotator
 
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.genomicsdb.GenomicsDBImport
 
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.walkers.bqsr.BaseRecalibrator
 
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.walkers.CombineGVCFs
 
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.walkers.contamination.GetPileupSummaries
 
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.walkers.CountVariants
 
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.FilterMutectCalls
 
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2
 
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.walkers.qc.CheckPileup
 
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.FilterAlignmentArtifacts
 
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.CalculateMixingFractions
 
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.Concordance
 
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.CountFalsePositives
 
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.RemoveNearbyIndels
 
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.walkers.variantutils.ValidateVariants
 
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.CNNScoreVariants
 
onTraversalSuccess() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantRecalibrator
 
open - Variable in class org.broadinstitute.hellbender.utils.read.ArtificialReadIterator
Is this iterator currently open or closed? Closed iterators can be reused.
openFile(String) - Static method in class org.broadinstitute.hellbender.utils.gcs.BucketUtils
Open a file for reading regardless of whether it's on GCS, HDFS or local disk.
openInputs() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.AbstractMarkDuplicatesCommandLineProgram
Since this may read it's inputs more than once this method does all the opening and checking of the inputs.
openInputs(boolean) - Method in class picard.sam.markduplicates.util.AbstractMarkDuplicatesCommandLineProgram
Since this may read its inputs more than once this method does all the opening and checking of the inputs.
OPTICAL_DUPLICATE_PIXEL_DISTANCE - Variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.OpticalDuplicatesArgumentCollection
 
OPTICAL_DUPLICATE_PIXEL_DISTANCE - Variable in class picard.sam.markduplicates.util.AbstractOpticalDuplicateFinderCommandLineProgram
 
OPTICAL_DUPLICATE_PIXEL_DISTANCE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.OpticalDuplicatesArgumentCollection
 
OPTICAL_DUPLICATE_TOTAL_ATTRIBUTE_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.transforms.markduplicates.MarkDuplicatesSparkUtils
 
opticalDuplicateFinder - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.AbstractOpticalDuplicateFinderCommandLineProgram
 
opticalDuplicateFinder - Variable in class picard.sam.markduplicates.util.AbstractOpticalDuplicateFinderCommandLineProgram
 
OpticalDuplicateFinder - Class in picard.sam.markduplicates.util
Contains methods for finding optical/co-localized/sequencing duplicates.
OpticalDuplicateFinder() - Constructor for class picard.sam.markduplicates.util.OpticalDuplicateFinder
Uses the default duplicate distance OpticalDuplicateFinder.DEFAULT_OPTICAL_DUPLICATE_DISTANCE (100) and the default read name regex ReadNameParser.DEFAULT_READ_NAME_REGEX.
OpticalDuplicateFinder(String, int, Log) - Constructor for class picard.sam.markduplicates.util.OpticalDuplicateFinder
 
OpticalDuplicateFinder(String, int, long, Log) - Constructor for class picard.sam.markduplicates.util.OpticalDuplicateFinder
 
opticalDuplicatePixelDistance - Variable in class picard.sam.markduplicates.util.OpticalDuplicateFinder
 
OpticalDuplicatesArgumentCollection - Class in org.broadinstitute.hellbender.cmdline.argumentcollections
An argument collection for use with tools that mark optical duplicates.
OpticalDuplicatesArgumentCollection() - Constructor for class org.broadinstitute.hellbender.cmdline.argumentcollections.OpticalDuplicatesArgumentCollection
 
opticalDuplicatesArgumentCollection - Variable in class org.broadinstitute.hellbender.tools.spark.transforms.markduplicates.MarkDuplicatesSpark
 
opticalDuplicatesArgumentCollection - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.AbstractOpticalDuplicateFinderCommandLineProgram
 
OPTIMAL_GVCF_INDEX_BIN_SIZE - Static variable in class org.broadinstitute.hellbender.tools.IndexFeatureFile
 
OptimizationUtils - Class in org.broadinstitute.hellbender.utils
Created by davidben on 4/27/16.
optimumHashSize(int) - Static method in class org.broadinstitute.hellbender.utils.Utils
Calculates the optimum initial size for a hash table given the maximum number of elements it will need to hold.
OptionalFeatureInputArgumentCollection - Class in org.broadinstitute.hellbender.cmdline.argumentcollections
An argument collection for use with tools that accept zero or more input files containing Feature records (eg., BED files, hapmap files, etc.).
OptionalFeatureInputArgumentCollection() - Constructor for class org.broadinstitute.hellbender.cmdline.argumentcollections.OptionalFeatureInputArgumentCollection
 
OptionalField(String, T) - Constructor for class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.OptionalField
 
optionalFields - Variable in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeatureBaseData
Optional GENCODE GTF Fields.
OptionalIntervalArgumentCollection - Class in org.broadinstitute.hellbender.cmdline.argumentcollections
An interval argument class that allows -L to be specified but does not require it.
OptionalIntervalArgumentCollection() - Constructor for class org.broadinstitute.hellbender.cmdline.argumentcollections.OptionalIntervalArgumentCollection
 
OptionalReadInputArgumentCollection - Class in org.broadinstitute.hellbender.cmdline.argumentcollections
An argument collection for use with tools that accept zero or more input files containing reads (eg., BAM/SAM/CRAM files).
OptionalReadInputArgumentCollection() - Constructor for class org.broadinstitute.hellbender.cmdline.argumentcollections.OptionalReadInputArgumentCollection
 
OptionalReferenceArgumentCollection - Class in picard.cmdline.argumentcollections
Picard default argument collection for an optional reference.
OptionalReferenceArgumentCollection() - Constructor for class picard.cmdline.argumentcollections.OptionalReferenceArgumentCollection
 
OptionalReferenceInputArgumentCollection - Class in org.broadinstitute.hellbender.cmdline.argumentcollections
An argument collection for use with tools that optionally accept a reference file as input.
OptionalReferenceInputArgumentCollection() - Constructor for class org.broadinstitute.hellbender.cmdline.argumentcollections.OptionalReferenceInputArgumentCollection
 
OptionalVariantInputArgumentCollection - Class in org.broadinstitute.hellbender.cmdline.argumentcollections
An argument collection for use with tools that accept zero or more input files containing VariantContext records (eg., VCF files).
OptionalVariantInputArgumentCollection() - Constructor for class org.broadinstitute.hellbender.cmdline.argumentcollections.OptionalVariantInputArgumentCollection
 
or(CountingReadFilter) - Method in class org.broadinstitute.hellbender.engine.filters.CountingReadFilter
Specialization of Predicate.or(Predicate) so that CountingReadFilter ored with other CountingReadFilter produce a CountingReadFilter
or(CountingVariantFilter) - Method in class org.broadinstitute.hellbender.engine.filters.CountingVariantFilter
Specialization of Predicate.or(Predicate) so that CountingVariantFilter ored with other CountingVariantFilter produce a CountingVariantFilter
or(ReadFilter) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilter
Specialization of Predicate.or(Predicate) so that ReadFilters or'ed with other ReadFilters produce a ReadFilter
or(VariantFilter) - Method in interface org.broadinstitute.hellbender.engine.filters.VariantFilter
 
org.broadinstitute.hellbender - package org.broadinstitute.hellbender
 
org.broadinstitute.hellbender.cmdline - package org.broadinstitute.hellbender.cmdline
 
org.broadinstitute.hellbender.cmdline.argumentcollections - package org.broadinstitute.hellbender.cmdline.argumentcollections
 
org.broadinstitute.hellbender.cmdline.GATKPlugin - package org.broadinstitute.hellbender.cmdline.GATKPlugin
 
org.broadinstitute.hellbender.cmdline.programgroups - package org.broadinstitute.hellbender.cmdline.programgroups
 
org.broadinstitute.hellbender.engine - package org.broadinstitute.hellbender.engine
 
org.broadinstitute.hellbender.engine.datasources - package org.broadinstitute.hellbender.engine.datasources
 
org.broadinstitute.hellbender.engine.filters - package org.broadinstitute.hellbender.engine.filters
 
org.broadinstitute.hellbender.engine.spark - package org.broadinstitute.hellbender.engine.spark
 
org.broadinstitute.hellbender.engine.spark.datasources - package org.broadinstitute.hellbender.engine.spark.datasources
 
org.broadinstitute.hellbender.exceptions - package org.broadinstitute.hellbender.exceptions
 
org.broadinstitute.hellbender.metrics - package org.broadinstitute.hellbender.metrics
 
org.broadinstitute.hellbender.metrics.analysis - package org.broadinstitute.hellbender.metrics.analysis
 
org.broadinstitute.hellbender.tools - package org.broadinstitute.hellbender.tools
 
org.broadinstitute.hellbender.tools.copynumber - package org.broadinstitute.hellbender.tools.copynumber
 
org.broadinstitute.hellbender.tools.copynumber.arguments - package org.broadinstitute.hellbender.tools.copynumber.arguments
 
org.broadinstitute.hellbender.tools.copynumber.caller - package org.broadinstitute.hellbender.tools.copynumber.caller
 
org.broadinstitute.hellbender.tools.copynumber.datacollection - package org.broadinstitute.hellbender.tools.copynumber.datacollection
 
org.broadinstitute.hellbender.tools.copynumber.denoising - package org.broadinstitute.hellbender.tools.copynumber.denoising
 
org.broadinstitute.hellbender.tools.copynumber.formats - package org.broadinstitute.hellbender.tools.copynumber.formats
 
org.broadinstitute.hellbender.tools.copynumber.formats.collections - package org.broadinstitute.hellbender.tools.copynumber.formats.collections
 
org.broadinstitute.hellbender.tools.copynumber.formats.metadata - package org.broadinstitute.hellbender.tools.copynumber.formats.metadata
 
org.broadinstitute.hellbender.tools.copynumber.formats.records - package org.broadinstitute.hellbender.tools.copynumber.formats.records
 
org.broadinstitute.hellbender.tools.copynumber.gcnv - package org.broadinstitute.hellbender.tools.copynumber.gcnv
 
org.broadinstitute.hellbender.tools.copynumber.models - package org.broadinstitute.hellbender.tools.copynumber.models
 
org.broadinstitute.hellbender.tools.copynumber.plotting - package org.broadinstitute.hellbender.tools.copynumber.plotting
 
org.broadinstitute.hellbender.tools.copynumber.segmentation - package org.broadinstitute.hellbender.tools.copynumber.segmentation
 
org.broadinstitute.hellbender.tools.copynumber.utils - package org.broadinstitute.hellbender.tools.copynumber.utils
 
org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval - package org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval
 
org.broadinstitute.hellbender.tools.copynumber.utils.germlinetagging - package org.broadinstitute.hellbender.tools.copynumber.utils.germlinetagging
 
org.broadinstitute.hellbender.tools.copynumber.utils.optimization - package org.broadinstitute.hellbender.tools.copynumber.utils.optimization
 
org.broadinstitute.hellbender.tools.copynumber.utils.segmentation - package org.broadinstitute.hellbender.tools.copynumber.utils.segmentation
 
org.broadinstitute.hellbender.tools.examples - package org.broadinstitute.hellbender.tools.examples
 
org.broadinstitute.hellbender.tools.examples.metrics.multi - package org.broadinstitute.hellbender.tools.examples.metrics.multi
 
org.broadinstitute.hellbender.tools.examples.metrics.single - package org.broadinstitute.hellbender.tools.examples.metrics.single
 
org.broadinstitute.hellbender.tools.exome - package org.broadinstitute.hellbender.tools.exome
 
org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter - package org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter
 
org.broadinstitute.hellbender.tools.funcotator - package org.broadinstitute.hellbender.tools.funcotator
 
org.broadinstitute.hellbender.tools.funcotator.dataSources - package org.broadinstitute.hellbender.tools.funcotator.dataSources
 
org.broadinstitute.hellbender.tools.funcotator.dataSources.cosmic - package org.broadinstitute.hellbender.tools.funcotator.dataSources.cosmic
 
org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode - package org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode
 
org.broadinstitute.hellbender.tools.funcotator.dataSources.vcf - package org.broadinstitute.hellbender.tools.funcotator.dataSources.vcf
 
org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv - package org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv
 
org.broadinstitute.hellbender.tools.funcotator.mafOutput - package org.broadinstitute.hellbender.tools.funcotator.mafOutput
 
org.broadinstitute.hellbender.tools.funcotator.vcfOutput - package org.broadinstitute.hellbender.tools.funcotator.vcfOutput
 
org.broadinstitute.hellbender.tools.genomicsdb - package org.broadinstitute.hellbender.tools.genomicsdb
 
org.broadinstitute.hellbender.tools.readersplitters - package org.broadinstitute.hellbender.tools.readersplitters
 
org.broadinstitute.hellbender.tools.spark - package org.broadinstitute.hellbender.tools.spark
 
org.broadinstitute.hellbender.tools.spark.bwa - package org.broadinstitute.hellbender.tools.spark.bwa
 
org.broadinstitute.hellbender.tools.spark.pathseq - package org.broadinstitute.hellbender.tools.spark.pathseq
 
org.broadinstitute.hellbender.tools.spark.pathseq.loggers - package org.broadinstitute.hellbender.tools.spark.pathseq.loggers
 
org.broadinstitute.hellbender.tools.spark.pipelines - package org.broadinstitute.hellbender.tools.spark.pipelines
 
org.broadinstitute.hellbender.tools.spark.pipelines.metrics - package org.broadinstitute.hellbender.tools.spark.pipelines.metrics
 
org.broadinstitute.hellbender.tools.spark.sv - package org.broadinstitute.hellbender.tools.spark.sv
 
org.broadinstitute.hellbender.tools.spark.sv.discovery - package org.broadinstitute.hellbender.tools.spark.sv.discovery
 
org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment - package org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment
 
org.broadinstitute.hellbender.tools.spark.sv.discovery.inference - package org.broadinstitute.hellbender.tools.spark.sv.discovery.inference
 
org.broadinstitute.hellbender.tools.spark.sv.evidence - package org.broadinstitute.hellbender.tools.spark.sv.evidence
 
org.broadinstitute.hellbender.tools.spark.sv.utils - package org.broadinstitute.hellbender.tools.spark.sv.utils
 
org.broadinstitute.hellbender.tools.spark.transforms - package org.broadinstitute.hellbender.tools.spark.transforms
 
org.broadinstitute.hellbender.tools.spark.transforms.bqsr - package org.broadinstitute.hellbender.tools.spark.transforms.bqsr
 
org.broadinstitute.hellbender.tools.spark.transforms.markduplicates - package org.broadinstitute.hellbender.tools.spark.transforms.markduplicates
 
org.broadinstitute.hellbender.tools.spark.utils - package org.broadinstitute.hellbender.tools.spark.utils
 
org.broadinstitute.hellbender.tools.spark.validation - package org.broadinstitute.hellbender.tools.spark.validation
 
org.broadinstitute.hellbender.tools.validation - package org.broadinstitute.hellbender.tools.validation
 
org.broadinstitute.hellbender.tools.walkers - package org.broadinstitute.hellbender.tools.walkers
 
org.broadinstitute.hellbender.tools.walkers.annotator - package org.broadinstitute.hellbender.tools.walkers.annotator
 
org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific - package org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific
 
org.broadinstitute.hellbender.tools.walkers.bqsr - package org.broadinstitute.hellbender.tools.walkers.bqsr
 
org.broadinstitute.hellbender.tools.walkers.contamination - package org.broadinstitute.hellbender.tools.walkers.contamination
 
org.broadinstitute.hellbender.tools.walkers.filters - package org.broadinstitute.hellbender.tools.walkers.filters
 
org.broadinstitute.hellbender.tools.walkers.genotyper - package org.broadinstitute.hellbender.tools.walkers.genotyper
 
org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc - package org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc
 
org.broadinstitute.hellbender.tools.walkers.haplotypecaller - package org.broadinstitute.hellbender.tools.walkers.haplotypecaller
 
org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs - package org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs
 
org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading - package org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading
 
org.broadinstitute.hellbender.tools.walkers.markduplicates - package org.broadinstitute.hellbender.tools.walkers.markduplicates
 
org.broadinstitute.hellbender.tools.walkers.mutect - package org.broadinstitute.hellbender.tools.walkers.mutect
 
org.broadinstitute.hellbender.tools.walkers.qc - package org.broadinstitute.hellbender.tools.walkers.qc
 
org.broadinstitute.hellbender.tools.walkers.realignmentfilter - package org.broadinstitute.hellbender.tools.walkers.realignmentfilter
 
org.broadinstitute.hellbender.tools.walkers.rnaseq - package org.broadinstitute.hellbender.tools.walkers.rnaseq
 
org.broadinstitute.hellbender.tools.walkers.validation - package org.broadinstitute.hellbender.tools.walkers.validation
 
org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup - package org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup
 
org.broadinstitute.hellbender.tools.walkers.variantutils - package org.broadinstitute.hellbender.tools.walkers.variantutils
 
org.broadinstitute.hellbender.tools.walkers.vqsr - package org.broadinstitute.hellbender.tools.walkers.vqsr
 
org.broadinstitute.hellbender.transformers - package org.broadinstitute.hellbender.transformers
 
org.broadinstitute.hellbender.utils - package org.broadinstitute.hellbender.utils
 
org.broadinstitute.hellbender.utils.activityprofile - package org.broadinstitute.hellbender.utils.activityprofile
 
org.broadinstitute.hellbender.utils.artifacts - package org.broadinstitute.hellbender.utils.artifacts
 
org.broadinstitute.hellbender.utils.baq - package org.broadinstitute.hellbender.utils.baq
 
org.broadinstitute.hellbender.utils.bwa - package org.broadinstitute.hellbender.utils.bwa
 
org.broadinstitute.hellbender.utils.clipping - package org.broadinstitute.hellbender.utils.clipping
 
org.broadinstitute.hellbender.utils.codecs - package org.broadinstitute.hellbender.utils.codecs
 
org.broadinstitute.hellbender.utils.codecs.gencode - package org.broadinstitute.hellbender.utils.codecs.gencode
 
org.broadinstitute.hellbender.utils.codecs.sampileup - package org.broadinstitute.hellbender.utils.codecs.sampileup
 
org.broadinstitute.hellbender.utils.codecs.table - package org.broadinstitute.hellbender.utils.codecs.table
 
org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable - package org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable
 
org.broadinstitute.hellbender.utils.collections - package org.broadinstitute.hellbender.utils.collections
 
org.broadinstitute.hellbender.utils.config - package org.broadinstitute.hellbender.utils.config
 
org.broadinstitute.hellbender.utils.downsampling - package org.broadinstitute.hellbender.utils.downsampling
 
org.broadinstitute.hellbender.utils.fasta - package org.broadinstitute.hellbender.utils.fasta
 
org.broadinstitute.hellbender.utils.fragments - package org.broadinstitute.hellbender.utils.fragments
 
org.broadinstitute.hellbender.utils.functional - package org.broadinstitute.hellbender.utils.functional
 
org.broadinstitute.hellbender.utils.gcs - package org.broadinstitute.hellbender.utils.gcs
 
org.broadinstitute.hellbender.utils.genotyper - package org.broadinstitute.hellbender.utils.genotyper
 
org.broadinstitute.hellbender.utils.haplotype - package org.broadinstitute.hellbender.utils.haplotype
 
org.broadinstitute.hellbender.utils.help - package org.broadinstitute.hellbender.utils.help
 
org.broadinstitute.hellbender.utils.hmm - package org.broadinstitute.hellbender.utils.hmm
 
org.broadinstitute.hellbender.utils.illumina - package org.broadinstitute.hellbender.utils.illumina
 
org.broadinstitute.hellbender.utils.io - package org.broadinstitute.hellbender.utils.io
 
org.broadinstitute.hellbender.utils.iterators - package org.broadinstitute.hellbender.utils.iterators
 
org.broadinstitute.hellbender.utils.locusiterator - package org.broadinstitute.hellbender.utils.locusiterator
 
org.broadinstitute.hellbender.utils.logging - package org.broadinstitute.hellbender.utils.logging
 
org.broadinstitute.hellbender.utils.mcmc - package org.broadinstitute.hellbender.utils.mcmc
 
org.broadinstitute.hellbender.utils.nio - package org.broadinstitute.hellbender.utils.nio
 
org.broadinstitute.hellbender.utils.pairhmm - package org.broadinstitute.hellbender.utils.pairhmm
 
org.broadinstitute.hellbender.utils.param - package org.broadinstitute.hellbender.utils.param
 
org.broadinstitute.hellbender.utils.pileup - package org.broadinstitute.hellbender.utils.pileup
 
org.broadinstitute.hellbender.utils.python - package org.broadinstitute.hellbender.utils.python
 
org.broadinstitute.hellbender.utils.R - package org.broadinstitute.hellbender.utils.R
 
org.broadinstitute.hellbender.utils.read - package org.broadinstitute.hellbender.utils.read
 
org.broadinstitute.hellbender.utils.read.markduplicates - package org.broadinstitute.hellbender.utils.read.markduplicates
 
org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords - package org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords
 
org.broadinstitute.hellbender.utils.read.mergealignment - package org.broadinstitute.hellbender.utils.read.mergealignment
 
org.broadinstitute.hellbender.utils.recalibration - package org.broadinstitute.hellbender.utils.recalibration
 
org.broadinstitute.hellbender.utils.recalibration.covariates - package org.broadinstitute.hellbender.utils.recalibration.covariates
 
org.broadinstitute.hellbender.utils.reference - package org.broadinstitute.hellbender.utils.reference
 
org.broadinstitute.hellbender.utils.report - package org.broadinstitute.hellbender.utils.report
 
org.broadinstitute.hellbender.utils.runtime - package org.broadinstitute.hellbender.utils.runtime
 
org.broadinstitute.hellbender.utils.samples - package org.broadinstitute.hellbender.utils.samples
 
org.broadinstitute.hellbender.utils.smithwaterman - package org.broadinstitute.hellbender.utils.smithwaterman
 
org.broadinstitute.hellbender.utils.solver - package org.broadinstitute.hellbender.utils.solver
 
org.broadinstitute.hellbender.utils.spark - package org.broadinstitute.hellbender.utils.spark
 
org.broadinstitute.hellbender.utils.svd - package org.broadinstitute.hellbender.utils.svd
 
org.broadinstitute.hellbender.utils.test - package org.broadinstitute.hellbender.utils.test
 
org.broadinstitute.hellbender.utils.test.testers - package org.broadinstitute.hellbender.utils.test.testers
 
org.broadinstitute.hellbender.utils.text - package org.broadinstitute.hellbender.utils.text
 
org.broadinstitute.hellbender.utils.tsv - package org.broadinstitute.hellbender.utils.tsv
Utility classes to read and write tab separated value (tsv) files.
org.broadinstitute.hellbender.utils.variant - package org.broadinstitute.hellbender.utils.variant
 
org.broadinstitute.hellbender.utils.variant.writers - package org.broadinstitute.hellbender.utils.variant.writers
 
orientation - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
orientation - Variable in class picard.sam.markduplicates.util.ReadEnds
 
OrientationBiasFilterConstants - Class in org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter
 
OrientationBiasFilterer - Class in org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter
Perform operations for the orientation bias filter.
OrientationBiasFilterer() - Constructor for class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasFilterer
 
OrientationBiasFilterSummaryTableColumn - Enum in org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter
 
OrientationBiasUtils - Class in org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter
 
OrientationBiasUtils() - Constructor for class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasUtils
 
orientationForOpticalDuplicates - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
For optical duplicate detection the orientation matters regard to 1st or 2nd end of a mate
orientationForOpticalDuplicates - Variable in class picard.sam.markduplicates.util.ReadEnds
For optical duplicate detection the orientation matters regard to 1st or 2nd end of a mate
OrientationSampleTransitionSummary - Class in org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter
Simple class for holding summary information derived from the orientation bias filter.
OrientationSampleTransitionSummary(String, Transition, Transition, double, long, long, long, long) - Constructor for class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationSampleTransitionSummary
 
ORIGINAL_AC_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
ORIGINAL_AF_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
ORIGINAL_AN_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
ORIGINAL_BASE_QUALITIES_TAG - Static variable in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
ORIGINAL_CONTIG - Static variable in class picard.vcf.LiftoverVcf
Attribute used to store the name of the source contig/chromosome prior to liftover.
ORIGINAL_CONTIG_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
ORIGINAL_DEFAULT - Static variable in interface org.broadinstitute.hellbender.utils.smithwaterman.SmithWatermanAligner
 
ORIGINAL_DP_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
ORIGINAL_START - Static variable in class picard.vcf.LiftoverVcf
Attribute used to store the position of the variant on the source contig prior to liftover.
ORIGINAL_START_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
originalRegion - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmer.Result
Holds the input active region.
OTHER_TRANSCRIPT_DELIMITER - Static variable in class org.broadinstitute.hellbender.tools.funcotator.vcfOutput.VcfOutputRenderer
The delimiter for the `Other Transcript` field within the Funcotation annotation in the VCF.
OtherProgramGroup - Class in picard.cmdline.programgroups
Miscellaneous tools, e.g.
OtherProgramGroup() - Constructor for class picard.cmdline.programgroups.OtherProgramGroup
 
out - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.CountBasesSpark
 
out - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.CountReadsSpark
 
out - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.CountVariantsSpark
 
out - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.FlagStatSpark
 
out - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectBaseDistributionByCycleSpark
 
out - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.MeanQualityByCycleSpark
 
out - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.QualityScoreDistributionSpark
 
out - Variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
 
out - Variable in class org.broadinstitute.hellbender.tools.walkers.variantutils.CalculateGenotypePosteriors
 
out - Variable in class picard.sam.FixMateInformation
 
out - Variable in class picard.sam.markduplicates.util.ReadEndsForMarkDuplicatesCodec
 
out - Variable in class picard.sam.markduplicates.util.RepresentativeReadIndexerCodec
 
OUT_PREFIX - Variable in class picard.sam.SplitSamByNumberOfReads
 
outFile - Variable in class org.broadinstitute.hellbender.tools.walkers.qc.CheckPileup
 
outFile - Variable in class org.broadinstitute.hellbender.tools.walkers.qc.Pileup
 
outFile - Variable in class org.broadinstitute.hellbender.tools.walkers.variantutils.SelectVariants
 
outFile - Variable in class org.broadinstitute.hellbender.tools.walkers.variantutils.UpdateVCFSequenceDictionary
 
outgoingEdgeOf(V) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Get the outgoing edge of v.
outgoingVerticesOf(V) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Get the set of vertices connected by outgoing edges of V
OUTLIER_NEUTRAL_SEGMENT_COPY_RATIO_Z_SCORE_THRESHOLD_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.CallCopyRatioSegments
 
output - Variable in class org.broadinstitute.hellbender.metrics.MetricsArgumentCollection
 
output - Variable in class org.broadinstitute.hellbender.tools.FixCallSetSampleOrdering
 
OUTPUT - Variable in class org.broadinstitute.hellbender.tools.FixMisencodedBaseQualityReads
 
output - Variable in class org.broadinstitute.hellbender.tools.GatherVcfsCloud
 
output - Variable in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark
 
output - Variable in class org.broadinstitute.hellbender.tools.PrintReads
 
output - Variable in class org.broadinstitute.hellbender.tools.spark.CreateHadoopBamSplittingIndex
 
output - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.BQSRPipelineSpark
 
output - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.BwaAndMarkDuplicatesPipelineSpark
 
output - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.PrintReadsSpark
 
output - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.PrintVariantsSpark
 
output - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.ReadsPipelineSpark
 
output - Variable in class org.broadinstitute.hellbender.tools.spark.transforms.markduplicates.MarkDuplicatesSpark
 
OUTPUT - Variable in class org.broadinstitute.hellbender.tools.walkers.bqsr.ApplyBQSR
 
OUTPUT - Variable in class org.broadinstitute.hellbender.tools.walkers.markduplicates.EstimateLibraryComplexityGATK
 
OUTPUT - Variable in class org.broadinstitute.hellbender.tools.walkers.RevertBaseQualityScores
 
OUTPUT - Variable in class org.broadinstitute.hellbender.tools.walkers.UnmarkDuplicates
 
output - Variable in class org.broadinstitute.hellbender.utils.haplotype.HaplotypeBAMWriter
 
OUTPUT - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.AbstractMarkDuplicatesCommandLineProgram
 
OUTPUT - Variable in class picard.analysis.CollectJumpingLibraryMetrics
 
OUTPUT - Variable in class picard.analysis.CollectMultipleMetrics
 
OUTPUT - Variable in class picard.analysis.CollectOxoGMetrics
 
OUTPUT - Variable in class picard.analysis.CollectWgsMetrics
 
OUTPUT - Variable in class picard.analysis.directed.CollectTargetedMetrics
 
OUTPUT - Variable in class picard.analysis.replicates.CollectIndependentReplicateMetrics
 
OUTPUT - Variable in class picard.analysis.SinglePassSamProgram
 
OUTPUT - Variable in class picard.fingerprint.CheckFingerprint
 
OUTPUT - Variable in class picard.fingerprint.ClusterCrosscheckMetrics
 
OUTPUT - Variable in class picard.fingerprint.CrosscheckFingerprints
 
OUTPUT - Variable in class picard.fingerprint.IdentifyContaminant
 
OUTPUT - Variable in class picard.illumina.CollectIlluminaBasecallingMetrics
 
OUTPUT - Variable in class picard.illumina.IlluminaBasecallsToSam
 
OUTPUT - Variable in class picard.illumina.MarkIlluminaAdapters
 
OUTPUT - Variable in class picard.illumina.quality.CollectHiSeqXPfFailMetrics
 
OUTPUT - Variable in class picard.reference.ExtractSequences
 
OUTPUT - Variable in class picard.reference.NonNFastaSize
 
OUTPUT - Variable in class picard.reference.NormalizeFasta
 
OUTPUT - Variable in class picard.sam.AddCommentsToBam
 
OUTPUT - Variable in class picard.sam.AddOrReplaceReadGroups
 
OUTPUT - Variable in class picard.sam.BuildBamIndex
 
OUTPUT - Variable in class picard.sam.CalculateReadGroupChecksum
 
OUTPUT - Variable in class picard.sam.CleanSam
 
OUTPUT - Variable in class picard.sam.CreateSequenceDictionary
 
OUTPUT - Variable in class picard.sam.DownsampleSam
 
OUTPUT - Variable in class picard.sam.FastqToSam
 
OUTPUT - Variable in class picard.sam.FilterSamReads
 
OUTPUT - Variable in class picard.sam.FixMateInformation
 
OUTPUT - Variable in class picard.sam.GatherBamFiles
 
OUTPUT - Variable in class picard.sam.markduplicates.EstimateLibraryComplexity
 
OUTPUT - Variable in class picard.sam.markduplicates.util.AbstractMarkDuplicatesCommandLineProgram
 
OUTPUT - Variable in class picard.sam.MergeBamAlignment
 
OUTPUT - Variable in class picard.sam.MergeSamFiles
 
OUTPUT - Variable in class picard.sam.PositionBasedDownsampleSam
 
OUTPUT - Variable in class picard.sam.ReorderSam
 
OUTPUT - Variable in class picard.sam.ReplaceSamHeader
 
OUTPUT - Variable in class picard.sam.RevertOriginalBaseQualitiesAndAddMateCigar
 
OUTPUT - Variable in class picard.sam.RevertSam
 
OUTPUT - Variable in class picard.sam.SamFormatConverter
 
OUTPUT - Variable in class picard.sam.SetNmMdAndUqTags
 
OUTPUT - Variable in class picard.sam.SortSam
 
OUTPUT - Variable in class picard.sam.SplitSamByLibrary
 
OUTPUT - Variable in class picard.sam.SplitSamByNumberOfReads
 
OUTPUT - Variable in class picard.sam.ValidateSamFile
 
OUTPUT - Variable in class picard.util.BedToIntervalList
 
OUTPUT - Variable in class picard.util.IntervalListToBed
 
OUTPUT - Variable in class picard.util.IntervalListTools
 
OUTPUT - Variable in class picard.util.LiftOverIntervalList
 
OUTPUT - Variable in class picard.util.ScatterIntervalsByNs
 
OUTPUT - Variable in class picard.vcf.AccumulateVariantCallingMetrics
 
OUTPUT - Variable in class picard.vcf.CollectVariantCallingMetrics
 
OUTPUT - Variable in class picard.vcf.filter.FilterVcf
 
OUTPUT - Variable in class picard.vcf.FixVcfHeader
 
OUTPUT - Variable in class picard.vcf.GatherVcfs
 
OUTPUT - Variable in class picard.vcf.GenotypeConcordance
 
OUTPUT - Variable in class picard.vcf.LiftoverVcf
 
OUTPUT - Variable in class picard.vcf.MakeSitesOnlyVcf
 
OUTPUT - Variable in class picard.vcf.MendelianViolations.FindMendelianViolations
 
OUTPUT - Variable in class picard.vcf.MergeVcfs
 
OUTPUT - Variable in class picard.vcf.RenameSampleInVcf
 
OUTPUT - Variable in class picard.vcf.SortVcf
 
OUTPUT - Variable in class picard.vcf.UpdateVcfSequenceDictionary
 
OUTPUT - Variable in class picard.vcf.VcfFormatConverter
 
OUTPUT - Variable in class picard.vcf.VcfToIntervalList
 
OUTPUT_AGILENT_FILES - Variable in class picard.util.BaitDesigner
 
OUTPUT_ALL_ROWS - Variable in class picard.vcf.GenotypeConcordance
 
OUTPUT_BASE - Variable in class picard.analysis.artifacts.ConvertSequencingArtifactToOxoG
 
OUTPUT_BY_READGROUP - Variable in class picard.sam.RevertSam
 
OUTPUT_BY_READGROUP_FILE_FORMAT - Variable in class picard.sam.RevertSam
 
OUTPUT_DEBUG_INDEL_INFO - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.UnifiedArgumentCollection
 
OUTPUT_DIR - Variable in class picard.illumina.ExtractIlluminaBarcodes
 
OUTPUT_DIR - Variable in class picard.sam.SamToFastq
 
OUTPUT_DIRECTORY - Variable in class org.broadinstitute.hellbender.tools.SplitReads
 
OUTPUT_DIRECTORY - Variable in class picard.illumina.CollectIlluminaLaneMetrics
 
OUTPUT_DIRECTORY - Variable in class picard.util.BaitDesigner
 
OUTPUT_ERRORS_ONLY - Variable in class picard.fingerprint.CrosscheckFingerprints
 
OUTPUT_FILE_PREFIX - Variable in class picard.fastq.BamToBfq
 
OUTPUT_FORMAT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorArgumentDefinitions
 
OUTPUT_HDFS_DIRECTORY_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.ParallelCopyGCSDirectoryIntoHDFSSpark
 
OUTPUT_INTERVALS_VCF_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.PostprocessGermlineCNVCalls
 
OUTPUT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
OUTPUT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.ConvertHeaderlessHadoopBamShardToBam
 
OUTPUT_MAP - Variable in class picard.sam.RevertSam
 
OUTPUT_PER_RG - Variable in class picard.sam.SamToFastq
 
OUTPUT_PREFIX - Variable in class picard.illumina.CollectIlluminaLaneMetrics
 
OUTPUT_PREFIX - Variable in class picard.illumina.IlluminaBasecallsToFastq
 
OUTPUT_PREFIX_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.CopyNumberStandardArgument
 
OUTPUT_SEGMENTS_VCF_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.PostprocessGermlineCNVCalls
 
OUTPUT_SHARD_DIR_LONG_NAME - Static variable in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
 
OUTPUT_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
OUTPUT_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.ConvertHeaderlessHadoopBamShardToBam
 
OUTPUT_SHORT_NAME - Static variable in class picard.cmdline.StandardOptionDefinitions
 
OUTPUT_STATISTICS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.ClipReads
 
OUTPUT_STATISTICS_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.ClipReads
 
OUTPUT_TYPE - Variable in class picard.util.ScatterIntervalsByNs
 
OUTPUT_VCF - Variable in class picard.vcf.GenotypeConcordance
 
OUTPUT_VCF_CALL_SAMPLE_NAME - Static variable in class picard.vcf.GenotypeConcordance
 
OUTPUT_VCF_FILE_EXTENSION - Static variable in class picard.vcf.GenotypeConcordance
 
OUTPUT_VCF_TRUTH_SAMPLE_NAME - Static variable in class picard.vcf.GenotypeConcordance
 
outputAnnotatedIntervalsFile - Variable in class org.broadinstitute.hellbender.tools.copynumber.AnnotateIntervals
 
outputBam - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.ReadsPipelineSpark
 
outputBaseName - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectMultipleMetricsSpark
 
OutputCapture(CAPTURE_POLICY, ProcessControllerBase.ProcessStream, String, int) - Constructor for class org.broadinstitute.hellbender.utils.runtime.ProcessControllerBase.OutputCapture
Reads in the output of a stream on a background thread to keep the output pipe from backing up and freezing the called process.
outputCpxResultsInHumanReadableFormat - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.DiscoverVariantsFromContigsAlignmentsSparkArgumentCollection
 
outputDetailMetricsFile(VariantContext.Type, MetricsFile<GenotypeConcordanceDetailMetrics, ?>, GenotypeConcordanceCounts, String, String, boolean, boolean) - Static method in class picard.vcf.GenotypeConcordance
Outputs the detailed statistics tables for SNP and Indel match categories.
outputDir - Variable in class org.broadinstitute.hellbender.tools.walkers.SplitIntervals
 
outputFile - Variable in class org.broadinstitute.hellbender.tools.AnnotatePairOrientation
 
outputFile - Variable in class org.broadinstitute.hellbender.tools.examples.ExampleAssemblyRegionWalkerSpark
 
outputFile - Variable in class org.broadinstitute.hellbender.tools.exome.FilterByOrientationBias
 
outputFile - Variable in class org.broadinstitute.hellbender.tools.funcotator.Funcotator
 
outputFile - Variable in class org.broadinstitute.hellbender.tools.IndexFeatureFile
 
outputFile - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildKmers
 
outputFile - Variable in class org.broadinstitute.hellbender.tools.spark.PileupSpark
 
outputFile - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.SortSamSpark
 
outputFile - Variable in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotator
 
outputFile - Variable in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
outputFilename - Variable in class org.broadinstitute.hellbender.tools.validation.CompareBaseQualities
 
outputFormat - Variable in class org.broadinstitute.hellbender.tools.walkers.rnaseq.ASEReadCounter
Available options are csv, table, rtable.
outputFormatType - Variable in class org.broadinstitute.hellbender.tools.funcotator.Funcotator
 
outputInsertLength - Variable in class org.broadinstitute.hellbender.tools.spark.PileupSpark
Adds the length of the insert each base comes from to the output pileup.
outputInsertLength - Variable in class org.broadinstitute.hellbender.tools.walkers.qc.Pileup
Adds the length of the insert each base comes from to the output pileup.
OutputMapping - Class in picard.illumina.parser
In multiple locations we need to know what cycles are output, as of now we output all non-skip cycles, but rather than sprinkle this knowledge throughout the parser code, instead OutputMapping provides all the data a client might want about the cycles to be output including what ReadType they are.
OutputMapping(ReadStructure) - Constructor for class picard.illumina.parser.OutputMapping
Create an OutputMapping from a readStructure, currently the outputSubstructure just references the readStructure.nonSkips Substructure
OutputMode - Enum in org.broadinstitute.hellbender.tools.walkers.genotyper
Describes the mode of output for the caller.
outputMode - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.StandardCallerArgumentCollection
 
outputPaired - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBwaSpark
 
outputPaired - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqFilterSpark
 
outputPath - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildReferenceTaxonomy
 
outputPath - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqPipelineSpark
 
outputPath - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqScoreSpark
Records have a "YP" tag that lists the NCBI taxonomy IDs of any mapped organisms.
outputRecalibrationReport(PrintStream, RecalibrationArgumentCollection, QuantizationInfo, RecalibrationTables, StandardCovariateList) - Static method in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
Outputs the GATK report to RAC.RECAL_TABLE.
OutputRenderer - Class in org.broadinstitute.hellbender.tools.funcotator
An abstract class to allow for writing output for the Funcotator.
OutputRenderer() - Constructor for class org.broadinstitute.hellbender.tools.funcotator.OutputRenderer
 
outputReport - Variable in class org.broadinstitute.hellbender.tools.walkers.bqsr.GatherBQSRReports
 
outputReport - Variable in class org.broadinstitute.hellbender.tools.walkers.vqsr.GatherTranches
 
outputSampleNameFile - Variable in class org.broadinstitute.hellbender.tools.GetSampleName
 
outputShardSize - Static variable in class org.broadinstitute.hellbender.engine.spark.AddContextDataToReadSparkOptimized
 
outputSingletonValueAsHistogram(Double) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RankSumTest
 
outputSitesOnlyVCFs - Variable in class org.broadinstitute.hellbender.engine.GATKTool
 
OutputStreamSettings - Class in org.broadinstitute.hellbender.utils.runtime
Settings that define text to capture from a process stream.
OutputStreamSettings() - Constructor for class org.broadinstitute.hellbender.utils.runtime.OutputStreamSettings
 
outputUnpaired - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBwaSpark
 
outputUnpaired - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqFilterSpark
 
outputVCF - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCaller
A raw, unfiltered, highly sensitive callset in VCF format.
outputVCF - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2
 
outputWriter - Variable in class org.broadinstitute.hellbender.tools.copynumber.gcnv.GermlineCNVVariantComposer
 
OverclippedReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Filter out reads where the number of bases without soft-clips (M, I, X, and = CIGAR operators) is lower than a threshold.
OverclippedReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.OverclippedReadFilter
 
OverclippedReadFilter(int, boolean) - Constructor for class org.broadinstitute.hellbender.engine.filters.OverclippedReadFilter
 
OverhangFixingManager - Class in org.broadinstitute.hellbender.tools.walkers.rnaseq
The class manages reads and splices and tries to apply overhang clipping when appropriate.
OverhangFixingManager(SAMFileHeader, GATKReadWriter, GenomeLocParser, IndexedFastaSequenceFile, int, int, int, boolean, boolean) - Constructor for class org.broadinstitute.hellbender.tools.walkers.rnaseq.OverhangFixingManager
 
OverhangFixingManager.Splice - Class in org.broadinstitute.hellbender.tools.walkers.rnaseq
 
OverhangFixingManager.SplitRead - Class in org.broadinstitute.hellbender.tools.walkers.rnaseq
 
overhangingBasesMismatch(byte[], int, int, byte[], int, int) - Method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.OverhangFixingManager
Are there too many mismatches to the reference among the overhanging bases?
overlapFraction(SVIntervalTree<?>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree
fraction of the intervals in this tree that overlap with intervals in some other tree
OverlapIterator(SVInterval) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree.OverlapIterator
 
overlapLen(SVInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVInterval
 
overlapOnContig(AlignmentInterval, AlignmentInterval) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
 
overlapOnRefSpan(AlignmentInterval, AlignmentInterval) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
Computes overlap between reference span of the two input alignment intervals.
overlappers(PairedStrandedIntervals) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.PairedStrandedIntervalTree
 
overlappers(SVInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree
Return an iterator over all intervals overlapping the specified interval.
overlapping - Variable in class org.broadinstitute.hellbender.utils.read.ArtificialReadQueryIterator
 
overlaps(SVInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVInterval
This definition is appropriate for half-open intervals.
overlaps(Locatable) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
Checks if other overlaps with this GencodeGtfFeature.
overlaps(GenomeLoc) - Method in class org.broadinstitute.hellbender.utils.GenomeLocSortedSet
Determine if the given loc overlaps any loc in the sorted set
overlaps(Locatable, Locatable) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Check whether two locatables overlap.
overlaps(Locatable) - Method in class org.broadinstitute.hellbender.utils.SimpleInterval
Determines whether this interval overlaps the provided locatable.
overlapsP(GenomeLoc) - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
 
overlapsRegion(VariantContext, GenomeLoc) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Checks whether a variant-context overlaps with a region.
overlapsRegion(VariantContext, SimpleInterval) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Checks whether a variant-context overlaps with a region.
overlapsWithMargin(Locatable, int) - Method in class org.broadinstitute.hellbender.utils.SimpleInterval
Determines whether this interval comes within "margin" of overlapping the provided locatable.
OVERWRITE_WORKSPACE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.genomicsdb.GenomicsDBImport
 
OXIDATION_ERROR_RATE - Variable in class picard.analysis.CollectOxoGMetrics.CpcgMetrics
The oxo error rate, calculated as max(ALT_OXO_BASES - ALT_NONOXO_BASES, 1) / TOTAL_BASES
OXIDATION_Q - Variable in class picard.analysis.CollectOxoGMetrics.CpcgMetrics
-10 * log10(OXIDATION_ERROR_RATE)
OxoGReadCounts - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Count of read pairs in the F1R2 and F2R1 configurations supporting the reference and alternate alleles
OxoGReadCounts() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.OxoGReadCounts
 

P

P_ACTIVE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineCallingArgumentCollection
 
P_ALT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineCallingArgumentCollection
 
P_ARTIFACT_FIELD_NAME - Static variable in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasFilterConstants
 
P_VALUE_FOR_NOISE - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.PowerCalculationUtils
 
PACKED_STRING_REP_SEPARATOR - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
 
paddedHaplotypeLength - Variable in class org.broadinstitute.hellbender.utils.pairhmm.PairHMM
 
paddedMaxHaplotypeLength - Variable in class org.broadinstitute.hellbender.utils.pairhmm.PairHMM
 
paddedMaxReadLength - Variable in class org.broadinstitute.hellbender.utils.pairhmm.PairHMM
 
paddedReadLength - Variable in class org.broadinstitute.hellbender.utils.pairhmm.PairHMM
 
padding - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmer.Result
Required padding around the variant trimming region.
PADDING - Variable in class picard.util.BaitDesigner
 
PADDING - Variable in class picard.util.IntervalListTools
 
PADDING_IN_BP_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.utils.TagGermlineEvents
 
PADDING_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.PreprocessIntervals
 
Pair - Class in org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords
Class representing a pair of reads together with accompanying optical duplicate marking information.
Pair(GATKRead, GATKRead, SAMFileHeader, int, MarkDuplicatesScoringStrategy) - Constructor for class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Pair
 
Pair.Serializer - Class in org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords
Serializers for each subclass of PairedEnds which rely on implementations of serializations within each class itself
PAIR_ORIENTATION - Variable in class org.broadinstitute.hellbender.metrics.InsertSizeMetrics
The pair orientation of the reads in this data category.
PAIR_ORIENTATION - Variable in class picard.analysis.InsertSizeMetrics
The pair orientation of the reads in this data category.
PAIRED - Static variable in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary
 
PAIRED_INPUT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBwaSpark
 
PAIRED_INPUT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqScoreSpark
 
PAIRED_INPUT_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBwaSpark
 
PAIRED_INPUT_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqScoreSpark
 
PAIRED_OUTPUT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBwaSpark
 
PAIRED_OUTPUT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqFilterSpark
 
PAIRED_OUTPUT_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBwaSpark
 
PAIRED_OUTPUT_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqFilterSpark
 
PAIRED_RUN - Variable in class picard.fastq.BamToBfq
 
PAIRED_RUN - Variable in class picard.illumina.MarkIlluminaAdapters
 
PAIRED_RUN - Variable in class picard.sam.MergeBamAlignment
Deprecated.
PairedEnds - Class in org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords
Struct-like class to store information about the paired reads for mark duplicates.
pairedInput - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqScoreSpark
 
PairedReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.PairedReadFilter
 
PairedStrandedIntervals - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
PairedStrandedIntervals(StrandedInterval, StrandedInterval) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.PairedStrandedIntervals
 
PairedStrandedIntervalTree<V> - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
PairedStrandedIntervalTree() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.PairedStrandedIntervalTree
 
PairedStrandedIntervalTree(Kryo, Input) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.PairedStrandedIntervalTree
 
PairedStrandedIntervalTree.PairedStrandedIntervalTreeIterator - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
PairedStrandedIntervalTree.PairedStrandedIntervalTreeOverlapperIterator - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
PairedStrandedIntervalTree.Serializer<T> - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
PairedStrandedIntervalTreeOverlapperIterator(PairedStrandedIntervalTree<V>, PairedStrandedIntervals) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.PairedStrandedIntervalTree.PairedStrandedIntervalTreeOverlapperIterator
 
PairedVariantSubContextIterator - Class in picard.vcf
An iterator that takes a pair of iterators over VariantContexts and iterates over them in tandem.
PairedVariantSubContextIterator(Iterator<VariantContext>, String, Iterator<VariantContext>, String, SAMSequenceDictionary) - Constructor for class picard.vcf.PairedVariantSubContextIterator
 
PairedVariantSubContextIterator.VcfTuple - Class in picard.vcf
Little class to hold a pair of VariantContexts that are in sync with one another.
pairHMM - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.UnifiedArgumentCollection
The PairHMM implementation to use for -glm INDEL genotype likelihood calculations.
pairHMM - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.LikelihoodEngineArgumentCollection
The PairHMM implementation to use for genotype likelihood calculations.
PairHMM - Class in org.broadinstitute.hellbender.utils.pairhmm
Class for performing the pair HMM for local alignment.
PairHMM() - Constructor for class org.broadinstitute.hellbender.utils.pairhmm.PairHMM
 
PairHMM.Implementation - Enum in org.broadinstitute.hellbender.utils.pairhmm
 
pairHMMComputeTime - Static variable in class org.broadinstitute.hellbender.utils.pairhmm.PairHMM
 
PairHMMLikelihoodCalculationEngine - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
 
PairHMMLikelihoodCalculationEngine(byte, PairHMMNativeArguments, PairHMM.Implementation, double, PairHMMLikelihoodCalculationEngine.PCRErrorModel) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.PairHMMLikelihoodCalculationEngine
Create a new PairHMMLikelihoodCalculationEngine using provided parameters and hmm to do its calculations
PairHMMLikelihoodCalculationEngine(byte, PairHMMNativeArguments, PairHMM.Implementation, double, PairHMMLikelihoodCalculationEngine.PCRErrorModel, byte) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.PairHMMLikelihoodCalculationEngine
Create a new PairHMMLikelihoodCalculationEngine using provided parameters and hmm to do its calculations
PairHMMLikelihoodCalculationEngine.PCRErrorModel - Enum in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
 
PairHMMModel - Class in org.broadinstitute.hellbender.utils.pairhmm
Helper class that implement calculations required to implement the PairHMM Finite State Automation (FSA) model.
pairHMMNativeArgs - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.LikelihoodEngineArgumentCollection
 
PairHMMNativeArgumentCollection - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
Arguments for native PairHMM implementations
PairHMMNativeArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.PairHMMNativeArgumentCollection
 
PANEL_OF_NORMALS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
PANEL_OF_NORMALS_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
ParallelCopyGCSDirectoryIntoHDFSSpark - Class in org.broadinstitute.hellbender.tools.spark
Parallel copy a file or directory from Google Cloud Storage into the HDFS file system used by Spark
ParallelCopyGCSDirectoryIntoHDFSSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.ParallelCopyGCSDirectoryIntoHDFSSpark
 
Parameter<T extends java.lang.Enum<T> & ParameterEnum,U> - Class in org.broadinstitute.hellbender.utils.mcmc
Represents a parameter value with a named ParameterEnum key.
Parameter(T, U) - Constructor for class org.broadinstitute.hellbender.utils.mcmc.Parameter
Constructs a Parameter given a ParameterEnum key name and value.
PARAMETER_DOC - Static variable in class picard.illumina.parser.ReadStructure
 
ParameterDecileCollection<T extends java.lang.Enum<T> & ParameterEnum> - Class in org.broadinstitute.hellbender.tools.copynumber.formats.collections
 
ParameterDecileCollection(SampleMetadata, Map<T, DecileCollection>, Class<T>) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.collections.ParameterDecileCollection
 
ParameterDecileCollection(File, Class<T>) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.collections.ParameterDecileCollection
 
ParameterEnum - Interface in org.broadinstitute.hellbender.utils.mcmc
Interface for tagging an enum that represents the name of every Parameter comprising a ParameterizedState.
ParameterizedFileUtil - Class in picard.illumina.parser
 
ParameterizedFileUtil(boolean, String, File, FileFaker, int, boolean) - Constructor for class picard.illumina.parser.ParameterizedFileUtil
 
ParameterizedFileUtil(boolean, String, File, FileFaker, int) - Constructor for class picard.illumina.parser.ParameterizedFileUtil
 
ParameterizedFileUtil(String, String, File, FileFaker, int) - Constructor for class picard.illumina.parser.ParameterizedFileUtil
 
ParameterizedModel<V1 extends java.lang.Enum<V1> & ParameterEnum,S1 extends ParameterizedState<V1>,T1 extends DataCollection> - Class in org.broadinstitute.hellbender.utils.mcmc
Represents a parameterized model.
ParameterizedModel.GibbsBuilder<V2 extends java.lang.Enum<V2> & ParameterEnum,S2 extends ParameterizedState<V2>,T2 extends DataCollection> - Class in org.broadinstitute.hellbender.utils.mcmc
Builder for constructing a ParameterizedModel to be Gibbs sampled using GibbsSampler.
ParameterizedModel.UpdateMethod - Enum in org.broadinstitute.hellbender.utils.mcmc
 
ParameterizedState<T extends java.lang.Enum<T> & ParameterEnum> - Class in org.broadinstitute.hellbender.utils.mcmc
Represents a mapped collection of Parameter objects, i.e., named, ordered, enumerated keys associated with values of mixed type via a key -> key, value map.
ParameterizedState(List<Parameter<T, ?>>) - Constructor for class org.broadinstitute.hellbender.utils.mcmc.ParameterizedState
Constructs a ParameterizedState with parameters enumerated by ParameterEnum from a List of Parameter objects with values of mixed type, checking that all parameters are present without duplicates.
ParameterizedState(ParameterizedState<T>) - Constructor for class org.broadinstitute.hellbender.utils.mcmc.ParameterizedState
Copy constructor.
ParameterReader<T extends java.lang.Enum<T> & ParameterEnum> - Class in org.broadinstitute.hellbender.utils.mcmc
Table reader for reading a PosteriorSummary for each global parameter in a ParameterEnum.
ParameterReader(File, Class<T>) - Constructor for class org.broadinstitute.hellbender.utils.mcmc.ParameterReader
 
ParameterSampler<U,V extends java.lang.Enum<V> & ParameterEnum,S extends ParameterizedState<V>,T extends DataCollection> - Interface in org.broadinstitute.hellbender.utils.mcmc
Interface for generating random samples of a Parameter value, given an ParameterizedState and a DataCollection.
ParameterTableColumn - Enum in org.broadinstitute.hellbender.utils.mcmc
 
ParameterWriter<T extends java.lang.Enum<T> & ParameterEnum> - Class in org.broadinstitute.hellbender.utils.mcmc
Table writer for ouputting a PosteriorSummary for each global parameter in a ParameterEnum.
ParameterWriter(File, String) - Constructor for class org.broadinstitute.hellbender.utils.mcmc.ParameterWriter
 
ParamUtils - Class in org.broadinstitute.hellbender.utils.param
This class should eventually be merged into Utils, which is in hellbender, and then this class should be deleted.
parse(File, EnumSet<PedReader.MissingPedField>, SampleDB) - Method in class org.broadinstitute.hellbender.utils.samples.PedReader
 
parse(String, EnumSet<PedReader.MissingPedField>, SampleDB) - Method in class org.broadinstitute.hellbender.utils.samples.PedReader
 
parse(Reader, EnumSet<PedReader.MissingPedField>, SampleDB) - Method in class org.broadinstitute.hellbender.utils.samples.PedReader
 
parseArgs(String[]) - Method in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
Parse arguments and initialize any values annotated with Argument
parseArgs(String[]) - Method in class picard.cmdline.CommandLineProgram
 
parseArgsForConfigSetup(String[]) - Method in class org.broadinstitute.hellbender.Main
Reads from the given command-line arguments, pulls out configuration options, and initializes the configuration for this instance of Main.
parseBasesAndQuals(String, String, byte) - Method in class org.broadinstitute.hellbender.utils.codecs.sampileup.SAMPileupCodec
 
parseCatalog(BufferedReader, Map<String, Tuple2<String, Long>>, Map<Integer, PSPathogenReferenceTaxonProperties>, boolean, Set<String>) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBuildReferenceTaxonomyUtils
Builds maps of reference contig accessions to their taxonomic ids and vice versa.
parseCommaDelimitedArgList(String) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSUtils
 
parseFilterLowerLimit(String) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.ApplyVQSR
 
parseGenomeLoc(String) - Method in class org.broadinstitute.hellbender.utils.GenomeLocParser
parse a genome interval, from a location string Performs interval-style validation: contig is valid; start and stop less than the end; start <= stop, and start/stop are on the contig
parseIntervalArguments(GenomeLocParser, List<String>) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Turns a set of strings describing intervals into a parsed set of intervals.
parseIntervalArguments(GenomeLocParser, String) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
 
parseMask(String, int) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSUtils
Parses command-line option for specifying kmer spacing masks
parseMDString(String) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.TextMDCodec
 
parseMissingFieldTags(Object, List<String>) - Static method in class org.broadinstitute.hellbender.utils.samples.PedReader
Parses a list of tags from the command line, assuming it comes from the GATK Engine tags, and returns the corresponding EnumSet.
parseNameForReport() - Method in interface org.broadinstitute.hellbender.utils.recalibration.covariates.Covariate
Returns the names of the covariate, which is the simple class name without the "Covariate" part;
parseNamesFile(BufferedReader, Map<Integer, PSPathogenReferenceTaxonProperties>) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBuildReferenceTaxonomyUtils
Parses scientific name of each taxon and puts it in taxIdToProperties
parseNodesFile(BufferedReader, Map<Integer, PSPathogenReferenceTaxonProperties>) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBuildReferenceTaxonomyUtils
Gets the rank and parent of each taxon.
parseOneContig(AlignedContig, SAMSequenceDictionary, boolean, int, int, boolean) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.DiscoverVariantsFromContigAlignmentsSAMSpark
Parse all alignment records for a single locally-assembled contig and generate chimeric alignments if available.
parsePlatformForRead(GATKRead, SAMFileHeader, RecalibrationArgumentCollection) - Static method in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
Section of code shared between the two recalibration walkers which uses the command line arguments to adjust attributes of the read such as quals or platform string
parsePosteriorsIntoPhredSpace(Genotype) - Static method in class org.broadinstitute.hellbender.tools.walkers.variantutils.PosteriorProbabilitiesUtils
 
parsePosteriorsIntoProbSpace(Genotype) - Static method in class org.broadinstitute.hellbender.tools.walkers.variantutils.PosteriorProbabilitiesUtils
 
parseRawDataString(ReducibleAnnotationData<Histogram>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RankSumTest
 
parseRawDataString(ReducibleAnnotationData<Double>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RMSMappingQuality
 
parseRawDataString(ReducibleAnnotationData<List<Integer>>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_StrandBiasTest
 
parseRawDataString(ReducibleAnnotationData<Number>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.RMSMappingQuality
 
parseReadsAndOptionallySplitGappedAlignments(Iterable<SAMRecord>, int, boolean) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoverFromLocalAssemblyContigAlignmentsSpark.SAMFormattedContigAlignmentParser
Iterates through the input noSecondaryAlignments, which are assumed to contain no secondary alignment (i.e.
parseReferenceRecords(List<SAMSequenceRecord>, Map<Integer, PSPathogenReferenceTaxonProperties>) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBuildReferenceTaxonomyUtils
Build set of accessions contained in the reference.
parseTileMetrics(File, Map<Integer, File>, ReadStructure, ValidationStringency) - Static method in class picard.illumina.parser.TileMetricsUtil
 
parseTileMetrics(File, ReadStructure, ValidationStringency) - Static method in class picard.illumina.parser.TileMetricsUtil
Returns an unmodifiable collection of tile data read from the provided file.
parseTrainingSets(FeatureContext, VariantContext, VariantDatum, boolean) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
 
PartitionBounds(int, int, int, int, int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.PartitionBounds
 
PartitionCrossingChecker - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
It allows you to ask whether a given interval is near the beginning or end of the partition.
PartitionCrossingChecker() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.PartitionCrossingChecker
A constructor that will always report onBoundary to be false.
PartitionCrossingChecker(int, ReadMetadata, int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.PartitionCrossingChecker
A constructor from the metadata with a specified boundary width.
partitionIndex - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.MarkDuplicatesSparkRecord
 
PartitionStatistics(Iterator<GATKRead>, SVReadFilter, int, Map<String, String>) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.PartitionStatistics
 
PASS_FILTER - Static variable in class picard.vcf.filter.FilterApplyingVariantIterator
The "PASS"ing filter String.
PASSES_VENDOR_QUALITY_CHECK - Static variable in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary
 
passesCallThreshold(double) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
 
passesEmitThreshold(double, boolean) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
 
passesMinimumThreshold(ReducibleAnnotationData<List<Integer>>, int) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_StrandBiasTest
Does this strand data array pass the minimum threshold for inclusion?
passesMinimumThreshold(int[], int) - Static method in class org.broadinstitute.hellbender.tools.walkers.annotator.StrandBiasTest
Does this strand data array pass the minimum threshold for inclusion?
PassesVendorQualityCheckReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.PassesVendorQualityCheckReadFilter
 
Passthrough - Class in org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords
Dummy class used for preserving reads that need to be marked as non-duplicate despite not wanting to perform any processing on the reads.
PassThroughDownsampler - Class in org.broadinstitute.hellbender.utils.downsampling
Pass-Through Downsampler: Implementation of the ReadsDownsampler interface that does no downsampling whatsoever, and instead simply "passes-through" all the reads it's given.
PassThroughDownsampler() - Constructor for class org.broadinstitute.hellbender.utils.downsampling.PassThroughDownsampler
 
path() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KBestHaplotype
Returns the path across the original graph that correspond to the solution haplotype.
Path<T extends BaseVertex,E extends BaseEdge> - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs
A path thought a BaseGraph class to keep track of paths
Path(T, BaseGraph<T, E>) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.Path
Create a new Path containing no edges and starting at initialVertex
Path(Path<T, E>, E) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.Path
Create a new Path extending p with edge
Path(E, Path<T, E>) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.Path
Prepend a path with an edge.
pathExists(JavaSparkContext, Path) - Static method in class org.broadinstitute.hellbender.utils.spark.SparkUtils
Determine if the targetPath exists.
PathHelper - Class in picard.nio
A class who's purpose is to initialize the various plugins that provide Path support.
PathHelper.PathProviders - Enum in picard.nio
 
PathLineIterator - Class in org.broadinstitute.hellbender.utils.nio
Iterate through the lines of a Path.
PathLineIterator(Path) - Constructor for class org.broadinstitute.hellbender.utils.nio.PathLineIterator
Returns an iterator so you can iterate over the lines in the text file like so: for (String line: new PathLineIterator(path)) { // do something with the line } It's also closeable so you can close it when done, or use it in a try-with-resources to close it automatically.
PATHS - Static variable in class org.broadinstitute.hellbender.utils.runtime.RuntimeUtils
 
pathsAreTheSame(Path<T, E>) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.Path
Check that two paths have the same edges and total score
PathSeqBuildKmers - Class in org.broadinstitute.hellbender.tools.spark.pathseq
Produce a set of k-mers from the given host reference.
PathSeqBuildKmers() - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildKmers
 
PathSeqBuildReferenceTaxonomy - Class in org.broadinstitute.hellbender.tools.spark.pathseq
Build an annotated taxonomy datafile for a given microbe reference.
PathSeqBuildReferenceTaxonomy() - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildReferenceTaxonomy
 
PathSeqBwaSpark - Class in org.broadinstitute.hellbender.tools.spark.pathseq
Align reads to a microbe reference using BWA-MEM and Spark.
PathSeqBwaSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBwaSpark
 
PathSeqFilterSpark - Class in org.broadinstitute.hellbender.tools.spark.pathseq
Filters low complexity, low quality, duplicate, and host reads.
PathSeqFilterSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqFilterSpark
 
pathseqGetRecommendedNumReducers(String, int, int) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSUtils
Same as GATKSparkTool's getRecommendedNumReducers(), but can specify input BAM path (for when --input is not used)
PathSeqPipelineSpark - Class in org.broadinstitute.hellbender.tools.spark.pathseq
Combined tool that performs all PathSeq steps: read filtering, microbe reference alignment and abundance scoring
PathSeqPipelineSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqPipelineSpark
 
PathSeqScoreSpark - Class in org.broadinstitute.hellbender.tools.spark.pathseq
Classify reads and estimate abundances of each taxon in the reference.
PathSeqScoreSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqScoreSpark
 
PATTERN - Static variable in enum org.broadinstitute.hellbender.tools.spark.sv.utils.Strand
 
PCR_error - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.UnifiedArgumentCollection
The PCR error rate is independent of the sequencing error rate, which is necessary because we cannot necessarily distinguish between PCR errors vs.
PCR_SLIPPAGE_P_VALUE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
PCR_SLIPPAGE_RATE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
pcrErrorModel - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.LikelihoodEngineArgumentCollection
When calculating the likelihood of variants, we can try to correct for PCR errors that cause indel artifacts.
pcrSlippagePValueThreshold - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
pcrSlippageRate - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
PCT_100X - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The fraction of bases that attained at least 100X sequence coverage in post-filtering bases.
PCT_10X - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The fraction of bases that attained at least 10X sequence coverage in post-filtering bases.
PCT_15X - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The fraction of bases that attained at least 15X sequence coverage in post-filtering bases.
PCT_1X - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The fraction of bases that attained at least 1X sequence coverage in post-filtering bases.
PCT_20X - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The fraction of bases that attained at least 20X sequence coverage in post-filtering bases.
PCT_25X - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The fraction of bases that attained at least 25X sequence coverage in post-filtering bases.
PCT_30X - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The fraction of bases that attained at least 30X sequence coverage in post-filtering bases.
PCT_40X - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The fraction of bases that attained at least 40X sequence coverage in post-filtering bases.
PCT_50X - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The fraction of bases that attained at least 50X sequence coverage in post-filtering bases.
PCT_5X - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The fraction of bases that attained at least 5X sequence coverage in post-filtering bases.
PCT_60X - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The fraction of bases that attained at least 60X sequence coverage in post-filtering bases.
PCT_70X - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The fraction of bases that attained at least 70X sequence coverage in post-filtering bases.
PCT_80X - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The fraction of bases that attained at least 80X sequence coverage in post-filtering bases.
PCT_90X - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The fraction of bases that attained at least 90X sequence coverage in post-filtering bases.
PCT_A - Variable in class org.broadinstitute.hellbender.metrics.analysis.BaseDistributionByCycleMetrics
 
PCT_A - Variable in class picard.analysis.BaseDistributionByCycleMetrics
 
PCT_ADAPTER - Variable in class picard.analysis.AlignmentSummaryMetrics
The fraction of PF reads that are unaligned and match to a known adapter sequence right from the start of the read.
PCT_AMPLIFIED_BASES - Variable in class picard.analysis.directed.TargetedPcrMetrics
The fraction of PF_BASES_ALIGNED that mapped to or near an amplicon, (ON_AMPLICON_BASES + NEAR_AMPLICON_BASES)/PF_BASES_ALIGNED.
PCT_C - Variable in class org.broadinstitute.hellbender.metrics.analysis.BaseDistributionByCycleMetrics
 
PCT_C - Variable in class picard.analysis.BaseDistributionByCycleMetrics
 
PCT_CHIMERAS - Variable in class picard.analysis.AlignmentSummaryMetrics
The fraction of reads that map outside of a maximum insert size (usually 100kb) or that have the two ends mapping to different chromosomes.
PCT_CHIMERAS - Variable in class picard.analysis.JumpingLibraryMetrics
The number of chimeric pairs expressed as a fraction of the total of all outward facing pairs, inward-facing pairs, and chimeric pairs.
PCT_CODING_BASES - Variable in class picard.analysis.RnaSeqMetrics
Fraction of PF_ALIGNED_BASES that mapped to protein coding regions of genes, CODING_BASES/PF_ALIGNED_BASES
PCT_CONVERTED - Variable in class picard.analysis.RrbsCpgDetailMetrics
CpG CONVERTED_BASES / CpG TOTAL_BASES (fraction)
PCT_CORRECT_STRAND_READS - Variable in class picard.analysis.RnaSeqMetrics
Fraction of reads corresponding to mRNA transcripts which map to the correct strand of a reference genome = CORRECT_STRAND_READS/(CORRECT_STRAND_READS + INCORRECT_STRAND_READS).
PCT_CPG_BASES_CONVERTED - Variable in class picard.analysis.RrbsSummaryMetrics
CPG_BASES_CONVERTED / CPG_BASES_SEEN (fraction)
PCT_DBSNP - Variable in class picard.vcf.CollectVariantCallingMetrics.VariantCallingSummaryMetrics
The fraction of passing bi-allelic SNPs in dbSNP
PCT_DBSNP_INDELS - Variable in class picard.vcf.CollectVariantCallingMetrics.VariantCallingSummaryMetrics
The fraction of passing indels in dbSNP
PCT_EXC_BASEQ - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The fraction of aligned bases that were filtered out because they were of low base quality (default is < 20).
PCT_EXC_BASEQ - Variable in class picard.analysis.directed.HsMetrics
The fraction of aligned bases that were filtered out because they were of low base quality.
PCT_EXC_BASEQ - Variable in class picard.analysis.directed.TargetedPcrMetrics
The fraction of aligned bases that were filtered out because they were of low base quality.
PCT_EXC_BASEQ - Variable in class picard.analysis.directed.TargetMetrics
The fraction of aligned bases that were filtered out because they were of low base quality.
PCT_EXC_CAPPED - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The fraction of aligned bases that were filtered out because they would have raised coverage above the capped value (default cap = 250x).
PCT_EXC_DUPE - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The fraction of aligned bases that were filtered out because they were in reads marked as duplicates.
PCT_EXC_DUPE - Variable in class picard.analysis.directed.HsMetrics
The fraction of aligned bases that were filtered out because they were in reads marked as duplicates.
PCT_EXC_DUPE - Variable in class picard.analysis.directed.TargetedPcrMetrics
The fraction of aligned bases that were filtered out because they were in reads marked as duplicates.
PCT_EXC_DUPE - Variable in class picard.analysis.directed.TargetMetrics
The fraction of aligned bases that were filtered out because they were in reads marked as duplicates.
PCT_EXC_MAPQ - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The fraction of aligned bases that were filtered out because they were in reads with low mapping quality (default is < 20).
PCT_EXC_MAPQ - Variable in class picard.analysis.directed.HsMetrics
The fraction of aligned bases that were filtered out because they were in reads with low mapping quality.
PCT_EXC_MAPQ - Variable in class picard.analysis.directed.TargetedPcrMetrics
The fraction of aligned bases that were filtered out because they were in reads with low mapping quality.
PCT_EXC_MAPQ - Variable in class picard.analysis.directed.TargetMetrics
The fraction of aligned bases that were filtered out because they were in reads with low mapping quality.
PCT_EXC_OFF_TARGET - Variable in class picard.analysis.directed.HsMetrics
The fraction of aligned bases that were filtered out because they did not align over a target base.
PCT_EXC_OFF_TARGET - Variable in class picard.analysis.directed.TargetedPcrMetrics
The fraction of bases that were filtered out because they did not map to a base within a target region.
PCT_EXC_OFF_TARGET - Variable in class picard.analysis.directed.TargetMetrics
The fraction of aligned bases that were filtered out because they did not align over a target base.
PCT_EXC_OVERLAP - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The fraction of aligned bases that were filtered out because they were the second observation from an insert with overlapping reads.
PCT_EXC_OVERLAP - Variable in class picard.analysis.directed.HsMetrics
The fraction of aligned bases that were filtered out because they were the second observation from an insert with overlapping reads.
PCT_EXC_OVERLAP - Variable in class picard.analysis.directed.TargetedPcrMetrics
The fraction of aligned bases that were filtered out because they were the second observation from an insert with overlapping reads.
PCT_EXC_OVERLAP - Variable in class picard.analysis.directed.TargetMetrics
The fraction of aligned bases that were filtered out because they were the second observation from an insert with overlapping reads.
PCT_EXC_TOTAL - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The total fraction of aligned bases excluded due to all filters.
PCT_EXC_UNPAIRED - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The fraction of aligned bases that were filtered out because they were in reads without a mapped mate pair.
PCT_G - Variable in class org.broadinstitute.hellbender.metrics.analysis.BaseDistributionByCycleMetrics
 
PCT_G - Variable in class picard.analysis.BaseDistributionByCycleMetrics
 
PCT_GQ0_VARIANTS - Variable in class picard.vcf.CollectVariantCallingMetrics.VariantCallingDetailMetrics
The percentage of variants in a particular sample that have a GQ score of 0.
PCT_INTERGENIC_BASES - Variable in class picard.analysis.RnaSeqMetrics
Fraction of PF_ALIGNED_BASES that mapped to intergenic regions of genomic DNA, INTERGENIC_BASES/PF_ALIGNED_BASES
PCT_INTRONIC_BASES - Variable in class picard.analysis.RnaSeqMetrics
Fraction of PF_ALIGNED_BASES that correspond to gene introns, INTRONIC_BASES/PF_ALIGNED_BASES
PCT_JUMPS - Variable in class picard.analysis.JumpingLibraryMetrics
The number of outward-facing pairs expressed as a fraction of the total of all outward facing pairs, inward-facing pairs, and chimeric pairs.
PCT_MATCHES - Variable in class picard.illumina.ExtractIlluminaBarcodes.BarcodeMetric
The fraction of all reads in the lane that matched to this barcode.
PCT_MRNA_BASES - Variable in class picard.analysis.RnaSeqMetrics
Sum of bases mapped to regions corresponding to UTRs and coding regions of mRNA transcripts, PCT_UTR_BASES + PCT_CODING_BASES
PCT_N - Variable in class org.broadinstitute.hellbender.metrics.analysis.BaseDistributionByCycleMetrics
 
PCT_N - Variable in class picard.analysis.BaseDistributionByCycleMetrics
 
PCT_NON_CPG_BASES_CONVERTED - Variable in class picard.analysis.RrbsSummaryMetrics
NON_CPG_CONVERTED_BASES / NON_CPG_BASES (fraction)
PCT_NONJUMPS - Variable in class picard.analysis.JumpingLibraryMetrics
The number of inward-facing pairs expressed as a fraction of the total of all outward facing pairs, inward-facing pairs, and chimeric pairs.
PCT_OFF_AMPLICON - Variable in class picard.analysis.directed.TargetedPcrMetrics
The fraction of PF_BASES_ALIGNED that mapped neither onto or near an amplicon, OFF_AMPLICON_BASES/PF_BASES_ALIGNED
PCT_OFF_BAIT - Variable in class picard.analysis.directed.HsMetrics
The fraction of PF_BASES_ALIGNED that are mapped away from any baited region, OFF_BAIT_BASES/PF_BASES_ALIGNED.
PCT_OFF_PROBE - Variable in class picard.analysis.directed.TargetMetrics
The fraction of aligned PF bases that mapped neither on or near a probe, OFF_PROBE_BASES/(ON_PROBE_BASES + NEAR_PROBE_BASES + OFF_PROBE_BASES).
PCT_PF_FAIL_EMPTY - Variable in class picard.illumina.quality.CollectHiSeqXPfFailMetrics.PFFailSummaryMetric
The fraction of non-PF reads in this tile that are deemed empty (as fraction of all non-PF reads).
PCT_PF_FAIL_MISALIGNED - Variable in class picard.illumina.quality.CollectHiSeqXPfFailMetrics.PFFailSummaryMetric
The fraction of non-PF reads in this tile that are deemed "misaligned" (as fraction of all non-PF reads).
PCT_PF_FAIL_POLYCLONAL - Variable in class picard.illumina.quality.CollectHiSeqXPfFailMetrics.PFFailSummaryMetric
The fraction of non-PF reads in this tile that are deemed multiclonal (as fraction of all non-PF reads).
PCT_PF_FAIL_READS - Variable in class picard.illumina.quality.CollectHiSeqXPfFailMetrics.PFFailSummaryMetric
The fraction of PF_READS
PCT_PF_FAIL_UNKNOWN - Variable in class picard.illumina.quality.CollectHiSeqXPfFailMetrics.PFFailSummaryMetric
The fraction of non-PF reads in this tile that have not been classified (as fraction of all non-PF reads).
PCT_PF_READS - Variable in class picard.analysis.AlignmentSummaryMetrics
The fraction of reads that are PF (PF_READS / TOTAL_READS)
PCT_PF_READS - Variable in class picard.analysis.directed.HsMetrics
The fraction of reads passing the vendor's filter, PF_READS/TOTAL_READS.
PCT_PF_READS - Variable in class picard.analysis.directed.TargetedPcrMetrics
The fraction of reads passing filter, PF_READS/TOTAL_READS.
PCT_PF_READS - Variable in class picard.analysis.directed.TargetMetrics
The fraction of reads passing filter, PF_READS/TOTAL_READS.
PCT_PF_READS_ALIGNED - Variable in class picard.analysis.AlignmentSummaryMetrics
The percentage of PF reads that aligned to the reference sequence.
PCT_PF_READS_IMPROPER_PAIRS - Variable in class picard.analysis.AlignmentSummaryMetrics
The fraction of (primary) reads that are *not* "properly" aligned in pairs (as per SAM flag 0x2).
PCT_PF_UQ_READS - Variable in class picard.analysis.directed.HsMetrics
The fraction of PF_UNIQUE_READS from the TOTAL_READS, PF_UNIQUE_READS/TOTAL_READS.
PCT_PF_UQ_READS - Variable in class picard.analysis.directed.TargetedPcrMetrics
The fraction of TOTAL_READS that are unique, PF, and are not duplicates, PF_UNIQUE_READS/TOTAL_READS
PCT_PF_UQ_READS - Variable in class picard.analysis.directed.TargetMetrics
The fraction of unique reads passing filter, PF_UNIQUE_READS/TOTAL_READS.
PCT_PF_UQ_READS_ALIGNED - Variable in class picard.analysis.directed.HsMetrics
The fraction of PF_UQ_READS_ALIGNED from the total number of PF reads.
PCT_PF_UQ_READS_ALIGNED - Variable in class picard.analysis.directed.TargetedPcrMetrics
Fraction of PF_READS that are unique and align to the reference genome, PF_UQ_READS_ALIGNED/PF_READS
PCT_PF_UQ_READS_ALIGNED - Variable in class picard.analysis.directed.TargetMetrics
The fraction of unique reads passing filter that align to the reference, PF_UQ_READS_ALIGNED/PF_UNIQUE_READS.
PCT_R1_TRANSCRIPT_STRAND_READS - Variable in class picard.analysis.RnaSeqMetrics
The fraction of reads that support the model where R1 is on the strand of transcription and R2 is on the opposite strand.
PCT_R2_TRANSCRIPT_STRAND_READS - Variable in class picard.analysis.RnaSeqMetrics
The fraction of reads that support the model where R2 is on the strand of transcription and R1 is on the opposite strand.
PCT_READS_ALIGNED_IN_PAIRS - Variable in class picard.analysis.AlignmentSummaryMetrics
The fraction of reads whose mate pair was also aligned to the reference.
PCT_RIBOSOMAL_BASES - Variable in class picard.analysis.RnaSeqMetrics
Fraction of PF_ALIGNED_BASES that mapped to regions encoding ribosomal RNA, RIBOSOMAL_BASES/PF_ALIGNED_BASES
PCT_SELECTED_BASES - Variable in class picard.analysis.directed.HsMetrics
The fraction of PF_BASES_ALIGNED located on or near a baited region (ON_BAIT_BASES + NEAR_BAIT_BASES)/PF_BASES_ALIGNED.
PCT_SELECTED_BASES - Variable in class picard.analysis.directed.TargetMetrics
The fraction of bases that map on or near a probe (ON_PROBE_BASES + NEAR_PROBE_BASES)/(ON_PROBE_BASES + NEAR_PROBE_BASES + OFF_PROBE_BASES).
PCT_T - Variable in class org.broadinstitute.hellbender.metrics.analysis.BaseDistributionByCycleMetrics
 
PCT_T - Variable in class picard.analysis.BaseDistributionByCycleMetrics
 
PCT_TARGET_BASES_100X - Variable in class picard.analysis.directed.HsMetrics
The fraction of all target bases achieving 100X or greater coverage.
PCT_TARGET_BASES_100X - Variable in class picard.analysis.directed.TargetMetrics
The fraction of all target bases achieving 100X or greater coverage.
PCT_TARGET_BASES_10X - Variable in class picard.analysis.directed.HsMetrics
The fraction of all target bases achieving 10X or greater coverage.
PCT_TARGET_BASES_10X - Variable in class picard.analysis.directed.TargetedPcrMetrics
The fraction of all target bases achieving 10X or greater coverage depth.
PCT_TARGET_BASES_10X - Variable in class picard.analysis.directed.TargetMetrics
The fraction of all target bases achieving 10X or greater coverage.
PCT_TARGET_BASES_1X - Variable in class picard.analysis.directed.HsMetrics
The fraction of all target bases achieving 1X or greater coverage.
PCT_TARGET_BASES_1X - Variable in class picard.analysis.directed.TargetedPcrMetrics
The fraction of all target bases achieving 1X or greater coverage.
PCT_TARGET_BASES_1X - Variable in class picard.analysis.directed.TargetMetrics
The fraction of all target bases achieving 1X or greater coverage.
PCT_TARGET_BASES_20X - Variable in class picard.analysis.directed.HsMetrics
The fraction of all target bases achieving 20X or greater coverage.
PCT_TARGET_BASES_20X - Variable in class picard.analysis.directed.TargetedPcrMetrics
The fraction of all target bases achieving 20X or greater coverage depth.
PCT_TARGET_BASES_20X - Variable in class picard.analysis.directed.TargetMetrics
The fraction of all target bases achieving 20X or greater coverage.
PCT_TARGET_BASES_2X - Variable in class picard.analysis.directed.HsMetrics
The fraction of all target bases achieving 2X or greater coverage.
PCT_TARGET_BASES_2X - Variable in class picard.analysis.directed.TargetedPcrMetrics
The fraction of all target bases achieving 2X or greater coverage depth.
PCT_TARGET_BASES_2X - Variable in class picard.analysis.directed.TargetMetrics
The fraction of all target bases achieving 2X or greater coverage.
PCT_TARGET_BASES_30X - Variable in class picard.analysis.directed.HsMetrics
The fraction of all target bases achieving 30X or greater coverage.
PCT_TARGET_BASES_30X - Variable in class picard.analysis.directed.TargetedPcrMetrics
The fraction of all target bases achieving 30X or greater coverage depth.
PCT_TARGET_BASES_30X - Variable in class picard.analysis.directed.TargetMetrics
The fraction of all target bases achieving 30X or greater coverage.
PCT_TARGET_BASES_40X - Variable in class picard.analysis.directed.HsMetrics
The fraction of all target bases achieving 40X or greater coverage.
PCT_TARGET_BASES_40X - Variable in class picard.analysis.directed.TargetMetrics
The fraction of all target bases achieving 40X or greater coverage.
PCT_TARGET_BASES_50X - Variable in class picard.analysis.directed.HsMetrics
The fraction of all target bases achieving 50X or greater coverage.
PCT_TARGET_BASES_50X - Variable in class picard.analysis.directed.TargetMetrics
The fraction of all target bases achieving 50X or greater coverage.
PCT_UMI_WITH_N - Variable in class picard.sam.markduplicates.UmiMetrics
The percentage of reads that contain an UMI that contains at least one N
PCT_USABLE_BASES - Variable in class picard.analysis.RnaSeqMetrics
The fraction of bases mapping to mRNA divided by the total number of PF bases, (CODING_BASES + UTR_BASES)/PF_BASES.
PCT_USABLE_BASES_ON_BAIT - Variable in class picard.analysis.directed.HsMetrics
The number of aligned, de-duped, on-bait bases out of the PF bases available.
PCT_USABLE_BASES_ON_TARGET - Variable in class picard.analysis.directed.HsMetrics
The number of aligned, de-duped, on-target bases out of all of the PF bases available.
PCT_UTR_BASES - Variable in class picard.analysis.RnaSeqMetrics
Fraction of PF_ALIGNED_BASES that mapped to untranslated regions (UTR) of genes, UTR_BASES/PF_ALIGNED_BASES
PDF_FILE_EXTENSION - Static variable in class picard.analysis.CollectRrbsMetrics
 
pdfFile - Variable in class org.broadinstitute.hellbender.tools.walkers.bqsr.AnalyzeCovariates
Output report file name.
PedFile - Class in picard.pedigree
Represents a .ped file of family information as documented here: http://pngu.mgh.harvard.edu/~purcell/plink/data.shtml Stores the information in memory as a map of individualId -> Pedigree information for that individual
PedFile(boolean) - Constructor for class picard.pedigree.PedFile
 
PedFile.PedTrio - Class in picard.pedigree
 
PEDIGREE_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
PEDIGREE_FILE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
PedigreeAnnotation - Class in org.broadinstitute.hellbender.tools.walkers.annotator
A common interface for handling annotations that require pedigree file information either in the form of explicitly selected founderIDs or in the form of an imported pedigreeFile.
PedigreeAnnotation(Set<String>) - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.PedigreeAnnotation
 
PedigreeAnnotation(File) - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.PedigreeAnnotation
 
PedigreeValidationType - Enum in org.broadinstitute.hellbender.utils.samples
 
PedReader - Class in org.broadinstitute.hellbender.utils.samples
Reads PED file-formatted tabular text files See http://www.broadinstitute.org/mpg/tagger/faq.html See http://pngu.mgh.harvard.edu/~purcell/plink/data.shtml#ped The "ped" file format refers to the widely-used format for linkage pedigree data.
PedReader() - Constructor for class org.broadinstitute.hellbender.utils.samples.PedReader
 
PedReader.Field - Enum in org.broadinstitute.hellbender.utils.samples
 
PedReader.MissingPedField - Enum in org.broadinstitute.hellbender.utils.samples
An enum that specifies which, if any, of the standard PED fields are missing from the input records.
PedTrio(String, String, String, String, Sex, Number) - Constructor for class picard.pedigree.PedFile.PedTrio
Constructs a TRIO that cannot be modified after the fact.
peek() - Method in class org.broadinstitute.hellbender.utils.read.ArtificialReadIterator
peek at the next sam record
peek() - Method in class picard.sam.markduplicates.util.MarkQueue
Returns the first element in this queue
peekFinalized() - Method in class org.broadinstitute.hellbender.utils.downsampling.Downsampler
Peek at the first finalized item stored in this downsampler (or null if there are no finalized items)
peekFinalized() - Method in class org.broadinstitute.hellbender.utils.downsampling.FractionalDownsampler
 
peekFinalized() - Method in class org.broadinstitute.hellbender.utils.downsampling.LevelingDownsampler
 
peekFinalized() - Method in class org.broadinstitute.hellbender.utils.downsampling.MutectDownsampler
 
peekFinalized() - Method in class org.broadinstitute.hellbender.utils.downsampling.PassThroughDownsampler
 
peekFinalized() - Method in class org.broadinstitute.hellbender.utils.downsampling.PositionalDownsampler
 
peekFinalized() - Method in class org.broadinstitute.hellbender.utils.downsampling.ReservoirDownsampler
 
peekPending() - Method in class org.broadinstitute.hellbender.utils.downsampling.Downsampler
Peek at the first pending item stored in this downsampler (or null if there are no pending items)
peekPending() - Method in class org.broadinstitute.hellbender.utils.downsampling.FractionalDownsampler
 
peekPending() - Method in class org.broadinstitute.hellbender.utils.downsampling.LevelingDownsampler
 
peekPending() - Method in class org.broadinstitute.hellbender.utils.downsampling.MutectDownsampler
 
peekPending() - Method in class org.broadinstitute.hellbender.utils.downsampling.PassThroughDownsampler
 
peekPending() - Method in class org.broadinstitute.hellbender.utils.downsampling.PositionalDownsampler
 
peekPending() - Method in class org.broadinstitute.hellbender.utils.downsampling.ReservoirDownsampler
 
PER_BASE_COVERAGE - Variable in class picard.analysis.directed.CollectTargetedMetrics
 
PER_TARGET_COVERAGE - Variable in class picard.analysis.directed.CollectTargetedMetrics
 
PER_TILE_PATTERN_STRING - Static variable in class picard.illumina.parser.ParameterizedFileUtil
 
PerAlleleAnnotation - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Apply an annotation based on aggregation data from all reads supporting each allele.
PerAlleleAnnotation() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.PerAlleleAnnotation
 
PerAlleleCollection<X extends java.lang.Number> - Class in org.broadinstitute.hellbender.tools.walkers.mutect
A container for allele to value mapping.
PerAlleleCollection(PerAlleleCollection.Type) - Constructor for class org.broadinstitute.hellbender.tools.walkers.mutect.PerAlleleCollection
 
PerAlleleCollection.Type - Enum in org.broadinstitute.hellbender.tools.walkers.mutect
 
PERCENT_DUPLICATION - Variable in class picard.sam.DuplicationMetrics
The fraction of mapped sequence that is marked as duplicate.
percentageOrNull(Long, Long) - Static method in class picard.util.MathUtil
Obtains percentage of two Longs
PERFECT_MATCHES - Variable in class picard.illumina.ExtractIlluminaBarcodes.BarcodeMetric
The number of all reads matching this barcode that matched with 0 errors or no-calls.
performSequenceDictionaryValidation() - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.SequenceDictionaryValidationArgumentCollection.NoValidationCollection
 
performSequenceDictionaryValidation() - Method in interface org.broadinstitute.hellbender.cmdline.argumentcollections.SequenceDictionaryValidationArgumentCollection
Should sequence dictionary validation be performed
performSequenceDictionaryValidation() - Method in class org.broadinstitute.hellbender.cmdline.argumentcollections.SequenceDictionaryValidationArgumentCollection.StandardValidationCollection
 
Permutation<E> - Interface in org.broadinstitute.hellbender.utils.collections
Represent a permutation of a ordered set or list of elements.
permutation(AlleleList<A>) - Method in interface org.broadinstitute.hellbender.utils.genotyper.AlleleList
Returns a permutation between two allele lists.
permutationTest(double[], double[], double) - Method in class org.broadinstitute.hellbender.utils.MannWhitneyU
Creates histogram of test statistics from a permutation test.
PersistenceOptimizer - Class in org.broadinstitute.hellbender.tools.copynumber.utils.optimization
Given 1-dimensional data, finds all local minima sorted by decreasing topological persistence.
PersistenceOptimizer(double[]) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.utils.optimization.PersistenceOptimizer
Identifies the local minima of data based on topological persistence upon construction.
PerTileBarcodeExtractor(int, File, Map<String, ExtractIlluminaBarcodes.BarcodeMetric>, ExtractIlluminaBarcodes.BarcodeMetric, IlluminaDataProviderFactory, int, int, int, int, List<File>, List<AbstractIlluminaPositionFileReader.PositionInfo>, File[]) - Constructor for class picard.illumina.ExtractIlluminaBarcodes.PerTileBarcodeExtractor
 
PerTileBarcodeExtractor(int, File, Map<String, ExtractIlluminaBarcodes.BarcodeMetric>, ExtractIlluminaBarcodes.BarcodeMetric, IlluminaDataProviderFactory, int, int, int, int) - Constructor for class picard.illumina.ExtractIlluminaBarcodes.PerTileBarcodeExtractor
Constructor
PerTileFileUtil - Class in picard.illumina.parser
 
PerTileFileUtil(String, File, FileFaker, int) - Constructor for class picard.illumina.parser.PerTileFileUtil
 
PerTileFileUtil(String, File, FileFaker, int, boolean) - Constructor for class picard.illumina.parser.PerTileFileUtil
 
PerTileOrPerRunFileUtil - Class in picard.illumina.parser
 
PerTileOrPerRunFileUtil(String, File, FileFaker, int) - Constructor for class picard.illumina.parser.PerTileOrPerRunFileUtil
 
PerTileParser<ILLUMINA_DATA extends picard.illumina.parser.IlluminaData> - Class in picard.illumina.parser
Abstract base class for Parsers that open a single tile file at a time and iterate through them.
PerTileParser(IlluminaFileMap) - Constructor for class picard.illumina.parser.PerTileParser
 
PerTileParser(IlluminaFileMap, int) - Constructor for class picard.illumina.parser.PerTileParser
 
PerTilePerCycleFileUtil - Class in picard.illumina.parser
 
PerTilePerCycleFileUtil(String, File, FileFaker, int) - Constructor for class picard.illumina.parser.PerTilePerCycleFileUtil
 
PerUnitExampleMultiMetricsCollector - Class in org.broadinstitute.hellbender.tools.examples.metrics.multi
A Collector for individual ExampleMultiMetrics for a given SAMPLE or SAMPLE/LIBRARY or SAMPLE/LIBRARY/READ_GROUP (depending on aggregation levels)
PerUnitExampleMultiMetricsCollector(String, String, String) - Constructor for class org.broadinstitute.hellbender.tools.examples.metrics.multi.PerUnitExampleMultiMetricsCollector
 
PerUnitGcBiasMetricsCollector(String, String, String) - Constructor for class picard.analysis.GcBiasMetricsCollector.PerUnitGcBiasMetricsCollector
 
PerUnitInsertSizeMetricsCollector - Class in org.broadinstitute.hellbender.metrics
A Collector for individual InsertSizeMetrics for a given SAMPLE or SAMPLE/LIBRARY or SAMPLE/LIBRARY/READ_GROUP (depending on aggregation levels)
PerUnitInsertSizeMetricsCollector(String, String, String, double, double, Integer) - Constructor for class org.broadinstitute.hellbender.metrics.PerUnitInsertSizeMetricsCollector
 
PerUnitInsertSizeMetricsCollector(String, String, String) - Constructor for class picard.analysis.directed.InsertSizeMetricsCollector.PerUnitInsertSizeMetricsCollector
 
PerUnitMetricCollector<BEAN extends htsjdk.samtools.metrics.MetricBase,HKEY extends java.lang.Comparable<HKEY>,ARGTYPE> - Interface in org.broadinstitute.hellbender.metrics
PerRecordCollector - An interface for classes that collect data in order to generate one or more metrics.
PerUnitMetricCollector<BEAN extends htsjdk.samtools.metrics.MetricBase,HKEY extends java.lang.Comparable,ARGTYPE> - Interface in picard.metrics
PerRecordCollector - An interface for classes that collect data in order to generate one or more metrics.
PerUnitRnaSeqMetricsCollector(RnaSeqMetrics, String, String, String, Long) - Constructor for class picard.analysis.directed.RnaSeqMetricsCollector.PerUnitRnaSeqMetricsCollector
Derived classes that need to capture some additional metrics can use this ctor to supply a metrics instance that is a subclass of RnaSeqMetrics.
PerUnitRnaSeqMetricsCollector(String, String, String, Long) - Constructor for class picard.analysis.directed.RnaSeqMetricsCollector.PerUnitRnaSeqMetricsCollector
 
PerUnitTargetMetricCollector(String, Set<Interval>, String, String, String, long, long, long, Map<Interval, Double>, int, int, boolean) - Constructor for class picard.analysis.directed.TargetMetricsCollector.PerUnitTargetMetricCollector
Constructor that parses the squashed reference to genome reference file and stores the information in a map for later use.
PF_ALIGNED_BASES - Variable in class picard.analysis.AlignmentSummaryMetrics
The total number of aligned bases, in all mapped PF reads, that are aligned to the reference sequence.
PF_ALIGNED_BASES - Variable in class picard.analysis.RnaSeqMetrics
The total number of aligned PF bases.
PF_BASES - Variable in class org.broadinstitute.hellbender.metrics.QualityYieldMetrics
The total number of bases in all PF reads
PF_BASES - Variable in class picard.analysis.CollectQualityYieldMetrics.QualityYieldMetrics
The total number of bases in all PF reads
PF_BASES - Variable in class picard.analysis.directed.TargetedPcrMetrics
The total number of bases within the PF_READS of the SAM or BAM file to be examined
PF_BASES - Variable in class picard.analysis.directed.TargetMetrics
The number of bases in the PF_READS of a SAM or BAM file
PF_BASES - Variable in class picard.analysis.RnaSeqMetrics
The total number of PF bases including non-aligned reads.
PF_BASES - Variable in class picard.illumina.IlluminaBasecallingMetrics
The total number of passing-filter bases assigned to the index.
PF_BASES_ALIGNED - Variable in class picard.analysis.directed.HsMetrics
The number of PF unique bases that are aligned to the reference genome with mapping scores > 0.
PF_BASES_ALIGNED - Variable in class picard.analysis.directed.TargetedPcrMetrics
The number of bases from PF_READS that align to the reference genome with mapping score > 0
PF_BASES_ALIGNED - Variable in class picard.analysis.directed.TargetMetrics
The number of PF_BASES that are aligned with mapping score > 0 to the reference genome.
PF_CLUSTERS - Variable in class picard.illumina.IlluminaBasecallingMetrics
The total number of PF clusters assigned to the index.
PF_FAIL_EMPTY - Variable in class picard.illumina.quality.CollectHiSeqXPfFailMetrics.PFFailSummaryMetric
The number of non-PF reads in this tile that are deemed empty.
PF_FAIL_MISALIGNED - Variable in class picard.illumina.quality.CollectHiSeqXPfFailMetrics.PFFailSummaryMetric
The number of non-PF reads in this tile that are deemed "misaligned".
PF_FAIL_POLYCLONAL - Variable in class picard.illumina.quality.CollectHiSeqXPfFailMetrics.PFFailSummaryMetric
The number of non-PF reads in this tile that are deemed multiclonal.
PF_FAIL_READS - Variable in class picard.illumina.quality.CollectHiSeqXPfFailMetrics.PFFailSummaryMetric
The number of non-PF reads in this tile.
PF_FAIL_UNKNOWN - Variable in class picard.illumina.quality.CollectHiSeqXPfFailMetrics.PFFailSummaryMetric
The number of non-PF reads in this tile that have not been classified.
PF_HQ_ALIGNED_BASES - Variable in class picard.analysis.AlignmentSummaryMetrics
The number of bases aligned to the reference sequence in reads that were mapped at high quality.
PF_HQ_ALIGNED_Q20_BASES - Variable in class picard.analysis.AlignmentSummaryMetrics
The subset of PF_HQ_ALIGNED_BASES where the base call quality was Q20 or higher.
PF_HQ_ALIGNED_READS - Variable in class picard.analysis.AlignmentSummaryMetrics
The number of PF reads that were aligned to the reference sequence with a mapping quality of Q20 or higher signifying that the aligner estimates a 1/100 (or smaller) chance that the alignment is wrong.
PF_HQ_ERROR_RATE - Variable in class picard.analysis.AlignmentSummaryMetrics
The fraction of bases that mismatch the reference in PF HQ aligned reads.
PF_HQ_MEDIAN_MISMATCHES - Variable in class picard.analysis.AlignmentSummaryMetrics
The median number of mismatches versus the reference sequence in reads that were aligned to the reference at high quality (i.e.
PF_INDEL_RATE - Variable in class picard.analysis.AlignmentSummaryMetrics
The number of insertion and deletion events per 100 aligned bases.
PF_MISMATCH_RATE - Variable in class picard.analysis.AlignmentSummaryMetrics
The rate of bases mismatching the reference for all bases aligned to the reference sequence.
PF_NOISE_READS - Variable in class picard.analysis.AlignmentSummaryMetrics
The number of PF reads that are marked as noise reads.
PF_NORMALIZED_MATCHES - Variable in class picard.illumina.ExtractIlluminaBarcodes.BarcodeMetric
The "normalized" matches to each barcode.
PF_ONE_MISMATCH_MATCHES - Variable in class picard.illumina.ExtractIlluminaBarcodes.BarcodeMetric
The number of PF reads matching this barcode that matched with 1 error or no-call.
PF_PCT_MATCHES - Variable in class picard.illumina.ExtractIlluminaBarcodes.BarcodeMetric
The fraction of PF reads in the lane that matched to this barcode.
PF_PERFECT_MATCHES - Variable in class picard.illumina.ExtractIlluminaBarcodes.BarcodeMetric
The number of PF reads matching this barcode that matched with 0 errors or no-calls.
PF_Q20_BASES - Variable in class org.broadinstitute.hellbender.metrics.QualityYieldMetrics
The number of bases in PF reads that achieve quality score 20 or higher
PF_Q20_BASES - Variable in class picard.analysis.CollectQualityYieldMetrics.QualityYieldMetrics
The number of bases in PF reads that achieve quality score 20 or higher
PF_Q20_EQUIVALENT_YIELD - Variable in class org.broadinstitute.hellbender.metrics.QualityYieldMetrics
The sum of quality scores of all bases divided by 20
PF_Q20_EQUIVALENT_YIELD - Variable in class picard.analysis.CollectQualityYieldMetrics.QualityYieldMetrics
The sum of quality scores of all bases in PF reads divided by 20
PF_Q30_BASES - Variable in class org.broadinstitute.hellbender.metrics.QualityYieldMetrics
The number of bases in PF reads that achieve quality score 30 or higher
PF_Q30_BASES - Variable in class picard.analysis.CollectQualityYieldMetrics.QualityYieldMetrics
The number of bases in PF reads that achieve quality score 30 or higher
PF_RATIO_THIS_BARCODE_TO_BEST_BARCODE_PCT - Variable in class picard.illumina.ExtractIlluminaBarcodes.BarcodeMetric
The rate of PF reads matching this barcode to PF reads matching the most prevelant barcode.
PF_READS - Variable in class org.broadinstitute.hellbender.metrics.QualityYieldMetrics
The number of reads that are PF - pass filter
PF_READS - Variable in class picard.analysis.AlignmentSummaryMetrics
The number of PF reads where PF is defined as passing Illumina's filter.
PF_READS - Variable in class picard.analysis.CollectQualityYieldMetrics.QualityYieldMetrics
The number of reads that are PF - pass filter
PF_READS - Variable in class picard.analysis.directed.HsMetrics
The total number of reads that pass the vendor's filter.
PF_READS - Variable in class picard.analysis.directed.TargetedPcrMetrics
The total number of reads passing filter (PF), where the filter(s) can be platform/vendor quality controls
PF_READS - Variable in class picard.analysis.directed.TargetMetrics
The number of passing filter reads (PF).
PF_READS - Variable in class picard.illumina.ExtractIlluminaBarcodes.BarcodeMetric
The number of PF reads matching this barcode (always less than or equal to READS).
PF_READS - Variable in class picard.illumina.IlluminaBasecallingMetrics
The total number of passing-filter reads assigned to the index.
PF_READS_ALIGNED - Variable in class picard.analysis.AlignmentSummaryMetrics
The number of PF reads that were aligned to the reference sequence.
PF_READS_IMPROPER_PAIRS - Variable in class picard.analysis.AlignmentSummaryMetrics
The number of (primary) aligned reads that are **not** "properly" aligned in pairs (as per SAM flag 0x2).
PF_READS_ONLY - Variable in class picard.analysis.CollectBaseDistributionByCycle
 
PF_READS_ONLY - Variable in class picard.analysis.MeanQualityByCycle
 
PF_READS_ONLY - Variable in class picard.analysis.QualityScoreDistribution
 
PF_READS_ONLY_SHORT_NAME - Static variable in class picard.cmdline.StandardOptionDefinitions
 
PF_SELECTED_PAIRS - Variable in class picard.analysis.directed.TargetedPcrMetrics
Tracks the number of PF read pairs (used to calculate library size)
PF_SELECTED_PAIRS - Variable in class picard.analysis.directed.TargetMetrics
Tracks the number of read pairs that we see that are PF (used to calculate library size)
PF_SELECTED_UNIQUE_PAIRS - Variable in class picard.analysis.directed.TargetedPcrMetrics
Tracks the number of unique, PF, read pairs, observed (used to calculate library size)
PF_SELECTED_UNIQUE_PAIRS - Variable in class picard.analysis.directed.TargetMetrics
Tracks the number of unique PF_SELECTED_PAIRS we see (used to calc library size)
PF_STATUS - Variable in class picard.sam.ViewSam
 
PF_UNIQUE_READS - Variable in class picard.analysis.directed.HsMetrics
The number of PF reads that are not marked as duplicates.
PF_UNIQUE_READS - Variable in class picard.analysis.directed.TargetedPcrMetrics
The number of PF_READS that were not marked as sample or optical duplicates.
PF_UNIQUE_READS - Variable in class picard.analysis.directed.TargetMetrics
The number of PF_READS that are not marked as duplicates.
PF_UQ_BASES_ALIGNED - Variable in class picard.analysis.directed.HsMetrics
The number of bases in the PF_UQ_READS_ALIGNED reads.
PF_UQ_BASES_ALIGNED - Variable in class picard.analysis.directed.TargetedPcrMetrics
The number of bases from PF_UNIQUE_READS that align to the reference genome and have a mapping score > 0
PF_UQ_BASES_ALIGNED - Variable in class picard.analysis.directed.TargetMetrics
The number of PF unique bases that are aligned with mapping score > 0 to the reference genome.
PF_UQ_READS_ALIGNED - Variable in class picard.analysis.directed.HsMetrics
The number of PF_UNIQUE_READS that aligned to the reference genome with a mapping score > 0.
PF_UQ_READS_ALIGNED - Variable in class picard.analysis.directed.TargetedPcrMetrics
The total number of PF_UNIQUE_READS that align to the reference genome with mapping scores > 0
PF_UQ_READS_ALIGNED - Variable in class picard.analysis.directed.TargetMetrics
The number of PF_UNIQUE_READS that are aligned with mapping score > 0 to the reference genome.
PFFailDetailedMetric(Integer, int, int, int, int, CollectHiSeqXPfFailMetrics.ReadClassifier.PfFailReason) - Constructor for class picard.illumina.quality.CollectHiSeqXPfFailMetrics.PFFailDetailedMetric
 
PFFailDetailedMetric() - Constructor for class picard.illumina.quality.CollectHiSeqXPfFailMetrics.PFFailDetailedMetric
This ctor is necessary for when reading metrics from file
PFFailSummaryMetric(String) - Constructor for class picard.illumina.quality.CollectHiSeqXPfFailMetrics.PFFailSummaryMetric
 
PFFailSummaryMetric() - Constructor for class picard.illumina.quality.CollectHiSeqXPfFailMetrics.PFFailSummaryMetric
This ctor is necessary for when reading metrics from file
pfReadsOnly - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectBaseDistributionByCycleSpark
 
pfReadsOnly - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.MeanQualityByCycleSpark
 
pfReadsOnly - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.QualityScoreDistributionSpark
 
PG_PROGRAM_NAME - Static variable in class picard.sam.PositionBasedDownsampleSam
 
pgIdsSeen - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.AbstractMarkDuplicatesCommandLineProgram
The program groups that have been seen during the course of examining the input records.
pgIdsSeen - Variable in class picard.sam.markduplicates.util.AbstractMarkDuplicatesCommandLineProgram
The program groups that have been seen during the course of examining the input records.
pgTagArgumentCollection - Variable in class picard.sam.markduplicates.util.AbstractMarkDuplicatesCommandLineProgram
 
pgTagArgumentCollection - Variable in class picard.sam.MergeBamAlignment
 
PGTagArgumentCollection - Class in picard.sam.util
Argument Collection which holds parameters common to classes that want to add PG tags to reads in SAM/BAM files
PGTagArgumentCollection() - Constructor for class picard.sam.util.PGTagArgumentCollection
 
phaseCalls(List<VariantContext>, Set<Haplotype>) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerGenotypingEngine
Tries to phase the individual alleles based on pairwise comparisons to the other alleles based on all called haplotypes
PHASED_HOM_VAR_STRING - Static variable in class org.broadinstitute.hellbender.tools.walkers.GenotypeGVCFs
 
PHASESET_PREFIX - Static variable in class picard.fingerprint.HaplotypeMap
 
PHASING_APPLIED - Variable in class picard.illumina.IlluminaPhasingMetrics
Median phasing value across all tiles in a lane, applied to the first and second template reads
phasingWeight - Variable in class picard.illumina.parser.readers.EmpiricalPhasingMetricsOutReader.IlluminaPhasingMetrics
 
PHRED_SCALED_MIN_P_VALUE - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.ExcessHet
 
PHRED_SCALED_POSTERIORS_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
PHRED_TO_LOG_PROB_MULTIPLIER - Static variable in class org.broadinstitute.hellbender.utils.QualityUtils
conversion factor from phred scaled quality to log error probability and vice versa
phredScaleCorrectRate(double) - Static method in class org.broadinstitute.hellbender.utils.QualityUtils
Convert a probability of being right to a phred-scaled quality score of being wrong as a double This is a very generic method, that simply computes a phred-scaled double quality score given an error rate.
phredScaledGlobalReadMismappingRate - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.LikelihoodEngineArgumentCollection
The phredScaledGlobalReadMismappingRate reflects the average global mismapping rate of all reads, regardless of their mapping quality.
phredScaledPrior - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.UnifiedArgumentCollection
 
phredScaleErrorRate(double) - Static method in class org.broadinstitute.hellbender.utils.QualityUtils
Convert a probability of being wrong to a phred-scaled quality score as a double This is a very generic method, that simply computes a phred-scaled double quality score given an error rate.
phredScaleLog10CorrectRate(double) - Static method in class org.broadinstitute.hellbender.utils.QualityUtils
Convert a log10 probability of being right to a phred-scaled quality score of being wrong as a double This is a very generic method, that simply computes a phred-scaled double quality score given an error rate.
phredScaleLog10ErrorRate(double) - Static method in class org.broadinstitute.hellbender.utils.QualityUtils
Convert a log10 probability of being wrong to a phred-scaled quality score as a double This is a very generic method, that simply computes a phred-scaled double quality score given an error rate.
PhysicalLocation - Interface in picard.sam.util
Small interface that provides access to the physical location information about a cluster.
PhysicalLocationForMateCigar - Class in picard.sam.markduplicates.util
Stores the minimal information needed for optical duplicate detection.
PhysicalLocationForMateCigar(PhysicalLocation) - Constructor for class picard.sam.markduplicates.util.PhysicalLocationForMateCigar
 
PhysicalLocationForMateCigarSet - Class in picard.sam.markduplicates.util
This stores records that are comparable for detecting optical duplicates.
PhysicalLocationForMateCigarSet() - Constructor for class picard.sam.markduplicates.util.PhysicalLocationForMateCigarSet
 
PhysicalLocationInt - Class in picard.sam.util
Small class that provides access to the physical location information about a cluster.
PhysicalLocationInt() - Constructor for class picard.sam.util.PhysicalLocationInt
 
PhysicalLocationShort - Class in picard.sam.util
Small class that provides access to the physical location information about a cluster.
PhysicalLocationShort() - Constructor for class picard.sam.util.PhysicalLocationShort
 
picard - package picard
 
picard.analysis - package picard.analysis
 
picard.analysis.artifacts - package picard.analysis.artifacts
 
picard.analysis.directed - package picard.analysis.directed
 
picard.analysis.replicates - package picard.analysis.replicates
 
picard.annotation - package picard.annotation
 
picard.cmdline - package picard.cmdline
 
picard.cmdline.argumentcollections - package picard.cmdline.argumentcollections
 
picard.cmdline.programgroups - package picard.cmdline.programgroups
 
picard.fastq - package picard.fastq
 
picard.filter - package picard.filter
 
picard.fingerprint - package picard.fingerprint
 
picard.illumina - package picard.illumina
 
picard.illumina.parser - package picard.illumina.parser
 
picard.illumina.parser.fakers - package picard.illumina.parser.fakers
 
picard.illumina.parser.readers - package picard.illumina.parser.readers
 
picard.illumina.quality - package picard.illumina.quality
 
picard.metrics - package picard.metrics
 
picard.nio - package picard.nio
 
picard.pedigree - package picard.pedigree
 
picard.reference - package picard.reference
 
picard.sam - package picard.sam
 
picard.sam.markduplicates - package picard.sam.markduplicates
 
picard.sam.markduplicates.util - package picard.sam.markduplicates.util
 
picard.sam.util - package picard.sam.util
 
picard.util - package picard.util
 
picard.util.help - package picard.util.help
 
picard.vcf - package picard.vcf
 
picard.vcf.filter - package picard.vcf.filter
 
picard.vcf.MendelianViolations - package picard.vcf.MendelianViolations
 
picard.vcf.processor - package picard.vcf.processor
 
picard.vcf.processor.util - package picard.vcf.processor.util
 
PICARD_TOOL_EXCEPTION - Static variable in class org.broadinstitute.hellbender.Main
Exit value used when a Picard tool returns a non-zero exit code (the actual value is displayed on the command line)
PicardCommandLine - Class in picard.cmdline
This is the main class of Picard and is the way of executing individual command line programs.
PicardCommandLine() - Constructor for class picard.cmdline.PicardCommandLine
 
PicardCommandLineProgram - Class in org.broadinstitute.hellbender.cmdline
Base class for all Picard tools.
PicardCommandLineProgram() - Constructor for class org.broadinstitute.hellbender.cmdline.PicardCommandLineProgram
 
PicardCommandLineProgramExecutor - Class in org.broadinstitute.hellbender.cmdline
Adapter shim for use within GATK to run Picard tools.
PicardCommandLineProgramExecutor(CommandLineProgram) - Constructor for class org.broadinstitute.hellbender.cmdline.PicardCommandLineProgramExecutor
 
PicardException - Exception in picard
Basic Picard runtime exception that, for now, does nothing much
PicardException(String) - Constructor for exception picard.PicardException
 
PicardException(String, Throwable) - Constructor for exception picard.PicardException
 
PicardHelpDoclet - Class in picard.util.help
Custom Barclay-based Javadoc Doclet used for generating Picard help/documentation.
PicardHelpDoclet() - Constructor for class picard.util.help.PicardHelpDoclet
 
PicardHelpDocWorkUnitHandler - Class in picard.util.help
The Picard Documentation work unit handler class that is the companion to PicardHelpDoclet.
PicardHelpDocWorkUnitHandler(HelpDoclet) - Constructor for class picard.util.help.PicardHelpDocWorkUnitHandler
 
PicardNonZeroExitException - Exception in org.broadinstitute.hellbender.exceptions
Exception used to propagate non-zero return values from Picard tools.
PicardNonZeroExitException(int) - Constructor for exception org.broadinstitute.hellbender.exceptions.PicardNonZeroExitException
 
pickBestConfigurations(AlignedContig, Set<String>, Double) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigAlignmentsConfigPicker
Pick the best configurations based on a heuristic scoring scheme implemented in AssemblyContigAlignmentsConfigPicker.computeScoreOfConfiguration(List, Set, int).
pickPrimaryAlignment(HitsForInsert) - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.BestEndMapqPrimaryAlignmentStrategy
Primary alignment was filtered out.
pickPrimaryAlignment(HitsForInsert) - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.BestMapqPrimaryAlignmentSelectionStrategy
Primary alignment was filtered out.
pickPrimaryAlignment(HitsForInsert) - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.EarliestFragmentPrimaryAlignmentSelectionStrategy
 
pickPrimaryAlignment(HitsForInsert) - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.MostDistantPrimaryAlignmentSelectionStrategy
 
pickPrimaryAlignment(HitsForInsert) - Method in interface org.broadinstitute.hellbender.utils.read.mergealignment.PrimaryAlignmentSelectionStrategy
When this method returns, one alignment has been marked as primary according to the implementation's strategy.
pickPrimaryAlignment(HitsForInsert) - Method in class picard.sam.BestEndMapqPrimaryAlignmentStrategy
Primary alignment was filtered out.
pickPrimaryAlignment(HitsForInsert) - Method in class picard.sam.BestMapqPrimaryAlignmentSelectionStrategy
Primary alignment was filtered out.
pickPrimaryAlignment(HitsForInsert) - Method in class picard.sam.EarliestFragmentPrimaryAlignmentSelectionStrategy
 
pickPrimaryAlignment(HitsForInsert) - Method in class picard.sam.MostDistantPrimaryAlignmentSelectionStrategy
 
pickPrimaryAlignment(HitsForInsert) - Method in interface picard.sam.PrimaryAlignmentSelectionStrategy
When this method returns, one alignment has been marked as primary according to the implementation's strategy.
pickTranscripts(Map<Gene.Transcript, int[]>) - Method in class picard.analysis.directed.RnaSeqMetricsCollector.PerUnitRnaSeqMetricsCollector
Picks the set of transcripts on which the coverage metrics are to be calculated.
Pileup - Class in org.broadinstitute.hellbender.tools.walkers.qc
Prints read alignments in samtools pileup format.
Pileup() - Constructor for class org.broadinstitute.hellbender.tools.walkers.qc.Pileup
 
pileupDiff(ReadPileup, SAMPileupFeature) - Method in class org.broadinstitute.hellbender.tools.walkers.qc.CheckPileup
 
PileupElement - Class in org.broadinstitute.hellbender.utils.pileup
Represents an individual base in a reads pileup.
PileupElement(GATKRead, int, CigarElement, int, int) - Constructor for class org.broadinstitute.hellbender.utils.pileup.PileupElement
Create a new pileup element
PileupElement(PileupElement) - Constructor for class org.broadinstitute.hellbender.utils.pileup.PileupElement
Create a new PileupElement that's a copy of toCopy
PileupSpark - Class in org.broadinstitute.hellbender.tools.spark
Prints read alignments in samtools pileup format.
PileupSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.PileupSpark
 
PileupSummary - Class in org.broadinstitute.hellbender.tools.walkers.contamination
Created by David Benjamin on 2/14/17.
PileupSummary(String, int, int, int, int, double) - Constructor for class org.broadinstitute.hellbender.tools.walkers.contamination.PileupSummary
 
PileupSummary(VariantContext, ReadPileup) - Constructor for class org.broadinstitute.hellbender.tools.walkers.contamination.PileupSummary
 
PL_FILTER_NAME_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ReadFilterArgumentDefinitions
 
PL_FOR_ALL_SNP_ALLELES_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
PLATFORM - Variable in class picard.illumina.IlluminaBasecallsToSam
 
PLATFORM - Variable in class picard.sam.FastqToSam
 
PLATFORM_MODEL - Variable in class picard.sam.FastqToSam
 
PLATFORM_UNIT - Variable in class picard.sam.FastqToSam
 
PlatformReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Keep only reads where the the Read Group platform attribute (RG:PL tag) contains the given string.
PlatformReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.PlatformReadFilter
 
PlatformReadFilter(SAMFileHeader) - Constructor for class org.broadinstitute.hellbender.engine.filters.PlatformReadFilter
 
PlatformUnitReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Filter out reads where the the platform unit attribute (PU tag) contains the given string.
PlatformUnitReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.PlatformUnitReadFilter
 
PlatformUnitReadFilter(SAMFileHeader) - Constructor for class org.broadinstitute.hellbender.engine.filters.PlatformUnitReadFilter
 
PLFilterNames - Variable in class org.broadinstitute.hellbender.engine.filters.PlatformReadFilter
 
ploidy() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeAlleleCounts
 
ploidy() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeLikelihoodCalculator
Returns the ploidy for this genotype likelihood calculator.
ploidyModel() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingData
Returns the ploidy model that corresponds to the data provided.
PloidyModel - Interface in org.broadinstitute.hellbender.tools.walkers.genotyper
Information about the number of chromosome per sample at a given location.
PlotDenoisedCopyRatios - Class in org.broadinstitute.hellbender.tools.copynumber.plotting
Creates plots of denoised copy ratios.
PlotDenoisedCopyRatios() - Constructor for class org.broadinstitute.hellbender.tools.copynumber.plotting.PlotDenoisedCopyRatios
 
PlotModeledSegments - Class in org.broadinstitute.hellbender.tools.copynumber.plotting
Creates plots of denoised and segmented copy-ratio and minor-allele-fraction estimates.
PlotModeledSegments() - Constructor for class org.broadinstitute.hellbender.tools.copynumber.plotting.PlotModeledSegments
 
pluginBaseClass - Static variable in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKAnnotationPluginDescriptor
 
pluginPackageName - Static variable in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKAnnotationPluginDescriptor
 
pNormalizeLogProbability(double[]) - Static method in class picard.util.MathUtil
Takes a complete set of mutually exclusive logPosteriors and converts them to probabilities that sum to 1 with as much fidelity as possible.
pNormalizeVector(double[]) - Static method in class picard.util.MathUtil
Takes a vector of numbers and converts it to a vector of probabilities that sum to 1 with as much fidelity as possible.
poll(SamRecordTrackingBuffer, SAMFileHeader, OpticalDuplicateFinder, LibraryIdGenerator) - Method in class picard.sam.markduplicates.util.MarkQueue
The poll method will return the read end that is *not* the duplicate of all comparable read ends that have been seen.
pon - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
A panel of normals can be a useful (optional) input to help filter out commonly seen sequencing noise that may appear as low allele-fraction somatic variants.
PON_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
PON_FILE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
PON_FILTER_NAME - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
POOL_SIZE - Variable in class picard.util.BaitDesigner
 
POOLED_BAM_DEPTH_ANNOTATION_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.AnnotateVcfWithBamDepth
 
popReadyAssemblyRegions(int, int, int, boolean) - Method in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfile
Get the next completed assembly regions from this profile, and remove all states supporting them from this profile Takes the current profile and finds all of the active / inactive from the start of the profile that are ready.
popStat(float) - Method in class org.broadinstitute.hellbender.tools.spark.utils.IntHistogram.CDF
An observed value for which the specified fraction of the sample population has that value or less.
POPULATION_AF_VCF_ATTRIBUTE - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
popVariantBubbles - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
PosFileFaker - Class in picard.illumina.parser.fakers
Created by jcarey on 3/13/14.
PosFileFaker() - Constructor for class picard.illumina.parser.fakers.PosFileFaker
 
PosFileReader - Class in picard.illumina.parser.readers
The pos file format is one 3 Illumina formats(pos, locs, and clocs) that stores position data exclusively.
PosFileReader(File) - Constructor for class picard.illumina.parser.readers.PosFileReader
 
position() - Method in class org.broadinstitute.hellbender.utils.nio.ChannelAsSeekableStream
 
position() - Method in class org.broadinstitute.hellbender.utils.nio.SeekableByteChannelPrefetcher
Returns this channel's position.
position(long) - Method in class org.broadinstitute.hellbender.utils.nio.SeekableByteChannelPrefetcher
Sets this channel's position.
position() - Method in class org.broadinstitute.hellbender.utils.test.XorWrapper
 
position(long) - Method in class org.broadinstitute.hellbender.utils.test.XorWrapper
 
POSITION - Variable in class picard.analysis.FingerprintingDetailMetrics
The position of the SNP on the chromosome.
POSITION - Variable in class picard.analysis.RrbsCpgDetailMetrics
Position within the sequence of the CpG site
PositionalDownsampler - Class in org.broadinstitute.hellbender.utils.downsampling
PositionalDownsampler: Downsample each stack of reads at each alignment start to a size <= a target coverage using a ReservoirDownsampler.
PositionalDownsampler(int, SAMFileHeader) - Constructor for class org.broadinstitute.hellbender.utils.downsampling.PositionalDownsampler
Construct a PositionalDownsampler
PositionBasedDownsampleSam - Class in picard.sam
Summary
PositionBasedDownsampleSam() - Constructor for class picard.sam.PositionBasedDownsampleSam
 
PositionInfo(float, float, int, int) - Constructor for class picard.illumina.parser.readers.AbstractIlluminaPositionFileReader.PositionInfo
 
positions() - Method in interface org.broadinstitute.hellbender.utils.hmm.ForwardBackwardAlgorithm.Result
Returns the list of positions passed to the forward-backward algorithm
POSITIVE_LABEL_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
PosParser - Class in picard.illumina.parser
PosParser parses multiple files formatted as one of the three file formats that contain position information only (pos, locs, and clocs).
PosParser(IlluminaFileMap, IlluminaFileUtil.SupportedIlluminaFormat) - Constructor for class picard.illumina.parser.PosParser
 
PosParser(IlluminaFileMap, int, IlluminaFileUtil.SupportedIlluminaFormat) - Constructor for class picard.illumina.parser.PosParser
 
PossibleDeNovo - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Existence of a de novo mutation in at least one of the given families
PossibleDeNovo(Set<Trio>, double) - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.PossibleDeNovo
 
PossibleDeNovo() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.PossibleDeNovo
This is dummy constructor that will do nothing until https://github.com/broadinstitute/gatk/issues/1880 is addressed
POSTERIOR_PROB_OF_CONTAMINATION_ATTRIBUTE - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
POSTERIOR_PROBABILITIES_KEY - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.StrandArtifact
 
PosteriorProbabilitiesOptions(double, double, boolean, boolean, boolean, boolean) - Constructor for class org.broadinstitute.hellbender.tools.walkers.variantutils.PosteriorProbabilitiesUtils.PosteriorProbabilitiesOptions
 
PosteriorProbabilitiesUtils - Class in org.broadinstitute.hellbender.tools.walkers.variantutils
 
PosteriorProbabilitiesUtils.PosteriorProbabilitiesOptions - Class in org.broadinstitute.hellbender.tools.walkers.variantutils
A class to wrangle all the various and sundry genotype posterior options, mostly from CalculateGenotypePosteriors
posteriors(double[], double[]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
PosteriorSummary - Class in org.broadinstitute.hellbender.utils.mcmc
Represents central tendency and upper/lower credible-interval bounds of the posterior of a univariate model parameter, along with optional deciles.
PosteriorSummary(double, double, double) - Constructor for class org.broadinstitute.hellbender.utils.mcmc.PosteriorSummary
Constructs a PosteriorSummary with only given central tendency and upper/lower credible-interval bounds.
PosteriorSummaryUtils - Class in org.broadinstitute.hellbender.utils.mcmc
Contains methods for computing summary statistics for the posterior of a univariate model parameter.
PostprocessGermlineCNVCalls - Class in org.broadinstitute.hellbender.tools.copynumber
Postprocesses the output of GermlineCNVCaller and generates VCF files.
PostprocessGermlineCNVCalls() - Constructor for class org.broadinstitute.hellbender.tools.copynumber.PostprocessGermlineCNVCalls
 
POWER - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
PowerCalculationUtils - Class in org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup
 
Ppv(GenotypeConcordanceScheme, GenotypeConcordanceStates.CallState[]) - Method in class picard.vcf.GenotypeConcordanceCounts
Returns the PPV defined by the scheme across the subset of call states.
PRE_ADAPTER_DETAILS_EXT - Static variable in class picard.analysis.artifacts.SequencingArtifactMetrics
 
PRE_ADAPTER_METRIC_FIELD_NAME - Static variable in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasFilterConstants
 
PRE_ADAPTER_METRIC_NOT_ARTIFACT_SCORE - Static variable in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasFilterer
 
PRE_ADAPTER_METRIC_RC_FIELD_NAME - Static variable in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasFilterConstants
 
PRE_ADAPTER_METRICS_DETAIL_FILE_FULL_NAME - Static variable in class org.broadinstitute.hellbender.tools.exome.FilterByOrientationBias
 
PRE_ADAPTER_METRICS_DETAIL_FILE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.exome.FilterByOrientationBias
 
PRE_ADAPTER_SUMMARY_EXT - Static variable in class picard.analysis.artifacts.SequencingArtifactMetrics
 
PRE_TANGENT_NORMALIZED_COUNTS_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
PRE_TANGENT_NORMALIZED_COUNTS_FILE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
PreAdapterDetailMetrics() - Constructor for class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterDetailMetrics
 
preAdapterMetricsFile - Variable in class org.broadinstitute.hellbender.tools.exome.FilterByOrientationBias
 
PreAdapterOrientationScorer - Class in org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter
This class handles the reading of a picard metrics file PreAdapterDetailMetrics.
PreAdapterSummaryMetrics() - Constructor for class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterSummaryMetrics
 
predecessor(SVKmer.Base, int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmer
 
predecessor(SVKmer.Base, int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerLong
Returns a new SVKmerLong that's like this one, but with its trailing base discarded and a new one added to the start.
predecessor(SVKmer.Base, int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerShort
Returns a new SVKmerShort that's like this one, but with its trailing base discarded and a new one added to the start.
PredicateFilterDecoratingClosableIterator<T> - Class in picard.vcf.processor.util
Performs on-the-fly filtering of the provided VariantContext Iterator such that only variants that satisfy all predicates are emitted.
PredicateFilterDecoratingClosableIterator(CloseableIterator<T>, Collection<Predicate<T>>) - Constructor for class picard.vcf.processor.util.PredicateFilterDecoratingClosableIterator
 
PREDICTED_INSERT_SIZE - Variable in class picard.sam.FastqToSam
 
prepareReadAlleleLikelihoodsForAnnotation(ReadLikelihoods<Haplotype>, Map<String, List<GATKRead>>, boolean, Map<Allele, List<Haplotype>>, ReadLikelihoods<Allele>, VariantContext) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerGenotypingEngine
 
PREPHASING_APPLIED - Variable in class picard.illumina.IlluminaPhasingMetrics
Median pre-phasing value across all tiles in a lane, applied to the first and second template reads
prephasingWeight - Variable in class picard.illumina.parser.readers.EmpiricalPhasingMetricsOutReader.IlluminaPhasingMetrics
 
preprocess(SvDiscoveryInputMetaData, JavaRDD<GATKRead>) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoverFromLocalAssemblyContigAlignmentsSpark
First parse the input alignments, then classify the assembly contigs based on their alignment signatures, and return the contigs that are classified together for downstream inference.
preprocessAndStandardizeSample(double[], double[]) - Static method in class org.broadinstitute.hellbender.tools.copynumber.denoising.SVDDenoisingUtils
Preprocess (i.e., transform to fractional coverage and correct GC bias) and standardize read counts for samples when no panel of normals is available.
PreprocessIntervals - Class in org.broadinstitute.hellbender.tools.copynumber
Prepares bins for coverage collection.
PreprocessIntervals() - Constructor for class org.broadinstitute.hellbender.tools.copynumber.PreprocessIntervals
 
PRESERVE_QSCORES_LESS_THAN - Variable in class org.broadinstitute.hellbender.tools.ApplyBQSRArgumentCollection
This flag tells GATK not to modify quality scores less than this value.
PRESERVE_QSCORES_LESS_THAN - Variable in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationArgumentCollection
This flag tells GATK not to modify quality scores less than this value.
prettyPrint() - Method in enum org.broadinstitute.hellbender.utils.recalibration.EventType
 
prettyPrintSequenceRecords(SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
previousHaplotypeBases - Variable in class org.broadinstitute.hellbender.utils.pairhmm.PairHMM
 
PRIMARY_ALIGNMENT_STRATEGY - Variable in class picard.sam.MergeBamAlignment
 
PRIMARY_LINE - Static variable in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary
 
PRIMARY_READS - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterMetrics
Number of input reads that are not secondary or supplementary alignments
PrimaryAlignmentKey - Class in org.broadinstitute.hellbender.utils.read
It is useful to define a key such that the key will occur at most once among the primary alignments in a given file (assuming the file is valid).
PrimaryAlignmentKey(SAMRecord) - Constructor for class org.broadinstitute.hellbender.utils.read.PrimaryAlignmentKey
 
PrimaryAlignmentSelectionStrategy - Interface in org.broadinstitute.hellbender.utils.read.mergealignment
Given a set of alignments for a read or read pair, mark one alignment as primary, according to whatever strategy is appropriate.
PrimaryAlignmentSelectionStrategy - Interface in picard.sam
Given a set of alignments for a read or read pair, mark one alignment as primary, according to whatever strategy is appropriate.
PrimaryLineReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.PrimaryLineReadFilter
 
primaryReads(JavaRDD<GATKRead>) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSUtils
 
print(PrintStream) - Method in class org.broadinstitute.hellbender.utils.report.GATKReport
Print all tables contained within this container to a PrintStream
print(PrintStream, GATKReportTable.Sorting) - Method in class org.broadinstitute.hellbender.utils.report.GATKReport
Print all tables contained within this container to a PrintStream
PRINT_DELIM - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RankSumTest
 
PRINT_DELIM - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RMSMappingQuality
 
PRINT_DELIM - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_StrandBiasTest
 
PRINT_SUMMARY_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.validation.CompareDuplicatesSpark
 
printDecoratedExceptionMessage(PrintStream, Exception, String) - Static method in class org.broadinstitute.hellbender.Main
Prints the given message (may be null) to the provided stream, adding adornments and formatting.
printDOT(PrintWriter) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KBestHaplotypeFinder
Print a DOT representation of search graph.
printDOT(File) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KBestHaplotypeFinder
Print a DOT representation of search graph.
printDOTFile(String) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KBestHaplotypeFinder
Print a DOT representation of search graph.
printEfficiency(Level) - Method in class org.broadinstitute.hellbender.utils.fasta.CachingIndexedFastaSequenceFile
Print the efficiency (hits / queries) to logger with priority
printGraph(File, int) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Print out the graph in the dot language for visualization
printGraph(PrintStream, boolean, int) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
 
printHeader() - Static method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VQSLODTranche
 
printIGVFormatHeader(PrintStream, String, String...) - Static method in class org.broadinstitute.hellbender.utils.IGVUtils
Prints a header for an IGV-format file.
printIGVFormatRow(PrintStream, Locatable, String, double...) - Static method in class org.broadinstitute.hellbender.utils.IGVUtils
Prints a row in an IGV-format file.
printLibraryVersions() - Method in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
Output versions of important dependencies to the logger.
printOutResults(String) - Method in class org.broadinstitute.hellbender.tools.validation.CompareMatrix
 
PrintReads - Class in org.broadinstitute.hellbender.tools
Write reads from SAM format file (SAM/BAM/CRAM) that pass criteria to a new file.
PrintReads() - Constructor for class org.broadinstitute.hellbender.tools.PrintReads
 
PrintReadsSpark - Class in org.broadinstitute.hellbender.tools.spark.pipelines
 
PrintReadsSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.pipelines.PrintReadsSpark
 
printReport() - Method in class org.broadinstitute.hellbender.utils.read.SamComparison
 
printSettings() - Method in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
Output a curated set of important settings to the logger.
printStandard(boolean) - Method in class org.broadinstitute.hellbender.utils.runtime.OutputStreamSettings
 
printStartupMessage(ZonedDateTime) - Method in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
Prints a user-friendly message on startup with some information about who we are and the runtime environment.
printSummary - Variable in class org.broadinstitute.hellbender.tools.spark.validation.CompareDuplicatesSpark
 
printUnknown(Set<Class<?>>, String) - Static method in class picard.cmdline.PicardCommandLine
When a command does not match any known command, searches for similar commands, using the same method as GIT
PrintVariantsSpark - Class in org.broadinstitute.hellbender.tools.spark.pipelines
Print out variants from a VCF file.
PrintVariantsSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.pipelines.PrintVariantsSpark
 
prior - Variable in class org.broadinstitute.hellbender.tools.walkers.vqsr.TrainingSet
 
PRO_ALT_BASES - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterDetailMetrics
The number of REF_BASE:ALT_BASE alignments having a read number and orientation that supports the presence of this artifact.
PRO_REF_BASES - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterDetailMetrics
The number of REF_BASE:REF_BASE alignments having a read number and orientation that supports the presence of this artifact.
PROB_EXPLICIT_READS - Variable in class picard.illumina.quality.CollectHiSeqXPfFailMetrics
 
probability(int) - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.BetaBinomialDistribution
 
PROBABILITY - Variable in class picard.sam.DownsampleSam
 
ProbabilityVector - Class in org.broadinstitute.hellbender.utils.genotyper
Represents a 1-dimentional probability distribution.
ProbabilityVector(double[], boolean) - Constructor for class org.broadinstitute.hellbender.utils.genotyper.ProbabilityVector
Default constructor: take vector in log-space, with support from range [0,len-1]
ProbabilityVector(double[]) - Constructor for class org.broadinstitute.hellbender.utils.genotyper.ProbabilityVector
 
ProbabilityVector(ProbabilityVector, boolean) - Constructor for class org.broadinstitute.hellbender.utils.genotyper.ProbabilityVector
 
PROBE_SET - Variable in class picard.analysis.directed.TargetMetrics
The name of the PROBE_SET (BAIT_SET, AMPLICON_SET, ...) used in this metrics collection run
PROBE_TERRITORY - Variable in class picard.analysis.directed.TargetMetrics
The number of unique bases covered by the intervals of all probes in the probe set
process - Variable in class org.broadinstitute.hellbender.utils.runtime.ProcessControllerBase
 
process() - Method in class picard.vcf.processor.VariantProcessor
 
processAlignments(JavaRDD<LocusWalkerContext>, JavaSparkContext) - Method in class org.broadinstitute.hellbender.engine.spark.LocusWalkerSpark
Process the alignments and write output.
processAlignments(JavaRDD<LocusWalkerContext>, JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.PileupSpark
 
processAllCommandLinePrograms(List<String>, BiConsumer<Class<CommandLineProgram>, CommandLineProgramProperties>) - Static method in class picard.cmdline.PicardCommandLine
Process each CommandLineProgram-derived class given a list of packages.
processAssemblyRegions(JavaRDD<AssemblyRegionWalkerContext>, JavaSparkContext) - Method in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerSpark
Process the assembly regions and write output.
processAssemblyRegions(JavaRDD<AssemblyRegionWalkerContext>, JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.examples.ExampleAssemblyRegionWalkerSpark
 
processCigarForInitialEvents(int) - Method in class org.broadinstitute.hellbender.utils.haplotype.EventMap
 
processColumns(TableColumnCollection) - Method in class org.broadinstitute.hellbender.utils.tsv.TableReader
Process the header line's column names.
processCommentLine(String, long) - Method in class org.broadinstitute.hellbender.utils.tsv.TableReader
Called with the content of the comment line every time one is found in the input.
ProcessController - Class in org.broadinstitute.hellbender.utils.runtime
Facade to Runtime.exec() and java.lang.Process.
ProcessController() - Constructor for class org.broadinstitute.hellbender.utils.runtime.ProcessController
 
ProcessControllerBase<CAPTURE_POLICY extends CapturedStreamOutput> - Class in org.broadinstitute.hellbender.utils.runtime
 
ProcessControllerBase() - Constructor for class org.broadinstitute.hellbender.utils.runtime.ProcessControllerBase
 
ProcessControllerBase.OutputCapture - Class in org.broadinstitute.hellbender.utils.runtime
 
ProcessControllerBase.ProcessStream - Enum in org.broadinstitute.hellbender.utils.runtime
 
processFile() - Method in interface picard.analysis.WgsMetricsProcessor
Method processes the input data and accumulates result data
processFile() - Method in class picard.analysis.WgsMetricsProcessorImpl
Method gets the data from iterator for each locus and processes it with the help of collector.
processIntervals(JavaRDD<IntervalWalkerContext>, JavaSparkContext) - Method in class org.broadinstitute.hellbender.engine.spark.IntervalWalkerSpark
Process the intervals and write output.
processIntervals(JavaRDD<IntervalWalkerContext>, JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.examples.ExampleIntervalWalkerSpark
 
ProcessOutput - Class in org.broadinstitute.hellbender.utils.runtime
 
ProcessOutput(int, StreamOutput, StreamOutput) - Constructor for class org.broadinstitute.hellbender.utils.runtime.ProcessOutput
The output of a process.
processRead(GATKRead, ReferenceDataSource, Iterable<? extends Locatable>) - Method in class org.broadinstitute.hellbender.utils.recalibration.BaseRecalibrationEngine
For each read at this locus get the various covariate values and increment that location in the map based on whether or not the base matches the reference at this particular location
processReads(JavaRDD<ReadWalkerContext>, JavaSparkContext) - Method in class org.broadinstitute.hellbender.engine.spark.ReadWalkerSpark
Process the reads and write output.
processReads(JavaRDD<ReadWalkerContext>, JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.examples.ExampleReadWalkerWithReferenceSpark
 
ProcessSettings - Class in org.broadinstitute.hellbender.utils.runtime
 
ProcessSettings(String[]) - Constructor for class org.broadinstitute.hellbender.utils.runtime.ProcessSettings
 
ProcessSettings(String[], boolean, File, Map<String, String>, InputStreamSettings, OutputStreamSettings, OutputStreamSettings) - Constructor for class org.broadinstitute.hellbender.utils.runtime.ProcessSettings
 
processState(ActivityProfileState) - Method in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfile
Process justAddedState, returning a collection of derived states that actually be added to the stateList The purpose of this function is to transform justAddedStates, if needed, into a series of atomic states that we actually want to track.
processState(ActivityProfileState) - Method in class org.broadinstitute.hellbender.utils.activityprofile.BandPassActivityProfile
Band pass the probabilities in the ActivityProfile, producing a new profile that's band pass filtered
processStream - Variable in class org.broadinstitute.hellbender.utils.runtime.CapturedStreamOutput
 
processVariants(JavaRDD<VariantWalkerContext>, JavaSparkContext) - Method in class org.broadinstitute.hellbender.engine.spark.VariantWalkerSpark
Process the variants and write output.
processVariants(JavaRDD<VariantWalkerContext>, JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.examples.ExampleVariantWalkerSpark
 
processVariants(JavaRDD<VariantWalkerContext>, JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.PrintVariantsSpark
 
produceAlleles(SimpleInterval, ReferenceMultiSource, SvType) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.AnnotatedVariantProducer
 
produceAlleles(byte[], SvType) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.AnnotatedVariantProducer
 
produceAnnotatedAndLinkedVcFromNovelAdjacency(Tuple2<SvType, SvType>, SimpleNovelAdjacencyAndChimericAlignmentEvidence, Broadcast<ReferenceMultiSource>, Broadcast<SAMSequenceDictionary>, Broadcast<SVIntervalTree<VariantContext>>, String, String) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.AnnotatedVariantProducer
Given novel adjacency and inferred variant types that should be linked together, produce annotated, and linked VCF records.
produceAnnotatedVcFromEvidenceTargetLink(EvidenceTargetLink, SvType, ReadMetadata, ReferenceMultiSource) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.AnnotatedVariantProducer
 
produceAnnotatedVcFromInferredTypeAndRefLocations(NovelAdjacencyAndAltHaplotype, SvType, Iterable<SimpleChimera>, Broadcast<ReferenceMultiSource>, Broadcast<SAMSequenceDictionary>, Broadcast<SVIntervalTree<VariantContext>>, String) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.AnnotatedVariantProducer
Produces a VC from a NovelAdjacencyAndAltHaplotype (consensus among different assemblies if they all point to the same breakpoint).
producePlot - Variable in class org.broadinstitute.hellbender.metrics.InsertSizeMetricsArgumentCollection
 
product(double...) - Method in class picard.util.MathUtil.LogMath
Computes the sum of the provided log values.
PROFILE_OUT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
PROGRAM - Variable in class picard.analysis.CollectMultipleMetrics
 
PROGRAM_GROUP - Variable in class picard.sam.FastqToSam
 
PROGRAM_GROUP_COMMAND_LINE - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.AbstractMarkDuplicatesCommandLineProgram
 
PROGRAM_GROUP_COMMAND_LINE - Variable in class picard.sam.markduplicates.util.AbstractMarkDuplicatesCommandLineProgram
 
PROGRAM_GROUP_COMMAND_LINE - Variable in class picard.sam.MergeBamAlignment
 
PROGRAM_GROUP_NAME - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.AbstractMarkDuplicatesCommandLineProgram
 
PROGRAM_GROUP_NAME - Variable in class picard.sam.markduplicates.util.AbstractMarkDuplicatesCommandLineProgram
 
PROGRAM_GROUP_NAME - Variable in class picard.sam.MergeBamAlignment
 
PROGRAM_GROUP_VERSION - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.AbstractMarkDuplicatesCommandLineProgram
 
PROGRAM_GROUP_VERSION - Variable in class picard.sam.markduplicates.util.AbstractMarkDuplicatesCommandLineProgram
 
PROGRAM_GROUP_VERSION - Variable in class picard.sam.MergeBamAlignment
 
PROGRAM_RECORD_ID - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.AbstractMarkDuplicatesCommandLineProgram
 
PROGRAM_RECORD_ID - Variable in class picard.sam.markduplicates.util.AbstractMarkDuplicatesCommandLineProgram
 
PROGRAM_RECORD_ID - Variable in class picard.sam.MergeBamAlignment
 
PROGRAM_RECORD_ID_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
PROGRAM_RECORD_ID_SHORT_NAME - Static variable in class picard.cmdline.StandardOptionDefinitions
 
programName - Variable in class org.broadinstitute.hellbender.engine.spark.SparkCommandLineProgram
 
ProgressLogger - Class in org.broadinstitute.hellbender.utils.runtime
Facilitate consistent logging output when progressing through a stream of SAM records.
ProgressLogger(Logger, int, String, String) - Constructor for class org.broadinstitute.hellbender.utils.runtime.ProgressLogger
Construct a progress logger.
ProgressLogger(Logger, int, String) - Constructor for class org.broadinstitute.hellbender.utils.runtime.ProgressLogger
Construct a progress logger.
ProgressLogger(Logger, int) - Constructor for class org.broadinstitute.hellbender.utils.runtime.ProgressLogger
Construct a progress logger with the desired log and frequency and the verb "Processed".
ProgressLogger(Logger) - Constructor for class org.broadinstitute.hellbender.utils.runtime.ProgressLogger
Construct a progress logger with the desired log, the verb "Processed" and a period of 1m records.
progressMeter - Variable in class org.broadinstitute.hellbender.engine.GATKTool
Progress meter to print out traversal statistics.
ProgressMeter - Class in org.broadinstitute.hellbender.engine
A basic progress meter to print out the number of records processed (and other metrics) during a traversal at a configurable time interval.
ProgressMeter() - Constructor for class org.broadinstitute.hellbender.engine.ProgressMeter
Create a progress meter with the default update interval of ProgressMeter.DEFAULT_SECONDS_BETWEEN_UPDATES seconds and the default time function ProgressMeter.DEFAULT_TIME_FUNCTION.
ProgressMeter(double) - Constructor for class org.broadinstitute.hellbender.engine.ProgressMeter
Create a progress meter with a custom update interval and the default time function ProgressMeter.DEFAULT_TIME_FUNCTION
ProgressReportingDelegatingCodec<A extends htsjdk.tribble.Feature,B> - Class in org.broadinstitute.hellbender.utils.codecs
This class is useful when we want to report progress when indexing.
ProgressReportingDelegatingCodec() - Constructor for class org.broadinstitute.hellbender.utils.codecs.ProgressReportingDelegatingCodec
 
ProgressReportingDelegatingCodec(FeatureCodec<A, B>, double) - Constructor for class org.broadinstitute.hellbender.utils.codecs.ProgressReportingDelegatingCodec
 
promote(int[]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
"Promotes" an int[] into a double array with the same values (or as close as precision allows).
promote(int[]) - Static method in class picard.util.MathUtil
"Promotes" an int[] into a double array with the same values (or as close as precision allows).
PROPAGATION_LONG_NAME - Static variable in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
PROPERLY_PAIRED - Static variable in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary
 
ProperlyPairedReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.ProperlyPairedReadFilter
 
PropertyUtils - Class in picard.util
Utility for loading properties files from resources.
PropertyUtils() - Constructor for class picard.util.PropertyUtils
 
proportionsAboveThresholds(List<ArrayList<Integer>>, List<Double>) - Static method in class picard.analysis.TheoreticalSensitivity
 
PRUNE_ADAPTER_LIST_AFTER_THIS_MANY_ADAPTERS_SEEN - Variable in class picard.illumina.MarkIlluminaAdapters
 
pruneLowWeightChains(int) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Prune all chains from this graph where all edges in the path have multiplicity < pruneFactor
pruneLowWeightChains(BaseGraph<V, E>) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.LowWeightChainPruner
Prune graph
pSameAlleleWhenMismatchingUmi - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
pSameUmiInIndependentBiDup - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
PSBuildReferenceTaxonomyUtils - Class in org.broadinstitute.hellbender.tools.spark.pathseq
 
PSBuildReferenceTaxonomyUtils() - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSBuildReferenceTaxonomyUtils
 
PSBwaAligner - Class in org.broadinstitute.hellbender.tools.spark.pathseq
Loads Bwa index and aligns reads.
PSBwaAligner(PSBwaArgumentCollection, boolean) - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSBwaAligner
 
PSBwaAlignerSpark - Class in org.broadinstitute.hellbender.tools.spark.pathseq
Wrapper class for using the PathSeq Bwa aligner class in Spark.
PSBwaAlignerSpark(JavaSparkContext, PSBwaArgumentCollection) - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSBwaAlignerSpark
 
PSBwaArgumentCollection - Class in org.broadinstitute.hellbender.tools.spark.pathseq
 
PSBwaArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSBwaArgumentCollection
 
PSBwaFilter - Class in org.broadinstitute.hellbender.tools.spark.pathseq
Aligns using BWA and filters out reads above the minimum coverage and identity.
PSBwaFilter(String, int, int, int, boolean) - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSBwaFilter
 
PSBwaUtils - Class in org.broadinstitute.hellbender.tools.spark.pathseq
Utility functions for PathSeq Bwa tool
PSBwaUtils() - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSBwaUtils
 
PSEUDO_AUTOSOMAL_REGIONS - Variable in class picard.vcf.MendelianViolations.FindMendelianViolations
 
PSFilter - Class in org.broadinstitute.hellbender.tools.spark.pathseq
Performs PathSeq filtering steps and manages associated resources.
PSFilter(JavaSparkContext, PSFilterArgumentCollection, SAMFileHeader) - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilter
 
PSFilterArgumentCollection - Class in org.broadinstitute.hellbender.tools.spark.pathseq
 
PSFilterArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
PSFilterEmptyLogger - Class in org.broadinstitute.hellbender.tools.spark.pathseq.loggers
Dummy filter metrics class that does nothing
PSFilterEmptyLogger() - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterEmptyLogger
 
PSFilterFileLogger - Class in org.broadinstitute.hellbender.tools.spark.pathseq.loggers
Logs filtering read counts to metrics file
PSFilterFileLogger(MetricsFile<PSFilterMetrics, Long>, String) - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterFileLogger
 
PSFilterLogger - Interface in org.broadinstitute.hellbender.tools.spark.pathseq.loggers
Interface for filter metrics logging
PSFilterMetrics - Class in org.broadinstitute.hellbender.tools.spark.pathseq.loggers
Metrics that are calculated during the PathSeq filter
PSFilterMetrics() - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterMetrics
 
PSKmerBloomFilter - Class in org.broadinstitute.hellbender.tools.spark.pathseq
Kmer Bloom Filter class that encapsulates the filter, kmer size, and kmer mask
PSKmerBloomFilter(LongBloomFilter, int, SVKmerShort, long) - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerBloomFilter
Note values in the Bloom filter should have been run through PSKmerCollection's canonicalizeAndMask()
PSKmerBloomFilter.Serializer - Class in org.broadinstitute.hellbender.tools.spark.pathseq
 
PSKmerCollection - Class in org.broadinstitute.hellbender.tools.spark.pathseq
Classes that provide a way to test kmers for set membership and keep track of the kmer size and mask
PSKmerCollection() - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerCollection
 
PSKmerSet - Class in org.broadinstitute.hellbender.tools.spark.pathseq
Kmer Hopscotch set class that encapsulates the filter, kmer size, and kmer mask
PSKmerSet(LargeLongHopscotchSet, int, SVKmerShort) - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerSet
Note values in the input set should have been run through PSKmerCollection's canonicalizeAndMask()
PSKmerSet.Serializer - Class in org.broadinstitute.hellbender.tools.spark.pathseq
 
PSKmerUtils - Class in org.broadinstitute.hellbender.tools.spark.pathseq
PathSeq utilities for kmer libraries
PSKmerUtils() - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerUtils
 
PSPairedUnpairedSplitterSpark - Class in org.broadinstitute.hellbender.tools.spark.pathseq
Class for separating paired and unpaired reads in an RDD
PSPairedUnpairedSplitterSpark(JavaRDD<GATKRead>, int, boolean) - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSPairedUnpairedSplitterSpark
Gets RDDs of the paired and unpaired reads.
PSPathogenAlignmentHit - Class in org.broadinstitute.hellbender.tools.spark.pathseq
Stores taxonomic IDs that were hits of a read pair.
PSPathogenAlignmentHit(Collection<Integer>, int) - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenAlignmentHit
 
PSPathogenReferenceTaxonProperties - Class in org.broadinstitute.hellbender.tools.spark.pathseq
Helper class for ClassifyReads that stores the name, taxonomic class and parent, reference length, and reference contig names of a given taxon in the pathogen reference.
PSPathogenReferenceTaxonProperties() - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenReferenceTaxonProperties
 
PSPathogenReferenceTaxonProperties(String) - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenReferenceTaxonProperties
 
PSPathogenTaxonScore - Class in org.broadinstitute.hellbender.tools.spark.pathseq
Pathogen abundance scores assigned to a taxonomic node and reported by the PathSeqScoreSpark tool.
PSPathogenTaxonScore() - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenTaxonScore
 
PSScoreArgumentCollection - Class in org.broadinstitute.hellbender.tools.spark.pathseq
 
PSScoreArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
 
PSScoreFileLogger - Class in org.broadinstitute.hellbender.tools.spark.pathseq.loggers
Logs number of mapped and unmapped reads to metrics file
PSScoreFileLogger(MetricsFile<PSScoreMetrics, Long>, String) - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSScoreFileLogger
 
PSScoreLogger - Interface in org.broadinstitute.hellbender.tools.spark.pathseq.loggers
Interface for score metrics logging
PSScoreMetrics - Class in org.broadinstitute.hellbender.tools.spark.pathseq.loggers
Metrics that are calculated during the PathSeq scoring
PSScoreMetrics() - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSScoreMetrics
 
PSScorer - Class in org.broadinstitute.hellbender.tools.spark.pathseq
 
PSScorer(PSScoreArgumentCollection) - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSScorer
 
PSTaxonomyConstants - Class in org.broadinstitute.hellbender.tools.spark.pathseq
Important NCBI taxonomy database constants
PSTaxonomyConstants() - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSTaxonomyConstants
 
PSTaxonomyDatabase - Class in org.broadinstitute.hellbender.tools.spark.pathseq
Helper class for holding taxonomy data used by ClassifyReads
PSTaxonomyDatabase(PSTree, Map<String, Integer>) - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSTaxonomyDatabase
 
PSTaxonomyDatabase.Serializer - Class in org.broadinstitute.hellbender.tools.spark.pathseq
 
PSTree - Class in org.broadinstitute.hellbender.tools.spark.pathseq
Represents a taxonomic tree with nodes assigned a name and taxonomic rank (e.g.
PSTree(int) - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSTree
 
PSTree(Kryo, Input) - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSTree
 
PSTree.Serializer - Class in org.broadinstitute.hellbender.tools.spark.pathseq
 
PSTreeNode - Class in org.broadinstitute.hellbender.tools.spark.pathseq
Node class for PSTree
PSTreeNode() - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSTreeNode
 
PSTreeNode.Serializer - Class in org.broadinstitute.hellbender.tools.spark.pathseq
 
PSUtils - Class in org.broadinstitute.hellbender.tools.spark.pathseq
Common functions for PathSeq
PSUtils() - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSUtils
 
put(PairedStrandedIntervals, V) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.PairedStrandedIntervalTree
 
put(SVInterval, V) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree
Put a new interval into the tree (or update the value associated with an existing interval).
put(T, int...) - Method in class org.broadinstitute.hellbender.utils.collections.NestedIntegerArray
Insert a value at the position specified by the given keys.
put(int, String, ReadEndsForMarkDuplicates) - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.DiskBasedReadEndsForMarkDuplicatesMap
 
put(int, String, ReadEndsForMarkDuplicates) - Method in interface org.broadinstitute.hellbender.utils.read.markduplicates.ReadEndsForMarkDuplicatesMap
Store the element in the map with the given key.
put(int, int[][][]) - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.CovariateKeyCache
Store the given array in the cache.
put(int, String, ReadEndsForMarkDuplicates) - Method in class picard.sam.markduplicates.util.DiskBasedReadEndsForMarkDuplicatesMap
 
put(int, String, ReadEndsForMarkDuplicates) - Method in interface picard.sam.markduplicates.util.ReadEndsForMarkDuplicatesMap
Store the element in the map with the given key.
putAttribute(Allele, T) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.ReducibleAnnotationData
 
putReadsWithTheSameNameInTheSamePartition(SAMFileHeader, JavaRDD<GATKRead>, JavaSparkContext) - Static method in class org.broadinstitute.hellbender.utils.spark.SparkUtils
Ensure all reads with the same name appear in the same partition of a queryname sorted RDD.
pValueForContingencyTable(int[][]) - Static method in class org.broadinstitute.hellbender.tools.walkers.annotator.FisherStrand
 
PYTHON_EXTENSION - Static variable in class org.broadinstitute.hellbender.utils.python.PythonExecutorBase
 
PYTHON_PROMPT - Static variable in class org.broadinstitute.hellbender.utils.python.StreamingPythonScriptExecutor
 
pythonArg - Variable in enum org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection.HybridADVIArgument
 
PythonExecutorBase - Class in org.broadinstitute.hellbender.utils.python
Base class for services for executing Python Scripts.
PythonExecutorBase(boolean) - Constructor for class org.broadinstitute.hellbender.utils.python.PythonExecutorBase
 
PythonExecutorBase(PythonExecutorBase.PythonExecutableName, boolean) - Constructor for class org.broadinstitute.hellbender.utils.python.PythonExecutorBase
 
PythonExecutorBase.PythonExecutableName - Enum in org.broadinstitute.hellbender.utils.python
Enum of possible executables that can be launched by this executor.
PythonScriptExecutor - Class in org.broadinstitute.hellbender.utils.python
Generic service for executing Python Scripts.
PythonScriptExecutor(boolean) - Constructor for class org.broadinstitute.hellbender.utils.python.PythonScriptExecutor
 
PythonScriptExecutor(PythonExecutorBase.PythonExecutableName, boolean) - Constructor for class org.broadinstitute.hellbender.utils.python.PythonScriptExecutor
 
PythonScriptExecutorException - Exception in org.broadinstitute.hellbender.utils.python
Python script execution exception.
PythonScriptExecutorException(String) - Constructor for exception org.broadinstitute.hellbender.utils.python.PythonScriptExecutorException
 

Q

Q20_BASES - Variable in class org.broadinstitute.hellbender.metrics.QualityYieldMetrics
The number of bases in all reads that achieve quality score 20 or higher
Q20_BASES - Variable in class picard.analysis.CollectQualityYieldMetrics.QualityYieldMetrics
The number of bases in all reads that achieve quality score 20 or higher
Q20_EQUIVALENT_YIELD - Variable in class org.broadinstitute.hellbender.metrics.QualityYieldMetrics
The sum of quality scores of all bases divided by 20
Q20_EQUIVALENT_YIELD - Variable in class picard.analysis.CollectQualityYieldMetrics.QualityYieldMetrics
The sum of quality scores of all bases divided by 20
Q30_BASES - Variable in class org.broadinstitute.hellbender.metrics.QualityYieldMetrics
The number of bases in all reads that achieve quality score 30 or higher
Q30_BASES - Variable in class picard.analysis.CollectQualityYieldMetrics.QualityYieldMetrics
The number of bases in all reads that achieve quality score 30 or higher
Q_TRIMMING_THRESHOLD_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.ClipReads
 
Q_TRIMMING_THRESHOLD_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.ClipReads
 
QD_DISTANCE_FROM_MEAN - Static variable in class org.broadinstitute.hellbender.tools.examples.ExampleTwoPassVariantWalker
 
QdFilter - Class in picard.vcf.filter
Filters out sites that have a QD annotation applied to them and where the QD value is lower than a lower limit.
QdFilter(double) - Constructor for class picard.vcf.filter.QdFilter
 
QNameAndInterval - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
A template name and an intervalId.
QNameAndInterval(String, int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.QNameAndInterval
 
QNameAndInterval.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
QNameFinder - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
Class to find the template names associated with reads in specified intervals.
QNameFinder(ReadMetadata, List<SVInterval>, SVReadFilter, SVIntervalTree<SVInterval>) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.QNameFinder
 
QNameIntervalFinder - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
Iterates over reads, kmerizing them, and checking the kmers against a set of KmerAndIntervals to figure out which intervals (if any) a read belongs in.
QNameIntervalFinder(int, HopscotchUniqueMultiMap<SVKmer, Integer, KmerAndInterval>) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.QNameIntervalFinder
 
QNameKmerizer - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
Class that acts as a mapper from a stream of reads to a stream of KmerAndIntervals.
QNameKmerizer(HopscotchUniqueMultiMap<String, Integer, QNameAndInterval>, Set<SVKmer>, int, int, SVReadFilter) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.QNameKmerizer
 
qNamesAssemblyFile - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
QNamesForKmersFinder - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
Class that acts as a mapper from a stream of reads to a stream of pairs for a set of interesting kmers.
QNamesForKmersFinder(int, HopscotchUniqueMultiMap<SVKmer, Integer, KmerAndInterval>, SVReadFilter) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.QNamesForKmersFinder
 
qNamesMappedFile - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
QSCORE - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasDetailMetrics
The Phred-scaled quality score of the artifact, calculated as -10 * log10(ERROR_RATE).
QSCORE - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterDetailMetrics
The Phred-scaled quality score of the artifact, calculated as -10 * log10(ERROR_RATE).
QUAL_BY_DEPTH_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
QualByDepth - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Variant confidence normalized by unfiltered depth of variant samples
QualByDepth() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.QualByDepth
 
QualInterval(int, int, long, long, int) - Constructor for class org.broadinstitute.hellbender.utils.recalibration.QualQuantizer.QualInterval
 
QualInterval(int, int, long, long, int, Set<QualQuantizer.QualInterval>) - Constructor for class org.broadinstitute.hellbender.utils.recalibration.QualQuantizer.QualInterval
 
QualInterval(int, int, long, long, int, int) - Constructor for class org.broadinstitute.hellbender.utils.recalibration.QualQuantizer.QualInterval
 
QualInterval(int, int, long, long, int, int, Set<QualQuantizer.QualInterval>) - Constructor for class org.broadinstitute.hellbender.utils.recalibration.QualQuantizer.QualInterval
 
qualities - Variable in class picard.illumina.parser.BclData
 
QUALITY - Variable in class picard.sam.SamToFastq
 
QUALITY_FORMAT - Variable in class picard.sam.FastqToSam
 
QUALITY_SCORE_COLUMN_NAME - Static variable in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
 
QUALITY_SCORE_REPORT_TABLE_TITLE - Static variable in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
 
QUALITY_SCORE_THRESHOLD_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
QUALITY_SCORE_THRESHOLD_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
QUALITY_TAG_GROUP - Variable in class picard.sam.SamToFastqWithTags
 
QualityScoreCovariate - Class in org.broadinstitute.hellbender.utils.recalibration.covariates
The Reported Quality Score covariate.
QualityScoreCovariate(RecalibrationArgumentCollection) - Constructor for class org.broadinstitute.hellbender.utils.recalibration.covariates.QualityScoreCovariate
 
QualityScoreDistribution - Class in picard.analysis
Charts quality score distribution within a BAM file.
QualityScoreDistribution() - Constructor for class picard.analysis.QualityScoreDistribution
 
QualityScoreDistributionSpark - Class in org.broadinstitute.hellbender.tools.spark.pipelines.metrics
Charts quality score distribution within a BAM file.
QualityScoreDistributionSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.QualityScoreDistributionSpark
 
QualityUtils - Class in org.broadinstitute.hellbender.utils
QualityUtils is a static class with some utility methods for manipulating quality scores.
QualityYieldMetrics - Class in org.broadinstitute.hellbender.metrics
A set of metrics used to describe the general quality of a BAM file
QualityYieldMetrics() - Constructor for class org.broadinstitute.hellbender.metrics.QualityYieldMetrics
 
QualityYieldMetrics() - Constructor for class picard.analysis.CollectQualityYieldMetrics.QualityYieldMetrics
 
QualityYieldMetricsArgumentCollection - Class in org.broadinstitute.hellbender.metrics
MetricsArgumentCollection argument collection for QualityYield metrics.
QualityYieldMetricsArgumentCollection() - Constructor for class org.broadinstitute.hellbender.metrics.QualityYieldMetricsArgumentCollection
 
QualityYieldMetricsCollector(boolean, boolean, boolean) - Constructor for class picard.analysis.CollectQualityYieldMetrics.QualityYieldMetricsCollector
 
QualityYieldMetricsCollectorSpark - Class in org.broadinstitute.hellbender.tools.spark.pipelines.metrics
QualityYieldMetricsCollector for Spark.
QualityYieldMetricsCollectorSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.QualityYieldMetricsCollectorSpark
 
qualPhredThresh - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
QualQuantizer - Class in org.broadinstitute.hellbender.utils.recalibration
A general algorithm for quantizing quality score distributions to use a specific number of levels Takes a histogram of quality scores and a desired number of levels and produces a map from original quality scores -> quantized quality scores.
QualQuantizer(int) - Constructor for class org.broadinstitute.hellbender.utils.recalibration.QualQuantizer
Protected creator for testng use only
QualQuantizer(List<Long>, int, int) - Constructor for class org.broadinstitute.hellbender.utils.recalibration.QualQuantizer
Creates a QualQuantizer for the histogram that has nLevels Note this is the only interface to the system.
QualQuantizer.QualInterval - Class in org.broadinstitute.hellbender.utils.recalibration
Represents an contiguous interval of quality scores.
qualToErrorProb(double) - Static method in class org.broadinstitute.hellbender.utils.QualityUtils
Convert a phred-scaled quality score to its probability of being wrong (Q30 => 0.001) This is the Phred-style conversion, *not* the Illumina-style conversion.
qualToErrorProb(byte) - Static method in class org.broadinstitute.hellbender.utils.QualityUtils
Convert a phred-scaled quality score to its probability of being wrong (Q30 => 0.001) This is the Phred-style conversion, *not* the Illumina-style conversion.
qualToErrorProbLog10(byte) - Static method in class org.broadinstitute.hellbender.utils.QualityUtils
Convert a phred-scaled quality score to its log10 probability of being wrong (Q30 => log10(0.001)) This is the Phred-style conversion, *not* the Illumina-style conversion.
qualToErrorProbLog10(double) - Static method in class org.broadinstitute.hellbender.utils.QualityUtils
Convert a phred-scaled quality score to its log10 probability of being wrong (Q30 => log10(0.001)) This is the Phred-style conversion, *not* the Illumina-style conversion.
qualToProb(byte) - Static method in class org.broadinstitute.hellbender.utils.QualityUtils
Convert a phred-scaled quality score to its probability of being true (Q30 => 0.999) This is the Phred-style conversion, *not* the Illumina-style conversion.
qualToProb(double) - Static method in class org.broadinstitute.hellbender.utils.QualityUtils
Convert a phred-scaled quality score to its probability of being true (Q30 => 0.999) This is the Phred-style conversion, *not* the Illumina-style conversion.
qualToProbLog10(byte) - Static method in class org.broadinstitute.hellbender.utils.QualityUtils
Convert a phred-scaled quality score to its log10 probability of being true (Q30 => log10(0.999)) This is the Phred-style conversion, *not* the Illumina-style conversion.
qualToTransProbs(double[], byte, byte, byte) - Static method in class org.broadinstitute.hellbender.utils.pairhmm.PairHMMModel
Fills a transition probability array given the different quality scores affecting a read site
qualToTransProbs(byte, byte, byte) - Static method in class org.broadinstitute.hellbender.utils.pairhmm.PairHMMModel
Returns a transition probability array given the different quality scores affecting a read site.
qualToTransProbs(double[][], byte[], byte[], byte[]) - Static method in class org.broadinstitute.hellbender.utils.pairhmm.PairHMMModel
Fills ax matrix with the transition probabilities for a number of bases.
qualToTransProbs(byte[], byte[], byte[]) - Static method in class org.broadinstitute.hellbender.utils.pairhmm.PairHMMModel
Returns a matrix with the transition probabilities for a number of bases.
qualToTransProbsLog10(double[], byte, byte, byte) - Static method in class org.broadinstitute.hellbender.utils.pairhmm.PairHMMModel
Fills a transition log10-probability array given the different quality scores affecting a read site.
qualToTransProbsLog10(byte, byte, byte) - Static method in class org.broadinstitute.hellbender.utils.pairhmm.PairHMMModel
Returns a transition log10 probability array given the different quality scores affecting a read site.
qualToTransProbsLog10(double[][], byte[], byte[], byte[]) - Static method in class org.broadinstitute.hellbender.utils.pairhmm.PairHMMModel
Fills a matrix with the log10 transition probabilities for a number of bases.
qualToTransProbsLog10(byte[], byte[], byte[]) - Static method in class org.broadinstitute.hellbender.utils.pairhmm.PairHMMModel
Returns a matrix with the log10 transition probabilities for a number of bases.
QuantizationInfo - Class in org.broadinstitute.hellbender.utils.recalibration
Class that encapsulates the information necessary for quality score quantization for BQSR
QuantizationInfo(List<Byte>, List<Long>) - Constructor for class org.broadinstitute.hellbender.utils.recalibration.QuantizationInfo
 
QuantizationInfo(RecalibrationTables, int) - Constructor for class org.broadinstitute.hellbender.utils.recalibration.QuantizationInfo
 
quantizationLevels - Variable in class org.broadinstitute.hellbender.tools.ApplyBQSRUniqueArgumentCollection
Turns on the base quantization module.
QUANTIZED_COUNT_COLUMN_NAME - Static variable in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
 
QUANTIZED_REPORT_TABLE_TITLE - Static variable in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
 
QUANTIZED_VALUE_COLUMN_NAME - Static variable in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
 
quantizeQualityScores(int) - Method in class org.broadinstitute.hellbender.utils.recalibration.QuantizationInfo
 
QUANTIZING_LEVELS - Variable in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationArgumentCollection
BQSR generates a quantization table for quick quantization later by subsequent tools.
query(SimpleInterval) - Method in class org.broadinstitute.hellbender.engine.FeatureDataSource
Gets an iterator over all Features in this data source that overlap the provided interval.
query(SimpleInterval) - Method in interface org.broadinstitute.hellbender.engine.GATKDataSource
 
query(SimpleInterval) - Method in class org.broadinstitute.hellbender.engine.MultiVariantDataSource
Gets an iterator over all Variants in this data source that overlap the provided interval.
query(SimpleInterval) - Method in class org.broadinstitute.hellbender.engine.ReadsDataSource
Query reads over a specific interval.
query(SimpleInterval) - Method in interface org.broadinstitute.hellbender.engine.ReferenceDataSource
Query a specific interval on this reference, and get back an iterator over the bases spanning that interval.
query(SimpleInterval) - Method in class org.broadinstitute.hellbender.engine.ReferenceMemorySource
Query a specific interval on this reference, and get back an iterator over the bases spanning that interval.
query(String, int, int, boolean) - Method in class org.broadinstitute.hellbender.utils.read.ArtificialReadQueryIterator
 
queryAndPrefetch(SimpleInterval) - Method in class org.broadinstitute.hellbender.engine.FeatureDataSource
Returns a List of all Features in this data source that overlap the provided interval.
queryAndPrefetch(SimpleInterval) - Method in interface org.broadinstitute.hellbender.engine.ReferenceDataSource
Query a specific interval on this reference, and get back all bases spanning that interval at once.
queryAndPrefetch(String, long, long) - Method in interface org.broadinstitute.hellbender.engine.ReferenceDataSource
Query a specific interval on this reference, and get back all bases spanning that interval at once.
queryAndPrefetch(String, long, long) - Method in class org.broadinstitute.hellbender.engine.ReferenceFileSource
Query a specific interval on this reference, and get back all bases spanning that interval at once.
queryAndPrefetch(SimpleInterval) - Method in class org.broadinstitute.hellbender.engine.ReferenceMemorySource
Query a specific interval on this reference, and get back all bases spanning that interval at once.
queryAndPrefetch(String, long, long) - Method in class org.broadinstitute.hellbender.engine.ReferenceMemorySource
Query a specific interval on this reference, and get back all bases spanning that interval at once.
queryAndPrefetch(String, long, long) - Method in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark.ReferenceMultiSourceAdapter
 
queryContained(String, int, int) - Method in class org.broadinstitute.hellbender.utils.read.ArtificialReadQueryIterator
query containing - get reads contained by the specified interval
queryOverlapping(String, int, int) - Method in class org.broadinstitute.hellbender.utils.read.ArtificialReadQueryIterator
query containing - get reads contained by the specified interval
QuerySortedReadPairIteratorUtil - Class in picard.util
A collection of helper utilities for iterating through reads that are in query-name sorted read order as pairs
QuerySortedReadPairIteratorUtil() - Constructor for class picard.util.QuerySortedReadPairIteratorUtil
 
QuerySortedReadPairIteratorUtil.ReadPair - Class in picard.util
 
queryUnmapped() - Method in class org.broadinstitute.hellbender.engine.ReadsDataSource
 
queue - Variable in class picard.illumina.parser.readers.BclReader
 
QUIET - Variable in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
 
QUIET - Variable in class picard.cmdline.CommandLineProgram
 
QUIET_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
QUOTE_CHARACTER - Static variable in class org.broadinstitute.hellbender.utils.tsv.TableUtils
Quote character .
QUOTE_STRING - Static variable in class org.broadinstitute.hellbender.utils.tsv.TableUtils
Quote character as a string.

R

R - Static variable in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
R - Static variable in class picard.sam.markduplicates.util.ReadEnds
 
R_LIBRARY_SUFFIX - Static variable in enum org.broadinstitute.hellbender.utils.R.RScriptLibrary
 
RANDOM_SEED - Variable in class picard.sam.DownsampleSam
 
RANDOM_SEED_FOR_CHAIN_GENERATION - Static variable in interface org.broadinstitute.hellbender.utils.hmm.HMM
 
randomIntegerInRange(int, int) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Get a random int between min and max (inclusive) using the global GATK random number generator.
RandomLikelihoodCalculationEngine - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
Random likelihoods generator, used for testing/benchmarking purposes.
RandomLikelihoodCalculationEngine() - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.RandomLikelihoodCalculationEngine
 
randomRemotePath(String, String, String) - Static method in class org.broadinstitute.hellbender.utils.gcs.BucketUtils
Picks a random name, by putting some random letters between "prefix" and "suffix".
randomSelect(List<E>, Function<E, Double>, RandomGenerator) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
randomSublist(List<T>, int) - Static method in class picard.fingerprint.FingerprintChecker
A small utility function to choose n random elements (un-shuffled) from a list
Range - Class in picard.illumina.parser
While structurally identical to CompositeIndex, this class is maintained as it makes code more readable when the two are used together (see QSeqParser)
Range(int, int) - Constructor for class picard.illumina.parser.Range
 
rank() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KBestHaplotype
The rank of this solution within the list of solutions that resulted from the same search.
RankedData(MannWhitneyU.Rank[], ArrayList<Integer>) - Constructor for class org.broadinstitute.hellbender.utils.MannWhitneyU.RankedData
 
RankSumTest - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Abstract root for all RankSum based annotations
RankSumTest() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.RankSumTest
 
rapidParseInt(String) - Static method in class picard.sam.util.ReadNameParser
Very specialized method to rapidly parse a sequence of digits from a String up until the first non-digit character.
RATIO_THIS_BARCODE_TO_BEST_BARCODE_PCT - Variable in class picard.illumina.ExtractIlluminaBarcodes.BarcodeMetric
The rate of all reads matching this barcode to all reads matching the most prevelant barcode.
RAW_DELIM - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RankSumTest
 
RAW_MAP_QUAL_RANK_SUM_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
RAW_RMS_MAPPING_QUALITY_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
rawData - Variable in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.ReducibleAnnotationData
 
rawQuals - Variable in class org.broadinstitute.hellbender.utils.baq.BAQ.BAQCalculationResult
 
rawValueAsString(int[][]) - Static method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_StrandBiasTest
 
RawWgsMetrics() - Constructor for class picard.analysis.CollectRawWgsMetrics.RawWgsMetrics
 
RawWgsMetrics(IntervalList, Histogram<Integer>, Histogram<Integer>, double, double, double, double, double, double, double, int, Histogram<Integer>, int) - Constructor for class picard.analysis.CollectRawWgsMetrics.RawWgsMetrics
 
RBP_HAPLOTYPE_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
RBP_INCONSISTENT_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
rCount - Variable in class org.broadinstitute.hellbender.utils.read.ArtificialReadIterator
 
RE_REVERSE - Variable in class picard.sam.SamToFastq
 
read(Kryo, Input, Class<T>) - Method in class org.broadinstitute.hellbender.engine.spark.JsonSerializer
 
read(Kryo, Input, Class<SAMRecord>) - Method in class org.broadinstitute.hellbender.engine.spark.SAMRecordSerializer
 
read(Kryo, Input, Class<SAMRecordToGATKReadAdapter>) - Method in class org.broadinstitute.hellbender.engine.spark.SAMRecordToGATKReadAdapterSerializer
 
read(HDF5File) - Static method in class org.broadinstitute.hellbender.tools.copynumber.denoising.HDF5SVDReadCountPanelOfNormals
Create an interface to an HDF5 file.
read(File) - Static method in class org.broadinstitute.hellbender.tools.copynumber.formats.collections.SimpleCountCollection
 
read(Kryo, Input, Class<PSKmerBloomFilter>) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerBloomFilter.Serializer
 
read(Kryo, Input, Class<PSKmerSet>) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerSet.Serializer
 
read(Kryo, Input, Class<PSTaxonomyDatabase>) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTaxonomyDatabase.Serializer
 
read(Kryo, Input, Class<PSTree>) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTree.Serializer
 
read(Kryo, Input, Class<PSTreeNode>) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTreeNode.Serializer
 
read(Kryo, Input, Class<AlignedAssembly>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignedAssembly.Serializer
 
read(Kryo, Input, Class<AlignedContig>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignedContig.Serializer
 
read(Kryo, Input, Class<AlignmentInterval>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval.Serializer
 
read(Kryo, Input, Class<AssemblyContigWithFineTunedAlignments>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments.Serializer
 
read(Kryo, Input, Class<BreakpointComplications.IntraChrStrandSwitchBreakpointComplications>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications.IntraChrStrandSwitchBreakpointComplications.Serializer
 
read(Kryo, Input, Class<BreakpointComplications.SmallDuplicationWithImpreciseDupRangeBreakpointComplications>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications.SmallDuplicationWithImpreciseDupRangeBreakpointComplications.Serializer
 
read(Kryo, Input, Class<BreakpointComplications.SmallDuplicationWithPreciseDupRangeBreakpointComplications>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications.SmallDuplicationWithPreciseDupRangeBreakpointComplications.Serializer
 
read(Kryo, Input, Class<NovelAdjacencyAndAltHaplotype>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.NovelAdjacencyAndAltHaplotype.Serializer
 
read(Kryo, Input, Class<SimpleChimera>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SimpleChimera.Serializer
 
read(Kryo, Input, Class<SimpleNovelAdjacencyAndChimericAlignmentEvidence>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SimpleNovelAdjacencyAndChimericAlignmentEvidence.Serializer
 
read(Kryo, Input, Class<AlignedAssemblyOrExcuse>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.AlignedAssemblyOrExcuse.Serializer
 
read(Kryo, Input, Class<BreakpointEvidence.ExternalEvidence>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.ExternalEvidence.Serializer
 
read(Kryo, Input, Class<BreakpointEvidence.InterContigPair>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.InterContigPair.Serializer
 
read(Kryo, Input, Class<BreakpointEvidence.LargeIndel>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.LargeIndel.Serializer
 
read(Kryo, Input, Class<BreakpointEvidence.MateUnmapped>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.MateUnmapped.Serializer
 
read(Kryo, Input, Class<BreakpointEvidence.OutiesPair>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.OutiesPair.Serializer
 
read(Kryo, Input, Class<BreakpointEvidence.ReadEvidence>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.ReadEvidence.Serializer
 
read(Kryo, Input, Class<BreakpointEvidence.SameStrandPair>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.SameStrandPair.Serializer
 
read(Kryo, Input, Class<BreakpointEvidence>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.Serializer
 
read(Kryo, Input, Class<BreakpointEvidence.SplitRead>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.SplitRead.Serializer
 
read(Kryo, Input, Class<BreakpointEvidence.TemplateSizeAnomaly>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.TemplateSizeAnomaly.Serializer
 
read(Kryo, Input, Class<BreakpointEvidence.WeirdTemplateSize>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.WeirdTemplateSize.Serializer
 
read(Kryo, Input, Class<EvidenceTargetLink>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.EvidenceTargetLink.Serializer
 
read(Kryo, Input, Class<KmerAndInterval>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.KmerAndInterval.Serializer
 
read(Kryo, Input, Class<LibraryStatistics>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.LibraryStatistics.Serializer
 
read(Kryo, Input, Class<QNameAndInterval>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.QNameAndInterval.Serializer
 
read(Kryo, Input, Class<ReadMetadata.LibraryRawStatistics>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.LibraryRawStatistics.Serializer
 
read(Kryo, Input, Class<ReadMetadata.PartitionBounds>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.PartitionBounds.Serializer
 
read(Kryo, Input, Class<ReadMetadata.PartitionStatistics>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.PartitionStatistics.Serializer
 
read(Kryo, Input, Class<ReadMetadata>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.Serializer
 
read(Kryo, Input, Class<KmerAndCount>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.KmerAndCount.Serializer
 
read(Kryo, Input, Class<PairedStrandedIntervalTree<T>>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.PairedStrandedIntervalTree.Serializer
 
read(Kryo, Input, Class<Strand>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.Strand.Serializer
 
read(Kryo, Input, Class<StrandedInterval>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.StrandedInterval.Serializer
 
read(Kryo, Input, Class<SVFastqUtils.FastqRead>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils.FastqRead.Serializer
 
read(Kryo, Input, Class<SVInterval>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVInterval.Serializer
 
read(Kryo, Input, Class<SVIntervalTree<T>>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree.Serializer
 
read(Kryo, Input, Class<SVKmerLong>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerLong.Serializer
 
read(Kryo, Input, Class<SVKmerShort>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerShort.Serializer
 
read(Kryo, Input, Class<HopscotchCollection<T>>) - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchCollection.Serializer
 
read(Kryo, Input, Class<HopscotchMap>) - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchMap.Serializer
 
read(Kryo, Input, Class<HopscotchMultiMap>) - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchMultiMap.Serializer
 
read(Kryo, Input, Class<HopscotchSet>) - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchSet.Serializer
 
read(Kryo, Input, Class<HopscotchUniqueMultiMap>) - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchUniqueMultiMap.Serializer
 
read(Kryo, Input, Class<IntHistogram.CDF>) - Method in class org.broadinstitute.hellbender.tools.spark.utils.IntHistogram.CDF.Serializer
 
read(Kryo, Input, Class<IntHistogram>) - Method in class org.broadinstitute.hellbender.tools.spark.utils.IntHistogram.Serializer
 
read(Kryo, Input, Class<LargeLongHopscotchSet>) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LargeLongHopscotchSet.Serializer
 
read(Kryo, Input, Class<LongBloomFilter>) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongBloomFilter.Serializer
 
read(Kryo, Input, Class<LongHopscotchSet>) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongHopscotchSet.Serializer
 
read - Variable in class org.broadinstitute.hellbender.tools.walkers.rnaseq.OverhangFixingManager.SplitRead
 
read(char[], int, int) - Method in class org.broadinstitute.hellbender.utils.codecs.LineIteratorReader
Reads lines from the buffer, and if empty from the underlying line-iterator.
read - Variable in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods.BestAllele
The query read.
read() - Method in class org.broadinstitute.hellbender.utils.nio.ChannelAsSeekableStream
Reads the next byte of data from the input stream.
read(byte[], int, int) - Method in class org.broadinstitute.hellbender.utils.nio.ChannelAsSeekableStream
 
read(ByteBuffer) - Method in class org.broadinstitute.hellbender.utils.nio.SeekableByteChannelPrefetcher
Reads a sequence of bytes from this channel into the given buffer.
read(Kryo, Input, Class<Pair>) - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Pair.Serializer
 
read() - Method in class org.broadinstitute.hellbender.utils.runtime.CapturedStreamOutput
Drain the input stream to keep the process from backing up until it's empty.
read() - Method in class org.broadinstitute.hellbender.utils.runtime.CapturedStreamOutputSnapshot
Drain the input stream to keep the process from backing up until it's empty.
read(ByteBuffer) - Method in class org.broadinstitute.hellbender.utils.test.XorWrapper
 
read(byte[], int, int) - Method in class picard.util.CircularByteBuffer
Read bytes from the buffer into the supplied array.
read1 - Variable in class picard.util.QuerySortedReadPairIteratorUtil.ReadPair
 
READ1_ALIGNED_BAM - Variable in class picard.sam.MergeBamAlignment
 
READ1_MAX_BASES_TO_WRITE - Variable in class picard.sam.SamToFastq
 
READ1_TRIM - Variable in class picard.sam.MergeBamAlignment
 
READ1_TRIM - Variable in class picard.sam.SamToFastq
 
read1Coordinate - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
read1Coordinate - Variable in class picard.sam.markduplicates.util.ReadEnds
 
read1IndexInFile - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEndsForMarkDuplicates
 
read1IndexInFile - Variable in class picard.sam.markduplicates.util.ReadEndsForMarkDuplicates
 
read1ReferenceIndex - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
read1ReferenceIndex - Variable in class picard.sam.markduplicates.util.ReadEnds
 
read2 - Variable in class picard.util.QuerySortedReadPairIteratorUtil.ReadPair
 
READ2_ALIGNED_BAM - Variable in class picard.sam.MergeBamAlignment
 
READ2_MAX_BASES_TO_WRITE - Variable in class picard.sam.SamToFastq
 
READ2_TRIM - Variable in class picard.sam.MergeBamAlignment
 
READ2_TRIM - Variable in class picard.sam.SamToFastq
 
read2Coordinate - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
read2Coordinate - Variable in class picard.sam.markduplicates.util.ReadEnds
 
read2IndexInFile - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEndsForMarkDuplicates
 
read2IndexInFile - Variable in class picard.sam.markduplicates.util.ReadEndsForMarkDuplicates
 
read2ReferenceIndex - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
read2ReferenceIndex - Variable in class picard.sam.markduplicates.util.ReadEnds
 
READ_CHUNK_SIZE - Variable in class picard.fastq.BamToBfq
 
READ_END - Variable in class org.broadinstitute.hellbender.metrics.analysis.BaseDistributionByCycleMetrics
 
READ_END - Variable in class picard.analysis.BaseDistributionByCycleMetrics
 
READ_FILTER_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ReadFilterArgumentDefinitions
 
READ_FILTER_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ReadFilterArgumentDefinitions
 
READ_GROUP - Variable in class org.broadinstitute.hellbender.metrics.MultiLevelMetrics
The read group to which these metrics apply.
READ_GROUP - Variable in class org.broadinstitute.hellbender.tools.SplitReads
 
READ_GROUP - Variable in class picard.analysis.FingerprintingDetailMetrics
The sequencing read group from which sequence data was fingerprinted.
READ_GROUP - Variable in class picard.analysis.FingerprintingSummaryMetrics
The read group from which sequence data was drawn for comparison.
READ_GROUP - Variable in class picard.metrics.MultilevelMetrics
The read group to which these metrics apply.
READ_GROUP_BLACK_LIST_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ReadFilterArgumentDefinitions
 
READ_GROUP_ID - Variable in class picard.illumina.IlluminaBasecallsToSam
 
READ_GROUP_ID_SHORT_NAME - Static variable in class picard.cmdline.StandardOptionDefinitions
 
READ_GROUP_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.SplitReads
 
READ_GROUP_NAME - Variable in class picard.sam.FastqToSam
 
READ_GROUP_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.SplitReads
 
READ_INDEX_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
READ_INDEX_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
READ_LENGTH - Variable in class org.broadinstitute.hellbender.metrics.QualityYieldMetrics
The average read length of all the reads (will be fixed for a lane)
READ_LENGTH - Variable in class picard.analysis.CollectQualityYieldMetrics.QualityYieldMetrics
The average read length of all the reads (will be fixed for a lane)
READ_LENGTH - Variable in class picard.analysis.CollectWgsMetrics
 
READ_LIST_FILE - Variable in class picard.sam.FilterSamReads
 
READ_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.ClipReads
 
READ_NAME_FORMAT - Variable in class picard.illumina.IlluminaBasecallsToFastq
 
READ_NAME_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ReadFilterArgumentDefinitions
 
READ_NAME_PREFIX - Variable in class picard.fastq.BamToBfq
 
READ_NAME_REGEX - Variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.OpticalDuplicatesArgumentCollection
 
READ_NAME_REGEX - Variable in class picard.sam.markduplicates.util.AbstractOpticalDuplicateFinderCommandLineProgram
 
READ_NAME_REGEX - Variable in class picard.sam.PositionBasedDownsampleSam
 
READ_NAME_REGEX_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.OpticalDuplicatesArgumentCollection
 
READ_ONE_BARCODE_TAG - Variable in class picard.sam.markduplicates.EstimateLibraryComplexity
 
READ_ONE_BARCODE_TAG - Variable in class picard.sam.markduplicates.MarkDuplicates
 
READ_PAIR_DUPLICATES - Variable in class picard.sam.DuplicationMetrics
The number of read pairs that were marked as duplicates.
READ_PAIR_OPTICAL_DUPLICATES - Variable in class picard.sam.DuplicationMetrics
The number of read pairs duplicates that were caused by optical duplication.
READ_PAIR_SUPPORT - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
READ_PAIRS - Variable in class org.broadinstitute.hellbender.metrics.InsertSizeMetrics
The total number of read pairs that were examined in the entire distribution.
READ_PAIRS - Variable in class picard.analysis.InsertSizeMetrics
The total number of read pairs that were examined in the entire distribution.
READ_PAIRS_EXAMINED - Variable in class picard.sam.DuplicationMetrics
The number of mapped read pairs examined.
READ_POS_RANK_SUM_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
READ_POSITION_FILTER_NAME - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
READ_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.ClipReads
 
READ_STARTS - Variable in class picard.analysis.GcBiasDetailMetrics
The number of reads whose start position is at the start of a window of this GC.
READ_STRUCTURE - Variable in class picard.illumina.CheckIlluminaDirectory
 
READ_STRUCTURE - Variable in class picard.illumina.CollectIlluminaBasecallingMetrics
 
READ_STRUCTURE - Variable in class picard.illumina.CollectIlluminaLaneMetrics
 
READ_STRUCTURE - Variable in class picard.illumina.ExtractIlluminaBarcodes
 
READ_STRUCTURE - Variable in class picard.illumina.IlluminaBasecallsToFastq
 
READ_STRUCTURE - Variable in class picard.illumina.IlluminaBasecallsToSam
 
READ_TWO_BARCODE_TAG - Variable in class picard.sam.markduplicates.EstimateLibraryComplexity
 
READ_TWO_BARCODE_TAG - Variable in class picard.sam.markduplicates.MarkDuplicates
 
READ_VALIDATION_STRINGENCY_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
READ_VALIDATION_STRINGENCY_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
readActualHeader(LineIterator) - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalCodec
 
readActualHeader(LineIterator) - Method in class org.broadinstitute.hellbender.utils.codecs.sampileup.SAMPileupCodec
 
readActualHeader(LineIterator) - Method in class org.broadinstitute.hellbender.utils.codecs.table.TableCodec
 
readActualHeader(LineIterator) - Method in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvLocatableTableCodec
Read until we get to the header of this xsv Dev note: We also determine the actual locatable columns here.
readAndMateAreUnmapped(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Helper method for interrogating if a read and its mate (if it exists) are unmapped
readArguments - Variable in class org.broadinstitute.hellbender.engine.GATKTool
 
readArguments - Variable in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
 
ReadAttributeTypeMismatch(String, String) - Constructor for exception org.broadinstitute.hellbender.exceptions.GATKException.ReadAttributeTypeMismatch
 
ReadAttributeTypeMismatch(String, String, Throwable) - Constructor for exception org.broadinstitute.hellbender.exceptions.GATKException.ReadAttributeTypeMismatch
 
ReadAttributeTypeMismatch(SAMRecord, String, String) - Constructor for exception org.broadinstitute.hellbender.exceptions.GATKException.ReadAttributeTypeMismatch
 
ReadAttributeTypeMismatch(SAMRecord, String, String, Object) - Constructor for exception org.broadinstitute.hellbender.exceptions.GATKException.ReadAttributeTypeMismatch
 
ReadAttributeTypeMismatch(SAMRecord, String, String, Throwable) - Constructor for exception org.broadinstitute.hellbender.exceptions.GATKException.ReadAttributeTypeMismatch
 
readBases - Variable in class org.broadinstitute.hellbender.utils.baq.BAQ.BAQCalculationResult
 
readBreakpointsFromTruthVCF(String, SAMSequenceDictionary, int) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVVCFReader
 
ReadCachingIterator - Class in org.broadinstitute.hellbender.utils.iterators
Trivial wrapper around a GATKRead iterator that saves all reads returned in a cache, which can be periodically returned and emptied by the client.
ReadCachingIterator(Iterator<GATKRead>) - Constructor for class org.broadinstitute.hellbender.utils.iterators.ReadCachingIterator
 
readChunkedDoubleMatrix(HDF5File, String) - Static method in class org.broadinstitute.hellbender.tools.copynumber.utils.HDF5Utils
Reads a large matrix stored as a set of chunks (submatrices) using the sub-paths and conventions used by HDF5Utils.writeChunkedDoubleMatrix(org.broadinstitute.hdf5.HDF5File, java.lang.String, double[][], int).
ReadClassifier - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
Figures out what kind of BreakpointEvidence, if any, a read represents.
ReadClassifier(ReadMetadata, GATKRead, int, SVReadFilter, SVIntervalTree<SVInterval>) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadClassifier
 
ReadClassifier(ReadData) - Constructor for class picard.illumina.quality.CollectHiSeqXPfFailMetrics.ReadClassifier
Heart of CLP.
ReadClipper - Class in org.broadinstitute.hellbender.utils.clipping
A comprehensive clipping tool.
ReadClipper(GATKRead) - Constructor for class org.broadinstitute.hellbender.utils.clipping.ReadClipper
Initializes a ReadClipper object.
ReadClipperTestUtils - Class in org.broadinstitute.hellbender.utils.test
 
ReadClipperTestUtils() - Constructor for class org.broadinstitute.hellbender.utils.test.ReadClipperTestUtils
 
ReadClipperWithData(GATKRead, List<ClipReads.SeqToClip>) - Constructor for class org.broadinstitute.hellbender.tools.ClipReads.ReadClipperWithData
 
ReadConstants - Class in org.broadinstitute.hellbender.utils.read
Constants for use with the GATKRead interface
readContext - Variable in class org.broadinstitute.hellbender.engine.ContextShard
 
ReadContextData - Class in org.broadinstitute.hellbender.engine
ReadContextData is additional data that's useful when processing reads.
ReadContextData(ReferenceBases, Iterable<GATKVariant>) - Constructor for class org.broadinstitute.hellbender.engine.ReadContextData
 
ReadContextData(ReferenceBases, List<GATKVariant>) - Constructor for class org.broadinstitute.hellbender.engine.ReadContextData
 
ReadCoordinateComparator - Class in org.broadinstitute.hellbender.utils.read
Comparator for sorting Reads by coordinate.
ReadCoordinateComparator(SAMFileHeader) - Constructor for class org.broadinstitute.hellbender.utils.read.ReadCoordinateComparator
 
readCount() - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Returns the total number of reads in the read-likelihood collection.
readCount - Variable in class picard.analysis.directed.TargetMetricsCollector.Coverage
 
ReadCovariates - Class in org.broadinstitute.hellbender.utils.recalibration.covariates
The object temporarily held by a read that describes all of its covariates.
ReadCovariates(int, int, CovariateKeyCache) - Constructor for class org.broadinstitute.hellbender.utils.recalibration.covariates.ReadCovariates
Use an LRU cache to keep cache of keys (int[][][]) arrays for each read length we've seen.
ReadData - Class in picard.illumina.parser
Data for a single end of a paired-end read, a barcode read, or for the entire read if not paired end.
ReadData() - Constructor for class picard.illumina.parser.ReadData
 
ReadData(ReadType) - Constructor for class picard.illumina.parser.ReadData
 
ReadDataManipulationProgramGroup - Class in picard.cmdline.programgroups
Tools that manipulate read data in SAM, BAM or CRAM format
ReadDataManipulationProgramGroup() - Constructor for class picard.cmdline.programgroups.ReadDataManipulationProgramGroup
 
ReadDescriptor - Class in picard.illumina.parser
Represents one set of cycles in an ReadStructure (e.g.
ReadDescriptor(int, ReadType) - Constructor for class picard.illumina.parser.ReadDescriptor
 
ReadEnds - Class in org.broadinstitute.hellbender.utils.read.markduplicates
Little struct-like class to hold read pair (and fragment) end data for duplicate marking.
ReadEnds() - Constructor for class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
ReadEnds - Class in picard.sam.markduplicates.util
Little struct-like class to hold read pair (and fragment) end data for duplicate marking.
ReadEnds() - Constructor for class picard.sam.markduplicates.util.ReadEnds
 
ReadEndsForMarkDuplicates - Class in org.broadinstitute.hellbender.utils.read.markduplicates
Little struct-like class to hold read pair (and fragment) end data for MarkDuplicatesWithMateCigar
ReadEndsForMarkDuplicates() - Constructor for class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEndsForMarkDuplicates
 
ReadEndsForMarkDuplicates - Class in picard.sam.markduplicates.util
Little struct-like class to hold read pair (and fragment) end data for MarkDuplicatesWithMateCigar
ReadEndsForMarkDuplicates() - Constructor for class picard.sam.markduplicates.util.ReadEndsForMarkDuplicates
 
ReadEndsForMarkDuplicates(ReadEndsForMarkDuplicates) - Constructor for class picard.sam.markduplicates.util.ReadEndsForMarkDuplicates
 
ReadEndsForMarkDuplicatesCodec - Class in org.broadinstitute.hellbender.utils.read.markduplicates
Codec for ReadEnds that just outputs the primitive fields and reads them back.
ReadEndsForMarkDuplicatesCodec() - Constructor for class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEndsForMarkDuplicatesCodec
 
ReadEndsForMarkDuplicatesCodec - Class in picard.sam.markduplicates.util
Codec for ReadEnds that just outputs the primitive fields and reads them back.
ReadEndsForMarkDuplicatesCodec() - Constructor for class picard.sam.markduplicates.util.ReadEndsForMarkDuplicatesCodec
 
ReadEndsForMarkDuplicatesMap - Interface in org.broadinstitute.hellbender.utils.read.markduplicates
Interface for storing and retrieving ReadEnds objects.
ReadEndsForMarkDuplicatesMap - Interface in picard.sam.markduplicates.util
Interface for storing and retrieving ReadEnds objects.
ReadEndsForMarkDuplicatesWithBarcodes - Class in picard.sam.markduplicates.util
 
ReadEndsForMarkDuplicatesWithBarcodes() - Constructor for class picard.sam.markduplicates.util.ReadEndsForMarkDuplicatesWithBarcodes
 
ReadEndsForMarkDuplicatesWithBarcodes(ReadEndsForMarkDuplicates) - Constructor for class picard.sam.markduplicates.util.ReadEndsForMarkDuplicatesWithBarcodes
 
ReadEndsForMarkDuplicatesWithBarcodes(ReadEndsForMarkDuplicatesWithBarcodes) - Constructor for class picard.sam.markduplicates.util.ReadEndsForMarkDuplicatesWithBarcodes
 
ReadEndsForMarkDuplicatesWithBarcodesCodec - Class in picard.sam.markduplicates.util
Created by nhomer on 9/13/15.
ReadEndsForMarkDuplicatesWithBarcodesCodec() - Constructor for class picard.sam.markduplicates.util.ReadEndsForMarkDuplicatesWithBarcodesCodec
 
ReadEndsForMateCigar - Class in picard.sam.markduplicates.util
A class to store individual records for MarkDuplicatesWithMateCigar.
ReadEndsForMateCigar(SAMFileHeader, SamRecordWithOrdinal, OpticalDuplicateFinder, short) - Constructor for class picard.sam.markduplicates.util.ReadEndsForMateCigar
Builds a read ends object that represents a single read.
ReadEndsForMateCigar(ReadEndsForMateCigar, SamRecordWithOrdinal) - Constructor for class picard.sam.markduplicates.util.ReadEndsForMateCigar
Creates a shallow copy from the "other"
readEntireVCFIntoMemory(String) - Static method in class org.broadinstitute.hellbender.utils.test.VariantContextTestUtils
Reads an entire VCF into memory, returning both its VCFHeader and all VariantContext records in the vcf.
Reader(File) - Constructor for class org.broadinstitute.hellbender.tools.walkers.validation.ConcordanceSummaryRecord.Reader
 
reader(File, BiFunction<TableColumnCollection, Function<String, RuntimeException>, Function<DataLine, R>>) - Static method in class org.broadinstitute.hellbender.utils.tsv.TableUtils
Creates a new table reader given an record extractor factory based from the columns found in the input.
reader(Reader, BiFunction<TableColumnCollection, Function<String, RuntimeException>, Function<DataLine, R>>) - Static method in class org.broadinstitute.hellbender.utils.tsv.TableUtils
Creates a new table reader given an record extractor factory based from the columns found in the input.
reader(String, Reader, BiFunction<TableColumnCollection, Function<String, RuntimeException>, Function<DataLine, R>>) - Static method in class org.broadinstitute.hellbender.utils.tsv.TableUtils
Creates a new table reader given an record extractor factory based from the columns found in the input.
ReadErrorCorrector - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
Utility class that error-corrects reads.
ReadErrorCorrector(int, int, int, byte, int, boolean, byte, boolean, byte[]) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadErrorCorrector
Create a new kmer corrector
ReadErrorCorrector(int, byte, int, boolean, byte[]) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadErrorCorrector
Simple constructor with sensible defaults
ReadErrorCorrector.CorrectionSet - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
Wrapper utility class that holds, for each position in read, a list of bytes representing candidate corrections.
ReaderSplitter<T> - Class in org.broadinstitute.hellbender.tools.readersplitters
Splits a reader by some value.
ReaderSplitter() - Constructor for class org.broadinstitute.hellbender.tools.readersplitters.ReaderSplitter
 
readerThreads - Variable in class org.broadinstitute.hellbender.tools.FixCallSetSampleOrdering
 
ReadEvidence(GATKRead, ReadMetadata, int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.ReadEvidence
evidence offset and width is set to "the rest of the fragment" not covered by this read
ReadEvidence(GATKRead, ReadMetadata, int, int, boolean, int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.ReadEvidence
for use when the uncertainty in location has a fixed size
ReadEvidence(Kryo, Input) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.ReadEvidence
a technical constructor for use in Kryo (de-)serialization.
readFastqFile(String) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils
 
readFastqStream(BufferedReader, String) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils
 
readFileIntoByteArray(File) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
Reads the entirety of the given file into a byte array.
readFileIntoByteArray(File, int) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
Reads the entirety of the given file into a byte array using the requested read buffer size.
readFilesNames - Variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.RequiredReadInputArgumentCollection
 
ReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Filters which operate on GATKRead should subclass this by overriding ReadFilter.test(GATKRead) ReadFilter implements Predicate and Serializable.
ReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilter
 
ReadFilter.ReadFilterAnd - Class in org.broadinstitute.hellbender.engine.filters
 
ReadFilter.ReadFilterBinOp - Class in org.broadinstitute.hellbender.engine.filters
 
ReadFilterAnd(ReadFilter, ReadFilter) - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilter.ReadFilterAnd
 
ReadFilterArgumentDefinitions - Class in org.broadinstitute.hellbender.cmdline
 
ReadFilterBinOp(ReadFilter, ReadFilter) - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilter.ReadFilterBinOp
 
ReadFilteringIterator - Class in org.broadinstitute.hellbender.utils.iterators
An iterator that filters reads from an existing iterator of reads.
ReadFilteringIterator(Iterator<GATKRead>, ReadFilter) - Constructor for class org.broadinstitute.hellbender.utils.iterators.ReadFilteringIterator
Create a ReadFilteringIterator given a pre-existing iterator of reads and a read filter.
ReadFilterLibrary - Class in org.broadinstitute.hellbender.engine.filters
Standard ReadFilters
ReadFilterLibrary.AllowAllReadsReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Do not filter out any read.
ReadFilterLibrary.CigarContainsNoNOperator - Class in org.broadinstitute.hellbender.engine.filters
Filter out reads containing skipped region from the reference (CIGAR strings with 'N' operator).
ReadFilterLibrary.FirstOfPairReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Keep only reads that are first of pair (0x1 and 0x40).
ReadFilterLibrary.GoodCigarReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Keep only reads containing good CIGAR strings.
ReadFilterLibrary.HasReadGroupReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Filter out reads without the SAM record RG (Read Group) tag.
ReadFilterLibrary.MappedReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Filter out unmapped reads.
ReadFilterLibrary.MappingQualityAvailableReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Filter out reads without available mapping quality (MAPQ=255).
ReadFilterLibrary.MappingQualityNotZeroReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Filter out reads with mapping quality equal to zero.
ReadFilterLibrary.MatchingBasesAndQualsReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Filter out reads where the bases and qualities do not match in length.
ReadFilterLibrary.MateDifferentStrandReadFilter - Class in org.broadinstitute.hellbender.engine.filters
For paired reads (0x1), keep only reads that are mapped, have a mate that is mapped (read is not 0x8), and both the read and its mate are on different strands (when read is 0x20, it is not 0x10), as is the typical case.
ReadFilterLibrary.MateOnSameContigOrNoMappedMateReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Keep only reads that have a mate that maps to the same contig (RNEXT is "="), is single ended (not 0x1) or has an unmapped mate (0x8).
ReadFilterLibrary.NonZeroFragmentLengthReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Filter out reads with fragment length (insert size) different from zero.
ReadFilterLibrary.NonZeroReferenceLengthAlignmentReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Filter out reads that do not align to the reference.
ReadFilterLibrary.NotDuplicateReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Filter out reads marked as duplicate (0x400).
ReadFilterLibrary.NotSecondaryAlignmentReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Filter out reads representing secondary alignments (0x100).
ReadFilterLibrary.NotSupplementaryAlignmentReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Filter out reads representing supplementary alignments (0x800).
ReadFilterLibrary.PairedReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Filter out unpaired reads (not 0x1).
ReadFilterLibrary.PassesVendorQualityCheckReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Filter out reads failing platform/vendor quality checks (0x200).
ReadFilterLibrary.PrimaryLineReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Keep only reads representing primary alignments (those that satisfy both the NotSecondaryAlignment and NotSupplementaryAlignment filters, or in terms of SAM flag values, must have neither of the 0x100 or 0x800 flags set).
ReadFilterLibrary.ProperlyPairedReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Keep only paired reads that are properly paired (0x1 and 0x2).
ReadFilterLibrary.ReadLengthEqualsCigarLengthReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Filter out reads where the read and CIGAR do not match in length.
ReadFilterLibrary.SecondOfPairReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Keep only paired reads (0x1) that are second of pair (0x80).
ReadFilterLibrary.SeqIsStoredReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Keep only reads with sequenced bases.
ReadFilterLibrary.ValidAlignmentEndReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Keep only reads where the read end corresponds to a proper alignment -- that is, the read ends after the start (non-negative number of bases in the reference).
ReadFilterLibrary.ValidAlignmentStartReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Keep only reads with a valid alignment start (POS larger than 0) or is unmapped.
ReadFilterSparkifier - Class in org.broadinstitute.hellbender.tools.spark.utils
 
ReadFilterSparkifier(ReadFilter) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.ReadFilterSparkifier
 
readFromFile(File) - Static method in class org.broadinstitute.hellbender.tools.walkers.contamination.ContaminationRecord
 
readFromFile(File) - Static method in class org.broadinstitute.hellbender.tools.walkers.contamination.MinorAlleleFractionRecord
 
readFromFile(File) - Static method in class org.broadinstitute.hellbender.tools.walkers.contamination.PileupSummary
 
readFromFile(File) - Static method in class org.broadinstitute.hellbender.tools.walkers.validation.FilterAnalysisRecord
 
readGroup - Variable in class org.broadinstitute.hellbender.engine.filters.ReadGroupReadFilter
 
readGroup - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
readGroup - Variable in class picard.sam.markduplicates.util.ReadEnds
 
READGROUP_COLUMN_NAME - Static variable in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
 
READGROUP_ID_REGEX - Static variable in class picard.sam.AddOrReplaceReadGroups
 
READGROUP_REPORT_TABLE_TITLE - Static variable in class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
 
ReadGroupBlackListReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Keep records not matching the read group tag and exact match string.
ReadGroupBlackListReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadGroupBlackListReadFilter
 
ReadGroupBlackListReadFilter(List<String>, SAMFileHeader) - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadGroupBlackListReadFilter
Creates a filter using the lists of files with blacklisted read groups.
ReadGroupCovariate - Class in org.broadinstitute.hellbender.utils.recalibration.covariates
The Read Group covariate.
ReadGroupCovariate(RecalibrationArgumentCollection, List<String>) - Constructor for class org.broadinstitute.hellbender.utils.recalibration.covariates.ReadGroupCovariate
 
ReadGroupIdSplitter - Class in org.broadinstitute.hellbender.tools.readersplitters
Splits readers read group id.
ReadGroupIdSplitter() - Constructor for class org.broadinstitute.hellbender.tools.readersplitters.ReadGroupIdSplitter
 
ReadGroupReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Keep only reads from the specified read group.
ReadGroupReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadGroupReadFilter
 
ReadGroupSplitter<T> - Class in org.broadinstitute.hellbender.tools.readersplitters
Splits a reader based on a value from a read group.
ReadGroupSplitter() - Constructor for class org.broadinstitute.hellbender.tools.readersplitters.ReadGroupSplitter
 
readHasMappedMate(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
readHasMappedMate(SAMRecord) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
readHasNoAssignedPosition(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Checks whether the provided read has an assigned position.
readHeader(LineIterator) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfCodec
 
readHeader(B) - Method in class org.broadinstitute.hellbender.utils.codecs.ProgressReportingDelegatingCodec
 
readIndexInFile - Variable in class picard.sam.util.RepresentativeReadIndexer
 
readIndices - Variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.ReadInputArgumentCollection
 
ReadInputArgumentCollection - Class in org.broadinstitute.hellbender.cmdline.argumentcollections
An abstract argument collection for use with tools that accept input files containing reads (eg., BAM/SAM/CRAM files).
ReadInputArgumentCollection() - Constructor for class org.broadinstitute.hellbender.cmdline.argumentcollections.ReadInputArgumentCollection
 
readIntervalAlignedToRefSpan(SimpleInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
Given an alignment (represented by this AlignmentInterval) and a reference span (in this case otherRefSpan), the overlap between the two reference spans, if any, has a corresponding span on the read to which the alignment belongs.
readIntervals(HDF5File, String) - Static method in class org.broadinstitute.hellbender.tools.copynumber.utils.HDF5Utils
Reads a list of intervals from an HDF5 file using the sub-paths and conventions used by HDF5Utils.writeIntervals(org.broadinstitute.hdf5.HDF5File, java.lang.String, java.util.List<T>).
readIntervalsFile(String, Map<String, Integer>) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFileUtils
Read intervals from file.
readKmerFilter(String) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerUtils
 
readKmersFile(String, int) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFileUtils
Read a file of kmers.
readLaneTiles(File, ReadStructure, ValidationStringency, boolean) - Static method in class picard.illumina.CollectIlluminaLaneMetrics.IlluminaLaneMetricsCollector
Returns a partitioned collection of lane number to Tile objects from the provided basecall directory.
READLENGTH_EQUALS_CIGARLENGTH - Static variable in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary
 
ReadLengthEqualsCigarLengthReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.ReadLengthEqualsCigarLengthReadFilter
 
ReadLengthReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Keep only reads whose length is ≥ min value and ≤ max value.
ReadLengthReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadLengthReadFilter
 
ReadLengthReadFilter(int, int) - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadLengthReadFilter
 
readLengths - Variable in class picard.illumina.parser.ReadStructure
 
ReadLikelihoodCalculationEngine - Interface in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
Common interface for assembly-haplotype vs reads likelihood engines.
ReadLikelihoodCalculationEngine.Implementation - Enum in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
 
readLikelihoods() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingData
Returns read-likelihoods to use for genotyping.
ReadLikelihoods<A extends htsjdk.variant.variantcontext.Allele> - Class in org.broadinstitute.hellbender.utils.genotyper
Read-likelihoods container implementation based on integer indexed arrays.
ReadLikelihoods(SampleList, AlleleList<A>, Map<String, List<GATKRead>>) - Constructor for class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Constructs a new read-likelihood collection.
ReadLikelihoods.BestAllele - Class in org.broadinstitute.hellbender.utils.genotyper
Contains information about the best allele for a read search result.
readLines() - Method in class org.broadinstitute.hellbender.utils.text.XReadLines
Reads all of the lines in the file, and returns them as a list of strings
README_FILE_NAME - Static variable in class org.broadinstitute.hellbender.tools.funcotator.dataSources.DataSourceUtils
 
readMetadata - Variable in class org.broadinstitute.hellbender.tools.spark.sv.evidence.KSWindowFinder
 
ReadMetadata - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
A bag of data about reads: contig name to id mapping, fragment length statistics by read group, mean length.
ReadMetadata(Set<Integer>, SAMFileHeader, int, JavaRDD<GATKRead>, SVReadFilter, Logger) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata
 
ReadMetadata.LibraryRawStatistics - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
ReadMetadata.LibraryRawStatistics.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
ReadMetadata.PartitionBounds - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
A class to track the genomic location of the start of the first and last mapped reads in a partition.
ReadMetadata.PartitionBounds.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
ReadMetadata.PartitionStatistics - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
ReadMetadata.PartitionStatistics.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
ReadMetadata.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
ReadMissingReadGroup(GATKRead) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.ReadMissingReadGroup
 
readMixingFractions(File) - Static method in class org.broadinstitute.hellbender.tools.walkers.validation.MixingFraction
 
readName - Variable in class org.broadinstitute.hellbender.engine.filters.ReadNameReadFilter
 
ReadNameEncoder - Interface in picard.fastq
 
ReadNameParser - Class in picard.sam.util
Provides access to the physical location information about a cluster.
ReadNameParser() - Constructor for class picard.sam.util.ReadNameParser
Creates are read name parser using the default read name regex and optical duplicate distance.
ReadNameParser(String) - Constructor for class picard.sam.util.ReadNameParser
Creates are read name parser using the given read name regex.
ReadNameParser(String, Log) - Constructor for class picard.sam.util.ReadNameParser
Creates are read name parser using the given read name regex.
ReadNameReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Keep only reads with this read name.
ReadNameReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadNameReadFilter
 
readNextLine() - Method in class picard.util.AbstractInputParser
 
readNextLine() - Method in class picard.util.BasicInputParser
Workhorse method that reads the next line from the underlying reader
readObject(ObjectInputStream) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.ContainsKmerReadFilterSpark
 
readOneBarcode - Variable in class picard.sam.markduplicates.util.ReadEndsForMarkDuplicatesWithBarcodes
 
readOrientationBiasSummaryTable(File) - Static method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasUtils
 
readOverlapsRegion(GATKRead) - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
Returns true if read would overlap the extended extent of this region
ReadPair() - Constructor for class picard.util.QuerySortedReadPairIteratorUtil.ReadPair
 
ReadPileup - Class in org.broadinstitute.hellbender.utils.pileup
Represents a pileup of reads at a given position.
ReadPileup(Locatable, List<PileupElement>) - Constructor for class org.broadinstitute.hellbender.utils.pileup.ReadPileup
Create a new pileup at loc, using the reads and their corresponding offsets.
ReadPileup(Locatable, Map<String, ReadPileup>) - Constructor for class org.broadinstitute.hellbender.utils.pileup.ReadPileup
Create a new pileup at loc, using an stratified pileup Note: the current implementation of ReadPileup does not efficiently retrieve the stratified pileup
ReadPileup(Locatable) - Constructor for class org.broadinstitute.hellbender.utils.pileup.ReadPileup
Create a new pileup without any aligned reads
ReadPileup(Locatable, List<GATKRead>, int) - Constructor for class org.broadinstitute.hellbender.utils.pileup.ReadPileup
Create a new pileup with the given reads.
ReadPileup(Locatable, List<GATKRead>, List<Integer>) - Constructor for class org.broadinstitute.hellbender.utils.pileup.ReadPileup
Create a new pileup with the given reads.
ReadPosition - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Median distance of variant starts from ends of reads supporting each alt allele.
ReadPosition() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.ReadPosition
 
ReadPosRankSumTest - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Rank Sum Test for relative positioning of REF versus ALT alleles within reads
ReadPosRankSumTest() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.ReadPosRankSumTest
 
ReadQueryNameComparator - Class in org.broadinstitute.hellbender.utils.read
compare GATKRead by queryname duplicates the exact ordering of SAMRecordQueryNameComparator
ReadQueryNameComparator() - Constructor for class org.broadinstitute.hellbender.utils.read.ReadQueryNameComparator
 
ReadRecalibrationInfo - Class in org.broadinstitute.hellbender.utils.recalibration
 
ReadRecalibrationInfo(GATKRead, ReadCovariates, boolean[], double[], double[], double[]) - Constructor for class org.broadinstitute.hellbender.utils.recalibration.ReadRecalibrationInfo
 
readRecord() - Method in class org.broadinstitute.hellbender.utils.tsv.TableReader
Returns the next record form the source.
readRecord(String) - Method in class org.broadinstitute.hellbender.utils.tsv.TableReader
Reads the record from a string rather than from the input reader.
reads - Variable in class org.broadinstitute.hellbender.engine.ContextShard
 
reads() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.SubsettedLikelihoodMatrix
 
reads() - Method in interface org.broadinstitute.hellbender.utils.genotyper.LikelihoodMatrix
List of reads in the matrix sorted by their index therein.
READS - Variable in class picard.illumina.ExtractIlluminaBarcodes.BarcodeMetric
The total number of reads matching the barcode.
READS - Variable in class picard.illumina.quality.CollectHiSeqXPfFailMetrics.PFFailSummaryMetric
The total number of reads examined
READS_AFTER_DEDUPLICATION - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterMetrics
The number of reads after deduplication
READS_AFTER_HOST_FILTER - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterMetrics
The number of reads after host read filtering
READS_AFTER_PREALIGNED_HOST_FILTER - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterMetrics
The number of reads after filtering prealigned reads
READS_AFTER_QUALITY_AND_COMPLEXITY_FILTER - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSFilterMetrics
The number of reads after low-quality and low-complexity filtering
READS_ALIGNED - Variable in class picard.analysis.RrbsSummaryMetrics
Number of mapped reads processed
READS_ALIGNED_IN_PAIRS - Variable in class picard.analysis.AlignmentSummaryMetrics
The number of aligned reads whose mate pair was also aligned to the reference.
READS_IGNORED_MISMATCHES - Variable in class picard.analysis.RrbsSummaryMetrics
Number of reads discarded for exceeding the mismatch threshold
READS_IGNORED_SHORT - Variable in class picard.analysis.RrbsSummaryMetrics
Number of reads discarded due to being too short
READS_PER_PARTITION_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqPipelineSpark
 
READS_PER_PARTITION_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqPipelineSpark
 
READS_TO_ALIGN - Variable in class picard.fastq.BamToBfq
 
READS_USED - Variable in class picard.analysis.GcBiasDetailMetrics
This option is used to mark including or excluding duplicates.
READS_USED - Variable in class picard.analysis.GcBiasSummaryMetrics
This option is used to mark including or excluding duplicates.
READS_WITH_NO_CPG - Variable in class picard.analysis.RrbsSummaryMetrics
Number of reads discarded for having no CpG sites
readSampleName(SAMFileHeader) - Static method in class org.broadinstitute.hellbender.tools.copynumber.formats.metadata.MetadataUtils
 
readsBySampleIndex - Variable in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Reads by sample index.
ReadsContext - Class in org.broadinstitute.hellbender.engine
Wrapper around ReadsDataSource that presents reads overlapping a specific interval to a client, without improperly exposing the entire ReadsDataSource interface.
ReadsContext() - Constructor for class org.broadinstitute.hellbender.engine.ReadsContext
Create an empty ReadsContext with no backing data source or interval.
ReadsContext(GATKDataSource<GATKRead>, SimpleInterval) - Constructor for class org.broadinstitute.hellbender.engine.ReadsContext
Create a ReadsContext backed by the supplied source of reads.
ReadsContext(GATKDataSource<GATKRead>, SimpleInterval, ReadFilter) - Constructor for class org.broadinstitute.hellbender.engine.ReadsContext
Create a ReadsContext backed by the supplied source of reads.
ReadsDataSource - Class in org.broadinstitute.hellbender.engine
Manages traversals and queries over sources of reads (for now, SAM/BAM/CRAM files only).
ReadsDataSource(Path) - Constructor for class org.broadinstitute.hellbender.engine.ReadsDataSource
Initialize this data source with a single SAM/BAM file and validation stringency SILENT.
ReadsDataSource(List<Path>) - Constructor for class org.broadinstitute.hellbender.engine.ReadsDataSource
Initialize this data source with multiple SAM/BAM files and validation stringency SILENT.
ReadsDataSource(Path, SamReaderFactory) - Constructor for class org.broadinstitute.hellbender.engine.ReadsDataSource
Initialize this data source with a single SAM/BAM file and a custom SamReaderFactory
ReadsDataSource(List<Path>, SamReaderFactory) - Constructor for class org.broadinstitute.hellbender.engine.ReadsDataSource
Initialize this data source with multiple SAM/BAM files and a custom SamReaderFactory
ReadsDataSource(List<Path>, List<Path>) - Constructor for class org.broadinstitute.hellbender.engine.ReadsDataSource
Initialize this data source with multiple SAM/BAM/CRAM files, and explicit indices for those files.
ReadsDataSource(List<Path>, List<Path>, SamReaderFactory) - Constructor for class org.broadinstitute.hellbender.engine.ReadsDataSource
Initialize this data source with multiple SAM/BAM/CRAM files, explicit indices for those files, and a custom SamReaderFactory.
ReadsDataSource(List<Path>, List<Path>, SamReaderFactory, int, int) - Constructor for class org.broadinstitute.hellbender.engine.ReadsDataSource
Initialize this data source with multiple SAM/BAM/CRAM files, explicit indices for those files, and a custom SamReaderFactory.
ReadsDataSource(List<Path>, List<Path>, SamReaderFactory, Function<SeekableByteChannel, SeekableByteChannel>, Function<SeekableByteChannel, SeekableByteChannel>) - Constructor for class org.broadinstitute.hellbender.engine.ReadsDataSource
Initialize this data source with multiple SAM/BAM/CRAM files, explicit indices for those files, and a custom SamReaderFactory.
ReadsDownsampler - Class in org.broadinstitute.hellbender.utils.downsampling
An extension of the basic downsampler API with reads-specific operations
ReadsDownsampler() - Constructor for class org.broadinstitute.hellbender.utils.downsampling.ReadsDownsampler
 
ReadsDownsamplingIterator - Class in org.broadinstitute.hellbender.utils.downsampling
Iterator wrapper around our generic ReadsDownsampler) interface.
ReadsDownsamplingIterator(Iterator<GATKRead>, ReadsDownsampler) - Constructor for class org.broadinstitute.hellbender.utils.downsampling.ReadsDownsamplingIterator
 
ReadsForQNamesFinder - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
Find > pairs for interesting template names.
ReadsForQNamesFinder(HopscotchUniqueMultiMap<String, Integer, QNameAndInterval>, int, boolean, Iterator<GATKRead>, SVReadFilter) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadsForQNamesFinder
 
readShardPadding - Variable in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerSpark
 
readShardPadding - Variable in class org.broadinstitute.hellbender.engine.spark.LocusWalkerSpark
 
readShardPadding - Variable in class org.broadinstitute.hellbender.engine.spark.ReadWalkerSpark
 
readShardPadding - Variable in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark.ShardingArgumentCollection
 
readShardPadding - Variable in class org.broadinstitute.hellbender.tools.spark.BaseRecalibratorSpark
 
readShardPadding - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.BQSRPipelineSpark
 
readShardSize - Variable in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerSpark
 
readShardSize - Variable in class org.broadinstitute.hellbender.engine.spark.LocusWalkerSpark
 
readShardSize - Variable in class org.broadinstitute.hellbender.engine.spark.ReadWalkerSpark
 
readShardSize - Variable in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark.ShardingArgumentCollection
 
readShardSize - Variable in class org.broadinstitute.hellbender.tools.spark.BaseRecalibratorSpark
 
readShardSize - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.BQSRPipelineSpark
 
ReadsIterable - Class in org.broadinstitute.hellbender.utils.nio
ReadsIterable gives you all the reads for a given genomic interval.
ReadsIterable(String, byte[], QueryInterval) - Constructor for class org.broadinstitute.hellbender.utils.nio.ReadsIterable
 
ReadsKey - Class in org.broadinstitute.hellbender.utils.read.markduplicates
Encodes a unique key for read, read pairs and fragments.
ReadsKey() - Constructor for class org.broadinstitute.hellbender.utils.read.markduplicates.ReadsKey
 
readsPerPartition - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqPipelineSpark
 
readsPerPartitionEstimate - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
This parameter is for fine-tuning memory performance.
readsPerPartitionOutput - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqPipelineSpark
Because numReducers is based on the input size, it causes too many partitions to be produced when the output size is much smaller.
ReadsPipelineSpark - Class in org.broadinstitute.hellbender.tools.spark.pipelines
ReadsPipelineSpark is our standard pipeline that takes unaligned or aligned reads and runs BWA (if specified), MarkDuplicates, BQSR, and HaplotypeCaller.
ReadsPipelineSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.pipelines.ReadsPipelineSpark
 
ReadsPreprocessingPipelineTestData - Class in org.broadinstitute.hellbender.utils.test
ReadsPreprocessingPipelineTestData contains coordinated test data that can be used in the many transforms that are a part of the ReadsPreprocessingPipeline.
ReadsPreprocessingPipelineTestData(Class<?>) - Constructor for class org.broadinstitute.hellbender.utils.test.ReadsPreprocessingPipelineTestData
ReadsPreprocessingPipelineTestData holds a bunch of connected data for testing classes that work with reads, variants, references bases and pairing those types together.
ReadsSparkSink - Class in org.broadinstitute.hellbender.engine.spark.datasources
ReadsSparkSink writes GATKReads to a file.
ReadsSparkSink() - Constructor for class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSink
 
ReadsSparkSink.SparkBAMOutputFormat - Class in org.broadinstitute.hellbender.engine.spark.datasources
 
ReadsSparkSink.SparkCRAMOutputFormat - Class in org.broadinstitute.hellbender.engine.spark.datasources
 
ReadsSparkSink.SparkHeaderlessBAMOutputFormat - Class in org.broadinstitute.hellbender.engine.spark.datasources
 
ReadsSparkSink.SparkHeaderlessCRAMOutputFormat - Class in org.broadinstitute.hellbender.engine.spark.datasources
 
ReadsSparkSink.SparkHeaderlessSAMOutputFormat - Class in org.broadinstitute.hellbender.engine.spark.datasources
 
ReadsSparkSink.SparkSAMOutputFormat - Class in org.broadinstitute.hellbender.engine.spark.datasources
 
ReadsSparkSource - Class in org.broadinstitute.hellbender.engine.spark.datasources
Loads the reads from disk either serially (using samReaderFactory) or in parallel using Hadoop-BAM.
ReadsSparkSource(JavaSparkContext) - Constructor for class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSource
 
ReadsSparkSource(JavaSparkContext, ValidationStringency) - Constructor for class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSource
 
readsTaken() - Method in class org.broadinstitute.hellbender.utils.read.ArtificialReadIterator
some instrumentation methods
readStartsWithInsertion(Cigar) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
readStartsWithInsertion(Cigar, boolean) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
readStartsWithInsertion(List<CigarElement>, boolean) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Checks if a read starts with an insertion.
ReadStrandFilter - Class in org.broadinstitute.hellbender.engine.filters
Keep only reads whose strand is either forward (not 0x10) or reverse (0x10), as specified.
ReadStrandFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadStrandFilter
 
ReadStrandFilter(boolean) - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadStrandFilter
 
readStreamIntoByteArray(InputStream, int) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
Reads all data from the given stream into a byte array using the requested read buffer size.
ReadStructure - Class in picard.illumina.parser
Describes the intended logical output structure of clusters of an Illumina run.
ReadStructure(List<ReadDescriptor>) - Constructor for class picard.illumina.parser.ReadStructure
Copies collection into descriptors (making descriptors unmodifiable) and then calculates relevant statistics about descriptors.
ReadStructure(String) - Constructor for class picard.illumina.parser.ReadStructure
Converts readStructureString into a List and calls the primary constructor using this List as it's argument.
ReadStructure.Substructure - Class in picard.illumina.parser
Represents a subset of ReadDescriptors in the containing ReadStructure, they ARE NOT necessarily contiguous in the containing ReadStructure but they ARE in the order they appear in the containing ReadStructure
ReadsWriteFormat - Enum in org.broadinstitute.hellbender.utils.read
Possible output formats when writing reads.
readTaxonomyDatabase(String) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScorer
Reads taxonomy database that has been serialized to a file
ReadThreadingAssembler - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading
 
ReadThreadingAssembler(int, List<Integer>, boolean, boolean, int) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingAssembler
 
ReadThreadingAssemblerArgumentCollection - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
Set of arguments related to the ReadThreadingAssembler
ReadThreadingAssemblerArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadThreadingAssemblerArgumentCollection
 
ReadThreadingGraph - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading
Note: not final but only intendent to be subclassed for testing.
ReadThreadingGraph(int) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingGraph
Constructs an empty read-threading-grpah provided the kmerSize.
ReadThreadingGraph(int, EdgeFactory<MultiDeBruijnVertex, MultiSampleEdge>) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingGraph
Constructs a read-threading-graph for a string representation.
readToAlignmentByteArray(Cigar, byte[]) - Static method in class org.broadinstitute.hellbender.utils.read.AlignmentUtils
Generate an array of bases for just those that are aligned to the reference (i.e.
readToFastqSeqId(GATKRead, boolean) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils
Convert a read's name into a FASTQ record sequence ID
readTranches(File) - Static method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VQSLODTranche
Returns a list of tranches, sorted from most to least specific, read in from file f.
ReadTransformer - Interface in org.broadinstitute.hellbender.transformers
Classes which perform transformations from GATKRead -> GATKRead should implement this interface by overriding SerializableFunction#apply(GATKRead)
ReadTransformerSparkifier - Class in org.broadinstitute.hellbender.tools.spark.utils
 
ReadTransformerSparkifier(ReadTransformer) - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.ReadTransformerSparkifier
 
ReadTransformingIterator - Class in org.broadinstitute.hellbender.utils.iterators
An iterator that transforms read (i.e.
ReadTransformingIterator(Iterator<GATKRead>, ReadTransformer) - Constructor for class org.broadinstitute.hellbender.utils.iterators.ReadTransformingIterator
Create a ReadFilteringIterator given a pre-existing iterator of reads and a read filter.
readTrimThresh - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
Controls the stingency of base call quality-based read trimming.
readTwoBarcode - Variable in class picard.sam.markduplicates.util.ReadEndsForMarkDuplicatesWithBarcodes
 
ReadType - Enum in picard.illumina.parser
A read type describes a stretch of cycles in an ReadStructure (e.g.
ReadUtils - Class in org.broadinstitute.hellbender.utils.read
A miscellaneous collection of utilities for working with reads, headers, etc.
ReadUtils.ClippingTail - Enum in org.broadinstitute.hellbender.utils.read
A marker to tell which end of the read has been clipped
readValidationStringency - Variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.ReadInputArgumentCollection
 
readValidationStringency - Variable in class org.broadinstitute.hellbender.tools.spark.CreateHadoopBamSplittingIndex
 
readValuesFromFile(File) - Static method in class org.broadinstitute.hellbender.utils.param.ParamUtils
Reads a double array from the given filename.
ReadWalker - Class in org.broadinstitute.hellbender.engine
A ReadWalker is a tool that processes a single read at a time from one or multiple sources of reads, with optional contextual information from a reference and/or sets of variants/Features.
ReadWalker() - Constructor for class org.broadinstitute.hellbender.engine.ReadWalker
 
ReadWalkerContext - Class in org.broadinstitute.hellbender.engine.spark
Encapsulates an GATKRead with its ReferenceContext and FeatureContext.
ReadWalkerContext(GATKRead, ReferenceContext, FeatureContext) - Constructor for class org.broadinstitute.hellbender.engine.spark.ReadWalkerContext
 
ReadWalkerSpark - Class in org.broadinstitute.hellbender.engine.spark
A Spark version of ReadWalker.
ReadWalkerSpark() - Constructor for class org.broadinstitute.hellbender.engine.spark.ReadWalkerSpark
 
realign(GATKRead) - Method in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.RealignmentEngine
 
realignmentArgumentCollection - Variable in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.FilterAlignmentArtifacts
 
RealignmentArgumentCollection - Class in org.broadinstitute.hellbender.tools.walkers.realignmentfilter
 
RealignmentArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.RealignmentArgumentCollection
 
RealignmentEngine - Class in org.broadinstitute.hellbender.tools.walkers.realignmentfilter
 
RealignmentEngine(RealignmentArgumentCollection) - Constructor for class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.RealignmentEngine
 
RealignmentEngine.RealignmentResult - Class in org.broadinstitute.hellbender.tools.walkers.realignmentfilter
 
RealignmentResult(boolean, List<BwaMemAlignment>) - Constructor for class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.RealignmentEngine.RealignmentResult
 
realignReadsToTheirBestHaplotype(ReadLikelihoods<Haplotype>, Haplotype, Locatable, SmithWatermanAligner) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerUtils
Returns a map with the original read as a key and the realigned read as the value.
reallyFilterOut(SAMRecord) - Method in class picard.filter.CountingDuplicateFilter
 
reallyFilterOut(SAMRecord) - Method in class picard.filter.CountingFilter
Return true if we are to filter this record out, false otherwise.
reallyFilterOut(SAMRecord) - Method in class picard.filter.CountingMapQFilter
 
reallyFilterOut(SAMRecord) - Method in class picard.filter.CountingPairedFilter
 
RECAL_FILE - Static variable in class org.broadinstitute.hellbender.utils.report.GATKReport
 
RecalDatum - Class in org.broadinstitute.hellbender.utils.recalibration
An individual piece of recalibration data.
RecalDatum(long, double, byte) - Constructor for class org.broadinstitute.hellbender.utils.recalibration.RecalDatum
Create a new RecalDatum with given observation and mismatch counts, and an reported quality
RecalDatum(RecalDatum) - Constructor for class org.broadinstitute.hellbender.utils.recalibration.RecalDatum
Copy copy into this recal datum, overwriting all of this objects data
RecalibrationArgumentCollection - Class in org.broadinstitute.hellbender.utils.recalibration
A collection of the arguments that are used for BQSR.
RecalibrationArgumentCollection() - Constructor for class org.broadinstitute.hellbender.utils.recalibration.RecalibrationArgumentCollection
 
RecalibrationReport - Class in org.broadinstitute.hellbender.utils.recalibration
This class has all the static functionality for reading a recalibration report file into memory.
RecalibrationReport(File) - Constructor for class org.broadinstitute.hellbender.utils.recalibration.RecalibrationReport
 
RecalibrationReport(InputStream) - Constructor for class org.broadinstitute.hellbender.utils.recalibration.RecalibrationReport
 
RecalibrationReport(GATKReport) - Constructor for class org.broadinstitute.hellbender.utils.recalibration.RecalibrationReport
 
RecalibrationReport(GATKReport, SortedSet<String>) - Constructor for class org.broadinstitute.hellbender.utils.recalibration.RecalibrationReport
 
RecalibrationTables - Class in org.broadinstitute.hellbender.utils.recalibration
Utility class to facilitate base quality score recalibration.
RecalibrationTables(StandardCovariateList) - Constructor for class org.broadinstitute.hellbender.utils.recalibration.RecalibrationTables
 
RecalibrationTables(StandardCovariateList, int) - Constructor for class org.broadinstitute.hellbender.utils.recalibration.RecalibrationTables
 
RecalUtils - Class in org.broadinstitute.hellbender.utils.recalibration
This helper class holds the data HashMap as well as submaps that represent the marginal distributions collapsed over all needed dimensions.
RecalUtils() - Constructor for class org.broadinstitute.hellbender.utils.recalibration.RecalUtils
 
reciprocialOverlapFraction(GenomeLoc) - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
reciprocialOverlap: what is the min.
reclipCigar(Cigar, GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.CigarUtils
Given a cigar1 and a read with cigar2, this method creates cigar3 such that it has flanking clip operators from cigar2 and it has all operators from cigar1 in the middle.
reConstructContigFromPickedConfiguration(Tuple2<Tuple2<String, byte[]>, List<AssemblyContigAlignmentsConfigPicker.GoodAndBadMappings>>) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigAlignmentsConfigPicker
Reconstructs (possibly more than one) AlignedContig based on the given best-scored configuration(s) in nameSeqAndBestConfigurationsOfOneAssemblyContig.
recordAllValuesInStorage(GATKRead, SAMFileHeader, ReadCovariates, boolean) - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.StandardCovariateList
For each covariate compute the values for all positions in this read and record the values in the provided storage object.
RECORDS_ONLY - Variable in class picard.sam.ViewSam
 
recordValues(GATKRead, SAMFileHeader, ReadCovariates, boolean) - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.ContextCovariate
 
recordValues(GATKRead, SAMFileHeader, ReadCovariates, boolean) - Method in interface org.broadinstitute.hellbender.utils.recalibration.covariates.Covariate
Calculates covariate values for all positions in the read.
recordValues(GATKRead, SAMFileHeader, ReadCovariates, boolean) - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.CycleCovariate
 
recordValues(GATKRead, SAMFileHeader, ReadCovariates, boolean) - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.QualityScoreCovariate
 
recordValues(GATKRead, SAMFileHeader, ReadCovariates, boolean) - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.ReadGroupCovariate
 
recoverDanglingHeads(int, int, SmithWatermanAligner) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingGraph
Try to recover dangling heads
recoverDanglingTails(int, int, SmithWatermanAligner) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingGraph
Try to recover dangling tails
reduce(FindBreakpointEvidenceSpark.IntPair, FindBreakpointEvidenceSpark.IntPair) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.FindBreakpointEvidenceSpark.IntPair
 
reduce(ReadMetadata.LibraryRawStatistics, ReadMetadata.LibraryRawStatistics) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.LibraryRawStatistics
 
REDUCED_DELIM - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RankSumTest
 
REDUCED_DELIM - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_StrandBiasTest
 
ReducibleAnnotation - Interface in org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific
An interface for annotations that are calculated using raw data across samples, rather than the median (or median of median) of samples values
ReducibleAnnotationData<T> - Class in org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific
A class to encapsulate the raw data for classes compatible with the ReducibleAnnotation interface
ReducibleAnnotationData(String) - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.ReducibleAnnotationData
Create a new ReducibleAnnotationData using the raw data string from a VCF
REF - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
ref() - Method in enum org.broadinstitute.hellbender.utils.artifacts.Transition
 
ref() - Method in enum picard.analysis.artifacts.Transition
Gets the reference for the transition.
REF_BASE - Variable in class picard.analysis.artifacts.ErrorSummaryMetrics
The reference base (or it's complement).
REF_BASE - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasDetailMetrics
The (upper-case) original base on the reference strand.
REF_BASE - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasSummaryMetrics
The (upper-case) original base on the reference strand.
REF_BASE - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterDetailMetrics
The (upper-case) original base on the reference strand.
REF_BASE - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterSummaryMetrics
The (upper-case) original base on the reference strand.
REF_COUNT - Variable in class picard.analysis.artifacts.ErrorSummaryMetrics
The number of reference bases observed.
REF_FLAT - Variable in class picard.analysis.CollectRnaSeqMetrics
 
REF_NONOXO_BASES - Variable in class picard.analysis.CollectOxoGMetrics.CpcgMetrics
The number of reference alleles observed as C in read 1 and G in read 2.
REF_OXO_BASES - Variable in class picard.analysis.CollectOxoGMetrics.CpcgMetrics
The number of reference alleles observed as G in read 1 and C in read 2.
REF_RECORD_LEN - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.evidence.FindBadGenomicKmersSpark
 
REF_RECORDS_PER_PARTITION - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.evidence.FindBadGenomicKmersSpark
 
REF_TOTAL_BASES - Variable in class picard.analysis.CollectOxoGMetrics.CpcgMetrics
The total number of reference alleles observed
refactorNDNtoN(Cigar) - Static method in class org.broadinstitute.hellbender.transformers.NDNCigarReadTransformer
Refactor cigar strings that contain N-D-N elements to one N element (with total length of the three refactored elements).
refBases - Variable in class org.broadinstitute.hellbender.utils.baq.BAQ.BAQCalculationResult
 
reference - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildKmers
 
reference - Variable in class org.broadinstitute.hellbender.tools.walkers.rnaseq.OverhangFixingManager.Splice
 
REFERENCE - Variable in class picard.analysis.CollectRrbsMetrics.CollectRrbsMetricsReferenceArgumentCollection
 
REFERENCE - Variable in class picard.sam.CreateSequenceDictionary.CreateSeqDictReferenceArgumentCollection
 
REFERENCE - Variable in class picard.sam.ReorderSam.ReorderSamReferenceArgumentCollection
 
REFERENCE - Variable in class picard.util.ScatterIntervalsByNs.ScatterIntervalsByNReferenceArgumentCollection
 
REFERENCE_BASES_KEY - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.ReferenceBases
 
REFERENCE_GENOTYPE_QUALITY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
REFERENCE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
REFERENCE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildKmers
 
REFERENCE_SEQUENCE - Variable in class org.broadinstitute.hellbender.cmdline.PicardCommandLineProgram
 
REFERENCE_SEQUENCE - Variable in class picard.analysis.CollectAlignmentSummaryMetrics.CollectAlignmentRefArgCollection
 
REFERENCE_SEQUENCE - Variable in class picard.cmdline.argumentcollections.OptionalReferenceArgumentCollection
 
REFERENCE_SEQUENCE - Variable in class picard.cmdline.argumentcollections.RequiredReferenceArgumentCollection
 
REFERENCE_SEQUENCE - Variable in class picard.cmdline.CommandLineProgram
 
REFERENCE_SHARD_SIZE - Static variable in class org.broadinstitute.hellbender.engine.ReferenceShard
 
REFERENCE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
REFERENCE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildKmers
 
REFERENCE_SHORT_NAME - Static variable in class picard.cmdline.StandardOptionDefinitions
 
REFERENCE_VERSION_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorArgumentDefinitions
 
referenceAlleleMatchesReferenceForIndel(List<Allele>, ReferenceSequence, int, int) - Static method in class picard.util.LiftoverUtils
Checks whether the reference allele in the provided variant context actually matches the reference sequence
ReferenceArgumentCollection - Interface in picard.cmdline.argumentcollections
Base interface for a reference argument collection.
referenceArguments - Variable in class org.broadinstitute.hellbender.engine.GATKTool
 
referenceArguments - Variable in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
 
referenceArguments - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildReferenceTaxonomy
 
ReferenceBases - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Local reference context at a variant position.
ReferenceBases() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.ReferenceBases
 
ReferenceBases - Class in org.broadinstitute.hellbender.utils.reference
ReferenceBases stores the bases of the reference genome for a particular interval.
ReferenceBases(byte[], SimpleInterval) - Constructor for class org.broadinstitute.hellbender.utils.reference.ReferenceBases
 
ReferenceConfidenceMode - Enum in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
Reference confidence emission modes.
ReferenceConfidenceModel - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller
Code for estimating the reference confidence This code can estimate the probability that the data for a single sample is consistent with a well-determined REF/REF diploid genotype.
ReferenceConfidenceModel(SampleList, SAMFileHeader, int, int) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReferenceConfidenceModel
Create a new ReferenceConfidenceModel
ReferenceConfidenceVariantContextMerger - Class in org.broadinstitute.hellbender.tools.walkers
Variant context utilities related to merging variant-context instances.
ReferenceConfidenceVariantContextMerger(VariantAnnotatorEngine, VCFHeader) - Constructor for class org.broadinstitute.hellbender.tools.walkers.ReferenceConfidenceVariantContextMerger
 
ReferenceConfidenceVariantContextMerger.VCWithNewAlleles - Class in org.broadinstitute.hellbender.tools.walkers
 
ReferenceContext - Class in org.broadinstitute.hellbender.engine
Wrapper around ReferenceDataSource that presents data from a specific interval/window to a client, without improperly exposing the entire ReferenceDataSource interface.
ReferenceContext() - Constructor for class org.broadinstitute.hellbender.engine.ReferenceContext
Create a ReferenceContext with no backing data source.
ReferenceContext(ReferenceDataSource, SimpleInterval) - Constructor for class org.broadinstitute.hellbender.engine.ReferenceContext
Create a windowless ReferenceContext set up to lazily query the bases spanning just the provided interval (with no extra bases of context)
ReferenceContext(ReferenceDataSource, SimpleInterval, int, int) - Constructor for class org.broadinstitute.hellbender.engine.ReferenceContext
Create a windowed ReferenceContext set up to lazily query the provided interval, expanded by the specified number of bases in each direction.
ReferenceContext(ReferenceDataSource, SimpleInterval, SimpleInterval) - Constructor for class org.broadinstitute.hellbender.engine.ReferenceContext
Create a windowed ReferenceContext set up to lazily query the provided interval, expanded by the specified number of bases in each direction.
ReferenceDataSource - Interface in org.broadinstitute.hellbender.engine
Manages traversals and queries over reference data.
ReferenceDiploidExactAFCalculator - Class in org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc
Reference implementation of multi-allelic EXACT model.
ReferenceDiploidExactAFCalculator() - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.ReferenceDiploidExactAFCalculator
 
referenceFasta - Variable in class org.broadinstitute.hellbender.utils.read.mergealignment.AbstractAlignmentMerger
 
referenceFasta - Variable in class picard.sam.AbstractAlignmentMerger
 
ReferenceFileSource - Class in org.broadinstitute.hellbender.engine.datasources
Class to load a reference sequence from a fasta file.
ReferenceFileSource(String) - Constructor for class org.broadinstitute.hellbender.engine.datasources.ReferenceFileSource
 
ReferenceFileSource(Path) - Constructor for class org.broadinstitute.hellbender.engine.datasources.ReferenceFileSource
 
ReferenceFileSource - Class in org.broadinstitute.hellbender.engine
Manages traversals and queries over reference data (for now, fasta files only) Supports targeted queries over the reference by interval, but does not yet support complete iteration over the entire reference.
ReferenceFileSource(Path) - Constructor for class org.broadinstitute.hellbender.engine.ReferenceFileSource
Initialize this data source using a fasta file.
ReferenceFileSource(Path, boolean) - Constructor for class org.broadinstitute.hellbender.engine.ReferenceFileSource
Initialize this data source using a fasta file.
ReferenceHadoopSource - Class in org.broadinstitute.hellbender.engine.datasources
Class to load a reference sequence from a fasta file on HDFS.
ReferenceHadoopSource(String) - Constructor for class org.broadinstitute.hellbender.engine.datasources.ReferenceHadoopSource
 
ReferenceInputArgumentCollection - Class in org.broadinstitute.hellbender.cmdline.argumentcollections
An abstract ArgumentCollection for specifying a reference sequence file
ReferenceInputArgumentCollection() - Constructor for class org.broadinstitute.hellbender.cmdline.argumentcollections.ReferenceInputArgumentCollection
 
ReferenceMemorySource - Class in org.broadinstitute.hellbender.engine
Manages traversals and queries over in-memory reference data.
ReferenceMemorySource(ReferenceBases, SAMSequenceDictionary) - Constructor for class org.broadinstitute.hellbender.engine.ReferenceMemorySource
Initialize this data source using ReferenceBases and corresponding sequence dictionary.
ReferenceMultiSource - Class in org.broadinstitute.hellbender.engine.datasources
Wrapper to load a reference sequence from the Google Genomics API, or a file stored on HDFS or locally.
ReferenceMultiSource() - Constructor for class org.broadinstitute.hellbender.engine.datasources.ReferenceMultiSource
 
ReferenceMultiSource(String, SerializableFunction<GATKRead, SimpleInterval>) - Constructor for class org.broadinstitute.hellbender.engine.datasources.ReferenceMultiSource
 
ReferenceMultiSourceAdapter(ReferenceMultiSource) - Constructor for class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark.ReferenceMultiSourceAdapter
 
referencePath - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBwaArgumentCollection
 
ReferenceProgramGroup - Class in picard.cmdline.programgroups
Tools that analyze and manipulate FASTA format references
ReferenceProgramGroup() - Constructor for class picard.cmdline.programgroups.ReferenceProgramGroup
 
referenceSampleName - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.UnifiedArgumentCollection
 
referenceSampleRod - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.UnifiedArgumentCollection
 
referenceSequence - Variable in class picard.cmdline.CommandLineProgram
 
ReferenceShard - Class in org.broadinstitute.hellbender.engine
ReferenceShard is section of the reference genome that's used for sharding work for pairing things with the reference.
ReferenceShard(int, String) - Constructor for class org.broadinstitute.hellbender.engine.ReferenceShard
 
ReferenceSource - Interface in org.broadinstitute.hellbender.engine.datasources
Internal interface to load a reference sequence.
referenceSpan - Variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
 
ReferenceTwoBitSource - Class in org.broadinstitute.hellbender.engine.spark.datasources
A ReferenceSource impl that is backed by a .2bit representation of a reference genome.
ReferenceTwoBitSource(String) - Constructor for class org.broadinstitute.hellbender.engine.spark.datasources.ReferenceTwoBitSource
 
ReferenceUtils - Class in org.broadinstitute.hellbender.utils.reference
A collection of static methods for dealing with references.
referenceVersion - Variable in class org.broadinstitute.hellbender.tools.funcotator.Funcotator
 
ReferenceWindowFunctions - Class in org.broadinstitute.hellbender.engine.datasources
A library of reference window functions suitable for passing in to transforms such as AddContextDataToRead.
ReferenceWindowFunctions() - Constructor for class org.broadinstitute.hellbender.engine.datasources.ReferenceWindowFunctions
 
ReferenceWindowFunctions.FixedWindowFunction - Class in org.broadinstitute.hellbender.engine.datasources
A function for requesting a fixed number of extra bases of reference context on either side of each read.
RefFlatReader - Class in picard.annotation
Loads gene annotations from a refFlat file into an OverlapDetector.
RefFlatReader.RefFlatColumns - Enum in picard.annotation
 
ReflectionUtil - Class in picard.util
Class which contains utility functions that use reflection.
ReflectionUtil() - Constructor for class picard.util.ReflectionUtil
 
reflectiveCopy(TargetMetrics, MT, String[], String[]) - Static method in class picard.analysis.directed.TargetMetricsCollector
Since the targeted metrics (HsMetrics, TargetedPcrMetrics,...) share many of the same values as TargetMetrics, this copy will copy all public attributes in targetMetrics to the outputMetrics' attributes of the same name.
REFSAMPLE_DEPTH_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
REFSEQ_CATALOG_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildReferenceTaxonomy
 
REFSEQ_CATALOG_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildReferenceTaxonomy
 
refseqCatalogPath - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildReferenceTaxonomy
 
regionStartLoc - Variable in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfile
 
regionStopLoc - Variable in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfile
 
regionWithHigherCoordOnContig - Variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SimpleChimera
 
regionWithLowerCoordOnContig - Variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SimpleChimera
 
registerClasses(Kryo) - Method in class org.broadinstitute.hellbender.engine.spark.GATKRegistrator
 
REJECT - Variable in class picard.util.LiftOverIntervalList
 
REJECT - Variable in class picard.vcf.LiftoverVcf
 
remap(Allele) - Method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils.AlleleMapper
 
remap(List<Allele>) - Method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils.AlleleMapper
 
remapAlleles(VariantContext, Allele) - Static method in class org.broadinstitute.hellbender.tools.walkers.ReferenceConfidenceVariantContextMerger
This method does a couple of things: remaps the vc alleles considering the differences between the final reference allele and its own reference, collects alternative alleles present in variant context and add them to the finalAlleles set.
remove() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegionIterator
 
remove() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.PairedStrandedIntervalTree.PairedStrandedIntervalTreeIterator
 
remove() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.PairedStrandedIntervalTree.PairedStrandedIntervalTreeOverlapperIterator
 
remove(SVInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree
Remove an interval from the tree.
remove() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree.ValuesIterator
 
remove(Object) - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchCollection
 
remove(long) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LargeLongHopscotchSet
 
remove(long) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongHopscotchSet
 
remove(long, int) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongHopscotchSet
 
remove() - Method in interface org.broadinstitute.hellbender.tools.spark.utils.LongIterator
 
remove(Object) - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
 
remove(int) - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
Removes a single integer value for the set.
remove(Object) - Method in class org.broadinstitute.hellbender.utils.collections.IndexedSet
Removes an element from the set.
remove() - Method in class org.broadinstitute.hellbender.utils.downsampling.ReadsDownsamplingIterator
 
remove(GenomeLoc) - Method in class org.broadinstitute.hellbender.utils.GenomeLocSortedSet
a simple removal of an interval contained in this list.
remove() - Method in class org.broadinstitute.hellbender.utils.iterators.AllLocusIterator
 
remove() - Method in class org.broadinstitute.hellbender.utils.iterators.ReadCachingIterator
 
remove() - Method in class org.broadinstitute.hellbender.utils.read.ArtificialReadIterator
 
remove(int, String) - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.DiskBasedReadEndsForMarkDuplicatesMap
 
remove(int, String) - Method in interface org.broadinstitute.hellbender.utils.read.markduplicates.ReadEndsForMarkDuplicatesMap
Remove element with given key from the map.
remove() - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.MultiHitAlignedReadIterator
Unsupported operation.
remove() - Method in class org.broadinstitute.hellbender.utils.text.XReadLines
 
remove() - Method in class picard.illumina.parser.IlluminaDataProvider
 
remove() - Method in class picard.illumina.parser.MultiTileParser
 
remove() - Method in class picard.illumina.parser.PerTileParser
 
remove() - Method in class picard.illumina.parser.readers.AbstractIlluminaPositionFileReader
 
remove() - Method in class picard.illumina.parser.readers.BarcodeFileReader
 
remove() - Method in class picard.illumina.parser.readers.BclReader
 
remove() - Method in class picard.illumina.parser.readers.FilterFileReader
 
remove() - Method in class picard.illumina.parser.readers.TileMetricsOutReader
 
remove() - Method in class picard.sam.markduplicates.MarkDuplicatesWithMateCigarIterator
 
remove(int, String) - Method in class picard.sam.markduplicates.util.DiskBasedReadEndsForMarkDuplicatesMap
 
remove(ReadEndsForMateCigar) - Method in class picard.sam.markduplicates.util.PhysicalLocationForMateCigarSet
Removes the end from this set, if present
remove(int, String) - Method in interface picard.sam.markduplicates.util.ReadEndsForMarkDuplicatesMap
Remove element with given key from the map.
remove() - Method in class picard.util.AsyncIterator
 
remove() - Method in class picard.util.DelimitedTextFileWithHeaderIterator
 
remove() - Method in class picard.vcf.ByIntervalListVariantContextIterator
 
remove() - Method in class picard.vcf.filter.FilterApplyingVariantIterator
 
remove() - Method in class picard.vcf.PairedVariantSubContextIterator
 
remove() - Method in class picard.vcf.processor.util.PredicateFilterDecoratingClosableIterator
 
REMOVE_ALIGNMENT_INFORMATION - Variable in class picard.sam.RevertSam
 
REMOVE_DUPLICATE_INFORMATION - Variable in class picard.sam.PositionBasedDownsampleSam
 
REMOVE_DUPLICATE_INFORMATION - Variable in class picard.sam.RevertSam
 
REMOVE_DUPLICATES - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.AbstractMarkDuplicatesCommandLineProgram
 
REMOVE_DUPLICATES - Variable in class picard.sam.markduplicates.util.AbstractMarkDuplicatesCommandLineProgram
 
REMOVE_FILTERED_VARIANTS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorArgumentDefinitions
 
REMOVE_SEQUENCING_DUPLICATES - Variable in class picard.sam.markduplicates.MarkDuplicates
 
removeAll(Collection<GATKRead>) - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
Remove all of the reads in readsToRemove from this region
removeAll(Collection<?>) - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchCollection
unlike the AbstractCollection implementation, this one iterates over the supplied collection
removeAll(long[]) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LargeLongHopscotchSet
 
removeAll(LongHopscotchSet) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongHopscotchSet
 
removeAll(long[]) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongHopscotchSet
 
removeAll(Collection<?>) - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
 
removeChild(int) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTreeNode
 
removeEach(Object) - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchCollection
remove each of the elements equivalent to the key
removeEldestEntry(Map.Entry<K, V>) - Method in class org.broadinstitute.hellbender.utils.LRUCache
 
removeFilteredVariants - Variable in class org.broadinstitute.hellbender.tools.funcotator.Funcotator
 
removeIncompleteTrios() - Method in class picard.pedigree.PedFile
Scans through the pedigrees and removes all entries that do not have both paternal and maternal ids set.
removeLocationSet() - Method in class picard.sam.markduplicates.util.ReadEndsForMateCigar
 
RemoveNearbyIndels - Class in org.broadinstitute.hellbender.tools.walkers.validation
Remove indels that are close to another indel from a vcf file.
RemoveNearbyIndels() - Constructor for class org.broadinstitute.hellbender.tools.walkers.validation.RemoveNearbyIndels
 
removeNonUniqueMappings(AssemblyContigWithFineTunedAlignments, int, int) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigAlignmentsConfigPicker
Process provided originalConfiguration of an assembly contig and split between good and bad alignments.
removePathsNotConnectedToRef() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Remove all vertices in the graph that aren't on a path from the reference source vertex to the reference sink vertex More aggressive reference pruning algorithm than removeVerticesNotConnectedToRefRegardlessOfEdgeDirection, as it requires vertices to not only be connected by a series of directed edges but also prunes away paths that do not also meet eventually with the reference sink vertex
removePLsAndAD(Genotype) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
 
removeSampleReads(int, Collection<GATKRead>, int) - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
 
removeShadowedContigs - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
removeSingletonOrphanVertices() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Remove all vertices in the graph that have in and out degree of 0
removeSingletonOrphanVertices() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingGraph
 
removeStaleAttributesAfterMerge(Map<String, Object>) - Static method in class org.broadinstitute.hellbender.tools.walkers.ReferenceConfidenceVariantContextMerger
Remove the stale attributes from the merged set
removeTag(GATKRead) - Method in class org.broadinstitute.hellbender.utils.SATagBuilder
Method that removes all SATag units from the list corresponding to the provided read based on start location
removeTag(SATagBuilder) - Method in class org.broadinstitute.hellbender.utils.SATagBuilder
Method that removes all SATag units from the list corresponding to the provided read based on start location
removeTag(String, int) - Method in class org.broadinstitute.hellbender.utils.SATagBuilder
Method that searches supplementaryReads for every read matching contig and start and removes them from the list.
removeTrailingDeletions(Cigar) - Static method in class org.broadinstitute.hellbender.utils.read.AlignmentUtils
Removing a trailing deletion from the incoming cigar if present
removeUnreachableNodes() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTree
Deletes nodes unreachable from the root and returns the set of deleted nodes.
removeVertex(MultiDeBruijnVertex) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingGraph
 
removeVerticesNotConnectedToRefRegardlessOfEdgeDirection() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Remove all vertices on the graph that cannot be accessed by following any edge, regardless of its direction, from the reference source vertex
RenameSampleInVcf - Class in picard.vcf
Renames a sample within a VCF or BCF.
RenameSampleInVcf() - Constructor for class picard.vcf.RenameSampleInVcf
 
renderPhasingMetricsFilesFromBasecallingDirectory(File) - Static method in class picard.illumina.parser.TileMetricsUtil
 
renderSamFileHeader() - Method in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvLocatableTableCodec
Create a SAM File Header from the preamble.
renderTileMetricsFileFromBasecallingDirectory(File, boolean) - Static method in class picard.illumina.parser.TileMetricsUtil
Returns the path to the TileMetrics file given the basecalling directory.
ReorderSam - Class in picard.sam
Reorders a SAM/BAM input file according to the order of contigs in a second reference file.
ReorderSam() - Constructor for class picard.sam.ReorderSam
 
ReorderSam.ReorderSamReferenceArgumentCollection - Class in picard.sam
 
ReorderSamReferenceArgumentCollection() - Constructor for class picard.sam.ReorderSam.ReorderSamReferenceArgumentCollection
 
repairSupplementaryTags(List<GATKRead>, SAMFileHeader) - Static method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.SplitNCigarReads
A method that repairs the NH and NM tags for a group of reads
REPEAT_TOLERANCE - Variable in class picard.util.BaitDesigner
 
REPEAT_UNIT_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
repeatBytes(byte, int) - Static method in class org.broadinstitute.hellbender.utils.Utils
makes an array filled with n copies of the given byte.
repeatChars(char, int) - Static method in class org.broadinstitute.hellbender.utils.Utils
makes an array filled with n copies of the given char.
REPEATS_PER_ALLELE_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
replace(ReadEndsForMateCigar, ReadEndsForMateCigar) - Method in class picard.sam.markduplicates.util.PhysicalLocationForMateCigarSet
Replaces a given end with the other end.
REPLACE_ARGUMENT_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.variantutils.UpdateVCFSequenceDictionary
 
replaceClumpedEventsWithBlockSubstitutions() - Method in class org.broadinstitute.hellbender.utils.haplotype.EventMap
 
replaceExtension(String, String) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
 
replaceExtension(File, String) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
 
ReplaceSamHeader - Class in picard.sam
 
ReplaceSamHeader() - Constructor for class picard.sam.ReplaceSamHeader
 
replicationRateFromReplicateSets - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
reportMemoryStats - Variable in class org.broadinstitute.hellbender.tools.walkers.markduplicates.MarkDuplicatesGATK
 
RepresentativeReadIndexer - Class in picard.sam.util
Little struct-like class to hold a record index, the index of the corresponding representative read, and duplicate set size information.
RepresentativeReadIndexer() - Constructor for class picard.sam.util.RepresentativeReadIndexer
 
RepresentativeReadIndexerCodec - Class in picard.sam.markduplicates.util
Codec for read names and integers that outputs the primitive fields and reads them back.
RepresentativeReadIndexerCodec() - Constructor for class picard.sam.markduplicates.util.RepresentativeReadIndexerCodec
 
representativeReadIndexInFile - Variable in class picard.sam.util.RepresentativeReadIndexer
 
requestedAlleleFrequencyCalculationModel - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.StandardCallerArgumentCollection
Controls the model used to calculate the probability that a site is variant plus the various sample genotypes in the data at a given locus.
Require2BitReferenceForBroadcast() - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.Require2BitReferenceForBroadcast
 
REQUIRE_INDEX - Variable in class picard.vcf.VcfFormatConverter
 
RequiredFeatureInputArgumentCollection - Class in org.broadinstitute.hellbender.cmdline.argumentcollections
An argument collection for use with tools that accept one or more input files containing Feature records (eg., BED files, hapmap files, etc.), and require at least one such input.
RequiredFeatureInputArgumentCollection() - Constructor for class org.broadinstitute.hellbender.cmdline.argumentcollections.RequiredFeatureInputArgumentCollection
 
RequiredIntervalArgumentCollection - Class in org.broadinstitute.hellbender.cmdline.argumentcollections
An ArgumentCollection that requires one or more intervals be specified with -L at the command line
RequiredIntervalArgumentCollection() - Constructor for class org.broadinstitute.hellbender.cmdline.argumentcollections.RequiredIntervalArgumentCollection
 
RequiredReadInputArgumentCollection - Class in org.broadinstitute.hellbender.cmdline.argumentcollections
An argument collection for use with tools that accept one or more input files containing reads (eg., BAM/SAM/CRAM files), and require at least one such input.
RequiredReadInputArgumentCollection() - Constructor for class org.broadinstitute.hellbender.cmdline.argumentcollections.RequiredReadInputArgumentCollection
 
RequiredReferenceArgumentCollection - Class in picard.cmdline.argumentcollections
Argument collection for references that are required (and not common).
RequiredReferenceArgumentCollection() - Constructor for class picard.cmdline.argumentcollections.RequiredReferenceArgumentCollection
 
RequiredReferenceInputArgumentCollection - Class in org.broadinstitute.hellbender.cmdline.argumentcollections
An argument collection for use with tools that require a reference file as input.
RequiredReferenceInputArgumentCollection() - Constructor for class org.broadinstitute.hellbender.cmdline.argumentcollections.RequiredReferenceInputArgumentCollection
 
RequiredVariantInputArgumentCollection - Class in org.broadinstitute.hellbender.cmdline.argumentcollections
An argument collection for use with tools that accept one or more input files containing VariantContext records (eg., VCF files), and require at least one such input.
RequiredVariantInputArgumentCollection() - Constructor for class org.broadinstitute.hellbender.cmdline.argumentcollections.RequiredVariantInputArgumentCollection
 
requiresCoordinateSortOrder() - Method in class org.broadinstitute.hellbender.utils.downsampling.FractionalDownsampler
 
requiresCoordinateSortOrder() - Method in class org.broadinstitute.hellbender.utils.downsampling.MutectDownsampler
 
requiresCoordinateSortOrder() - Method in class org.broadinstitute.hellbender.utils.downsampling.PassThroughDownsampler
 
requiresCoordinateSortOrder() - Method in class org.broadinstitute.hellbender.utils.downsampling.PositionalDownsampler
 
requiresCoordinateSortOrder() - Method in class org.broadinstitute.hellbender.utils.downsampling.ReadsDownsampler
Does this downsampler require that reads be fed to it in coordinate order?
requiresCoordinateSortOrder() - Method in class org.broadinstitute.hellbender.utils.downsampling.ReservoirDownsampler
 
requiresFeatures() - Method in class org.broadinstitute.hellbender.engine.FeatureWalker
 
requiresFeatures() - Method in class org.broadinstitute.hellbender.engine.GATKTool
Does this tool require features? Traversals types and/or tools that do should override to return true.
requiresFeatures() - Method in class org.broadinstitute.hellbender.engine.VariantWalkerBase
 
requiresIntervals() - Method in class org.broadinstitute.hellbender.engine.GATKTool
Does this tool require intervals? Traversals types and/or tools that do should override to return true.
requiresIntervals() - Method in class org.broadinstitute.hellbender.engine.IntervalWalker
 
requiresIntervals() - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
Does this tool require intervals? Tools that do should override to return true.
requiresIntervals() - Method in class org.broadinstitute.hellbender.engine.spark.IntervalWalkerSpark
 
requiresIntervals() - Method in class org.broadinstitute.hellbender.tools.copynumber.AnnotateIntervals
 
requiresIntervals() - Method in class org.broadinstitute.hellbender.tools.copynumber.CollectAllelicCounts
 
requiresIntervals() - Method in class org.broadinstitute.hellbender.tools.copynumber.CollectReadCounts
 
requiresIntervals() - Method in class org.broadinstitute.hellbender.tools.genomicsdb.GenomicsDBImport
 
requiresReads() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
requiresReads() - Method in class org.broadinstitute.hellbender.engine.GATKTool
Does this tool require reads? Traversals types and/or tools that do should override to return true.
requiresReads() - Method in class org.broadinstitute.hellbender.engine.LocusWalker
LocusWalkers requires read sources
requiresReads() - Method in class org.broadinstitute.hellbender.engine.ReadWalker
 
requiresReads() - Method in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
Does this tool require reads? Tools that do should override to return true.
requiresReads() - Method in class org.broadinstitute.hellbender.engine.spark.LocusWalkerSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.engine.spark.ReadWalkerSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.AnnotatePairOrientation
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.GetSampleName
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.spark.ApplyBQSRSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.spark.BaseRecalibratorSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.spark.bwa.BwaSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqFilterSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqPipelineSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.spark.PileupSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.BQSRPipelineSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.BwaAndMarkDuplicatesPipelineSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.CountBasesSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.CountReadsSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.FlagStatSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.MetricsCollectorSparkTool
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.PrintReadsSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.ReadsPipelineSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.SortSamSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.DiscoverVariantsFromContigAlignmentsSAMSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.CpxVariantReInterpreterSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoverFromLocalAssemblyContigAlignmentsSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.CalcMetadataSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ExtractSVEvidenceSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.FindBreakpointEvidenceSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryPipelineSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.ExtractOriginalAlignmentRecordsByNameSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.spark.transforms.markduplicates.MarkDuplicatesSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.spark.validation.CompareDuplicatesSpark
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.walkers.contamination.GetPileupSummaries
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.FilterAlignmentArtifacts
 
requiresReads() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
requiresReference() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
requiresReference() - Method in class org.broadinstitute.hellbender.engine.GATKTool
Does this tool require reference data? Traversals types and/or tools that do should override to return true.
requiresReference() - Method in class org.broadinstitute.hellbender.engine.MultiVariantWalkerGroupedOnStart
 
requiresReference() - Method in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerSpark
 
requiresReference() - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
Does this tool require reference data? Tools that do should override to return true.
requiresReference() - Method in class org.broadinstitute.hellbender.tools.copynumber.AnnotateIntervals
 
requiresReference() - Method in class org.broadinstitute.hellbender.tools.copynumber.CollectAllelicCounts
 
requiresReference() - Method in class org.broadinstitute.hellbender.tools.copynumber.PreprocessIntervals
 
requiresReference() - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.TagGermlineEvents
 
requiresReference() - Method in class org.broadinstitute.hellbender.tools.examples.ExampleReadWalkerWithReferenceSpark
 
requiresReference() - Method in class org.broadinstitute.hellbender.tools.funcotator.Funcotator
 
requiresReference() - Method in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark
 
requiresReference() - Method in class org.broadinstitute.hellbender.tools.LeftAlignIndels
 
requiresReference() - Method in class org.broadinstitute.hellbender.tools.spark.BaseRecalibratorSpark
 
requiresReference() - Method in class org.broadinstitute.hellbender.tools.spark.bwa.BwaSpark
 
requiresReference() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.BQSRPipelineSpark
 
requiresReference() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.BwaAndMarkDuplicatesPipelineSpark
 
requiresReference() - Method in interface org.broadinstitute.hellbender.tools.spark.pipelines.metrics.MetricsCollectorSpark
Return whether or not this collector requires a reference.
requiresReference() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.ReadsPipelineSpark
 
requiresReference() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.DiscoverVariantsFromContigAlignmentsSAMSpark
 
requiresReference() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.CpxVariantReInterpreterSpark
 
requiresReference() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoverFromLocalAssemblyContigAlignmentsSpark
 
requiresReference() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.FindBadGenomicKmersSpark
 
requiresReference() - Method in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryPipelineSpark
 
requiresReference() - Method in class org.broadinstitute.hellbender.tools.walkers.bqsr.BaseRecalibrator
 
requiresReference() - Method in class org.broadinstitute.hellbender.tools.walkers.contamination.GetPileupSummaries
 
requiresReference() - Method in class org.broadinstitute.hellbender.tools.walkers.GenotypeGVCFs
 
requiresReference() - Method in class org.broadinstitute.hellbender.tools.walkers.qc.CheckPileup
 
requiresReference() - Method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.SplitNCigarReads
 
requiresReference() - Method in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
requiresReference() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.CNNScoreVariants
 
requiresReference() - Method in class picard.analysis.artifacts.CollectSequencingArtifactMetrics
 
requiresReference() - Method in class picard.analysis.CollectOxoGMetrics
 
requiresReference() - Method in class picard.analysis.CollectWgsMetrics
 
requiresReference() - Method in class picard.cmdline.CommandLineProgram
 
requiresReference() - Method in class picard.fingerprint.IdentifyContaminant
 
requiresReference() - Method in class picard.reference.ExtractSequences
 
requiresReference() - Method in class picard.sam.MergeBamAlignment
 
requiresReference() - Method in class picard.sam.SetNmMdAndUqTags
 
requiresReference() - Method in class picard.util.BaitDesigner
 
ReservoirDownsampler - Class in org.broadinstitute.hellbender.utils.downsampling
Reservoir Downsampler: Selects n reads out of a stream whose size is not known in advance, with every read in the stream having an equal chance of being selected for inclusion.
ReservoirDownsampler(int, boolean) - Constructor for class org.broadinstitute.hellbender.utils.downsampling.ReservoirDownsampler
Construct a ReservoirDownsampler
ReservoirDownsampler(int) - Constructor for class org.broadinstitute.hellbender.utils.downsampling.ReservoirDownsampler
Construct a ReservoirDownsampler
reset() - Method in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark.ReferenceMultiSourceAdapter
 
reset() - Method in class org.broadinstitute.hellbender.utils.read.ArtificialReadIterator
 
reset() - Method in class org.broadinstitute.hellbender.utils.read.ArtificialReadQueryIterator
 
resetFilteredCount() - Method in class org.broadinstitute.hellbender.engine.filters.CountingReadFilter
 
resetFilteredCount() - Method in class org.broadinstitute.hellbender.engine.filters.CountingVariantFilter
 
resetOriginalBaseQualities(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Resets the quality scores of the reads to the orginal (pre-BQSR) ones.
resetRandomGenerator() - Static method in class org.broadinstitute.hellbender.utils.Utils
 
resetRefSeqFileWalker() - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.AbstractAlignmentMerger
 
resetRefSeqFileWalker() - Method in class picard.sam.AbstractAlignmentMerger
 
resetStats() - Method in class org.broadinstitute.hellbender.utils.downsampling.Downsampler
Reset stats in the downsampler such as the number of discarded items *without* clearing the downsampler of items
resolveIncompatibleAlleles(Allele, VariantContext, LinkedHashSet<Allele>) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
 
Resource - Class in org.broadinstitute.hellbender.utils.io
Stores a resource by path and a relative class.
Resource(String, Class<?>) - Constructor for class org.broadinstitute.hellbender.utils.io.Resource
Create a resource with a path and a relative class.
resources - Variable in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotator
An external resource VCF file or files from which to annotate.
RESTORE_ORIGINAL_QUALITIES - Variable in class picard.sam.RevertOriginalBaseQualitiesAndAddMateCigar
 
RESTORE_ORIGINAL_QUALITIES - Variable in class picard.sam.RevertSam
 
restoreHeaderIfNecessary(GATKRead, SAMFileHeader) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Checks whether read is a headerless SAMRecordToGATKReadAdapter, and if it is, sets its header to the provided header.
restrictToIntervals - Variable in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfile
 
Result(boolean, boolean, AssemblyRegion, int, int, List<VariantContext>, Pair<SimpleInterval, SimpleInterval>, SimpleInterval, SimpleInterval, SimpleInterval, SimpleInterval) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmer.Result
Creates a trimming result given all its properties.
Result(double, double, double, double) - Constructor for class org.broadinstitute.hellbender.utils.MannWhitneyU.Result
 
RESULT - Variable in class picard.fingerprint.CrosscheckMetric
 
result() - Method in class picard.vcf.CallingMetricAccumulator
 
result() - Method in interface picard.vcf.processor.VariantProcessor.Accumulator
 
retainAll(Collection<?>) - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
 
retainNodes(Set<Integer>) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTree
Removes all nodes not in the given set
REV_COMPED_ALLELES - Static variable in class picard.util.LiftoverUtils
 
REV_CXT_ALT_BASES - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasDetailMetrics
The number of ~REF_BASE:~ALT_BASE alignments at sites complementary to the given reference context.
REV_CXT_REF_BASES - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasDetailMetrics
The number of ~REF_BASE:~REF_BASE alignments at sites complementary to the given reference context.
REV_ERROR_RATE - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasDetailMetrics
The substitution rate of ~REF_BASE:~ALT_BASE, calculated as max(1e-10, REV_CXT_ALT_BASES / (REV_CXT_ALT_BASES + REV_CXT_REF_BASES)).
REVERSE - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_StrandBiasTest
 
reverseComplement(int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmer
 
reverseComplement(long) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmer
 
reverseComplement(int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerLong
Returns a new SVKmerLong that's the reverse-complement of this one.
reverseComplement(int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerShort
Returns a new SVKmerShort that's the reverse-complement of this one.
reverseComplementByteValueAsLong(int) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmer
 
reverseComplementVariantContext(VariantContext, Interval, ReferenceSequence) - Static method in class picard.util.LiftoverUtils
 
reverseIterator() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree
Return an iterator over the entire tree that returns intervals in reverse order.
reverseIterator(SVInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree
Return an iterator over all intervals less than or equal to the specified interval, in reverse order.
reverseTrimAlleles(VariantContext) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Trim the alleles in inputVC from the reverse direction
RevertBaseQualityScores - Class in org.broadinstitute.hellbender.tools.walkers
 
RevertBaseQualityScores() - Constructor for class org.broadinstitute.hellbender.tools.walkers.RevertBaseQualityScores
 
RevertOriginalBaseQualitiesAndAddMateCigar - Class in picard.sam
This tool reverts the original base qualities (if specified) and adds the mate cigar tag to mapped BAMs.
RevertOriginalBaseQualitiesAndAddMateCigar() - Constructor for class picard.sam.RevertOriginalBaseQualitiesAndAddMateCigar
 
RevertOriginalBaseQualitiesAndAddMateCigar.CanSkipSamFile - Enum in picard.sam
Used as a return for the canSkipSAMFile function.
RevertSam - Class in picard.sam
Reverts a SAM file by optionally restoring original quality scores and by removing all alignment information.
RevertSam() - Constructor for class picard.sam.RevertSam
 
RevertSam.FileType - Enum in picard.sam
 
revertSamRecord(SAMRecord) - Method in class picard.sam.RevertSam
Takes an individual SAMRecord and applies the set of changes/reversions to it that have been requested by program level options.
revertSoftClippedBases(GATKRead) - Static method in class org.broadinstitute.hellbender.utils.clipping.ReadClipper
Reverts ALL soft-clipped bases
reviseAndConditionallyLogQuality(byte) - Method in class picard.illumina.parser.readers.BclQualityEvaluationStrategy
Accepts a quality read from a BCL file and (1) returns a 1 if the value was 0 and (2) makes a note of the provided quality if it is low.
RevIterator(SVIntervalTree.Node<V>) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree.RevIterator
 
RExecutor - Class in picard.util
Util class for executing R scripts.
RExecutor() - Constructor for class picard.util.RExecutor
 
RF - Static variable in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
RF - Static variable in class picard.sam.markduplicates.util.ReadEnds
 
RG_TAG - Variable in class picard.sam.SamToFastq
 
RGCN - Variable in class picard.sam.AddOrReplaceReadGroups
 
RGDS - Variable in class picard.sam.AddOrReplaceReadGroups
 
RGDT - Variable in class picard.sam.AddOrReplaceReadGroups
 
RGFO - Variable in class picard.sam.AddOrReplaceReadGroups
 
RGID - Variable in class picard.sam.AddOrReplaceReadGroups
 
RGKS - Variable in class picard.sam.AddOrReplaceReadGroups
 
RGLB - Variable in class picard.sam.AddOrReplaceReadGroups
 
RGPG - Variable in class picard.sam.AddOrReplaceReadGroups
 
RGPI - Variable in class picard.sam.AddOrReplaceReadGroups
 
RGPL - Variable in class picard.sam.AddOrReplaceReadGroups
 
RGPM - Variable in class picard.sam.AddOrReplaceReadGroups
 
RGPU - Variable in class picard.sam.AddOrReplaceReadGroups
 
RGSM - Variable in class picard.sam.AddOrReplaceReadGroups
 
rhs - Variable in class org.broadinstitute.hellbender.engine.filters.ReadFilter.ReadFilterBinOp
 
RIBOSOMAL_BASES - Variable in class picard.analysis.RnaSeqMetrics
Number of bases in primary alignments that align to ribosomal sequence.
RIBOSOMAL_INTERVALS - Variable in class picard.analysis.CollectRnaSeqMetrics
 
ribosomalInitialValue - Variable in class picard.analysis.directed.RnaSeqMetricsCollector
 
RIGHT_FILE - Variable in class picard.fingerprint.CrosscheckMetric
 
RIGHT_GROUP_VALUE - Variable in class picard.fingerprint.CrosscheckMetric
 
RIGHT_LANE - Variable in class picard.fingerprint.CrosscheckMetric
 
RIGHT_LIBRARY - Variable in class picard.fingerprint.CrosscheckMetric
 
RIGHT_MOLECULAR_BARCODE_SEQUENCE - Variable in class picard.fingerprint.CrosscheckMetric
 
RIGHT_PRIMER - Variable in class picard.util.BaitDesigner
 
RIGHT_RUN_BARCODE - Variable in class picard.fingerprint.CrosscheckMetric
 
RIGHT_SAMPLE - Variable in class picard.fingerprint.CrosscheckMetric
 
rightMedianDeviation(int) - Method in class org.broadinstitute.hellbender.tools.spark.utils.IntHistogram.CDF
 
rightVariantContext - Variable in class picard.vcf.PairedVariantSubContextIterator.VcfTuple
 
rms(Collection<Integer>) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Computes the root mean square of the given array or 0.0 if the array is empty.
RMSMappingQuality - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Root Mean Square of the mapping quality of reads across all samples.
RMSMappingQuality() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.RMSMappingQuality
 
RnaSeqMetrics - Class in picard.analysis
Metrics about the alignment of RNA-seq reads within a SAM file to genes, produced by the CollectRnaSeqMetrics program and usually stored in a file with the extension ".rna_metrics".
RnaSeqMetrics() - Constructor for class picard.analysis.RnaSeqMetrics
 
RnaSeqMetricsCollector - Class in picard.analysis.directed
 
RnaSeqMetricsCollector(Set<MetricAccumulationLevel>, List<SAMReadGroupRecord>, Long, OverlapDetector<Gene>, OverlapDetector<Interval>, HashSet<Integer>, int, RnaSeqMetricsCollector.StrandSpecificity, double, boolean) - Constructor for class picard.analysis.directed.RnaSeqMetricsCollector
 
RnaSeqMetricsCollector.PerUnitRnaSeqMetricsCollector - Class in picard.analysis.directed
 
RnaSeqMetricsCollector.StrandSpecificity - Enum in picard.analysis.directed
 
RobustBrentSolver - Class in org.broadinstitute.hellbender.utils.solver
A robust version of the Brent solver that tries to avoid spurious non-bracketing conditions.
RobustBrentSolver(double, double, double, UnivariateFunction, int, int) - Constructor for class org.broadinstitute.hellbender.utils.solver.RobustBrentSolver
 
round(double, int) - Static method in class picard.util.MathUtil
Round off the value to the specified precision.
ROUND_DOWN_QUANTIZED_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.validation.CompareBaseQualities
 
roundDown - Variable in class org.broadinstitute.hellbender.tools.ApplyBQSRUniqueArgumentCollection
Round down quantized only works with the static_quantized_quals option, and should not be used with the dynamic binning option provided by quantize_quals.
roundDown - Variable in class org.broadinstitute.hellbender.tools.validation.CompareBaseQualities
Round down quantized only works with the CompareBaseQualities.STATIC_QUANTIZED_QUALS_LONG_NAME option.
roundPhred(double, double) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Round a Phred scaled score to precision phredScorePrecision
roundToNDecimalPlaces(double, int) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Rounds the double to the given number of decimal places.
roundTripInKryo(T, Class<?>, SparkConf) - Static method in class org.broadinstitute.hellbender.utils.test.SparkTestUtils
Takes an input object and returns the value of the object after it has been serialized and then deserialized in Kryo.
rowMeans(RealMatrix) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
rowStdDevs(RealMatrix) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Calculates the standard deviation per row from a matrix.
rowSums(RealMatrix) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Return an array with row sums in each entry
rowVariances(RealMatrix) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
RR - Static variable in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
RR - Static variable in class picard.sam.markduplicates.util.ReadEnds
 
RrbsCpgDetailMetrics - Class in picard.analysis
Holds information about CpG sites encountered for RRBS processing QC
RrbsCpgDetailMetrics() - Constructor for class picard.analysis.RrbsCpgDetailMetrics
 
RrbsMetricsCollector - Class in picard.analysis
 
RrbsMetricsCollector(Set<MetricAccumulationLevel>, List<SAMReadGroupRecord>, int, int, int, double) - Constructor for class picard.analysis.RrbsMetricsCollector
 
RrbsSummaryMetrics - Class in picard.analysis
Holds summary statistics from RRBS processing QC
RrbsSummaryMetrics() - Constructor for class picard.analysis.RrbsSummaryMetrics
 
RRNA_FRAGMENT_PERCENTAGE - Variable in class picard.analysis.CollectRnaSeqMetrics
 
RScriptExecutor - Class in org.broadinstitute.hellbender.utils.R
Generic service for executing RScripts
RScriptExecutor() - Constructor for class org.broadinstitute.hellbender.utils.R.RScriptExecutor
 
RScriptExecutor(boolean) - Constructor for class org.broadinstitute.hellbender.utils.R.RScriptExecutor
 
RScriptExecutorException - Exception in org.broadinstitute.hellbender.utils.R
 
RScriptExecutorException(String) - Constructor for exception org.broadinstitute.hellbender.utils.R.RScriptExecutorException
 
RScriptLibrary - Enum in org.broadinstitute.hellbender.utils.R
Libraries embedded in the StingUtils package.
run() - Method in class picard.illumina.ExtractIlluminaBarcodes.PerTileBarcodeExtractor
run method which extracts barcodes and accumulates metrics for an entire tile
run() - Method in class picard.Test
 
RUN_BARCODE - Variable in class picard.fastq.BamToBfq
 
RUN_BARCODE - Variable in class picard.illumina.IlluminaBasecallsToFastq
 
RUN_BARCODE - Variable in class picard.illumina.IlluminaBasecallsToSam
 
RUN_DATE - Variable in class picard.sam.FastqToSam
 
RUN_DIRECTORY - Variable in class picard.illumina.CollectIlluminaLaneMetrics
 
RUN_MODE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.GermlineCNVCaller
 
RUN_START_DATE - Variable in class picard.illumina.IlluminaBasecallsToSam
 
RUN_WITHOUT_DBSNP - Static variable in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationArgumentCollection
 
runCommandLine(List<String>) - Method in interface org.broadinstitute.hellbender.utils.test.CommandLineProgramTester
Runs the command line implemented by this test.
runCommandLine(List<String>, String) - Method in interface org.broadinstitute.hellbender.utils.test.CommandLineProgramTester
Lets you explicitly specify a tool to run with the provided arguments Default behavior uses Main with the command line arguments created by CommandLineProgramTester.makeCommandLineArgs(List, String).
runCommandLine(String[]) - Method in interface org.broadinstitute.hellbender.utils.test.CommandLineProgramTester
 
runCommandLine(ArgumentsBuilder) - Method in interface org.broadinstitute.hellbender.utils.test.CommandLineProgramTester
 
runCommandLineProgram(CommandLineProgram, String[]) - Static method in class org.broadinstitute.hellbender.Main
Run the given command line program with the raw arguments from the command line
runLocalAssembly(AssemblyRegion, Haplotype, byte[], SimpleInterval, List<VariantContext>, ReadErrorCorrector, SAMFileHeader, SmithWatermanAligner) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingAssembler
Main entry point into the assembly engine.
runMCMC() - Method in class org.broadinstitute.hellbender.utils.mcmc.GibbsSampler
Runs the Monte Carlo Markov Chain, using the state of the model provided in the constructor to initialize.
running - Static variable in class org.broadinstitute.hellbender.utils.runtime.ProcessControllerBase
 
RunningAverage() - Constructor for class org.broadinstitute.hellbender.utils.MathUtils.RunningAverage
 
runningOnArchitecture(String) - Static method in class org.broadinstitute.hellbender.utils.NativeUtils
 
runningOnLinux() - Static method in class org.broadinstitute.hellbender.utils.NativeUtils
 
runningOnMac() - Static method in class org.broadinstitute.hellbender.utils.NativeUtils
 
runningOnPPCArchitecture() - Static method in class org.broadinstitute.hellbender.utils.NativeUtils
boolean : returns whether the current platform is PowerPC, LE only
runOnIsolatedMiniCluster(MiniClusterUtils.MiniClusterTest) - Static method in class org.broadinstitute.hellbender.utils.test.MiniClusterUtils
Create a new isolated MiniDFSCluster, run a MiniClusterUtils.MiniClusterTest on it and then shut it down.
runPipeline(JavaSparkContext) - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
 
runPipeline(JavaSparkContext) - Method in class org.broadinstitute.hellbender.engine.spark.SparkCommandLineProgram
Runs the pipeline.
runPipeline(JavaSparkContext) - Method in class org.broadinstitute.hellbender.engine.spark.VariantWalkerSpark
 
runPipeline(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.copynumber.CreateReadCountPanelOfNormals
 
runPipeline(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.examples.ExampleNioCountReads
Runs the pipeline.
runPipeline(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.BaseRecalibratorSparkSharded
 
runProcess(ProcessController, String[]) - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest
run an external process and assert that it finishes with exit code 0
runProcess(ProcessController, String[], String) - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest
run an external process and assert that it finishes with exit code 0
runProcess(ProcessController, String[], Map<String, String>, String) - Static method in class org.broadinstitute.hellbender.utils.test.BaseTest
run an external process and assert that it finishes with exit code 0
runTest() - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
Sets up the basic command line arguments for input and output and runs instanceMain.
RuntimeUtils - Class in org.broadinstitute.hellbender.utils.runtime
 
RuntimeUtils() - Constructor for class org.broadinstitute.hellbender.utils.runtime.RuntimeUtils
 
runTool() - Method in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
Template method that runs the startup hook, doWork and then the shutdown hook.
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
Runs the tool itself after initializing and validating inputs.
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.engine.spark.IntervalWalkerSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.engine.spark.LocusWalkerSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.engine.spark.ReadWalkerSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.engine.spark.VariantWalkerSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.ApplyBQSRSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.BaseRecalibratorSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.bwa.BwaSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.ParallelCopyGCSDirectoryIntoHDFSSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBwaSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqFilterSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqPipelineSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqScoreSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.BQSRPipelineSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.BwaAndMarkDuplicatesPipelineSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.CountBasesSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.CountReadsSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.CountVariantsSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.FlagStatSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectBaseDistributionByCycleSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectMultipleMetricsSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.MeanQualityByCycleSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.MetricsCollectorSparkTool
The runTool method used when metrics collector tools are run "standalone".
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.QualityScoreDistributionSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.PrintReadsSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.ReadsPipelineSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.SortSamSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.DiscoverVariantsFromContigAlignmentsSAMSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.CpxVariantReInterpreterSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoverFromLocalAssemblyContigAlignmentsSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.CalcMetadataSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ExtractSVEvidenceSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.FindBadGenomicKmersSpark
Get the list of high copy number kmers in the reference, and write them to a file.
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.FindBreakpointEvidenceSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryPipelineSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.ExtractOriginalAlignmentRecordsByNameSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.transforms.markduplicates.MarkDuplicatesSpark
 
runTool(JavaSparkContext) - Method in class org.broadinstitute.hellbender.tools.spark.validation.CompareDuplicatesSpark
 

S

S_LOCS_FILE - Static variable in class picard.illumina.parser.readers.AbstractIlluminaPositionFileReader
 
SA_TAG_FIELD_SEPARATOR - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
String used to separate fields in an alignment-interval string representation.
SA_TAG_INTERVAL_SEPARATOR_STR - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
String used to separate several alignment-intervals in a SA Tag like string.
safeCombine(RecalibrationTables, RecalibrationTables) - Static method in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationTables
Combines the two tables into a new table (allocating a new table in the process)
SAM_DUPLICATE_READ_FLAG - Static variable in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
SAM_FILE_HEADER_START - Static variable in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvLocatableTableCodec
 
SAM_FIRST_OF_PAIR_FLAG - Static variable in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
SAM_MATE_STRAND_FLAG - Static variable in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
SAM_MATE_UNMAPPED_FLAG - Static variable in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
SAM_NOT_PRIMARY_ALIGNMENT_FLAG - Static variable in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
SAM_PILEUP_FILE_EXTENSIONS - Static variable in class org.broadinstitute.hellbender.utils.codecs.sampileup.SAMPileupCodec
 
SAM_PROPER_PAIR_FLAG - Static variable in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
SAM_READ_FAILS_VENDOR_QUALITY_CHECK_FLAG - Static variable in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
SAM_READ_PAIRED_FLAG - Static variable in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
SAM_READ_STRAND_FLAG - Static variable in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
SAM_READ_UNMAPPED_FLAG - Static variable in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
SAM_SECOND_OF_PAIR_FLAG - Static variable in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
SAM_SUPPLEMENTARY_ALIGNMENT_FLAG - Static variable in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
SamAlignmentMerger - Class in org.broadinstitute.hellbender.utils.read.mergealignment
Class that takes in a set of alignment information in SAM format and merges it with the set of all reads for which alignment was attempted, stored in an unmapped SAM file.
SamAlignmentMerger(File, File, File, SAMProgramRecord, boolean, boolean, boolean, List<File>, int, List<String>, List<String>, Integer, Integer, List<File>, List<File>, List<SamPairUtil.PairOrientation>, SAMFileHeader.SortOrder, PrimaryAlignmentSelectionStrategy, boolean) - Constructor for class org.broadinstitute.hellbender.utils.read.mergealignment.SamAlignmentMerger
Constructor
SamAlignmentMerger - Class in picard.sam
Class that takes in a set of alignment information in SAM format and merges it with the set of all reads for which alignment was attempted, stored in an unmapped SAM file.
SamAlignmentMerger(File, File, File, SAMProgramRecord, boolean, boolean, boolean, List<File>, int, List<String>, List<String>, Integer, Integer, List<File>, List<File>, List<SamPairUtil.PairOrientation>, SAMFileHeader.SortOrder, PrimaryAlignmentSelectionStrategy, boolean, boolean, int) - Constructor for class picard.sam.SamAlignmentMerger
Constructor with a default value for unmappingReadStrategy
SamAlignmentMerger(File, File, File, SAMProgramRecord, boolean, boolean, boolean, List<File>, int, List<String>, List<String>, Integer, Integer, List<File>, List<File>, List<SamPairUtil.PairOrientation>, SAMFileHeader.SortOrder, PrimaryAlignmentSelectionStrategy, boolean, boolean, int, AbstractAlignmentMerger.UnmappingReadStrategy, List<String>) - Constructor for class picard.sam.SamAlignmentMerger
Constructor
SamAssertionUtils - Class in org.broadinstitute.hellbender.utils.test
Collection of utilities for making common assertions about SAM files for unit testing purposes.
SamAssertionUtils() - Constructor for class org.broadinstitute.hellbender.utils.test.SamAssertionUtils
 
SamComparison - Class in org.broadinstitute.hellbender.utils.read
Rudimentary SAM comparer.
SamComparison(SamReader, SamReader) - Constructor for class org.broadinstitute.hellbender.utils.read.SamComparison
Note: the caller must make sure the SamReaders are closed properly.
SAMFileDestination - Class in org.broadinstitute.hellbender.utils.haplotype
Class used to direct output from a HaplotypeBAMWriter to a bam/sam file.
SAMFileDestination(Path, boolean, boolean, SAMFileHeader, String) - Constructor for class org.broadinstitute.hellbender.utils.haplotype.SAMFileDestination
Create a new file destination.
SAMFileGATKReadWriter - Class in org.broadinstitute.hellbender.utils.read
A GATKRead writer that writes to a SAM/BAM file.
SAMFileGATKReadWriter(SAMFileWriter) - Constructor for class org.broadinstitute.hellbender.utils.read.SAMFileGATKReadWriter
 
samFiles - Variable in class org.broadinstitute.hellbender.tools.validation.CompareBaseQualities
 
samFiles - Variable in class picard.sam.CompareSAMs
 
SamFileTester - Class in org.broadinstitute.hellbender.utils.test.testers
Abstract class for doing basic on the fly SAM file testing.
SamFileTester(int, boolean, int, DuplicateScoringStrategy.ScoringStrategy, SAMFileHeader.SortOrder, boolean) - Constructor for class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
SamFileTester(int, boolean, int, DuplicateScoringStrategy.ScoringStrategy, SAMFileHeader.SortOrder) - Constructor for class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
SamFileTester(int, boolean, int, DuplicateScoringStrategy.ScoringStrategy) - Constructor for class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
SamFileTester(int, boolean, int) - Constructor for class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
SamFileTester(int, boolean) - Constructor for class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
SamFormatConverter - Class in picard.sam
Converts a BAM file to human-readable SAM output or vice versa
SamFormatConverter() - Constructor for class picard.sam.SamFormatConverter
 
SAMFormattedContigAlignmentParser(JavaRDD<GATKRead>, SAMFileHeader, boolean) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoverFromLocalAssemblyContigAlignmentsSpark.SAMFormattedContigAlignmentParser
 
samHeader - Variable in class org.broadinstitute.hellbender.engine.filters.ReadFilter
 
samHeader - Static variable in class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSink.SparkSAMOutputFormat
 
samHeader - Variable in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfile
 
SamHeaderAndIterator(SAMFileHeader, CloseableIterator<SAMRecord>, List<SamReader>) - Constructor for class org.broadinstitute.hellbender.utils.read.markduplicates.AbstractMarkDuplicatesCommandLineProgram.SamHeaderAndIterator
 
SamHeaderAndIterator(SAMFileHeader, CloseableIterator<SAMRecord>) - Constructor for class picard.sam.markduplicates.util.AbstractMarkDuplicatesCommandLineProgram.SamHeaderAndIterator
 
samjdk_compression_level() - Method in interface org.broadinstitute.hellbender.utils.config.GATKConfig
 
samjdk_use_async_io_read_samtools() - Method in interface org.broadinstitute.hellbender.utils.config.GATKConfig
 
samjdk_use_async_io_write_samtools() - Method in interface org.broadinstitute.hellbender.utils.config.GATKConfig
 
samjdk_use_async_io_write_tribble() - Method in interface org.broadinstitute.hellbender.utils.config.GATKConfig
 
SAMPileupCodec - Class in org.broadinstitute.hellbender.utils.codecs.sampileup
Decoder for single sample SAM pileup data.
SAMPileupCodec() - Constructor for class org.broadinstitute.hellbender.utils.codecs.sampileup.SAMPileupCodec
 
SAMPileupElement - Class in org.broadinstitute.hellbender.utils.codecs.sampileup
Simple representation of a single base with associated quality from a SAM pileup
SAMPileupFeature - Class in org.broadinstitute.hellbender.utils.codecs.sampileup
A tribble feature representing a SAM pileup.
SAMPLE - Variable in class org.broadinstitute.hellbender.metrics.MultiLevelMetrics
The sample to which these metrics apply.
SAMPLE - Variable in class org.broadinstitute.hellbender.tools.SplitReads
 
sample - Variable in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods.BestAllele
The containing sample.
sample(RandomGenerator, Function<Double, Double>) - Method in class org.broadinstitute.hellbender.utils.mcmc.AdaptiveMetropolisSampler
 
sample(RandomGenerator, Function<Double, Double>, int, int) - Method in class org.broadinstitute.hellbender.utils.mcmc.AdaptiveMetropolisSampler
Generate multiple samples from the probability density function.
sample(RandomGenerator, S, T) - Method in interface org.broadinstitute.hellbender.utils.mcmc.ParameterSampler
Returns a random sample of a value that is dependent on an ParameterizedState and a DataCollection.
sample(double) - Method in class org.broadinstitute.hellbender.utils.mcmc.SliceSampler
Generate a single sample from the probability density function, given an initial value to use in slice construction.
sample(double, int) - Method in class org.broadinstitute.hellbender.utils.mcmc.SliceSampler
Generate multiple samples from the probability density function, given an initial value to use in slice construction.
Sample - Class in org.broadinstitute.hellbender.utils.samples
Represents an individual under study.
Sample(String, String, String, String, Sex, Affection) - Constructor for class org.broadinstitute.hellbender.utils.samples.Sample
 
Sample(String, String, String, String, Sex) - Constructor for class org.broadinstitute.hellbender.utils.samples.Sample
 
SAMPLE - Variable in class picard.analysis.FingerprintingDetailMetrics
The name of the sample who's genotypes the sequence data was compared to.
SAMPLE - Variable in class picard.analysis.FingerprintingSummaryMetrics
The sample whose known genotypes the sequence data was compared to.
SAMPLE - Variable in class picard.analysis.replicates.CollectIndependentReplicateMetrics
 
SAMPLE - Variable in class picard.metrics.MultilevelMetrics
The sample to which these metrics apply.
SAMPLE - Variable in class picard.vcf.MakeSitesOnlyVcf
 
SAMPLE_ALIAS - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasDetailMetrics
 
SAMPLE_ALIAS - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasSummaryMetrics
The name of the sample being assayed.
SAMPLE_ALIAS - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterDetailMetrics
The name of the sample being assayed.
SAMPLE_ALIAS - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterSummaryMetrics
The name of the sample being assayed.
SAMPLE_ALIAS - Variable in class picard.analysis.CollectOxoGMetrics.CpcgMetrics
The name of the sample being assayed.
SAMPLE_ALIAS - Variable in class picard.fingerprint.IdentifyContaminant
 
SAMPLE_ALIAS - Variable in class picard.illumina.IlluminaBasecallsToSam
 
SAMPLE_ALIAS - Variable in class picard.sam.RevertSam
 
SAMPLE_ALIAS - Variable in class picard.vcf.CollectVariantCallingMetrics.VariantCallingDetailMetrics
The name of the sample being assayed
SAMPLE_ALIAS_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
SAMPLE_ALIAS_SHORT_NAME - Static variable in class picard.cmdline.StandardOptionDefinitions
 
SAMPLE_INDEX_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.PostprocessGermlineCNVCalls
 
SAMPLE_LIST_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
SAMPLE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.SplitReads
 
SAMPLE_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ReadFilterArgumentDefinitions
 
SAMPLE_NAME - Variable in class picard.sam.FastqToSam
 
SAMPLE_NAME_DISCOVERY_VCF_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
SAMPLE_NAME_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
SAMPLE_NAME_MAP_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.genomicsdb.GenomicsDBImport
 
SAMPLE_NAME_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
SAMPLE_NAME_TXT_FILE - Static variable in class org.broadinstitute.hellbender.tools.copynumber.gcnv.GermlineCNVNamingConstants
 
SAMPLE_NAME_VALIDATION_CASE - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
SAMPLE_NAME_VALIDATION_CONTROL - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
SAMPLE_PREFIX - Static variable in class org.broadinstitute.hellbender.tools.copynumber.gcnv.GermlineCNVNamingConstants
 
SAMPLE_PSI_SCALE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineContigPloidyModelArgumentCollection
 
SAMPLE_PSI_SCALE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineDenoisingModelArgumentCollection
 
SAMPLE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.SplitReads
 
SAMPLE_SIZE - Variable in class picard.analysis.CollectWgsMetrics
 
SAMPLE_SIZE - Variable in class picard.analysis.directed.CollectTargetedMetrics
 
sampleBarcodes - Variable in class picard.illumina.parser.ReadStructure
 
sampleCount() - Method in class org.broadinstitute.hellbender.utils.samples.SampleDB
Get number of sample objects
sampleCumulativeSums(int, int, boolean) - Method in class picard.analysis.TheoreticalSensitivity.RouletteWheel
 
SampleDB - Class in org.broadinstitute.hellbender.utils.samples
Simple database for managing samples
SampleDBBuilder - Class in org.broadinstitute.hellbender.utils.samples
Class for creating a temporary in memory database of samples.
SampleDBBuilder(PedigreeValidationType) - Constructor for class org.broadinstitute.hellbender.utils.samples.SampleDBBuilder
 
sampleIndicesWithoutReplacement(int, int) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Creates a new sample of k ints from [0..n-1], without duplicates.
sampleLikelihoods(int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingLikelihoods
Returns the genotype-likelihoods of the sample given its index in the collection.
SampleList - Class in org.broadinstitute.hellbender.tools.walkers.annotator
List samples that are non-reference at a given variant site
SampleList() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.SampleList
 
SampleList - Interface in org.broadinstitute.hellbender.utils.genotyper
An immutable, indexed set of samples.
SampleLocatableMetadata - Interface in org.broadinstitute.hellbender.tools.copynumber.formats.metadata
Interface for marking objects that contain metadata associated with a collection of locatables associated with a single sample.
sampleMatrix(int) - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Returns a read vs allele likelihood matrix corresponding to a sample.
SampleMetadata - Interface in org.broadinstitute.hellbender.tools.copynumber.formats.metadata
Interface for marking objects that contain metadata associated with a single sample.
sampleName - Variable in class org.broadinstitute.hellbender.tools.copynumber.gcnv.GermlineCNVVariantComposer
 
sampleNameMapPath - Variable in class org.broadinstitute.hellbender.tools.FixCallSetSampleOrdering
 
SampleNameSplitter - Class in org.broadinstitute.hellbender.tools.readersplitters
Splits readers sample names.
SampleNameSplitter() - Constructor for class org.broadinstitute.hellbender.tools.readersplitters.SampleNameSplitter
 
sampleNameToUse - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerArgumentCollection
You can use this argument to specify that HC should process a single sample out of a multisample BAM file.
samplePloidy - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeCalculationArgumentCollection
Sample ploidy - equivalent to number of chromosomes per pool.
samplePloidy(int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingLikelihoods
Returns the ploidy of the sample given its index in the collection.
samplePloidy(int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.HeterogeneousPloidyModel
 
samplePloidy(int) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.HomogeneousPloidyModel
 
samplePloidy(int) - Method in interface org.broadinstitute.hellbender.tools.walkers.genotyper.PloidyModel
Return the assumed ploidy for a sample given its index.
sampleReadCount(int) - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Returns the number of reads that belong to a sample in the read-likelihood collection.
SampleReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Keep only reads for a given sample.
SampleReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.SampleReadFilter
 
SampleReadFilter(SAMFileHeader) - Constructor for class org.broadinstitute.hellbender.engine.filters.SampleReadFilter
 
sampleReads(int) - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Returns the reads that belong to a sample sorted by their index (within that sample).
samples - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
 
samples - Variable in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Sample list
samples() - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Returns the samples in this read-likelihood collection.
SampleSpecificData(String, Broadcast<SVIntervalTree<VariantContext>>, List<SVInterval>, PairedStrandedIntervalTree<EvidenceTargetLink>, ReadMetadata, Broadcast<SAMFileHeader>) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoveryInputMetaData.SampleSpecificData
 
samplesToKeep - Variable in class org.broadinstitute.hellbender.engine.filters.SampleReadFilter
 
SamReaderQueryingIterator - Class in org.broadinstitute.hellbender.utils.iterators
An iterator that allows for traversals over a SamReader restricted to a set of intervals, unmapped reads, or both.
SamReaderQueryingIterator(SamReader, List<SimpleInterval>, boolean) - Constructor for class org.broadinstitute.hellbender.utils.iterators.SamReaderQueryingIterator
Create a SamReaderQueryingIterator given a SamReader, query intervals, and a flag indicating whether unmapped reads with no position assigned should be returned.
SamReaderQueryingIterator(SamReader, TraversalParameters) - Constructor for class org.broadinstitute.hellbender.utils.iterators.SamReaderQueryingIterator
Create a SamReaderQueryingIterator given a SamReader and a set of traversal parameters governing which reads are to be returned during iteration.
SAMRecordAndReference - Class in org.broadinstitute.hellbender.metrics
 
SAMRecordAndReference(SAMRecord, ReferenceSequence) - Constructor for class org.broadinstitute.hellbender.metrics.SAMRecordAndReference
 
SAMRecordAndReference - Class in picard.metrics
 
SAMRecordAndReference(SAMRecord, ReferenceSequence) - Constructor for class picard.metrics.SAMRecordAndReference
 
SAMRecordAndReferenceMultiLevelCollector<BEAN extends htsjdk.samtools.metrics.MetricBase,HKEY extends java.lang.Comparable<HKEY>> - Class in org.broadinstitute.hellbender.metrics
 
SAMRecordAndReferenceMultiLevelCollector() - Constructor for class org.broadinstitute.hellbender.metrics.SAMRecordAndReferenceMultiLevelCollector
 
SAMRecordAndReferenceMultiLevelCollector<BEAN extends htsjdk.samtools.metrics.MetricBase,HKEY extends java.lang.Comparable> - Class in picard.metrics
 
SAMRecordAndReferenceMultiLevelCollector() - Constructor for class picard.metrics.SAMRecordAndReferenceMultiLevelCollector
 
SAMRecordMultiLevelCollector<BEAN extends htsjdk.samtools.metrics.MetricBase,HKEY extends java.lang.Comparable<HKEY>> - Class in org.broadinstitute.hellbender.metrics
Defines a MultilevelPerRecordCollector using the argument type of SAMRecord so that this doesn't have to be redefined for each subclass of MultilevelPerRecordCollector
SAMRecordMultiLevelCollector() - Constructor for class org.broadinstitute.hellbender.metrics.SAMRecordMultiLevelCollector
 
SAMRecordMultiLevelCollector<BEAN extends htsjdk.samtools.metrics.MetricBase,HKEY extends java.lang.Comparable> - Class in picard.metrics
Defines a MultilevelPerRecordCollector using the argument type of SAMRecord so that this doesn't have to be redefined for each subclass of MultilevelPerRecordCollector
SAMRecordMultiLevelCollector() - Constructor for class picard.metrics.SAMRecordMultiLevelCollector
 
SAMRecordSerializer - Class in org.broadinstitute.hellbender.engine.spark
Efficient serializer for SAMRecords that uses SAMRecordSparkCodec for encoding/decoding.
SAMRecordSerializer() - Constructor for class org.broadinstitute.hellbender.engine.spark.SAMRecordSerializer
 
SAMRecordSparkCodec - Class in htsjdk.samtools
A class that uses a slightly adapted version of BAMRecordCodec for serialization/deserialization of SAMRecords.
SAMRecordSparkCodec() - Constructor for class htsjdk.samtools.SAMRecordSparkCodec
 
SAMRecordSparkCodec(SAMRecordFactory) - Constructor for class htsjdk.samtools.SAMRecordSparkCodec
 
samRecordToDuplicatesFlagsKey(SAMRecord) - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
SAMRecordToGATKReadAdapter - Class in org.broadinstitute.hellbender.utils.read
Implementation of the GATKRead interface for the SAMRecord class.
SAMRecordToGATKReadAdapter(SAMRecord) - Constructor for class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
SAMRecordToGATKReadAdapterSerializer - Class in org.broadinstitute.hellbender.engine.spark
Efficient serializer for SAMRecordToGATKReadAdapters that uses SAMRecordSparkCodec for encoding/decoding.
SAMRecordToGATKReadAdapterSerializer() - Constructor for class org.broadinstitute.hellbender.engine.spark.SAMRecordToGATKReadAdapterSerializer
 
SAMRecordToReadIterator - Class in org.broadinstitute.hellbender.utils.iterators
Wraps a SAMRecord iterator within an iterator of GATKReads.
SAMRecordToReadIterator(Iterator<SAMRecord>) - Constructor for class org.broadinstitute.hellbender.utils.iterators.SAMRecordToReadIterator
 
samRecordWithOrdinal - Variable in class picard.sam.markduplicates.util.ReadEndsForMateCigar
 
SamRecordWithOrdinalAndSetDuplicateReadFlag - Class in org.broadinstitute.hellbender.utils.read.markduplicates
This class sets the duplicate read flag as the result state when examining sets of records.
SamRecordWithOrdinalAndSetDuplicateReadFlag() - Constructor for class org.broadinstitute.hellbender.utils.read.markduplicates.SamRecordWithOrdinalAndSetDuplicateReadFlag
 
SamRecordWithOrdinalAndSetDuplicateReadFlag(SAMRecord, long) - Constructor for class org.broadinstitute.hellbender.utils.read.markduplicates.SamRecordWithOrdinalAndSetDuplicateReadFlag
 
SamRecordWithOrdinalAndSetDuplicateReadFlag - Class in picard.sam.markduplicates.util
This class sets the duplicate read flag as the result state when examining sets of records.
SamRecordWithOrdinalAndSetDuplicateReadFlag() - Constructor for class picard.sam.markduplicates.util.SamRecordWithOrdinalAndSetDuplicateReadFlag
 
SamRecordWithOrdinalAndSetDuplicateReadFlag(SAMRecord, long) - Constructor for class picard.sam.markduplicates.util.SamRecordWithOrdinalAndSetDuplicateReadFlag
 
samsEqualLenient(File, File, ValidationStringency, File) - Static method in class org.broadinstitute.hellbender.utils.test.SamAssertionUtils
Compares SAM/BAM files in a stringent way but not by byte identity (allow reorder of attributes).
samsEqualStringent(File, File, ValidationStringency, File) - Static method in class org.broadinstitute.hellbender.utils.test.SamAssertionUtils
Compares SAM/BAM files in a stringent way but not by byte identity (allow reorder of attributes) Comparing by MD5s is too strict and comparing by SamComparison is too lenient.
samsEqualStringent(Path, Path, ValidationStringency, Path) - Static method in class org.broadinstitute.hellbender.utils.test.SamAssertionUtils
Compares SAM/BAM files in a stringent way but not by byte identity (allow reorder of attributes) Comparing by MD5s is too strict and comparing by SamComparison is too lenient.
SamToFastq - Class in picard.sam
Extracts read sequences and qualities from the input SAM/BAM file and writes them into the output file in Sanger FASTQ format.
SamToFastq() - Constructor for class picard.sam.SamToFastq
 
SamToFastqWithTags - Class in picard.sam
Extracts read sequences and qualities from the input SAM/BAM file and SAM/BAM tags and writes them into output files in Sanger FASTQ format.
SamToFastqWithTags() - Constructor for class picard.sam.SamToFastqWithTags
 
SAMTOOLS_OVERLAP_LOW_CONFIDENCE - Static variable in class org.broadinstitute.hellbender.utils.pileup.ReadPileup
Constant used by samtools to downgrade a quality for overlapping reads that disagrees in their base.
SANITIZE - Variable in class picard.sam.RevertSam
 
SATagBuilder - Class in org.broadinstitute.hellbender.utils
A builder class that expands functionality for SA tags.
SATagBuilder(GATKRead) - Constructor for class org.broadinstitute.hellbender.utils.SATagBuilder
 
saveMetrics(MetricsFile<?, ?>, String) - Static method in class org.broadinstitute.hellbender.metrics.MetricsUtils
Write a MetricsFile to the given path, can be any destination supported by BucketUtils.createFile(String)
saveMetrics(String) - Method in class org.broadinstitute.hellbender.tools.examples.metrics.multi.ExampleCollectMultiMetricsSpark
Finish the collection process and save any results.
saveMetrics(MetricsFile<ExampleMultiMetrics, Integer>) - Method in class org.broadinstitute.hellbender.tools.examples.metrics.multi.ExampleMultiMetricsCollector
Finish the metrics collection and save any results to the metrics file.
saveMetrics(String) - Method in class org.broadinstitute.hellbender.tools.examples.metrics.multi.ExampleMultiMetricsCollectorSpark
Save the metrics out to a file.
saveMetrics(String) - Method in class org.broadinstitute.hellbender.tools.examples.metrics.single.ExampleCollectSingleMetricsSpark
Finish the collection process and save any results.
saveMetrics(String) - Method in class org.broadinstitute.hellbender.tools.examples.metrics.single.ExampleSingleMetricsCollectorSpark
Write out the results of the metrics collection
saveMetrics(String) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectInsertSizeMetricsSpark
 
saveMetrics(String) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectQualityYieldMetricsSpark
 
saveMetrics(String) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.InsertSizeMetricsCollectorSpark
 
saveMetrics(String) - Method in interface org.broadinstitute.hellbender.tools.spark.pipelines.metrics.MetricsCollectorSpark
This method is called after collectMetrics has returned and all Spark partitions have completed metrics collection.
saveMetrics(String) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.MetricsCollectorSparkTool
 
saveMetrics(String) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.QualityYieldMetricsCollectorSpark
Write out the results of the metrics collection
saveMetricsRDD(MetricsFile<GATKDuplicationMetrics, Double>, SAMFileHeader, JavaPairRDD<String, GATKDuplicationMetrics>, String) - Static method in class org.broadinstitute.hellbender.tools.spark.transforms.markduplicates.MarkDuplicatesSparkUtils
Saves the metrics to a file.
saveResults(MetricsFile<?, Integer>, SAMFileHeader, String) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectBaseDistributionByCycleSpark
 
saveTextualReport(String, SAMFileHeader, RecalibrationTables, RecalibrationArgumentCollection) - Static method in class org.broadinstitute.hellbender.tools.spark.transforms.bqsr.BaseRecalibratorEngineSparkWrapper
 
scaledEvidenceProbabilityUsingGenotypeFrequencies(double[]) - Method in class picard.fingerprint.HaplotypeProbabilities
This function returns the scaled probability of the evidence collected given a vector of priors on the haplotype using the internal likelihood, which may be scaled by an unknown factor.
scaleLogSpaceArrayForNumericalStability(double[]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Given an array of log space (log or log10) values, subtract all values by the array maximum so that the max element in log space is zero.
SCAN_WINDOW_SIZE - Variable in class picard.analysis.CollectGcBiasMetrics
 
scanDir(File, String) - Method in class picard.cmdline.ClassFinder
Scans a directory on the filesystem for classes.
scanJar(File, String) - Method in class picard.cmdline.ClassFinder
Scans the entries in a ZIP/JAR file for classes under the parent package.
scatter(IntervalList, int) - Method in class picard.util.IntervalListScatterer
 
scatter(IntervalList, int, boolean) - Method in class picard.util.IntervalListScatterer
 
SCATTER_COUNT - Variable in class picard.util.IntervalListTools
 
SCATTER_COUNT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.SplitIntervals
 
SCATTER_COUNT_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.SplitIntervals
 
scatterContigIntervals(SAMFileHeader, List<GenomeLoc>, List<File>) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Splits an interval list into multiple files.
scatterFixedIntervals(SAMFileHeader, List<List<GenomeLoc>>, List<File>) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Splits an interval list into multiple files.
ScatterIntervalsByNReferenceArgumentCollection() - Constructor for class picard.util.ScatterIntervalsByNs.ScatterIntervalsByNReferenceArgumentCollection
 
ScatterIntervalsByNs - Class in picard.util
A Tool for breaking up a reference into intervals of alternating regions of N and ACGT bases.
ScatterIntervalsByNs() - Constructor for class picard.util.ScatterIntervalsByNs
 
ScatterIntervalsByNs.ScatterIntervalsByNReferenceArgumentCollection - Class in picard.util
 
scheme - Variable in class picard.vcf.GenotypeConcordanceScheme
The underlying scheme
sChr - Variable in class org.broadinstitute.hellbender.utils.read.ArtificialReadIterator
 
score(byte[], int, int) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.AggregatedSubHaplotypeFinder
 
score() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KBestHaplotype
Returns the result haplotype score.
score(byte[]) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KBestHaplotypeFinder
Get the score of a give sequence of bases
score(Haplotype) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KBestHaplotypeFinder
Get the score of a give sequence of bases
score(GATKRead) - Method in enum org.broadinstitute.hellbender.utils.read.markduplicates.MarkDuplicatesScoringStrategy
Given a read, compute the reads's score for mark duplicates.
score - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEndsForMarkDuplicates
 
score - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Fragment
 
score - Variable in class picard.sam.markduplicates.util.ReadEndsForMarkDuplicates
 
SCORE - Variable in class picard.util.IntervalListToBed
 
SCORE_GENOME_LENGTH_UNITS - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScorer
 
SCORE_METRICS_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
 
SCORE_METRICS_FILE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
 
SCORE_READS_PER_PARTITION_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
 
SCORE_READS_PER_PARTITION_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
 
SCORE_THRESHOLD_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBwaArgumentCollection
 
SCORE_THRESHOLD_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBwaArgumentCollection
 
SCORE_WARNINGS_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
 
SCORE_WARNINGS_FILE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
 
scoreArgs - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqPipelineSpark
 
scoreArgs - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqScoreSpark
 
scoreMetricsFileUri - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
If specified, records the following metrics: Number of reads mapped to the microbial reference Number of unmapped reads
scoreOrientationBiasMetricsOverContext(List<SequencingArtifactMetrics.PreAdapterDetailMetrics>) - Static method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.PreAdapterOrientationScorer
Scores all modes regardless of whether required in the input.
scoreReads(JavaSparkContext, JavaRDD<GATKRead>, JavaRDD<GATKRead>, SAMFileHeader) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScorer
 
SCORES_OUTPUT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
 
SCORES_OUTPUT_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
 
scoresPath - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
 
scoreThreshold - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBwaArgumentCollection
This parameter controls the minimum quality of the BWA alignments for the output.
ScriptExecutor - Class in org.broadinstitute.hellbender.utils.runtime
Base class for executors that find and run scripts in an external script engine process (R, Python, etc).
ScriptExecutor(String) - Constructor for class org.broadinstitute.hellbender.utils.runtime.ScriptExecutor
 
ScriptExecutorException - Exception in org.broadinstitute.hellbender.utils.runtime
Base type for exceptions thrown by the ScriptExecutor.
ScriptExecutorException(String) - Constructor for exception org.broadinstitute.hellbender.utils.runtime.ScriptExecutorException
 
SD_CLUSTERS_PER_TILE - Variable in class picard.illumina.IlluminaBasecallingMetrics
The standard deviation of clusters per tile.
SD_COVERAGE - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The standard deviation of coverage of the genome after all filters are applied.
SD_PCT_PF_CLUSTERS_PER_TILE - Variable in class picard.illumina.IlluminaBasecallingMetrics
The standard deviation in percentage of pf clusters per tile.
SD_PF_CLUSTERS_PER_TILE - Variable in class picard.illumina.IlluminaBasecallingMetrics
The standard deviation in number of pf clusters per tile.
sDUST(GATKRead, int, double) - Static method in class org.broadinstitute.hellbender.transformers.DUSTReadTransformer
Wrapper method for runDUST so that we don't have to expose the IntTuple class.
SECOND_END_FASTQ - Variable in class picard.sam.SamToFastq
 
SECOND_INPUT - Variable in class picard.fingerprint.CrosscheckFingerprints
 
SECOND_INPUT - Variable in class picard.util.IntervalListTools
 
SECOND_INPUT_SAMPLE_MAP - Variable in class picard.fingerprint.CrosscheckFingerprints
 
SECOND_OF_PAIR - Static variable in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary
 
SECONDARY_OR_SUPPLEMENTARY_RDS - Variable in class picard.sam.DuplicationMetrics
The number of reads that were either secondary or supplementary
SecondOfPairReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.SecondOfPairReadFilter
 
secondPassApply(GATKRead, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.engine.TwoPassReadWalker
Process an individual read (with optional contextual information) on the second pass through the reads.
secondPassApply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.engine.TwoPassVariantWalker
secondPassApply(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.examples.ExampleTwoPassVariantWalker
 
secondPassApply(GATKRead, ReferenceContext, FeatureContext) - Method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.SplitNCigarReads
 
SECONDS_BETWEEN_PROGRESS_UPDATES_NAME - Static variable in class org.broadinstitute.hellbender.engine.GATKTool
 
secondSmallestMinusSmallest(int[], int) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Given an int array returns the difference between the second smallest element and the smallest element.
seedLength - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBwaArgumentCollection
This parameter controls the sensitivity of the BWA-MEM aligner.
seek(long) - Method in class org.broadinstitute.hellbender.utils.nio.ChannelAsSeekableStream
 
seek(int) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Changes the index of the next value to set using append operations.
seek(String) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Changes the index of the next value to set using append operations.
seek(Enum<?>) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Changes the index of the next value to set using append operations.
seek(List<File>, TileIndex, int) - Method in class picard.illumina.parser.readers.BclReader
 
SeekableByteChannelPrefetcher - Class in org.broadinstitute.hellbender.utils.nio
SeekableByteChannelPrefetcher wraps an existing SeekableByteChannel to add prefetching.
SeekableByteChannelPrefetcher(SeekableByteChannel, int) - Constructor for class org.broadinstitute.hellbender.utils.nio.SeekableByteChannelPrefetcher
 
seeked - Variable in class org.broadinstitute.hellbender.utils.read.ArtificialReadQueryIterator
 
seekToTile(int) - Method in class picard.illumina.parser.IlluminaDataProvider
Jump so that the next record returned will be from the specified tile.
seekToTile(int) - Method in class picard.illumina.parser.MultiTileParser
 
seekToTile(int) - Method in class picard.illumina.parser.NewIlluminaDataProvider
 
seekToTile(int) - Method in class picard.illumina.parser.PerTileParser
 
SEGMENT_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
SEGMENT_FILE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
SEGMENT_GERMLINE_CNV_CALLS_PYTHON_SCRIPT - Static variable in class org.broadinstitute.hellbender.tools.copynumber.PostprocessGermlineCNVCalls
 
SEGMENT_SIZE_ARG_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.genomicsdb.GenomicsDBImport
 
SegmentedCpxVariantSimpleVariantExtractor - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.inference
For extracting simple variants from input GATK-SV complex variants.
SegmentedCpxVariantSimpleVariantExtractor() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SegmentedCpxVariantSimpleVariantExtractor
 
SegmentedCpxVariantSimpleVariantExtractor.ExtractedSimpleVariants - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.inference
 
SEGMENTS_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.CopyNumberStandardArgument
 
SEGMENTS_FILE_SUFFIX - Static variable in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
selectAlleleBiasedReads(Map<A, List<GATKRead>>, double) - Static method in class org.broadinstitute.hellbender.utils.downsampling.AlleleBiasedDownsamplingUtils
Computes reads to remove based on an allele biased down-sampling
selectAlleleBiasedReads(Map<A, List<GATKRead>>, int, double) - Static method in class org.broadinstitute.hellbender.utils.downsampling.AlleleBiasedDownsamplingUtils
Computes reads to remove based on an allele biased down-sampling
SelectionMetric(String) - Constructor for class org.broadinstitute.hellbender.tools.walkers.vqsr.TrancheManager.SelectionMetric
 
SelectVariants - Class in org.broadinstitute.hellbender.tools.walkers.variantutils
Select a subset of variants from a VCF file
SelectVariants() - Constructor for class org.broadinstitute.hellbender.tools.walkers.variantutils.SelectVariants
 
selectWorstVariants() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
 
sendAsynchronousCommand(String) - Method in class org.broadinstitute.hellbender.utils.python.StreamingPythonScriptExecutor
Send a command to the remote process without waiting for a response.
sendSynchronousCommand(String) - Method in class org.broadinstitute.hellbender.utils.python.StreamingPythonScriptExecutor
Send a command to Python, and wait for a response prompt, returning all accumulated output since the last call to either or This is a blocking call, and should be used for commands that execute quickly and synchronously.
separator - Variable in class org.broadinstitute.hellbender.tools.walkers.rnaseq.ASEReadCounter
 
seq - Variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerizer
 
seq(double, double, double) - Static method in class picard.util.MathUtil
Mimic's R's seq() function to produce a sequence of equally spaced numbers.
SEQ_ALT_HAPLOTYPE - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
SEQ_IS_STORED - Static variable in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary
 
seqEquals(BaseVertex) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseVertex
Are b and this equal according to their base sequences?
SeqGraph - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs
A graph that contains base sequence at each node
SeqGraph(int) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.SeqGraph
Construct an empty SeqGraph where we'll add nodes based on a kmer size of kmer The kmer size is purely information.
SeqIsStoredReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.SeqIsStoredReadFilter
 
sequence - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseVertex
 
SEQUENCE_DICTIONARY - Variable in class picard.util.BedToIntervalList
 
SEQUENCE_DICTIONARY - Variable in class picard.util.LiftOverIntervalList
 
SEQUENCE_DICTIONARY - Variable in class picard.vcf.CollectVariantCallingMetrics
 
SEQUENCE_DICTIONARY - Variable in class picard.vcf.MergeVcfs
 
SEQUENCE_DICTIONARY - Variable in class picard.vcf.SortVcf
 
SEQUENCE_DICTIONARY - Variable in class picard.vcf.SplitVcfs
 
SEQUENCE_DICTIONARY - Variable in class picard.vcf.UpdateVcfSequenceDictionary
 
SEQUENCE_DICTIONARY_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
SEQUENCE_DICTIONARY_SHORT_NAME - Static variable in class picard.cmdline.StandardOptionDefinitions
 
SEQUENCE_NAME - Variable in class picard.analysis.RrbsCpgDetailMetrics
Sequence the CpG is seen in
SEQUENCE_NAMES - Variable in class picard.analysis.CollectRrbsMetrics
 
SEQUENCE_TAG_GROUP - Variable in class picard.sam.SamToFastqWithTags
 
SequenceComparison - Class in org.broadinstitute.hellbender.tools.funcotator
A simple data object to hold a comparison between a reference sequence and an alternate allele.
SequenceComparison() - Constructor for class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
SequenceDictionaryUtils - Class in org.broadinstitute.hellbender.utils
A series of utility functions that enable the GATK to compare two sequence dictionaries -- from the reference, from BAMs, or from feature sources -- for consistency.
SequenceDictionaryUtils.SequenceDictionaryCompatibility - Enum in org.broadinstitute.hellbender.utils
 
SequenceDictionaryValidationArgumentCollection - Interface in org.broadinstitute.hellbender.cmdline.argumentcollections
interface for argument collections that control how sequence dictionary validation should be handled
SequenceDictionaryValidationArgumentCollection.NoValidationCollection - Class in org.broadinstitute.hellbender.cmdline.argumentcollections
doesn't provide a configuration argument, and always returns false, useful for tools that do not want to perform sequence dictionary validation, like aligners
SequenceDictionaryValidationArgumentCollection.StandardValidationCollection - Class in org.broadinstitute.hellbender.cmdline.argumentcollections
most tools will want to use this, it defaults to performing sequence dictionary validation but provides the option to disable it
sequenceDictionaryValidationArguments - Variable in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
 
sequenceRecordsAreEquivalent(SAMSequenceRecord, SAMSequenceRecord) - Static method in class org.broadinstitute.hellbender.utils.SequenceDictionaryUtils
Helper routine that returns whether two sequence records are equivalent, defined as having the same name and lengths.
SequencerFlowClass - Enum in org.broadinstitute.hellbender.utils
In broad terms, each sequencing platform can be classified by whether it flows nucleotides in some order such that homopolymers get sequenced in a single event (ie 454 or Ion) or it reads each position in the sequence one at a time, regardless of base composition (Illumina or Solid).
sequencerType - Variable in enum org.broadinstitute.hellbender.utils.NGSPlatform
 
SEQUENCING_CENTER - Variable in class picard.illumina.IlluminaBasecallsToSam
 
SEQUENCING_CENTER - Variable in class picard.sam.FastqToSam
 
SequencingArtifactMetrics - Class in picard.analysis.artifacts
 
SequencingArtifactMetrics() - Constructor for class picard.analysis.artifacts.SequencingArtifactMetrics
 
SequencingArtifactMetrics.BaitBiasDetailMetrics - Class in picard.analysis.artifacts
Bait bias artifacts broken down by context.
SequencingArtifactMetrics.BaitBiasSummaryMetrics - Class in picard.analysis.artifacts
Summary analysis of a single bait bias artifact, also known as a reference bias artifact.
SequencingArtifactMetrics.PreAdapterDetailMetrics - Class in picard.analysis.artifacts
Pre-adapter artifacts broken down by context.
SequencingArtifactMetrics.PreAdapterSummaryMetrics - Class in picard.analysis.artifacts
Summary analysis of a single pre-adapter artifact.
SeqVertex - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs
A graph vertex containing a sequence of bases and a unique ID that allows multiple distinct nodes in the graph to have the same sequence.
SeqVertex(byte[]) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.SeqVertex
Create a new SeqVertex with sequence and the next available id
SeqVertex(String) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.SeqVertex
Create a new SeqVertex having bases of sequence.getBytes()
SerializableFunction<T,R> - Interface in org.broadinstitute.hellbender.utils
Represents a Function that is Serializable.
SerializableOpticalDuplicatesFinder - Class in org.broadinstitute.hellbender.utils.read.markduplicates
An intermediate class flagged as being serializable so that the Picard OpticalDuplicateFinder can be serialized despite it not being marked as such.
SerializableOpticalDuplicatesFinder(String, int) - Constructor for class org.broadinstitute.hellbender.utils.read.markduplicates.SerializableOpticalDuplicatesFinder
 
SerializableOpticalDuplicatesFinder() - Constructor for class org.broadinstitute.hellbender.utils.read.markduplicates.SerializableOpticalDuplicatesFinder
 
serialize(Kryo, Output) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTaxonomyDatabase
 
serialize(Kryo, Output) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTree
 
serialize(Kryo, Output) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications.IntraChrStrandSwitchBreakpointComplications
 
serialize(Kryo, Output) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications
 
serialize(Kryo, Output) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications.SmallDuplicationWithImpreciseDupRangeBreakpointComplications
 
serialize(Kryo, Output) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications.SmallDuplicationWithPreciseDupRangeBreakpointComplications
 
serialize(Kryo, Output) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.NovelAdjacencyAndAltHaplotype
 
serialize(Kryo, Output) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SimpleChimera
 
serialize(Kryo, Output) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.DiscordantReadPairEvidence
 
serialize(Kryo, Output) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.LargeIndel
 
serialize(Kryo, Output) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.OutiesPair
 
serialize(Kryo, Output) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.ReadEvidence
 
serialize(Kryo, Output) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence
 
serialize(Kryo, Output) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.SplitRead
 
serialize(Kryo, Output) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.TemplateSizeAnomaly
 
serialize(Kryo, Output) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.WeirdTemplateSize
 
serialize(Kryo, Output) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.EvidenceTargetLink
 
serialize(Kryo, Output) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.KmerAndInterval
 
serialize(Kryo, Output) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.KmerAndCount
 
serialize(Kryo, Output) - Method in enum org.broadinstitute.hellbender.tools.spark.sv.utils.Strand
 
serialize(Kryo, Output) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerLong
 
serialize(Kryo, Output) - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchCollection
 
serialize(Kryo, Output) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LargeLongHopscotchSet
 
serialize(Kryo, Output) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongBloomFilter
 
serialize(Kryo, Output) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongHopscotchSet
 
serialize(Kryo, Output) - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Pair
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerBloomFilter.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerSet.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSTaxonomyDatabase.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSTree.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.pathseq.PSTreeNode.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignedAssembly.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignedContig.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications.IntraChrStrandSwitchBreakpointComplications.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications.SmallDuplicationWithImpreciseDupRangeBreakpointComplications.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications.SmallDuplicationWithPreciseDupRangeBreakpointComplications.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.NovelAdjacencyAndAltHaplotype.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SimpleChimera.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SimpleNovelAdjacencyAndChimericAlignmentEvidence.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.AlignedAssemblyOrExcuse.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.ExternalEvidence.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.InterContigPair.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.LargeIndel.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.MateUnmapped.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.OutiesPair.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.ReadEvidence.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.SameStrandPair.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.SplitRead.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.TemplateSizeAnomaly.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.WeirdTemplateSize.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.EvidenceTargetLink.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.KmerAndInterval.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.LibraryStatistics.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.QNameAndInterval.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.LibraryRawStatistics.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.PartitionBounds.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.PartitionStatistics.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.KmerAndCount.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.PairedStrandedIntervalTree.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.Strand.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.StrandedInterval.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils.FastqRead.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVInterval.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerLong.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerShort.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.HopscotchCollection.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.HopscotchMap.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.HopscotchMultiMap.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.HopscotchSet.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.HopscotchUniqueMultiMap.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.IntHistogram.CDF.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.IntHistogram.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.LargeLongHopscotchSet.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.LongBloomFilter.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.LongHopscotchSet.Serializer
 
Serializer() - Constructor for class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Pair.Serializer
 
serializeToString() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
Serializes all data in GencodeGtfFeature to a string.
serializeToVcfString() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
serializeToVcfString() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.TableFuncotation
 
serializeToVcfString() - Method in interface org.broadinstitute.hellbender.tools.funcotator.Funcotation
Converts this Funcotation to a string suitable for insertion into a VCF file.
serializeToVcfString(String) - Method in interface org.broadinstitute.hellbender.tools.funcotator.Funcotation
TODO: This interface should have nothing specific to a VCF.
serialVersionUID - Static variable in interface org.broadinstitute.hellbender.engine.filters.VariantFilter
 
serialVersionUID - Static variable in class org.broadinstitute.hellbender.metrics.QualityYieldMetricsArgumentCollection
 
serialVersionUID - Static variable in class org.broadinstitute.hellbender.tools.examples.metrics.multi.ExampleMultiMetricsArgumentCollection
 
serialVersionUID - Static variable in class org.broadinstitute.hellbender.tools.examples.metrics.single.ExampleSingleMetricsArgumentCollection
 
serialVersionUID - Static variable in interface org.broadinstitute.hellbender.tools.spark.pipelines.metrics.MetricsCollectorSpark
 
serialVersionUID - Static variable in class org.broadinstitute.hellbender.transformers.DUSTReadTransformer
 
serialVersionUID - Static variable in interface org.broadinstitute.hellbender.transformers.ReadTransformer
 
serialVersionUID - Static variable in class org.broadinstitute.hellbender.transformers.StripMateNumberTransformer
 
serialVersionUID - Static variable in interface org.broadinstitute.hellbender.utils.recalibration.covariates.Covariate
 
set(Allele, X) - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.PerAlleleCollection
Take an allele, REF or ALT, and update its value appropriately
set(Collection<Allele>, Function<Allele, X>) - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.PerAlleleCollection
 
set(int, int, double) - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.SubsettedLikelihoodMatrix
 
set(int, E) - Method in class org.broadinstitute.hellbender.utils.collections.ExpandingArrayList
 
set(int, int, double) - Method in interface org.broadinstitute.hellbender.utils.genotyper.LikelihoodMatrix
Set the likelihood of a read given an allele through their indices.
set(Object, String, Object) - Method in class org.broadinstitute.hellbender.utils.report.GATKReportTable
Set the value for a given position in the table.
set(int, int, Object) - Method in class org.broadinstitute.hellbender.utils.report.GATKReportTable
Set the value for a given position in the table.
set(String, String) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Sets the string value in the data-line that correspond to a column by its name.
set(String, boolean) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Sets the boolean value in the data-line that correspond to a column by its name.
set(String, int) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Sets the int value in the data-line that correspond to a column by its name.
set(String, long) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Sets the long value in the data-line that correspond to a column by its name.
set(String, double) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Sets the double value in the data-line that correspond to a column by its name.
set(int, String) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Sets the string value of a column given its index.
set(int, int) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Sets the int value of a column given its index.
set(int, long) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Sets the long value of a column given its index.
set(int, double) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Sets the value for a column to a double given its index.
SET_ONLY_UQ - Variable in class picard.sam.SetNmMdAndUqTags
 
setAdditionalInfo(String) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseVertex
Set additional debugging information for this vertex
setAddPGTagToReads(boolean) - Method in class picard.sam.AbstractAlignmentMerger
Set addPGTagToReads.
setAlignedAlternateAllele(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
setAlignedAlternateAlleleStop(Integer) - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
setAlignedCodingSequenceAlleleStart(Integer) - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
setAlignedCodingSequenceAlternateAllele(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
setAlignedCodingSequenceReferenceAllele(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
setAlignedReferenceAllele(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
setAlignedReferenceAlleleStop(Integer) - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
setAlignmentStart(int) - Method in class org.broadinstitute.hellbender.utils.read.ArtificialBAMBuilder
 
setAlignmentStartHapwrtRef(int) - Method in class org.broadinstitute.hellbender.utils.haplotype.Haplotype
 
setAll(String...) - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Sets all the data-line values at once.
setAlleleStart(Integer) - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
setAllowDuplicateReads(boolean) - Method in class picard.fingerprint.FingerprintChecker
Sets whether duplicate reads should be allowed when calling genotypes from SAM files.
setAlreadyBuilt() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingGraph
 
setAlt(Allele, X) - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.PerAlleleCollection
 
setAlternateAllele(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
setAlternateAminoAcidSequence(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
setAnnotationEngine(VariantAnnotatorEngine) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
Changes the annotation engine for this genotyping-engine.
setAnnotationTranscript(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setAnnotationTranscript(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
Set the Transcript ID in the GencodeFuncotation.
setApplyEamssFiltering(boolean) - Method in class picard.illumina.parser.IlluminaDataProviderFactory
Sets whether or not EAMSS filtering will be applied if parsing BCL files for bases and quality scores.
setApprisRank(GencodeGtfFeature.FeatureTag) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setApprisRank(GencodeGtfFeature.FeatureTag) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
Set the Appris Rank in the GencodeFuncotation.
setArtifactMode(Transition) - Method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationSampleTransitionSummary
 
setArtifactModeComplement(Transition) - Method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationSampleTransitionSummary
 
setAttribute(String, Integer) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Set an integer-valued attribute on the read.
setAttribute(String, String) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Set a String-valued attribute on the read.
setAttribute(String, byte[]) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Set a byte array attribute on the read.
setAttribute(String, Integer) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setAttribute(String, String) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setAttribute(String, byte[]) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setAttributeMap(Map<Allele, T>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AlleleSpecificAnnotationData
 
setAttributeMap(Map<Allele, T>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.ReducibleAnnotationData
Assign all of the per-allele raw data at once
setAttributesToReverse(Set<String>) - Method in class picard.sam.AbstractAlignmentMerger
Sets the set of attributes to be reversed on reads marked as negative strand.
setAttributesToReverseComplement(Set<String>) - Method in class picard.sam.AbstractAlignmentMerger
Sets the set of attributes to be reverse complemented on reads marked as negative strand.
setBaitSetName(String) - Method in class picard.analysis.directed.TargetMetricsCollector.PerUnitTargetMetricCollector
Sets the name of the bait set explicitly instead of inferring it from the bait file.
setBaseQualities(byte[]) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Set the read's base qualities.
setBaseQualities(byte[]) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setBaseQualityString(GATKRead, String) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Set the base qualities from a string of ASCII encoded values
setBases(byte[]) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Set the read's sequence.
setBases(byte[]) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setBases(byte[]) - Method in class picard.illumina.parser.ReadData
 
setBigDuplicateSetSize(int) - Method in class picard.sam.markduplicates.util.OpticalDuplicateFinder
Sets the size of a set that is big enough to log progress about.
setBufferSize(int) - Method in class org.broadinstitute.hellbender.utils.runtime.OutputStreamSettings
 
setcDnaChange(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setcDnaChange(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
Set the CDNA Change String in the GencodeFuncotation.
setCds(GencodeGtfCDSFeature) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfExonFeature
 
setChromosome(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setChromosome(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
Set the Chromosome name in the GencodeFuncotation.
setCigar(Cigar) - Method in class org.broadinstitute.hellbender.utils.haplotype.Haplotype
Set the cigar of this haplotype to cigar.
setCigar(Cigar) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Set the read's Cigar using an existing Cigar object describing how the read aligns to the reference.
setCigar(String) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Set the read's Cigar using a textual cigar String describing how the read aligns to the reference.
setCigar(Cigar) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setCigar(String) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setClipOverlappingReads(boolean) - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.AbstractAlignmentMerger
 
setClipOverlappingReads(boolean) - Method in class picard.sam.AbstractAlignmentMerger
 
setCodingSequenceAlleleStart(Integer) - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
setCodonChange(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setCodonChange(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
Set the Codon Change String in the GencodeFuncotation.
setCollectorsToRun(List<CollectMultipleMetricsSpark.SparkCollectorProvider>) - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectMultipleMetricsSpark
Use this method when invoking CollectMultipleMetricsSpark programmatically to run programs other than the ones available via enum.
setCommand(String[]) - Method in class org.broadinstitute.hellbender.utils.runtime.ProcessSettings
 
setCompareBamFilesSorted(boolean) - Method in class org.broadinstitute.hellbender.utils.test.IntegrationTestSpec
 
setContig(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
setCounter(long) - Method in class picard.analysis.AbstractWgsMetricsCollector
Sets the counter to the current number of processed loci.
setCovariateIndex(int) - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.ReadCovariates
 
setData(ClipReads.ClippingData) - Method in class org.broadinstitute.hellbender.tools.ClipReads.ReadClipperWithData
 
setData(List<VariantDatum>) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
 
setDataSourceName(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setDataSourceName(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
Set the Data Source Name String in the GencodeFuncotation.
setDebug(boolean) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingAssembler
 
setDebugGraphOutputPath(File) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingAssembler
Set where to write debug graph files if ReadThreadingAssembler.debugGraphTransformations == true
setDebugGraphTransformations(boolean) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingAssembler
 
setDeciles(DecileCollection) - Method in class org.broadinstitute.hellbender.utils.mcmc.PosteriorSummary
 
setDefaultHeaders(List<Header>) - Method in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
Replaces the set of default metrics headers by the given argument.
setDefaultHeaders(List<Header>) - Method in class picard.cmdline.CommandLineProgram
 
setDeletionBaseQualities(GATKRead, byte[]) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
setDirectory(File) - Method in class org.broadinstitute.hellbender.utils.runtime.ProcessSettings
 
setDownsampler(ReadsDownsampler) - Method in class org.broadinstitute.hellbender.engine.MultiIntervalLocalReadShard
Reads in this shard will be downsampled using this downsampler before being returned.
setDownsamplingInfo(LIBSDownsamplingInfo) - Method in class org.broadinstitute.hellbender.utils.locusiterator.AlignmentContextIteratorBuilder
 
setEmitEmptyLoci(boolean) - Method in class org.broadinstitute.hellbender.utils.locusiterator.AlignmentContextIteratorBuilder
 
setEmpiricalQuality(double) - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalDatum
 
setEnabled(boolean) - Static method in class org.broadinstitute.hellbender.utils.logging.BunnyLog
Pass false to disable all logging via bunnylog (it's enabled by default).
setEnd(int) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setEnd(int) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
Set the end position (1-based, inclusive) in the GencodeFuncotation.
setEnvironment(Map<String, String>) - Method in class org.broadinstitute.hellbender.utils.runtime.ProcessSettings
 
setErrorCorrectKmers(boolean) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingAssembler
 
setEstimatedQReported(double) - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalDatum
 
setEventMap(EventMap) - Method in class org.broadinstitute.hellbender.utils.haplotype.Haplotype
 
setExonEndPosition(Integer) - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
setExonPosition(SimpleInterval) - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
setExonStartPosition(Integer) - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
setFailsVendorQualityCheck(boolean) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Mark the read as failing platform/vendor quality checks
setFailsVendorQualityCheck(boolean) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setFeatureCodecClass(Class<FeatureCodec<T, ?>>) - Method in class org.broadinstitute.hellbender.engine.FeatureInput
Remember the FeatureCodec class for this input the first time it is discovered so we can bypass dynamic codec discovery when multiple FeatureDataSources are created for the same input.
setFeatureOrderNumber(int) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
setFieldSerializationOverrideValue(String, String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setFieldSerializationOverrideValue(String, String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.TableFuncotation
 
setFieldSerializationOverrideValue(String, String) - Method in interface org.broadinstitute.hellbender.tools.funcotator.Funcotation
Override the given field with a given value for when it comes time to serialize and write this Funcotation.
setFieldSerializationOverrideValues(Map<String, String>) - Method in interface org.broadinstitute.hellbender.tools.funcotator.Funcotation
Override fields with values as specified by the input map (for when it comes time to serialize and write this Funcotation).
setFilteredGenotypesToNocall - Variable in class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
If this argument is provided, set filtered genotypes to no-call (./.).
setFilteredGenotypeToNocall(VariantContextBuilder, VariantContext, boolean, BiFunction<VariantContext, Genotype, List<String>>) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Set the builder's filtered genotypes to no-call and update AC, AN and AF
setFinalized(boolean) - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
 
setFounderIds(List<String>) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.PedigreeAnnotation
 
setFragmentLength(int) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Set the observed length of the read's fragment (equivalent to TLEN in SAM).
setFragmentLength(int) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setFullReferenceWithPadding(byte[]) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResultSet
Sets the full reference with padding base sequence.
setGcContent(Double) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setGcContent(Double) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
Set the GC Content Double in the GencodeFuncotation.
setGcContent(Double) - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
setGeneTranscriptType(GencodeGtfFeature.GeneTranscriptType) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setGeneTranscriptType(GencodeGtfFeature.GeneTranscriptType) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
Set the GeneTranscriptType GencodeGtfFeature.GeneTranscriptType in the GencodeFuncotation.
setGenomeChange(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setGenomeChange(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
Set the Genome Change in the GencodeFuncotation.
setGenomeLocation(Locatable) - Method in class org.broadinstitute.hellbender.utils.haplotype.Haplotype
 
setGenotypeQualityFromPLs(GenotypeBuilder, Genotype) - Static method in class org.broadinstitute.hellbender.utils.GATKProtectedVariantContextUtils
Instead of using the GQ value, it re-calculates the quality from the PL so that it does not need to be bounded by an artificial maximum such as the standard GQ = 99.
setGenotypingErrorRate(double) - Method in class picard.fingerprint.FingerprintChecker
Sets the assumed genotyping error rate used when accurate error rates are not available.
setGlobalNIODefaultOptions() - Static method in class org.broadinstitute.hellbender.utils.gcs.BucketUtils
Sets NIO_MAX_REOPENS and generous timeouts as the global default.
setGlobalNIODefaultOptions(int) - Static method in class org.broadinstitute.hellbender.utils.gcs.BucketUtils
 
setGraphWriter(File) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingAssembler
 
setHeader(SAMFileHeader) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilter
 
setHeader(SAMFileHeader) - Method in class org.broadinstitute.hellbender.engine.filters.WellformedReadFilter
 
setHeader(SAMFileHeader) - Static method in class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSink.SparkBAMOutputFormat
 
setHeader(SAMFileHeader) - Static method in class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSink.SparkCRAMOutputFormat
 
setHeader(SAMFileHeader) - Static method in class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSink.SparkSAMOutputFormat
 
setHeader(SAMFileHeader) - Method in class org.broadinstitute.hellbender.utils.read.ArtificialBAMBuilder
 
setHeader(SAMFileHeader) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setHeader(SAMFileHeader) - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
setHeader(VCFHeader) - Method in class org.broadinstitute.hellbender.utils.variant.writers.GVCFWriter
 
sethInfo(VCFInfoHeaderLine) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotatorEngine.VAExpression
 
setHugoSymbol(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setHugoSymbol(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
Set the Hugo Symbol / Gene Name in the GencodeFuncotation.
setIgnoreExceptions(boolean) - Method in class org.broadinstitute.hellbender.utils.runtime.ScriptExecutor
Set to true to have the ScriptExecutor catch and ignore GATK exceptions.
setIncludeDeletions(boolean) - Method in class org.broadinstitute.hellbender.utils.locusiterator.AlignmentContextIteratorBuilder
 
setIncludeNs(boolean) - Method in class org.broadinstitute.hellbender.utils.locusiterator.AlignmentContextIteratorBuilder
 
setIncludeSecondaryAlignments(boolean) - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.AbstractAlignmentMerger
 
setIncludeSecondaryAlignments(boolean) - Method in class picard.sam.AbstractAlignmentMerger
 
setInputBuffer(String) - Method in class org.broadinstitute.hellbender.utils.runtime.InputStreamSettings
 
setInputFile(File) - Method in class org.broadinstitute.hellbender.utils.runtime.InputStreamSettings
 
setInputStream(InputStream) - Method in class htsjdk.samtools.SAMRecordSparkCodec
Sets the input stream that records will be read from.
setInputStream(InputStream, String) - Method in class htsjdk.samtools.SAMRecordSparkCodec
Sets the input stream that records will be read from.
setInputStream(InputStream) - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEndsForMarkDuplicatesCodec
 
setInputStream(InputStream) - Method in class picard.sam.markduplicates.util.ReadEndsForMarkDuplicatesCodec
 
setInputStream(InputStream) - Method in class picard.sam.markduplicates.util.RepresentativeReadIndexerCodec
 
setInsertionBaseQualities(GATKRead, byte[]) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
 
setIntervalsForTraversal(List<SimpleInterval>) - Method in class org.broadinstitute.hellbender.engine.FeatureDataSource
Restricts traversals of this data source via FeatureDataSource.iterator() to only return Features that overlap the provided intervals.
setIntervalsForTraversal(List<SimpleInterval>) - Method in class org.broadinstitute.hellbender.engine.MultiVariantDataSource
Restricts traversals of this data source via MultiVariantDataSource.iterator() to only return variants that overlap the provided intervals.
setIsActiveProb(double) - Method in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfileState
Set the probability that this site is active.
setIsDuplicate(boolean) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Mark the read as a PCR or optical duplicate.
setIsDuplicate(boolean) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setIsFirstOfPair() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Mark the read as the first read of a pair.
setIsFirstOfPair() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setIsPaired(boolean) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Mark the read as paired (having a mate) or not paired.
setIsPaired(boolean) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setIsProperlyPaired(boolean) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Mark the read as properly paired (or not properly paired).
setIsProperlyPaired(boolean) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setIsRef(boolean) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseEdge
Indicate that this edge follows the reference sequence, or not
setIsReverseStrand(boolean) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Mark the read as being on the reverse (or forward) strand.
setIsReverseStrand(boolean) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setIsSecondaryAlignment(boolean) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Mark the read as a secondary alignment (an alternative to the primary alignment)
setIsSecondaryAlignment(boolean) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setIsSecondOfPair() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Mark the read as the second read of a pair.
setIsSecondOfPair() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setIsSupplementaryAlignment(boolean) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Mark the read as a supplementary alignment (used in the representation of a chimeric alignment)
setIsSupplementaryAlignment(boolean) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setIsUnmapped() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Mark the read as unmapped (lacking a defined position on the genome).
setIsUnmapped() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setKeepAlignerProperPairFlags(boolean) - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.AbstractAlignmentMerger
If true, keep the aligner's idea of proper pairs rather than letting alignment merger decide.
setKeepAlignerProperPairFlags(boolean) - Method in class picard.sam.AbstractAlignmentMerger
If true, keep the aligner's idea of proper pairs rather than letting alignment merger decide.
setKeepUniqueReadListInLibs(boolean) - Method in class org.broadinstitute.hellbender.utils.locusiterator.AlignmentContextIteratorBuilder
 
setKingdomTaxonId(int) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenTaxonScore
 
setLane(int) - Method in class picard.illumina.parser.ClusterData
 
setLength(long) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTreeNode
 
setLengthOf(int, long) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTree
 
setLibraryId(short) - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
setLibraryId(short) - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Pair
 
setLibraryId(short) - Method in class picard.sam.markduplicates.util.PhysicalLocationForMateCigar
 
setLibraryId(short) - Method in class picard.sam.markduplicates.util.ReadEnds
 
setLibraryId(short) - Method in interface picard.sam.util.PhysicalLocation
 
setLibraryId(short) - Method in class picard.sam.util.PhysicalLocationInt
 
setLocationSet(PhysicalLocationForMateCigarSet) - Method in class picard.sam.markduplicates.util.ReadEndsForMateCigar
 
setLocusLevel(Integer) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setLocusLevel(Integer) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
Set the LocusLevel Integer in the GencodeFuncotation.
setLogger(Logger) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingEngine
Changes the logger for this genotyper engine.
setLoggingLevel(Log.LogLevel) - Static method in class org.broadinstitute.hellbender.utils.LoggingUtils
Propagate the verbosity level to Picard, log4j, the java built in logger, and Kryo's MinLog
setMappingQuality(int) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Set the mapping quality of this alignment, representing how likely the read maps to this position as opposed to other locations.
setMappingQuality(int) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setMatchedBarcode(String) - Method in class picard.illumina.parser.ClusterData
 
setMateChanged() - Method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.OverhangFixingManager.SplitRead
 
setMateIsReverseStrand(boolean) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Mark the read's mate as being on the reverse (or forward) strand.
setMateIsReverseStrand(boolean) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setMateIsUnmapped() - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Mark the read's mate as unmapped (lacking a defined position on the genome).
setMateIsUnmapped() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setMatePosition(String, int) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Set the position of the read's mate (the contig and the start position).
setMatePosition(Locatable) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Set the position of the read's mate using the position of an existing Locatable.
setMatePosition(String, int) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setMatePosition(Locatable) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setMaxDuplicateSetSize(long) - Method in class picard.sam.markduplicates.util.OpticalDuplicateFinder
Sets the size of a set that is too big to process.
setmaximalPLDifference(int) - Method in class picard.fingerprint.FingerprintChecker
Sets the maximal difference in PL scores considered when reading PLs from a VCF.
setMaxPairErrorRate(double) - Method in class picard.util.AdapterMarker
 
setMaxRecordsInRam(int) - Method in class picard.sam.AbstractAlignmentMerger
Allows the caller to override the maximum records in RAM.
setMaxSingleEndErrorRate(double) - Method in class picard.util.AdapterMarker
 
setMinBaseQualityToUseInAssembly(byte) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingAssembler
 
setMinDanglingBranchLength(int) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingAssembler
 
setMinimumBaseQuality(int) - Method in class picard.fingerprint.FingerprintChecker
Sets the minimum base quality for bases used when computing a fingerprint from sequence data.
setMinimumMappingQuality(int) - Method in class picard.fingerprint.FingerprintChecker
Sets the minimum mapping quality for reads used when computing fingerprints from sequence data.
setMinimumSeriesLengthForNormalApproximation(int) - Method in class org.broadinstitute.hellbender.utils.MannWhitneyU
Sets the minimum number of values in each data series to use the normal distribution approximation.
setMinPairMatchBases(int) - Method in class picard.util.AdapterMarker
 
setMinSingleEndMatchBases(int) - Method in class picard.util.AdapterMarker
 
setMultiplicity(int) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseEdge
Set the multiplicity of this edge to value
setName(String) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenReferenceTaxonProperties
 
setName(String) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTreeNode
 
setName(String) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.OptionalField
 
setName(String) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Set the name of the read (equivalent to QNAME in SAM), or set to null if the read has no name.
setName(String) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setName(String) - Method in class org.broadinstitute.hellbender.utils.test.BaseTest.TestDataProvider
 
setNameOf(int, String) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTree
 
setNcbiBuild(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setNcbiBuild(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
Set the NCBI build in the GencodeFuncotation.
setNearProbeDistance(int) - Method in class picard.analysis.directed.TargetMetricsCollector
Sets the distance that is allowed between a read and the nearest probe for it to be considered "near probe" and "selected.
SetNmAndUqTags - Class in picard.sam
Deprecated.
SetNmAndUqTags() - Constructor for class picard.sam.SetNmAndUqTags
Deprecated.
 
SetNmMdAndUqTags - Class in picard.sam
Fixes the NM, MD, and UQ tags in a SAM or BAM file.
SetNmMdAndUqTags() - Constructor for class picard.sam.SetNmMdAndUqTags
 
setNoise(FourChannelIntensityData) - Method in class picard.illumina.parser.ReadData
 
setNoMateCigars(boolean) - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
setNormalization(Map<String, Double>, Map<String, Double>) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
 
setNoSideEffects(boolean) - Method in class picard.analysis.directed.TargetMetricsCollector
In the case of ignoring bases in overlapping reads from the same template, we choose to internally modify the SAM record's CIGAR to clip overlapping bases.
setNumAdaptersToKeep(int) - Method in class picard.util.AdapterMarker
After seeing the thresholdForSelectingAdapters number of adapters, keep up to this many of the original adapters.
setNumArtifactMode(long) - Method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationSampleTransitionSummary
 
setNumArtifactModeFiltered(long) - Method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationSampleTransitionSummary
 
setNumMismatches(double) - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalDatum
 
setNumNonRefPassingVariants(long) - Method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationSampleTransitionSummary
 
setNumNotArtifactMode(long) - Method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationSampleTransitionSummary
 
setNumObservations(long) - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalDatum
 
setNumSamplesPerLogEntry(int) - Method in class org.broadinstitute.hellbender.utils.mcmc.GibbsSampler
Changes the number of samples per log entry.
setObq(double) - Method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationSampleTransitionSummary
 
setOrCheckLane(int) - Method in class picard.illumina.parser.ClusterData
Either set this value if not already set, or if already set, throw an exception if new value != current value.
setOrCheckPf(boolean) - Method in class picard.illumina.parser.ClusterData
Either set this value if not already set, or if already set, throw an exception if new value != current value.
setOrCheckTile(int) - Method in class picard.illumina.parser.ClusterData
Either set this value if not already set, or if already set, throw an exception if new value != current value.
setOrCheckX(int) - Method in class picard.illumina.parser.ClusterData
Either set this value if not already set, or if already set, throw an exception if new value != current value.
setOrCheckY(int) - Method in class picard.illumina.parser.ClusterData
Either set this value if not already set, or if already set, throw an exception if new value != current value.
setOtherTranscripts(List<String>) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setOtherTranscripts(List<String>) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
Set the list of other Transcript IDs in the GencodeFuncotation.
setOutput(File) - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
setOutputFile(File) - Method in class org.broadinstitute.hellbender.utils.runtime.OutputStreamSettings
Overwrites the outputFile with the process output.
setOutputFile(File, boolean) - Method in class org.broadinstitute.hellbender.utils.runtime.OutputStreamSettings
 
setOutputStream(OutputStream) - Method in class htsjdk.samtools.SAMRecordSparkCodec
Sets the output stream that records will be written to.
setOutputStream(OutputStream, String) - Method in class htsjdk.samtools.SAMRecordSparkCodec
Sets the output stream that records will be written to.
setOutputStream(OutputStream) - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEndsForMarkDuplicatesCodec
 
setOutputStream(OutputStream) - Method in class picard.sam.markduplicates.util.ReadEndsForMarkDuplicatesCodec
 
setOutputStream(OutputStream) - Method in class picard.sam.markduplicates.util.RepresentativeReadIndexerCodec
 
setOverrideValuesInFuncotations(List<Funcotation>) - Method in class org.broadinstitute.hellbender.tools.funcotator.DataSourceFuncotationFactory
Apply the override values in DataSourceFuncotationFactory.annotationOverrideMap to every Funcotation in the given outputFuncotations.
setPaddedReferenceLoc(SimpleInterval) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResultSet
Changes the padded reference location.
setParent(int) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenReferenceTaxonProperties
 
setParent(int) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTreeNode
 
setPedigreeFile(File) - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.PedigreeAnnotation
Setter for pedigree file and founderIDs to be used by the GATKAnnotationPluginDescriptor to handle duplicated annotaiton arguments between InbreedingCoeff and ExcessHet
setPerBaseOutput(File) - Method in class picard.analysis.directed.TargetMetricsCollector.PerUnitTargetMetricCollector
Sets the (optional) File to write per-base coverage information to.
setPerTargetOutput(File) - Method in class picard.analysis.directed.TargetMetricsCollector.PerUnitTargetMetricCollector
Sets the (optional) File to write per-target coverage information to.
setPf(boolean) - Method in class picard.illumina.parser.ClusterData
 
setpLossofHet(double) - Method in class picard.fingerprint.FingerprintChecker
 
setPosition(String, int) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Set the position of the read (the contig and the start position).
setPosition(Locatable) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Set the position of the read using the position of an existing Locatable.
setPosition(String, int) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setPosition(Locatable) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setPositionInfo(AbstractIlluminaPositionFileReader.PositionInfo) - Method in class picard.illumina.parser.CbclData
 
setPostReadFilterTransformer(ReadTransformer) - Method in class org.broadinstitute.hellbender.engine.MultiIntervalLocalReadShard
Reads in this shard will be transformed after filtering and before downsampling
setPredictedMateInformation(GATKRead) - Method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.OverhangFixingManager
Will edit the mate MC tag and mate start position field for given read if that read has been recorded being edited by the OverhangFixingManager before.
setPreReadFilterTransformer(ReadTransformer) - Method in class org.broadinstitute.hellbender.engine.MultiIntervalLocalReadShard
Reads in this shard will be transformed before filtering
setPrimaryAlignment(int) - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.HitsForInsert
Set all alignments to not primary, except for the one specified by the argument.
setProgramRecord(SAMProgramRecord) - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.AbstractAlignmentMerger
 
setProgramRecord(SAMProgramRecord) - Method in class picard.sam.AbstractAlignmentMerger
 
setProgramsToRun(Collection<CollectMultipleMetrics.ProgramInterface>) - Method in class picard.analysis.CollectMultipleMetrics
Use this method when invoking CollectMultipleMetrics programmatically to run programs other than the ones available via enum.
setProteinChange(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setProteinChange(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
Set the Protein Change String in the GencodeFuncotation.
setProteinChangeEndPosition(Integer) - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
setProteinChangeStartPosition(Integer) - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
setPruneFactor(int) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingAssembler
 
setQualities(byte[]) - Method in class picard.illumina.parser.ReadData
 
setRank(String) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenReferenceTaxonProperties
 
setRank(String) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTreeNode
 
setRankOf(int, String) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTree
 
setRawIntensities(FourChannelIntensityData) - Method in class picard.illumina.parser.ReadData
 
setRead(GATKRead) - Method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.OverhangFixingManager.SplitRead
 
setReadFilter(ReadFilter) - Method in class org.broadinstitute.hellbender.engine.MultiIntervalLocalReadShard
Reads in this shard will be filtered using this filter before being returned.
setReadGroup(String) - Method in interface org.broadinstitute.hellbender.utils.read.GATKRead
Set the ID of the read group this read belongs to, or null for none.
setReadGroup(short) - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
setReadGroup(short) - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Pair
 
setReadGroup(String) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
setReadGroup(short) - Method in class picard.sam.markduplicates.util.PhysicalLocationForMateCigar
 
setReadGroup(short) - Method in class picard.sam.markduplicates.util.ReadEnds
 
setReadGroup(short) - Method in interface picard.sam.util.PhysicalLocation
 
setReadGroup(short) - Method in class picard.sam.util.PhysicalLocationInt
 
setReadLength(int) - Method in class org.broadinstitute.hellbender.utils.read.ArtificialBAMBuilder
 
setReadsAsSupplemental(GATKRead, List<GATKRead>) - Static method in class org.broadinstitute.hellbender.utils.SATagBuilder
Sets a collection of GATKReads as supplemental reads of the primary read, This tool will set the isSupplemental attribute as well as the 'SA:' tag properly according to the Samspec (example: SA:rname,position,strand,Cigar,mapQ,NM;...) Note: this tool will not unset the primary read as supplemental, futhermore it will simply add to any existing SA tags on the given reads.
setReadType(ReadType) - Method in class picard.illumina.parser.ReadData
 
setRecordLabel(String) - Method in class org.broadinstitute.hellbender.engine.ProgressMeter
Change the label used for records in logger messages.
setRecordsBetweenTimeChecks(long) - Method in class org.broadinstitute.hellbender.engine.ProgressMeter
Set the number of records we need to process before we check the current time
setRecoverDanglingBranches(boolean) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingAssembler
 
setRedirectErrorStream(boolean) - Method in class org.broadinstitute.hellbender.utils.runtime.ProcessSettings
 
setRef(Allele, X) - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.PerAlleleCollection
 
setRefAllele(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setRefAllele(Allele) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
Set the Reference Allele in the GencodeFuncotation.
setReferenceAllele(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
setReferenceAminoAcidSequence(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
setReferenceBases(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
setReferenceCodingSequence(ReferenceSequence) - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
setReferenceContext(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setReferenceContext(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
Set the Reference Context String in the GencodeFuncotation.
setReferenceLength(long) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenTaxonScore
 
setReferenceSequence(File) - Method in class picard.analysis.SinglePassSamProgram
Set the reference File.
setReferenceWindow(Integer) - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
setRegionForGenotyping(AssemblyRegion) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResultSet
Sets the region for genotyping.
setRemovePathsNotConnectedToRef(boolean) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingAssembler
 
setResultState(boolean) - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.SamRecordWithOrdinalAndSetDuplicateReadFlag
 
setResultState(boolean) - Method in class picard.sam.markduplicates.util.SamRecordWithOrdinalAndSetDuplicateReadFlag
 
setSample(String) - Method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationSampleTransitionSummary
 
setSampleContamination(Map<String, Double>) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.StandardCallerArgumentCollection
Set the sample contamination map using the provided map.
setSATag() - Method in class org.broadinstitute.hellbender.utils.SATagBuilder
Sets the stored SA tag information into the SA attribute field of the read encapsulated by the SATagBuilder
setScore(double) - Method in class org.broadinstitute.hellbender.utils.haplotype.Haplotype
Set the score (an estimate of the support) of this haplotype.
setSecondaryVariantClassification(GencodeFuncotation.VariantClassification) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setSecondaryVariantClassification(GencodeFuncotation.VariantClassification) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
Set the Secondary Variant Classification in the GencodeFuncotation.
setSentinel(V) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree
Set the special sentinel value that will be used to signal novelty when putting a new interval into the tree, or to signal "not found" when removing an interval.
setSize() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerSet
 
setSize - Variable in class picard.sam.util.RepresentativeReadIndexer
 
SetSizeUtils - Class in org.broadinstitute.hellbender.tools.spark.utils
Set size utility
SetSizeUtils() - Constructor for class org.broadinstitute.hellbender.tools.spark.utils.SetSizeUtils
 
setSkipBlankLines(boolean) - Method in class picard.util.AbstractInputParser
 
setSkipNLoci(int) - Method in class org.broadinstitute.hellbender.utils.read.ArtificialBAMBuilder
 
setStart(int) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setStart(int) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
Set the start position (1-based, inclusive) in the GencodeFuncotation.
setStart(GenomeLoc, int) - Static method in class org.broadinstitute.hellbender.utils.GenomeLoc
create a new genome loc from an existing loc, with a new start position Note that this function will NOT explicitly check the ending offset, in case someone wants to set the start of a new GenomeLoc pertaining to a read that goes off the end of the contig.
setStartCodon(GencodeGtfStartCodonFeature) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfExonFeature
 
setStop(GenomeLoc, int) - Static method in class org.broadinstitute.hellbender.utils.GenomeLoc
create a new genome loc from an existing loc, with a new stop position Note that this function will NOT explicitly check the ending offset, in case someone wants to set the stop of a new GenomeLoc pertaining to a read that goes off the end of the contig.
setStopCodon(GencodeGtfStopCodonFeature) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfExonFeature
 
setStrand(Strand) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
Set the Strand in the GencodeFuncotation.
setStrand(Strand) - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
setSupportedFuncotationFields(List<Path>) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv.LocatableXsvFuncotationFactory
 
setTestVerbosity() - Method in class org.broadinstitute.hellbender.utils.test.BaseTest
 
setThreadingStartOnlyAtExistingVertex(boolean) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingGraph
Changes the threading start location policy.
setThresholdForSelectingAdaptersToKeep(int) - Method in class picard.util.AdapterMarker
When this number of adapters have been matched, discard the least-frequently matching ones.
setTile(short) - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
setTile(short) - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Pair
 
setTile(int) - Method in class picard.illumina.parser.ClusterData
 
setTile(short) - Method in interface picard.sam.util.PhysicalLocation
 
setTile(short) - Method in class picard.sam.util.PhysicalLocationInt
 
setTiles(List<Integer>) - Method in class picard.illumina.parser.ParameterizedFileUtil
 
setTilesForPerRunFile(List<Integer>) - Method in class picard.illumina.parser.ParameterizedFileUtil
 
setTilesForPerRunFile(List<Integer>) - Method in class picard.illumina.parser.PerTileOrPerRunFileUtil
 
setTo(int) - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
Set the set contents to a single integer value.
setTo(int...) - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
Set the content of this set to a collection of integers.
setToMarkQueueMinimumDistance(int) - Method in class picard.sam.markduplicates.util.MarkQueue
Sets the minimum genomic distance such that we can be assured that all duplicates have been considered.
setTranscriptAlleleStart(Integer) - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
setTranscriptCodingSequence(ReferenceSequence) - Method in class org.broadinstitute.hellbender.tools.funcotator.SequenceComparison
 
setTranscriptExonNumber(Integer) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setTranscriptExonNumber(int) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
Set the transcript exon number in the GencodeFuncotation.
setTranscriptLength(Integer) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setTranscriptLength(Integer) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
Set the Transcript Length Integer in the GencodeFuncotation.
setTranscriptPos(Integer) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setTranscriptPos(Integer) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
Set the position (1-based, inclusive) relative to the start of the transcript of a the variant in the GencodeFuncotation.
setTranscriptStrand(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setTransientAttribute(Object, Object) - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
This is used to access the transient attribute store in the underlying SAMRecord.
setTraversalBounds(List<SimpleInterval>) - Method in class org.broadinstitute.hellbender.engine.ReadsDataSource
Restricts a traversal of this data source via ReadsDataSource.iterator() to only return reads which overlap the given intervals.
setTraversalBounds(TraversalParameters) - Method in class org.broadinstitute.hellbender.engine.ReadsDataSource
Restricts a traversal of this data source via ReadsDataSource.iterator() to only return reads that overlap the given intervals, and to unmapped reads if specified.
setTraversalBounds(List<SimpleInterval>, boolean) - Method in class org.broadinstitute.hellbender.engine.ReadsDataSource
Restricts a traversal of this data source via ReadsDataSource.iterator() to only return reads that overlap the given intervals, and to unmapped reads if specified.
setTreatGroupedDelimitersAsOne(boolean) - Method in class picard.util.AbstractInputParser
 
setTumorSeqAllele2(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setTumorSeqAllele2(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
Set the bases of tumorSeqAllele2 in the GencodeFuncotation.
setUcscGenomeVersion(String) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
setup(Set<MetricAccumulationLevel>, List<SAMReadGroupRecord>) - Method in class org.broadinstitute.hellbender.metrics.MultiLevelCollector
Use an init method so that overloaded methods in subclasses can pass use parameters that are initialized in their constructor
setup(Set<MetricAccumulationLevel>, List<SAMReadGroupRecord>) - Method in class org.broadinstitute.hellbender.metrics.MultiLevelReducibleCollector
Use an init method so that overloaded methods in subclasses can pass use parameters that are initialized in their constructor
setup(SAMFileHeader, File) - Method in class picard.analysis.artifacts.CollectSequencingArtifactMetrics
 
setup(SAMFileHeader, File) - Method in class picard.analysis.CollectAlignmentSummaryMetrics
 
setup(SAMFileHeader, File) - Method in class picard.analysis.CollectBaseDistributionByCycle
 
setup(SAMFileHeader, File) - Method in class picard.analysis.CollectGcBiasMetrics
 
setup(SAMFileHeader, File) - Method in class picard.analysis.CollectInsertSizeMetrics
 
setup(SAMFileHeader, File) - Method in class picard.analysis.CollectQualityYieldMetrics
 
setup(SAMFileHeader, File) - Method in class picard.analysis.CollectRnaSeqMetrics
 
setup(SAMFileHeader, File) - Method in class picard.analysis.MeanQualityByCycle
 
setup(SAMFileHeader, File) - Method in class picard.analysis.QualityScoreDistribution
 
setup(SAMFileHeader, File) - Method in class picard.analysis.SinglePassSamProgram
Should be implemented by subclasses to do one-time initialization work.
setup(Set<MetricAccumulationLevel>, List<SAMReadGroupRecord>) - Method in class picard.metrics.MultiLevelCollector
Use an init method so that overloaded methods in subclasses can pass use parameters that are initialized in their constructor
setup(VCFHeader) - Method in class picard.vcf.CallingMetricAccumulator
 
setup(VCFHeader) - Method in class picard.vcf.GvcfMetricAccumulator
 
setupConfigAndExtractProgram(String[], List<String>, List<Class<? extends CommandLineProgram>>, String) - Method in class org.broadinstitute.hellbender.Main
Set up the configuration file store and create the CommandLineProgram to run.
setupOpticalDuplicateFinder() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.AbstractOpticalDuplicateFinderCommandLineProgram
 
setupOpticalDuplicateFinder() - Method in class picard.sam.markduplicates.util.AbstractOpticalDuplicateFinderCommandLineProgram
 
setUseOriginalQualities(boolean) - Method in class org.broadinstitute.hellbender.metrics.QualityYieldMetrics
 
setValidated(boolean) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence
 
setValidationStringency(ValidationStringency) - Method in class org.broadinstitute.hellbender.utils.test.IntegrationTestSpec
 
setValidationStringency(ValidationStringency) - Method in class picard.fingerprint.FingerprintChecker
 
setValue(Integer) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.KmerAndInterval
 
setValue(Integer) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.QNameAndInterval
 
setValue(Integer) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.KmerAndCount
 
setValue(V1) - Method in interface org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree.Entry
 
setValue(T) - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.OptionalField
 
setValuesFromAlignment(SAMRecord, SAMRecord) - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.AbstractAlignmentMerger
Sets the values from the alignment record on the unaligned BAM record.
setValuesFromAlignment(SAMRecord, SAMRecord, boolean) - Method in class picard.sam.AbstractAlignmentMerger
Sets the values from the alignment record on the unaligned BAM record.
setVariantClassification(GencodeFuncotation.VariantClassification) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setVariantClassification(GencodeFuncotation.VariantClassification) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
Set the Variant Classification in the GencodeFuncotation.
setVariantType(GencodeFuncotation.VariantType) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setVariantType(GencodeFuncotation.VariantType) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
Set the Variant Type (1-based, inclusive) in the GencodeFuncotation.
setVCFHeader(VCFHeader) - Static method in class org.broadinstitute.hellbender.engine.spark.datasources.VariantsSparkSink.SparkVCFOutputFormat
 
setVersion(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
setVersion(String) - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotationBuilder
Set the Version String in the GencodeFuncotation.
setWalkerType(String) - Method in class org.broadinstitute.hellbender.utils.help.GATKGSONWorkUnit
 
setWindow(int, int) - Method in class org.broadinstitute.hellbender.engine.ReferenceContext
Set expanded window boundaries, subject to cropping at contig boundaries Allows the client to request a specific number of extra reference bases to include before and after the bases within our interval.
setWordCount(int) - Method in class picard.util.AbstractInputParser
 
setWriteHaplotypes(boolean) - Method in class org.broadinstitute.hellbender.utils.haplotype.HaplotypeBAMWriter
Set the HaplotypeBAMWriter to write out the haplotypes as reads.
setX(int) - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
setX(int) - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Pair
 
setX(int) - Method in class picard.illumina.parser.ClusterData
 
setX(int) - Method in interface picard.sam.util.PhysicalLocation
 
setX(int) - Method in class picard.sam.util.PhysicalLocationInt
 
setX(int) - Method in class picard.sam.util.PhysicalLocationShort
 
setY(int) - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
setY(int) - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Pair
 
setY(int) - Method in class picard.illumina.parser.ClusterData
 
setY(int) - Method in interface picard.sam.util.PhysicalLocation
 
setY(int) - Method in class picard.sam.util.PhysicalLocationInt
 
setY(int) - Method in class picard.sam.util.PhysicalLocationShort
 
Sex - Enum in org.broadinstitute.hellbender.utils.samples
ENUM of possible human sexes: male, female, or unknown
Sex - Enum in picard.pedigree
Represents the sex of an individual.
Shard<T> - Interface in org.broadinstitute.hellbender.engine
A Shard of records of type T covering a specific genomic interval, optionally expanded by a configurable amount of padded data, that provides the ability to iterate over its records.
shard(JavaSparkContext, JavaRDD<L>, Class<L>, SAMSequenceDictionary, List<ShardBoundary>, int) - Static method in class org.broadinstitute.hellbender.engine.spark.SparkSharder
Create an RDD of Shard from an RDD of coordinate sorted Locatable without using a shuffle.
shard(JavaSparkContext, JavaRDD<L>, Class<L>, SAMSequenceDictionary, List<ShardBoundary>, int, boolean) - Static method in class org.broadinstitute.hellbender.engine.spark.SparkSharder
Create an RDD of Shard from an RDD of coordinate sorted Locatable, optionally using a shuffle.
ShardBoundary - Class in org.broadinstitute.hellbender.engine
Holds the bounds of a Shard, both with and without padding
ShardBoundary(SimpleInterval, SimpleInterval) - Constructor for class org.broadinstitute.hellbender.engine.ShardBoundary
Create a new ShardBoundary from the given intervals
ShardBoundaryShard<T> - Class in org.broadinstitute.hellbender.engine
A Shard backed by a ShardBoundary and a collection of records.
ShardBoundaryShard(ShardBoundary, Iterable<T>) - Constructor for class org.broadinstitute.hellbender.engine.ShardBoundaryShard
Create a new ShardBoundaryShard from the given ShardBoundary and records.
SHARDED_OUTPUT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
 
ShardedIntervalIterator - Class in org.broadinstitute.hellbender.utils.iterators
Iterator that will break up each input interval into shards.
ShardedIntervalIterator(Iterator<SimpleInterval>, int) - Constructor for class org.broadinstitute.hellbender.utils.iterators.ShardedIntervalIterator
 
shardedOutput - Variable in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
 
shardedPartsDir - Variable in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
 
shardIndex(int, int) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
number of the shard this offset is in.
shardingArgs - Variable in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark
 
shardingArgs - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.ReadsPipelineSpark
 
ShardingArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark.ShardingArgumentCollection
 
ShardToMultiIntervalShardAdapter<T> - Class in org.broadinstitute.hellbender.engine
adapts a normal Shard into a MultiIntervalShard that contains only the single wrapped shard this is a temporary shim until we can fully adopt MultiIntervalShard in HaplotypeCallerSpark
ShardToMultiIntervalShardAdapter(Shard<T>) - Constructor for class org.broadinstitute.hellbender.engine.ShardToMultiIntervalShardAdapter
 
SharedSequenceMerger - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs
Merges the incoming vertices of a vertex V of a graph Looks at the vertices that are incoming to V (i.e., have an outgoing edge connecting to V).
SharedVertexSequenceSplitter - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs
Split a collection of middle nodes in a graph into their shared prefix and suffix values This code performs the following transformation.
SharedVertexSequenceSplitter(SeqGraph, Collection<SeqVertex>) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.SharedVertexSequenceSplitter
Create a utility that will change the given graph so that the vertices in toSplitsArg (with their shared suffix and prefix sequences) are extracted out.
shiftedLogEvidenceProbability() - Method in class picard.fingerprint.HaplotypeProbabilities
Returns log (p(evidence)) + c assuming that the prior on haplotypes is given by the internal haplotypeFrequencies
shiftedLogEvidenceProbabilityGivenOtherEvidence(HaplotypeProbabilities) - Method in class picard.fingerprint.HaplotypeProbabilities
returns the log-probability the evidence, using as priors the posteriors of another object
shiftedLogEvidenceProbabilityUsingGenotypeFrequencies(double[]) - Method in class picard.fingerprint.HaplotypeProbabilities
 
ShortVariantDiscoveryProgramGroup - Class in org.broadinstitute.hellbender.cmdline.programgroups
Tools that perform variant calling and genotyping for short variants (SNPs, SNVs and Indels)
ShortVariantDiscoveryProgramGroup() - Constructor for class org.broadinstitute.hellbender.cmdline.programgroups.ShortVariantDiscoveryProgramGroup
 
shouldBeInLocations(ReadEndsForMateCigar) - Method in class picard.sam.markduplicates.util.MarkQueue
Returns true if we should track this for optical duplicate detection, false otherwise
shouldErrorCorrectKmers() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingAssembler
 
ShouldNeverReachHereException(String) - Constructor for exception org.broadinstitute.hellbender.exceptions.GATKException.ShouldNeverReachHereException
 
ShouldNeverReachHereException(String, Throwable) - Constructor for exception org.broadinstitute.hellbender.exceptions.GATKException.ShouldNeverReachHereException
 
ShouldNeverReachHereException(Throwable) - Constructor for exception org.broadinstitute.hellbender.exceptions.GATKException.ShouldNeverReachHereException
 
showVerbose - Variable in class org.broadinstitute.hellbender.tools.spark.PileupSpark
In addition to the standard pileup output, adds 'verbose' output too.
showVerbose - Variable in class org.broadinstitute.hellbender.tools.walkers.qc.Pileup
In addition to the standard pileup output, adds 'verbose' output too.
shuffle - Variable in class org.broadinstitute.hellbender.engine.spark.AssemblyRegionWalkerSpark
 
shuffle - Variable in class org.broadinstitute.hellbender.engine.spark.IntervalWalkerSpark
 
shuffle - Variable in class org.broadinstitute.hellbender.engine.spark.LocusWalkerSpark
 
shuffle - Variable in class org.broadinstitute.hellbender.engine.spark.ReadWalkerSpark
 
shuffle - Variable in class org.broadinstitute.hellbender.engine.spark.VariantWalkerSpark
 
ShuffleJoinReadsWithRefBases - Class in org.broadinstitute.hellbender.engine.spark
RefBasesForReads queries the Google Genomics API for reference bases overlapping all of the reads.
ShuffleJoinReadsWithRefBases() - Constructor for class org.broadinstitute.hellbender.engine.spark.ShuffleJoinReadsWithRefBases
 
ShuffleJoinReadsWithVariants - Class in org.broadinstitute.hellbender.engine.spark
PairReadsAndVariants takes two RDDs (GATKRead and Variant) and returns an RDD with a (GATKRead,Iterable) for every read and all the variants that overlap.
ShuffleJoinReadsWithVariants() - Constructor for class org.broadinstitute.hellbender.engine.spark.ShuffleJoinReadsWithVariants
 
shutdown() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerEngine
Shutdown this HC engine, closing resources as appropriate
shutdown() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2Engine
 
signalEndOfInput() - Method in class org.broadinstitute.hellbender.utils.downsampling.Downsampler
Used to tell the downsampler that no more items will be submitted to it, and that it should finalize any pending items.
signalEndOfInput() - Method in class org.broadinstitute.hellbender.utils.downsampling.FractionalDownsampler
 
signalEndOfInput() - Method in class org.broadinstitute.hellbender.utils.downsampling.LevelingDownsampler
 
signalEndOfInput() - Method in class org.broadinstitute.hellbender.utils.downsampling.MutectDownsampler
 
signalEndOfInput() - Method in class org.broadinstitute.hellbender.utils.downsampling.PassThroughDownsampler
 
signalEndOfInput() - Method in class org.broadinstitute.hellbender.utils.downsampling.PositionalDownsampler
 
signalEndOfInput() - Method in class org.broadinstitute.hellbender.utils.downsampling.ReservoirDownsampler
 
signalNoMoreReadsBefore(GATKRead) - Method in class org.broadinstitute.hellbender.utils.downsampling.FractionalDownsampler
 
signalNoMoreReadsBefore(GATKRead) - Method in class org.broadinstitute.hellbender.utils.downsampling.MutectDownsampler
 
signalNoMoreReadsBefore(GATKRead) - Method in class org.broadinstitute.hellbender.utils.downsampling.PassThroughDownsampler
 
signalNoMoreReadsBefore(GATKRead) - Method in class org.broadinstitute.hellbender.utils.downsampling.PositionalDownsampler
 
signalNoMoreReadsBefore(GATKRead) - Method in class org.broadinstitute.hellbender.utils.downsampling.ReadsDownsampler
Tell this downsampler that no more reads located before the provided read (according to the sort order of the read stream) will be fed to it.
signalNoMoreReadsBefore(GATKRead) - Method in class org.broadinstitute.hellbender.utils.downsampling.ReservoirDownsampler
 
SILVERMANS_RULE_CONSTANT - Static variable in class org.broadinstitute.hellbender.utils.mcmc.PosteriorSummaryUtils
 
SILVERMANS_RULE_EXPONENT - Static variable in class org.broadinstitute.hellbender.utils.mcmc.PosteriorSummaryUtils
 
SimpleAnnotatedIntervalWriter - Class in org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval
SimpleAnnotatedIntervalWriter(File) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.SimpleAnnotatedIntervalWriter
Initialize this writer to the given output file.
simpleBaseToBaseIndex(byte) - Static method in class org.broadinstitute.hellbender.utils.BaseUtils
Converts a simple base to a base index
SimpleChimera - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.inference
Conceptually, a simple chimera represents the junction on AssemblyContigWithFineTunedAlignments that have exactly two good alignments.
SimpleChimera(Kryo, Input) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SimpleChimera
 
SimpleChimera(AlignmentInterval, AlignmentInterval, List<String>, String, String, SAMSequenceDictionary) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SimpleChimera
Construct a new SimpleChimera from two alignment intervals.
SimpleChimera.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.inference
 
simpleComplement(byte) - Static method in class org.broadinstitute.hellbender.utils.BaseUtils
Return the complement (A <-> T or C <-> G) of a base, or the specified base if it can't be complemented (i.e.
SimpleCopyRatioCaller - Class in org.broadinstitute.hellbender.tools.copynumber.caller
This caller is loosely based on the legacy ReCapSeg caller that was originally implemented in ReCapSeg v1.4.5.0, but introduces major changes.
SimpleCopyRatioCaller(CopyRatioSegmentCollection, double, double, double, double) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.caller.SimpleCopyRatioCaller
 
SimpleCount - Class in org.broadinstitute.hellbender.tools.copynumber.formats.records
Represents a count at an interval.
SimpleCount(SimpleInterval, int) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.records.SimpleCount
 
SimpleCountCollection - Class in org.broadinstitute.hellbender.tools.copynumber.formats.collections
Simple data structure to pass and read/write a List of SimpleCount objects.
SimpleCountCollection(SampleLocatableMetadata, List<SimpleCount>) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.collections.SimpleCountCollection
 
SimpleGermlineTagger - Class in org.broadinstitute.hellbender.tools.copynumber.utils.germlinetagging
This utility class performs a simple tagging of germline segments in a tumor segments file.
SimpleInterval - Class in org.broadinstitute.hellbender.utils
Minimal immutable class representing a 1-based closed ended genomic interval SimpleInterval does not allow null contig names.
SimpleInterval(String, int, int) - Constructor for class org.broadinstitute.hellbender.utils.SimpleInterval
Create a new immutable 1-based interval of the form [start, end]
SimpleInterval(Locatable) - Constructor for class org.broadinstitute.hellbender.utils.SimpleInterval
Create a new SimpleInterval from a Locatable
SimpleInterval(String) - Constructor for class org.broadinstitute.hellbender.utils.SimpleInterval
Makes an interval by parsing the string.
SimpleIntervalCollection - Class in org.broadinstitute.hellbender.tools.copynumber.formats.collections
Represents a collection of SimpleInterval associated to a sample.
SimpleIntervalCollection(File) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.collections.SimpleIntervalCollection
 
SimpleIntervalCollection(LocatableMetadata, List<SimpleInterval>) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.collections.SimpleIntervalCollection
 
SimpleKeyXsvFuncotationFactory - Class in org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv
Factory for creating TableFuncotations by handling `Separated Value` files with arbitrary delimiters (e.g.
SimpleKeyXsvFuncotationFactory(String, Path, String, String, int, SimpleKeyXsvFuncotationFactory.XsvDataKeyType) - Constructor for class org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv.SimpleKeyXsvFuncotationFactory
 
SimpleKeyXsvFuncotationFactory(String, Path, String, String, int, SimpleKeyXsvFuncotationFactory.XsvDataKeyType, LinkedHashMap<String, String>) - Constructor for class org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv.SimpleKeyXsvFuncotationFactory
 
SimpleKeyXsvFuncotationFactory(String, Path, String, String, int, SimpleKeyXsvFuncotationFactory.XsvDataKeyType, LinkedHashMap<String, String>, int) - Constructor for class org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv.SimpleKeyXsvFuncotationFactory
 
SimpleKeyXsvFuncotationFactory(String, Path, String, String, int, SimpleKeyXsvFuncotationFactory.XsvDataKeyType, LinkedHashMap<String, String>, int, boolean) - Constructor for class org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv.SimpleKeyXsvFuncotationFactory
 
SimpleKeyXsvFuncotationFactory.XsvDataKeyType - Enum in org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv
 
SimpleLocatableMetadata - Class in org.broadinstitute.hellbender.tools.copynumber.formats.metadata
Metadata associated with a collection of locatables.
SimpleLocatableMetadata(SAMSequenceDictionary) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.metadata.SimpleLocatableMetadata
 
SimpleMarkDuplicatesWithMateCigar - Class in picard.sam.markduplicates
This is a simple tool to mark duplicates using the DuplicateSetIterator, DuplicateSet, and SAMRecordDuplicateComparator.
SimpleMarkDuplicatesWithMateCigar() - Constructor for class picard.sam.markduplicates.SimpleMarkDuplicatesWithMateCigar
 
simpleMerge(Collection<VariantContext>, List<String>, GATKVariantContextUtils.FilteredRecordMergeType, GATKVariantContextUtils.GenotypeMergeType, boolean, boolean, String, boolean, boolean) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Merges VariantContexts into a single hybrid.
simpleMerge(Collection<VariantContext>, List<String>, int, GATKVariantContextUtils.FilteredRecordMergeType, GATKVariantContextUtils.GenotypeMergeType, boolean, boolean, String, boolean, boolean) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Merges VariantContexts into a single hybrid.
SimpleNovelAdjacencyAndChimericAlignmentEvidence - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.inference
 
SimpleNovelAdjacencyAndChimericAlignmentEvidence.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.inference
 
SimpleNovelAdjacencyInterpreter - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery.inference
This deals with the special case where a contig has exactly two alignments and seemingly has the complete alt haplotype assembled.
SimpleNovelAdjacencyInterpreter() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SimpleNovelAdjacencyInterpreter
 
SimplePosteriorSummary(double, double, double) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.records.ModeledSegment.SimplePosteriorSummary
 
SimplePosteriorSummary(List<Double>) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.records.ModeledSegment.SimplePosteriorSummary
 
SimpleRepeatMaskTransformer - Class in org.broadinstitute.hellbender.transformers
Masks read bases with a supra-threshold number of A/T's or G/C's within a given window size.
SimpleRepeatMaskTransformer(int, int, int) - Constructor for class org.broadinstitute.hellbender.transformers.SimpleRepeatMaskTransformer
 
simpleReverseComplement(byte[]) - Static method in class org.broadinstitute.hellbender.utils.BaseUtils
Reverse complement a byte array of bases (that is, chars casted to bytes, *not* base indices in byte form)
SimpleSampleLocatableMetadata - Class in org.broadinstitute.hellbender.tools.copynumber.formats.metadata
Metadata associated with a collection of locatables associated with a single sample.
SimpleSampleLocatableMetadata(String, SAMSequenceDictionary) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.metadata.SimpleSampleLocatableMetadata
 
SimpleSampleMetadata - Class in org.broadinstitute.hellbender.tools.copynumber.formats.metadata
Metadata associated with a single sample.
SimpleSampleMetadata(String) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.formats.metadata.SimpleSampleMetadata
 
SimpleSVD - Class in org.broadinstitute.hellbender.utils.svd
Simple implementation of the SVD interface for storing the matrices (and vector) of a SVD result.
SimpleSVD(RealMatrix, double[], RealMatrix, RealMatrix) - Constructor for class org.broadinstitute.hellbender.utils.svd.SimpleSVD
 
SimpleSVType - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery
 
SimpleSVType(String, Allele, int, Map<String, String>) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.SimpleSVType
 
SimpleSVType.Deletion - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery
 
SimpleSVType.DuplicationInverted - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery
 
SimpleSVType.DuplicationTandem - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery
 
SimpleSVType.ImpreciseDeletion - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery
 
SimpleSVType.Insertion - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery
 
SimpleSVType.Inversion - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery
 
SimpleSVType.TYPES - Enum in org.broadinstitute.hellbender.tools.spark.sv.discovery
 
simplifyGraph() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.SeqGraph
Simplify this graph, merging vertices together and restructuring the graph in an effort to minimize the number of overall vertices in the graph without changing in any way the sequences implied by a complex enumeration of all paths through the graph.
SINGLE_END_ALIGNMENT_FULL_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.bwa.BwaArgumentCollection
 
SINGLE_END_ALIGNMENT_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.bwa.BwaArgumentCollection
 
singleEndAlignment - Variable in class org.broadinstitute.hellbender.tools.spark.bwa.BwaArgumentCollection
Run single-end instead of paired-end alignment.
singleNewtonArgmaxUpdate(Function<Double, Double>, double, double, double, double, double) - Static method in class org.broadinstitute.hellbender.utils.OptimizationUtils
One iteration of Newton's method for univariate optimization (i.e.
singleNewtonArgmaxUpdate(Function<Double, Double>, double, double, double) - Static method in class org.broadinstitute.hellbender.utils.OptimizationUtils
 
SinglePassSamProgram - Class in picard.analysis
Super class that is designed to provide some consistent structure between subclasses that simply iterate once over a coordinate sorted BAM and collect information from the records as the go in order to produce some kind of output.
SinglePassSamProgram() - Constructor for class picard.analysis.SinglePassSamProgram
 
SingleSequenceReferenceAligner<T,U> - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
Encompasses an aligner to a single-sequence reference.
SingleSequenceReferenceAligner(String, byte[], Function<? super T, List<byte[]>>, SingleSequenceReferenceAligner.TriFunction<? super T, List<List<BwaMemAlignment>>, List<String>, ? extends U>) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SingleSequenceReferenceAligner
 
SingleSequenceReferenceAligner(String, byte[], Function<? super T, List<byte[]>>, SingleSequenceReferenceAligner.TriFunction<? super T, List<List<BwaMemAlignment>>, List<String>, ? extends U>, Predicate<? super BwaMemAlignment>) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SingleSequenceReferenceAligner
 
SingleSequenceReferenceAligner.TriFunction<T,U,V,W> - Interface in org.broadinstitute.hellbender.tools.spark.sv.utils
 
singletonIterator(T) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVUtils
 
singletonSampleList(String) - Static method in interface org.broadinstitute.hellbender.utils.genotyper.SampleList
Creates a list with a single sample.
SingularValueDecomposer - Interface in org.broadinstitute.hellbender.utils.svd
Perform singular value decomposition (and pseudoinverse calculation).
SITES_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
SITES_FILE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
SITES_ONLY_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
SIXTY_FOUR_MIB - Static variable in class org.broadinstitute.hellbender.tools.spark.ParallelCopyGCSDirectoryIntoHDFSSpark
 
size() - Method in class org.broadinstitute.hellbender.engine.AlignmentContext
How many reads cover this locus?
size() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
Get the number of reads currently in this region
size() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.collections.AbstractRecordCollection
 
size() - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalCollection
 
size() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.TableFuncotation
 
size() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.PairedStrandedIntervalTree
 
size() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree
Return the number of intervals in the tree.
size() - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchCollection
 
size() - Method in class org.broadinstitute.hellbender.tools.spark.utils.IntHistogram.CDF
 
size() - Method in class org.broadinstitute.hellbender.tools.spark.utils.LargeLongHopscotchSet
 
size() - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongHopscotchSet
 
size() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KBestHaplotypeFinder
 
size() - Method in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfile
How many profile results are in this profile?
size() - Method in class org.broadinstitute.hellbender.utils.codecs.sampileup.SAMPileupFeature
Return the number of observed bases over the genomic location
size() - Method in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvTableFeature
 
size() - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
 
size() - Method in class org.broadinstitute.hellbender.utils.collections.IndexedSet
Returns number of elements in the set.
size() - Method in class org.broadinstitute.hellbender.utils.Dirichlet
 
size() - Method in class org.broadinstitute.hellbender.utils.downsampling.Downsampler
Get the current number of items in this downsampler This should be the best estimate of the total number of elements that will come out of the downsampler were consumeFinalizedItems() to be called immediately after this call.
size() - Method in class org.broadinstitute.hellbender.utils.downsampling.FractionalDownsampler
 
size() - Method in class org.broadinstitute.hellbender.utils.downsampling.LevelingDownsampler
 
size() - Method in class org.broadinstitute.hellbender.utils.downsampling.MutectDownsampler
 
size() - Method in class org.broadinstitute.hellbender.utils.downsampling.PassThroughDownsampler
 
size() - Method in class org.broadinstitute.hellbender.utils.downsampling.PositionalDownsampler
 
size() - Method in class org.broadinstitute.hellbender.utils.downsampling.ReservoirDownsampler
 
size() - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
How many BPs are covered by this locus?
size() - Method in class org.broadinstitute.hellbender.utils.GenomeLocSortedSet
return the size of the collection
size() - Method in class org.broadinstitute.hellbender.utils.IndexRange
Returns number indexes expanded by this range.
size() - Method in class org.broadinstitute.hellbender.utils.nio.SeekableByteChannelPrefetcher
Returns the current size of entity to which this channel is connected.
size() - Method in class org.broadinstitute.hellbender.utils.pileup.ReadPileup
The number of elements in this pileup.
size() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.DiskBasedReadEndsForMarkDuplicatesMap
 
size() - Method in interface org.broadinstitute.hellbender.utils.read.markduplicates.ReadEndsForMarkDuplicatesMap
 
size() - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.CovariateKeyCache
Returns the size of this cache.
size() - Method in class org.broadinstitute.hellbender.utils.recalibration.covariates.StandardCovariateList
Returns the size of the list of standard covariates.
size() - Method in class org.broadinstitute.hellbender.utils.SimpleInterval
 
size() - Method in class org.broadinstitute.hellbender.utils.test.XorWrapper
 
size() - Method in class picard.fingerprint.HaplotypeBlock
Returns the number of SNPs within the haplotype block.
size() - Method in class picard.sam.markduplicates.util.DiskBasedReadEndsForMarkDuplicatesMap
 
size() - Method in class picard.sam.markduplicates.util.MarkQueue
The number of records currently in this queue.
size() - Method in class picard.sam.markduplicates.util.PhysicalLocationForMateCigarSet
The number of records in this set
size() - Method in interface picard.sam.markduplicates.util.ReadEndsForMarkDuplicatesMap
 
SIZE_AND_BASE_ORDER - Static variable in class org.broadinstitute.hellbender.utils.haplotype.Haplotype
Compares two haplotypes first by their lengths and then by lexicographic order of their bases.
SIZE_OF - Static variable in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEndsForMarkDuplicates
 
SIZE_OF - Static variable in class picard.sam.markduplicates.util.ReadEndsForMarkDuplicates
 
sizeBeforeLoc(GenomeLoc) - Method in class org.broadinstitute.hellbender.utils.GenomeLocSortedSet
Return the number of bps before loc in the sorted set
sizeInRam() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.DiskBasedReadEndsForMarkDuplicatesMap
 
sizeInRam() - Method in interface org.broadinstitute.hellbender.utils.read.markduplicates.ReadEndsForMarkDuplicatesMap
 
sizeInRam() - Method in class picard.sam.markduplicates.util.DiskBasedReadEndsForMarkDuplicatesMap
 
sizeInRam() - Method in interface picard.sam.markduplicates.util.ReadEndsForMarkDuplicatesMap
 
skimArray(T, boolean[]) - Static method in class org.broadinstitute.hellbender.utils.Utils
Skims out positions of an array returning a shorter one with the remaning positions in the same order.
skimArray(T, int, T, int, boolean[], int) - Static method in class org.broadinstitute.hellbender.utils.Utils
Skims out positions of an array returning a shorter one with the remaining positions in the same order.
skimArray(T, int, T, int, boolean[], int, int) - Static method in class org.broadinstitute.hellbender.utils.Utils
Skims out positions of an array returning a shorter one with the remaning positions in the same order.
skip(int) - Method in class org.broadinstitute.hellbender.utils.recalibration.ReadRecalibrationInfo
Should offset in this read be skipped (because it's covered by a known variation site?)
Skip - Static variable in enum picard.illumina.parser.ReadType
 
SKIP_CHROMS - Variable in class picard.vcf.MendelianViolations.FindMendelianViolations
 
SKIP_FILTERS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
SKIP_FILTERS_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
SKIP_MATE_VALIDATION - Variable in class picard.sam.ValidateSamFile
 
SKIP_PRE_BWA_REPARTITION_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
SKIP_PRE_BWA_REPARTITION_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
SKIP_PROMPT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.FixCallSetSampleOrdering
 
skipCommandLinePrompt - Variable in class org.broadinstitute.hellbender.tools.FixCallSetSampleOrdering
 
skipEmptyFiles - Variable in class picard.illumina.parser.ParameterizedFileUtil
 
skipFamilyPriors - Variable in class org.broadinstitute.hellbender.tools.walkers.variantutils.CalculateGenotypePosteriors
Skip application of family-based priors.
skipFilters - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
 
skipPopulationPriors - Variable in class org.broadinstitute.hellbender.tools.walkers.variantutils.CalculateGenotypePosteriors
Skip application of population-based priors
skipPreBwaRepartition - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSFilterArgumentCollection
Advanced optimization option that should be used only in the case of inputs with a high proportion of microbial reads that are not host-aligned/coordinate-sorted.
skipRecords(int) - Method in class picard.illumina.parser.readers.FilterFileReader
 
skipRecords(int) - Method in class picard.illumina.parser.readers.LocsFileReader
 
skips - Variable in class picard.illumina.parser.ReadStructure
 
SliceSampler - Class in org.broadinstitute.hellbender.utils.mcmc
Implements slice sampling of a continuous, univariate, unnormalized probability density function, which is assumed to be unimodal.
SliceSampler(RandomGenerator, Function<Double, Double>, double, double, double) - Constructor for class org.broadinstitute.hellbender.utils.mcmc.SliceSampler
Creates a new sampler, given a random number generator, a continuous, univariate, unimodal, unnormalized log probability density function, hard limits on the random variable, and a step width.
SliceSampler(RandomGenerator, Function<Double, Double>, double) - Constructor for class org.broadinstitute.hellbender.utils.mcmc.SliceSampler
Creates a new sampler, given a random number generator, a continuous, univariate, unimodal, unnormalized log probability density function, and a step width.
smallestPowerOfTwoGreaterThan(int) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Returns the smallest power of 2 that exceeds or equals val
SMITH_WATERMAN_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerArgumentCollection
 
SmithWatermanAligner - Interface in org.broadinstitute.hellbender.utils.smithwaterman
Interface and factory for Smith-Waterman aligners
SmithWatermanAligner.Implementation - Enum in org.broadinstitute.hellbender.utils.smithwaterman
 
SmithWatermanAlignment - Interface in org.broadinstitute.hellbender.utils.smithwaterman
 
smithWatermanImplementation - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerArgumentCollection
 
SmithWatermanIntelAligner - Class in org.broadinstitute.hellbender.utils.smithwaterman
SmithWatermanIntelAligner class that converts instance of SWAlignerNativeBinding into a SmithWatermanIntelAligner This is optimized for Intel Architectures and can fail if Machine does not support AVX and will throw UserException
SmithWatermanIntelAligner() - Constructor for class org.broadinstitute.hellbender.utils.smithwaterman.SmithWatermanIntelAligner
Create a new SW pairwise aligner, which is implementation of smith waterman aligner that's takes advantage of intel hardware optimizations.
SmithWatermanJavaAligner - Class in org.broadinstitute.hellbender.utils.smithwaterman
Pairwise discrete smith-waterman alignment implemented in pure java ************************************************************************ **** IMPORTANT NOTE: **** **** This class assumes that all bytes come from UPPERCASED chars! **** ************************************************************************
SmithWatermanJavaAligner.State - Enum in org.broadinstitute.hellbender.utils.smithwaterman
The state of a trace step through the matrix
SMOOTHING_CREDIBLE_INTERVAL_THRESHOLD_ALLELE_FRACTION_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
SMOOTHING_CREDIBLE_INTERVAL_THRESHOLD_COPY_RATIO_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
smoothSegments(int, int, double, double) - Method in class org.broadinstitute.hellbender.tools.copynumber.models.MultidimensionalModeller
 
SNP - Variable in class picard.analysis.FingerprintingDetailMetrics
The name of a representative SNP within the haplotype that was compared.
Snp - Class in picard.fingerprint
Class to represent a SNP in context of a haplotype block that is used in fingerprinting.
Snp(String, String, int, byte, byte, double, List<String>) - Constructor for class picard.fingerprint.Snp
 
SNP_ALLELES - Variable in class picard.analysis.FingerprintingDetailMetrics
The possible alleles for the SNP.
SNP_COLUMN_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.FalsePositiveRecord
 
SNP_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
SNP_FILE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
SNP_FPR_COLUMN_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.FalsePositiveRecord
 
SNP_HETEROZYGOSITY - Static variable in class org.broadinstitute.hellbender.utils.variant.HomoSapiensConstants
Standard heterozygous rate for SNP variation.
SNP_OUTPUT - Variable in class picard.vcf.SplitVcfs
 
SNP_REFERENCE_BIAS - Variable in class picard.vcf.CollectVariantCallingMetrics.VariantCallingSummaryMetrics
The rate at which reference bases are observed at ref/alt heterozygous SNP sites.
snpCounter - Variable in class picard.vcf.GenotypeConcordance
 
snpHeterozygosity - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeCalculationArgumentCollection
The expected heterozygosity value used to compute prior probability that a locus is non-reference.
snpHeterozygosity - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerGenotypingEngine
 
snpPadding - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmerArgumentCollection
 
snps - Variable in class org.broadinstitute.hellbender.utils.variant.DbSnpBitSetUtil.DbSnpBitSets
 
snps - Variable in class picard.util.DbSnpBitSetUtil.DbSnpBitSets
 
SNPSubstitutionType(byte, byte) - Static method in class org.broadinstitute.hellbender.utils.BaseUtils
Returns the base substitution type of the 2 state SNP
softClipBothEndsByReferenceCoordinates(GATKRead, int, int) - Static method in class org.broadinstitute.hellbender.utils.clipping.ReadClipper
 
softClipByReadCoordinates(GATKRead, int, int) - Static method in class org.broadinstitute.hellbender.utils.clipping.ReadClipper
 
softClipByReferenceCoordinates(int, int) - Method in class org.broadinstitute.hellbender.utils.clipping.ReadClipper
Generic functionality to soft clip a read (is analogous to hardClipByReferenceCoordinates()) Note, it REQUIRES you to give the directionality of your soft clip (i.e.
softClipToRegionIncludingClippedBases(GATKRead, int, int) - Static method in class org.broadinstitute.hellbender.utils.clipping.ReadClipper
Soft clip the read to the variable region (from refStart to refStop) processing also the clipped bases
SOLID_NOCALL_STRATEGY - Static variable in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationArgumentCollection
 
SOLID_RECAL_MODE - Static variable in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationArgumentCollection
 
solve(int, UnivariateFunction, double, double) - Method in class org.broadinstitute.hellbender.utils.solver.RobustBrentSolver
 
solve() - Method in class org.broadinstitute.hellbender.utils.solver.SynchronizedUnivariateSolver
Solve the equations
SomaticGenotypingEngine - Class in org.broadinstitute.hellbender.tools.walkers.mutect
 
SomaticGenotypingEngine(SampleList, M2ArgumentCollection, String, String) - Constructor for class org.broadinstitute.hellbender.tools.walkers.mutect.SomaticGenotypingEngine
 
SomaticLikelihoodsEngine - Class in org.broadinstitute.hellbender.tools.walkers.mutect
Created by David Benjamin on 3/9/17.
SomaticLikelihoodsEngine() - Constructor for class org.broadinstitute.hellbender.tools.walkers.mutect.SomaticLikelihoodsEngine
 
SORT - Variable in class picard.util.BedToIntervalList
 
SORT - Variable in class picard.util.IntervalListToBed
 
SORT - Variable in class picard.util.IntervalListTools
 
SORT_ORDER - Variable in class picard.sam.AddOrReplaceReadGroups
 
SORT_ORDER - Variable in class picard.sam.FastqToSam
 
SORT_ORDER - Variable in class picard.sam.FilterSamReads
 
SORT_ORDER - Variable in class picard.sam.FixMateInformation
 
SORT_ORDER - Variable in class picard.sam.MergeBamAlignment
 
SORT_ORDER - Variable in class picard.sam.MergeSamFiles
 
SORT_ORDER - Variable in class picard.sam.RevertOriginalBaseQualitiesAndAddMateCigar
 
SORT_ORDER - Variable in class picard.sam.RevertSam
 
SORT_ORDER - Variable in class picard.sam.SortSam
 
SORT_ORDER_SHORT_NAME - Static variable in class picard.cmdline.StandardOptionDefinitions
 
sortAlleles(VariantContext, VCFHeader) - Static method in class org.broadinstitute.hellbender.utils.test.VariantContextTestUtils
Method which reorders the AltAlleles of a VariantContext so that they are in alphabetical order.
sortAndMergeIntervals(GenomeLocParser, List<GenomeLoc>, IntervalMergingRule) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Sorts and merges an interval list.
sortedIterator() - Method in class org.broadinstitute.hellbender.utils.pileup.ReadPileup
Iterator over sorted by read start PileupElements.
SORTING_COLLECTION_SIZE_RATIO - Variable in class org.broadinstitute.hellbender.tools.walkers.markduplicates.MarkDuplicatesGATK
 
SORTING_COLLECTION_SIZE_RATIO - Variable in class picard.sam.markduplicates.MarkDuplicates
 
sortLocatablesBySequenceDictionary(Collection<T>, SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Sort by the contig then position as specified by the index order in the given sequence dictionary.
sortReadsAccordingToHeader(JavaRDD<GATKRead>, SAMFileHeader, int) - Static method in class org.broadinstitute.hellbender.utils.spark.SparkUtils
Do a total sort of an RDD of GATKRead according to the sort order in the header.
SortSam - Class in picard.sam
Sorts a SAM or BAM file.
SortSam() - Constructor for class picard.sam.SortSam
 
SortSamSpark - Class in org.broadinstitute.hellbender.tools.spark.pipelines
 
SortSamSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.pipelines.SortSamSpark
 
sortUsingElementsAsKeys(JavaRDD<T>, Comparator<T>, int) - Static method in class org.broadinstitute.hellbender.utils.spark.SparkUtils
Do a global sort of an RDD using the given comparator.
sortVariantContextsByPriority(Collection<VariantContext>, List<String>, GATKVariantContextUtils.GenotypeMergeType) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
 
sortVariantsByCoordinate(List<VariantContext>, SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVVCFWriter
 
SortVcf - Class in picard.vcf
Sorts one or more VCF files according to the order of the contigs in the header/sequence dictionary and then by coordinate.
SortVcf() - Constructor for class picard.vcf.SortVcf
 
sourceContigName - Variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SimpleChimera
 
SPANNING_DELETION_SYMBOLIC_ALLELE_DEPRECATED - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
SPANNING_DELETION_SYMBOLIC_ALLELE_NAME_DEPRECATED - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
SPANNING_DELETIONS_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
spanWith(Locatable) - Method in class org.broadinstitute.hellbender.utils.SimpleInterval
Returns a new SimpleInterval that represents the region between the endpoints of this and other.
spark_driver_extraJavaOptions() - Method in interface org.broadinstitute.hellbender.utils.config.GATKConfig
 
spark_driver_maxResultSize() - Method in interface org.broadinstitute.hellbender.utils.config.GATKConfig
 
spark_driver_userClassPathFirst() - Method in interface org.broadinstitute.hellbender.utils.config.GATKConfig
 
spark_executor_extraJavaOptions() - Method in interface org.broadinstitute.hellbender.utils.config.GATKConfig
 
spark_io_compression_codec() - Method in interface org.broadinstitute.hellbender.utils.config.GATKConfig
 
spark_kryoserializer_buffer_max() - Method in interface org.broadinstitute.hellbender.utils.config.GATKConfig
 
SPARK_PROGRAM_NAME_LONG_NAME - Static variable in class org.broadinstitute.hellbender.engine.spark.SparkCommandLineProgram
 
SPARK_PROPERTY_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
spark_yarn_executor_memoryOverhead() - Method in interface org.broadinstitute.hellbender.utils.config.GATKConfig
 
sparkArgs - Variable in class org.broadinstitute.hellbender.engine.spark.SparkCommandLineProgram
 
SparkBAMOutputFormat() - Constructor for class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSink.SparkBAMOutputFormat
 
SparkCommandLineArgumentCollection - Class in org.broadinstitute.hellbender.engine.spark
Command line arguments needed for configuring a spark context
SparkCommandLineArgumentCollection() - Constructor for class org.broadinstitute.hellbender.engine.spark.SparkCommandLineArgumentCollection
 
SparkCommandLineProgram - Class in org.broadinstitute.hellbender.engine.spark
 
SparkCommandLineProgram() - Constructor for class org.broadinstitute.hellbender.engine.spark.SparkCommandLineProgram
 
SparkContextFactory - Class in org.broadinstitute.hellbender.engine.spark
Manages creation of the Spark context.
SparkConverter - Class in org.broadinstitute.hellbender.utils.spark
Class with helper methods to convert objects (mostly matrices) to/from Spark (particularly, in MLLib)
SparkCRAMOutputFormat() - Constructor for class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSink.SparkCRAMOutputFormat
 
SparkHeaderlessBAMOutputFormat() - Constructor for class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSink.SparkHeaderlessBAMOutputFormat
 
SparkHeaderlessCRAMOutputFormat() - Constructor for class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSink.SparkHeaderlessCRAMOutputFormat
 
SparkHeaderlessSAMOutputFormat() - Constructor for class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSink.SparkHeaderlessSAMOutputFormat
 
SparkHeaderlessVCFOutputFormat() - Constructor for class org.broadinstitute.hellbender.engine.spark.datasources.VariantsSparkSink.SparkHeaderlessVCFOutputFormat
 
sparkReadAdapter(AlignmentRecord, SAMFileHeader) - Static method in class org.broadinstitute.hellbender.utils.read.BDGAlignmentRecordToGATKReadAdapter
 
sparkReadAdapter(AlignmentRecord) - Static method in class org.broadinstitute.hellbender.utils.read.BDGAlignmentRecordToGATKReadAdapter
 
SparkSAMOutputFormat() - Constructor for class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSink.SparkSAMOutputFormat
 
SparkSharder - Class in org.broadinstitute.hellbender.engine.spark
Utility methods for sharding Locatable objects (such as reads) for given intervals, without using a shuffle.
SparkSharder() - Constructor for class org.broadinstitute.hellbender.engine.spark.SparkSharder
 
SparkSingularValueDecomposer - Class in org.broadinstitute.hellbender.utils.svd
SVD using MLLib
SparkSingularValueDecomposer(JavaSparkContext) - Constructor for class org.broadinstitute.hellbender.utils.svd.SparkSingularValueDecomposer
 
SparkTestUtils - Class in org.broadinstitute.hellbender.utils.test
 
SparkUtils - Class in org.broadinstitute.hellbender.utils.spark
Miscellaneous Spark-related utilities
sparkVariantAdapter(VariantContext) - Static method in class org.broadinstitute.hellbender.utils.variant.VariantContextVariantAdapter
 
SparkVCFOutputFormat() - Constructor for class org.broadinstitute.hellbender.engine.spark.datasources.VariantsSparkSink.SparkVCFOutputFormat
 
specialArgumentsCollection - Variable in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
 
specialArgumentsCollection - Variable in class picard.cmdline.CommandLineProgram
 
SPECIES - Variable in class picard.sam.CreateSequenceDictionary
 
Splice(String, int, int) - Constructor for class org.broadinstitute.hellbender.tools.walkers.rnaseq.OverhangFixingManager.Splice
 
split(SimpleInterval) - Method in class org.broadinstitute.hellbender.engine.ContextShard
create a new shard, keeping only the variants that overlap with the new interval.
split(SeqGraph, SeqVertex) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.CommonSuffixSplitter
Simple single-function interface to split and then update a graph
split() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.SharedVertexSequenceSplitter
Actually do the splitting up of the vertices Must be called before calling updateGraph
split(int) - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
Splits the contig into to regions: [start,split point) and [split point, end].
split(String, char) - Static method in class org.broadinstitute.hellbender.utils.Utils
Splits a String using indexOf instead of regex to speed things up.
split(String, String) - Static method in class org.broadinstitute.hellbender.utils.Utils
Splits a String using indexOf instead of regex to speed things up.
split(String, String[], String) - Method in class picard.Test
 
SPLIT_DELIM - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RankSumTest
 
SPLIT_DELIM - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_RMSMappingQuality
 
SPLIT_DELIM - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.AS_StrandBiasTest
 
SPLIT_READ_SUPPORT - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
SPLIT_TO_N_FILES - Variable in class picard.sam.SplitSamByNumberOfReads
 
SPLIT_TO_N_READS - Variable in class picard.sam.SplitSamByNumberOfReads
 
splitAndTrimToIntervals(Set<SimpleInterval>) - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
Intersect this assembly region with the allowed intervals, returning a list of active regions that only contain locations present in intervals Note: modifications to the returned list have no effect on this region object.
splitAndUpdate(SeqVertex, SeqVertex) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.SharedVertexSequenceSplitter
Simple single-function interface to split and then update a graph
splitBySample(SAMFileHeader, String) - Method in class org.broadinstitute.hellbender.utils.pileup.ReadPileup
Splits the ReadPileup by sample
splitContextBySampleName(SAMFileHeader) - Method in class org.broadinstitute.hellbender.engine.AlignmentContext
 
splitContextBySampleName(String, SAMFileHeader) - Method in class org.broadinstitute.hellbender.engine.AlignmentContext
Splits the given AlignmentContext into a StratifiedAlignmentContext per sample, but referenced by sample name instead of sample object.
splitContextBySampleName(ReadPileup, SAMFileHeader) - Static method in class org.broadinstitute.hellbender.engine.AlignmentContext
 
spliterator() - Method in class org.broadinstitute.hellbender.utils.nio.PathLineIterator
 
spliterator() - Method in class org.broadinstitute.hellbender.utils.tsv.TableReader
 
splitFactor - Variable in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.RealignmentArgumentCollection
BWA-mem seed split factor
splitFixedIntervals(List<GenomeLoc>, int) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Splits the genome locs up by size.
splitFixedWidth(String, List<Integer>) - Static method in class org.broadinstitute.hellbender.utils.text.TextFormattingUtils
Parses a fixed width line of text.
splitGappedAlignment(AlignmentInterval, int, int) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.ContigAlignmentsModifier
Splits a gapped alignment into multiple alignment regions, based on input sensitivity: i.e.
SplitIntervals - Class in org.broadinstitute.hellbender.tools.walkers
This tool takes in intervals via the standard arguments of IntervalArgumentCollection and splits them into interval files for scattering.
SplitIntervals() - Constructor for class org.broadinstitute.hellbender.tools.walkers.SplitIntervals
 
splitIntervalsToSubLists(List<GenomeLoc>, List<Integer>) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Splits an interval list into multiple sublists.
splitIntoPrimitiveAlleles(VariantContext) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Splits the alleles for the provided variant context into its primitive parts.
splitLocusIntervals(List<GenomeLoc>, int) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
 
splitNCigarRead(GATKRead, OverhangFixingManager, boolean, SAMFileHeader, boolean) - Static method in class org.broadinstitute.hellbender.tools.walkers.rnaseq.SplitNCigarReads
Goes through the cigar string of the read and create new reads for each consecutive non-N elements (while soft clipping the rest of the read) that are supplemental to each other.
SplitNCigarReads - Class in org.broadinstitute.hellbender.tools.walkers.rnaseq
Splits reads that contain Ns in their cigar string (e.g.
SplitNCigarReads() - Constructor for class org.broadinstitute.hellbender.tools.walkers.rnaseq.SplitNCigarReads
 
SplitRead(GATKRead, ReadMetadata, boolean) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.SplitRead
 
SplitRead(GATKRead) - Constructor for class org.broadinstitute.hellbender.tools.walkers.rnaseq.OverhangFixingManager.SplitRead
 
SplitReads - Class in org.broadinstitute.hellbender.tools
Outputs reads from a SAM/BAM/CRAM by read group, sample and library name
SplitReads() - Constructor for class org.broadinstitute.hellbender.tools.SplitReads
 
splitReadsBySample(SampleList, SAMFileHeader, Collection<GATKRead>) - Static method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerUtils
 
splitReadsBySample(Collection<GATKRead>) - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2Engine
 
SplitSamByLibrary - Class in picard.sam
Command-line program to split a SAM or BAM file into separate files based on library name.
SplitSamByLibrary() - Constructor for class picard.sam.SplitSamByLibrary
 
SplitSamByNumberOfReads - Class in picard.sam

Splits the input queryname sorted or query-grouped SAM/BAM file and writes it into multiple BAM files, each with an approximately equal number of reads.

SplitSamByNumberOfReads() - Constructor for class picard.sam.SplitSamByNumberOfReads
 
SPLITTING_INDEX_GRANULARITY_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.CreateHadoopBamSplittingIndex
 
SplitVcfs - Class in picard.vcf
Splits the input VCF file into two, one for indels and one for SNPs.
SplitVcfs() - Constructor for class picard.vcf.SplitVcfs
 
splitWhiteSpace(String) - Static method in class org.broadinstitute.hellbender.utils.text.TextFormattingUtils
Parses a line of text by whitespace.
square(double) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Calculate f(x) = x^2
STANDARD_CONFIDENCE_FOR_CALLING - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeCalculationArgumentCollection
The minimum phred-scaled confidence threshold at which variants should be called.
STANDARD_DEVIATION - Variable in class org.broadinstitute.hellbender.metrics.InsertSizeMetrics
Standard deviation of insert sizes over the "core" of the distribution.
STANDARD_DEVIATION - Variable in class picard.analysis.InsertSizeMetrics
Standard deviation of insert sizes over the "core" of the distribution.
STANDARD_ENCODING - Static variable in class org.broadinstitute.hellbender.tools.GetSampleName
 
STANDARD_MUTECT_INFO_FIELDS - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
STANDARD_NGS - Static variable in interface org.broadinstitute.hellbender.utils.smithwaterman.SmithWatermanAligner
 
StandardAnnotation - Interface in org.broadinstitute.hellbender.tools.walkers.annotator
This is a marker interface used to indicate which annotations are "Standard".
StandardArgumentDefinitions - Class in org.broadinstitute.hellbender.cmdline
A set of String constants in which the name of the constant (minus the _SHORT_NAME suffix) is the standard long Option name, and the value of the constant is the standard shortName.
StandardCallerArgumentCollection - Class in org.broadinstitute.hellbender.tools.walkers.genotyper
This is pulled out so that every caller isn't exposed to the arguments from every other caller.
StandardCallerArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.StandardCallerArgumentCollection
 
StandardCovariateList - Class in org.broadinstitute.hellbender.utils.recalibration.covariates
Represents the list of standard BQSR covariates.
StandardCovariateList(RecalibrationArgumentCollection, List<String>) - Constructor for class org.broadinstitute.hellbender.utils.recalibration.covariates.StandardCovariateList
Creates a new list of standard BQSR covariates and initializes each covariate.
StandardCovariateList(RecalibrationArgumentCollection, SAMFileHeader) - Constructor for class org.broadinstitute.hellbender.utils.recalibration.covariates.StandardCovariateList
Creates a new list of standard BQSR covariates and initializes each covariate.
standardDeviation(double, int, boolean) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
 
StandardHCAnnotation - Interface in org.broadinstitute.hellbender.tools.walkers.annotator
This is a marker interface used to indicate which annotations are "Standard" for the HaplotypeCaller only.
STANDARDIZED_COPY_RATIOS_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.arguments.CopyNumberStandardArgument
 
StandardMutectAnnotation - Interface in org.broadinstitute.hellbender.tools.walkers.annotator
This is a marker interface used to indicate which annotations are "Standard" for Mutect2 only.
StandardOptionDefinitions - Class in picard.cmdline
A set of String constants in which the name of the constant (minus the _SHORT_NAME suffix) is the standard long Option name, and the value of the constant is the standard shortName.
StandardOptionDefinitions() - Constructor for class picard.cmdline.StandardOptionDefinitions
 
StandardValidationCollection() - Constructor for class org.broadinstitute.hellbender.cmdline.argumentcollections.SequenceDictionaryValidationArgumentCollection.StandardValidationCollection
 
start() - Method in class org.broadinstitute.hellbender.engine.ProgressMeter
Start the progress meter and produce preliminary output such as column headings.
START - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
start - Variable in class org.broadinstitute.hellbender.utils.clipping.ClippingOp
 
start - Variable in class org.broadinstitute.hellbender.utils.GenomeLoc
 
start(RootDoc) - Static method in class org.broadinstitute.hellbender.utils.help.GATKHelpDoclet
Create a doclet of the appropriate type and generate the FreeMarker templates properties.
start(String) - Method in class org.broadinstitute.hellbender.utils.logging.BunnyLog
 
start(List<String>) - Method in class org.broadinstitute.hellbender.utils.python.StreamingPythonScriptExecutor
Start the Python process.
start(List<String>, boolean) - Method in class org.broadinstitute.hellbender.utils.python.StreamingPythonScriptExecutor
Start the Python process.
start() - Method in class org.broadinstitute.hellbender.utils.runtime.StreamingProcessController
Starts the remote process running based on the setting specified in the constructor.
start - Variable in class picard.annotation.Gene.Transcript.Exon
 
start() - Method in class picard.annotation.Gene.Transcript
 
start - Variable in class picard.illumina.parser.Range
 
start(RootDoc) - Static method in class picard.util.help.PicardHelpDoclet
Create a doclet of the appropriate type and generate the FreeMarker templates properties.
start() - Method in class picard.vcf.processor.VariantAccumulatorExecutor.MultiThreadedChunkBased
 
start() - Method in interface picard.vcf.processor.VariantAccumulatorExecutor
Starts the work of the executor, returning immediately.
start() - Method in class picard.vcf.processor.VcfFileSegment
 
START_COL_COMMENT - Static variable in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalCodec
 
START_END_SEPARATOR - Static variable in class org.broadinstitute.hellbender.utils.SimpleInterval
 
startAsynchronousBatchWrite(List<T>) - Method in class org.broadinstitute.hellbender.utils.runtime.AsynchronousStreamWriterService
Request that a batch of items be written to the stream on a background thread.
started() - Method in class org.broadinstitute.hellbender.engine.ProgressMeter
Returns whether the meter has been started.
startInAssembledContig - Variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
 
startingChr - Variable in class org.broadinstitute.hellbender.utils.read.ArtificialReadQueryIterator
 
startPos - Variable in class org.broadinstitute.hellbender.utils.read.ArtificialReadQueryIterator
 
startSequence(String) - Method in class org.broadinstitute.hellbender.utils.reference.FastaReferenceWriter
Starts the input of the bases of a new sequence.
startSequence(String, int) - Method in class org.broadinstitute.hellbender.utils.reference.FastaReferenceWriter
Starts the input of the bases of a new sequence.
startSequence(String, String) - Method in class org.broadinstitute.hellbender.utils.reference.FastaReferenceWriter
Starts the input of the bases of a new sequence.
startSequence(String, String, int) - Method in class org.broadinstitute.hellbender.utils.reference.FastaReferenceWriter
Starts the input of the bases of a new sequence.
startsOrEndsWithInsertionOrDeletion(Cigar) - Static method in class org.broadinstitute.hellbender.utils.read.AlignmentUtils
Does cigar start or end with a deletion operation?
startTime - Variable in class org.broadinstitute.hellbender.utils.pairhmm.PairHMM
 
state - Variable in class org.broadinstitute.hellbender.utils.baq.BAQ.BAQCalculationResult
 
state() - Method in class org.broadinstitute.hellbender.utils.mcmc.ParameterizedModel
Returns a copy of the ParameterizedState held internally.
stateAlignedPosition(int) - Static method in class org.broadinstitute.hellbender.utils.baq.BAQ
decode the bit encoded state array values
stateIsIndel(int) - Static method in class org.broadinstitute.hellbender.utils.baq.BAQ
decode the bit encoded state array values
stateList - Variable in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfile
 
STATIC_QUANTIZED_QUALS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.validation.CompareBaseQualities
 
staticQuantizationQuals - Variable in class org.broadinstitute.hellbender.tools.ApplyBQSRUniqueArgumentCollection
Static quantized quals are entirely separate from the quantize_qual option which uses dynamic binning.
staticQuantizationQuals - Variable in class org.broadinstitute.hellbender.tools.validation.CompareBaseQualities
Return value is 0 if the two files have identical base qualities and non-zero otherwise.
status - Variable in class org.broadinstitute.hellbender.utils.solver.SynchronizedUnivariateSolver.UnivariateSolverSummary
 
stddev() - Method in class org.broadinstitute.hellbender.utils.MathUtils.RunningAverage
 
stdDev(Collection<? extends Number>) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Calculate the standard deviation of a collection of Number instances.
stdDev(double...) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Calculate the standard deviation of a double array.
stddev(double[], int, int) - Static method in class picard.util.MathUtil
Calculated the standard deviation of an array of doubles.
stddev(double[], int, int, double) - Static method in class picard.util.MathUtil
Calculated the standard deviation of an array of doubles.
stdErrFuture - Variable in class org.broadinstitute.hellbender.utils.runtime.ProcessControllerBase
 
stdOutFuture - Variable in class org.broadinstitute.hellbender.utils.runtime.ProcessControllerBase
 
stepEnd(String) - Method in class org.broadinstitute.hellbender.utils.logging.BunnyLog
 
stepForwardOnGenome() - Method in class org.broadinstitute.hellbender.utils.locusiterator.AlignmentStateMachine
Step the state machine forward one unit Takes the current state of this machine, and advances the state until the next on-genome cigar element (M, X, =, D) is encountered, at which point this function returns with the cigar operator of the current element.
stop() - Method in class org.broadinstitute.hellbender.engine.ProgressMeter
Stop the progress meter and output summary statistics to the logger
stop - Variable in class org.broadinstitute.hellbender.utils.clipping.ClippingOp
 
stop - Variable in class org.broadinstitute.hellbender.utils.GenomeLoc
 
stop() - Method in class picard.vcf.processor.VcfFileSegment
 
STOP_AFTER - Variable in class picard.analysis.CollectMultipleMetrics
 
STOP_AFTER - Variable in class picard.analysis.CollectOxoGMetrics
 
STOP_AFTER - Variable in class picard.analysis.CollectWgsMetrics
 
STOP_AFTER - Variable in class picard.analysis.replicates.CollectIndependentReplicateMetrics
 
STOP_AFTER - Variable in class picard.analysis.SinglePassSamProgram
 
STOP_AFTER - Variable in class picard.sam.PositionBasedDownsampleSam
 
stopCluster(MiniDFSCluster) - Static method in class org.broadinstitute.hellbender.utils.test.MiniClusterUtils
shut down the cluster
stopped() - Method in class org.broadinstitute.hellbender.engine.ProgressMeter
Returns whether the meter has been stopped.
stopSparkContext(JavaSparkContext) - Static method in class org.broadinstitute.hellbender.engine.spark.SparkContextFactory
Stop a JavaSparkContext, unless it is the test context.
STR_CONTRACTION_FILTER_NAME - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
STR_PRESENT_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
Strand - Enum in org.broadinstitute.hellbender.tools.spark.sv.utils
 
Strand.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
STRAND_ARTIFACT_FILTER_NAME - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
STRAND_BALANCE - Variable in class picard.analysis.AlignmentSummaryMetrics
The number of PF reads aligned to the positive strand of the genome divided by the number of PF reads aligned to the genome.
STRAND_BIAS_BY_SAMPLE_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
STRAND_COUNT_BY_SAMPLE_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
STRAND_ODDS_RATIO_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
STRAND_SPECIFICITY - Variable in class picard.analysis.CollectRnaSeqMetrics
 
StrandArtifact - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Annotations for strand artifact filter calculated by a Bayesian model described in https://github.com/broadinstitute/gatk/tree/master/docs/mutect/mutect.pdf.
StrandArtifact() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.StrandArtifact
 
StrandArtifact.ArtifactState - Enum in org.broadinstitute.hellbender.tools.walkers.annotator
 
strandArtifactAlleleFractionThreshold - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
strandArtifactPosteriorProbThreshold - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
StrandBiasBySample - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Number of forward and reverse reads that support REF and ALT alleles
StrandBiasBySample() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.StrandBiasBySample
 
StrandBiasTest - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Class of tests to detect strand bias.
StrandBiasTest() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.StrandBiasTest
 
StrandedInterval - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
Represents an interval and strand from the reference genome.
StrandedInterval(SVInterval, boolean) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.StrandedInterval
 
StrandedInterval(Kryo, Input) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.StrandedInterval
 
StrandedInterval.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
StrandOddsRatio - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Strand bias estimated by the Symmetric Odds Ratio test
StrandOddsRatio() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.StrandOddsRatio
 
StrandSwitch - Enum in org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment
For symbolizing the change of strand from one alignment to the next of an assembly contig.
STRANDSWITCHLESS_BND - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.BreakEndVariantType.TransLocBND
 
STRATEGY - Variable in class picard.sam.DownsampleSam
 
stratify(AlignmentContext.ReadOrientation) - Method in class org.broadinstitute.hellbender.engine.AlignmentContext
Returns a potentially derived subcontext containing only forward, reverse, or in fact all reads in alignment context context.
stream(CharSequence, int, int, SVKmer) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVDUSTFilteredKmerizer
 
stream(byte[], int, int, SVKmer) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVDUSTFilteredKmerizer
 
stream(CharSequence, int, int, SVKmer) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerizer
 
stream(byte[], int, int, SVKmer) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerizer
 
stream(byte[], int, SVKmer) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerizer
 
stream() - Method in class org.broadinstitute.hellbender.utils.tsv.TableReader
Returns an stream on the reaming records in the source.
stream(Iterable<T>) - Static method in class org.broadinstitute.hellbender.utils.Utils
 
stream(Iterator<T>) - Static method in class org.broadinstitute.hellbender.utils.Utils
 
STREAM_BLOCK_TRANSFER_SIZE - Static variable in class org.broadinstitute.hellbender.utils.runtime.CapturedStreamOutput
 
StreamingProcessController - Class in org.broadinstitute.hellbender.utils.runtime
Facade to Runtime.exec() and java.lang.Process.
StreamingProcessController(ProcessSettings) - Constructor for class org.broadinstitute.hellbender.utils.runtime.StreamingProcessController
 
StreamingProcessController(ProcessSettings, String) - Constructor for class org.broadinstitute.hellbender.utils.runtime.StreamingProcessController
Create a controller using the specified settings.
StreamingProcessController(ProcessSettings, String, boolean) - Constructor for class org.broadinstitute.hellbender.utils.runtime.StreamingProcessController
Create a controller using the specified settings.
StreamingPythonScriptExecutor - Class in org.broadinstitute.hellbender.utils.python
Python executor used to interact with a keep-alive Python process.
StreamingPythonScriptExecutor(boolean) - Constructor for class org.broadinstitute.hellbender.utils.python.StreamingPythonScriptExecutor
The start method must be called to actually start the remote executable.
StreamingPythonScriptExecutor(PythonExecutorBase.PythonExecutableName, boolean) - Constructor for class org.broadinstitute.hellbender.utils.python.StreamingPythonScriptExecutor
The start method must be called to actually start the remote executable.
StreamLocation - Enum in org.broadinstitute.hellbender.utils.runtime
Where to read/write a stream
StreamOutput - Class in org.broadinstitute.hellbender.utils.runtime
The content of stdout or stderr.
StreamOutput() - Constructor for class org.broadinstitute.hellbender.utils.runtime.StreamOutput
 
STRICT - Variable in class picard.vcf.SplitVcfs
 
stringForCSV() - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalDatum
 
stringRep(ReadMetadata, int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.ReadEvidence
All ReadEvidence has basic BreakpointEvidence.stringRep() with appended info: templateName/fragmentOrdinal forwardStrand cigarString mappingQuality Child classes may extend stringRep() by appending class-specific tab-separated info
stringRep(ReadMetadata, int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence
Returns string representation of BreakpointEvidence in tab-separated form: Contig[begin:end] weight validated EvidenceType distal_targets distal_targets is a (; separated) list of string representations (.toString()) for each distal target it is empty if there are no distal targets Child classes may extend stringRep() by appending class-specific tab-separated info
stringRep(ReadMetadata, int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.TemplateSizeAnomaly
 
stringSeqsToString(String[], String) - Static method in class picard.util.IlluminaUtil
 
stringSerializer - Static variable in class org.broadinstitute.hellbender.utils.runtime.AsynchronousStreamWriterService
Convenience function that can be provided to an AsynchronousStreamWriterService to serialize String objects.
STRIP_UNPAIRED_MATE_NUMBER - Variable in class picard.sam.FastqToSam
Deprecated.
StripMateNumberTransformer - Class in org.broadinstitute.hellbender.transformers
Removes /1 or /2 and any whitespace from the end of the read name if present
StripMateNumberTransformer() - Constructor for class org.broadinstitute.hellbender.transformers.StripMateNumberTransformer
 
stripPLsAndAD(GenotypesContext) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
 
STRUCTURAL_VARIANT_SIZE_LOWER_BOUND - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection
 
StructuralVariantDiscoveryProgramGroup - Class in org.broadinstitute.hellbender.cmdline.programgroups
Tools that detect structural variants
StructuralVariantDiscoveryProgramGroup() - Constructor for class org.broadinstitute.hellbender.cmdline.programgroups.StructuralVariantDiscoveryProgramGroup
 
StructuralVariationDiscoveryArgumentCollection - Class in org.broadinstitute.hellbender.tools.spark.sv
 
StructuralVariationDiscoveryArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection
 
StructuralVariationDiscoveryArgumentCollection.DiscoverVariantsFromContigsAlignmentsSparkArgumentCollection - Class in org.broadinstitute.hellbender.tools.spark.sv
 
StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection - Class in org.broadinstitute.hellbender.tools.spark.sv
 
StructuralVariationDiscoveryPipelineSpark - Class in org.broadinstitute.hellbender.tools.spark.sv
Runs the structural variation discovery workflow on a single sample
StructuralVariationDiscoveryPipelineSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryPipelineSpark
 
StructuralVariationDiscoveryPipelineSpark.InMemoryAlignmentParser - Class in org.broadinstitute.hellbender.tools.spark.sv
 
subComputeReadLikelihoodGivenHaplotypeLog10(byte[], byte[], byte[], byte[], byte[], byte[], int, boolean, int) - Method in class org.broadinstitute.hellbender.utils.pairhmm.Log10PairHMM
To be implemented by subclasses to do calculation for #computeReadLikelihoodGivenHaplotypeLog10
subComputeReadLikelihoodGivenHaplotypeLog10(byte[], byte[], byte[], byte[], byte[], byte[], int, boolean, int) - Method in class org.broadinstitute.hellbender.utils.pairhmm.LoglessPairHMM
To be implemented by subclasses to do calculation for #computeReadLikelihoodGivenHaplotypeLog10
subComputeReadLikelihoodGivenHaplotypeLog10(byte[], byte[], byte[], byte[], byte[], byte[], int, boolean, int) - Method in class org.broadinstitute.hellbender.utils.pairhmm.PairHMM
To be implemented by subclasses to do calculation for #computeReadLikelihoodGivenHaplotypeLog10
subdivideAndFillReads(String, int, int, ReadFilter) - Static method in class org.broadinstitute.hellbender.engine.spark.AddContextDataToReadSparkOptimized
Fill in reads that start in the given shard, and subshard the output to the requested size.
SubdivideAndFillReadsIterator(String, int, int, ReadFilter, ContextShard) - Constructor for class org.broadinstitute.hellbender.engine.spark.AddContextDataToReadSparkOptimized.SubdivideAndFillReadsIterator
 
SUBDIVISION_MODE - Variable in class picard.util.IntervalListTools
 
SUBDIVISION_MODE_lONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.SplitIntervals
 
SUBDIVISION_MODE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.SplitIntervals
 
subFinderLabels() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.AggregatedSubHaplotypeFinder
 
subKmer(int, int) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.Kmer
Create a derived shallow kmer that starts at newStart and has newLength bases
submit(T) - Method in class org.broadinstitute.hellbender.utils.downsampling.Downsampler
Submit one item to the downsampler for consideration.
submit(Collection<T>) - Method in class org.broadinstitute.hellbender.utils.downsampling.Downsampler
Submit a collection of items to the downsampler for consideration.
submit(GATKRead) - Method in class org.broadinstitute.hellbender.utils.downsampling.FractionalDownsampler
 
submit(T) - Method in class org.broadinstitute.hellbender.utils.downsampling.LevelingDownsampler
 
submit(Collection<T>) - Method in class org.broadinstitute.hellbender.utils.downsampling.LevelingDownsampler
 
submit(GATKRead) - Method in class org.broadinstitute.hellbender.utils.downsampling.MutectDownsampler
 
submit(GATKRead) - Method in class org.broadinstitute.hellbender.utils.downsampling.PassThroughDownsampler
 
submit(GATKRead) - Method in class org.broadinstitute.hellbender.utils.downsampling.PositionalDownsampler
 
submit(GATKRead) - Method in class org.broadinstitute.hellbender.utils.downsampling.ReservoirDownsampler
 
subSequence(int, int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerizer.ASCIICharSequence
 
subsetAlleles(GenotypesContext, int, List<Allele>, List<Allele>, GenotypeAssignmentMethod, int) - Static method in class org.broadinstitute.hellbender.tools.walkers.genotyper.AlleleSubsettingUtils
Create the new GenotypesContext with the subsetted PLs and ADs Will reorder subsetted alleles according to the ordering provided by the list allelesToKeep
subsetAlleles(VariantContext, List<Allele>) - Static method in class picard.util.AlleleSubsettingUtils
 
subsetAlleles(GenotypesContext, List<Allele>, List<Allele>) - Static method in class picard.util.AlleleSubsettingUtils
Create the new GenotypesContext with the subsetted PLs and ADs Expects allelesToKeep to be in the same order in which they are in originalAlleles.
SubsettedLikelihoodMatrix<A extends htsjdk.variant.variantcontext.Allele> - Class in org.broadinstitute.hellbender.tools.walkers.mutect
Fast wrapper for a LikelihoodMatrix that uses only a subset of alleles.
SubsettedLikelihoodMatrix(LikelihoodMatrix<A>, List<A>) - Constructor for class org.broadinstitute.hellbender.tools.walkers.mutect.SubsettedLikelihoodMatrix
 
subsettedPLIndices(int, List<Allele>, List<Allele>) - Static method in class org.broadinstitute.hellbender.tools.walkers.genotyper.AlleleSubsettingUtils
Given a list of original alleles and a subset of new alleles to retain, find the array of old PL indices that correspond to new PL indices i.e.
subsettedPLIndices(List<Allele>, List<Allele>) - Static method in class picard.util.AlleleSubsettingUtils
Given a list of original alleles and a subset of new alleles to retain, find the array of old PL indices that correspond to new PL indices i.e.
subsetToNeighbors(V, int) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Get a graph containing only the vertices within distance edges of target
subsetToRefOnly(VariantContext, int) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Subset the samples in VC to reference only information with ref call alleles Preserves DP if present
subsetToRefSource(int) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Get a subgraph of graph that contains only vertices within a given number of edges of the ref source vertex
subsetVCToMatchSnp(VariantContext, Snp) - Static method in class picard.util.AlleleSubsettingUtils
Method to subset the alleles in the VariantContext to those in the input snp.
SUBSTITUTION - Variable in class picard.analysis.artifacts.ErrorSummaryMetrics
A single string representing the substition from REF_BASE to ALT_BASE for convenience.
SUBSTITUTION_RATE - Variable in class picard.analysis.artifacts.ErrorSummaryMetrics
The rate of the substitution in question.
Substructure(List<Integer>, List<Range>) - Constructor for class picard.illumina.parser.ReadStructure.Substructure
Indices into the ReadStructure.descriptors for this specific substructure, indices must be in the order they appear in the descriptors list (but the indices do NOT have to be continuous)
subtract(GenomeLoc) - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
 
subtractRegions(GenomeLocSortedSet) - Method in class org.broadinstitute.hellbender.utils.GenomeLocSortedSet
 
successor(SVKmer.Base, int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmer
 
successor(SVKmer.Base, int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerLong
Returns a new SVKmerLong that's like this one, but with its leading base discarded and a new one added to the end.
successor(SVKmer.Base, int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerShort
Returns a new SVKmerShort that's like this one, but with its leading base discarded and a new one added to the end.
SUFFICIENT_GOOD_REALIGNMENTS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.FilterAlignmentArtifacts
 
sum(IntToDoubleFunction) - Method in class org.broadinstitute.hellbender.utils.IndexRange
Sums the values of an int -> double function applied to this range
sum(double[][][]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Return sum of 3d array
sum(double[]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
sum(int[]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
sum(byte[]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
sum(long[]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
sum(long[], int, int) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Returns the sum of the elements in the array starting with start and ending before stop.
sum(double[], int, int) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Returns the sum of the elements in the array starting with start and ending before stop.
sum() - Method in class org.broadinstitute.hellbender.utils.Nucleotide.Counter
 
sum(double...) - Method in class picard.util.MathUtil.LogMath
Computes the sum of the provided log values.
sum(double[], double[]) - Static method in class picard.util.MathUtil
calculates the sum of the arrays as a third array.
sum(double[]) - Static method in class picard.util.MathUtil
Returns the sum of the elements in the array.
sum(long[], int, int) - Static method in class picard.util.MathUtil
Returns the sum of the elements in the array starting with start and ending before stop.
SUM_GL_THRESH_NOCALL - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
 
sumArrayFunction(int, int, MathUtils.IntToDoubleArrayFunction) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
sumLog10(double[]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Returns the sum of values whose log10s we have.
summary - Variable in class org.broadinstitute.hellbender.tools.walkers.validation.Concordance
 
SUMMARY - Variable in class picard.metrics.GcBiasMetrics
 
SUMMARY_FILE_EXTENSION - Static variable in class picard.analysis.CollectRrbsMetrics
 
SUMMARY_FILE_SUFFIX - Static variable in class org.broadinstitute.hellbender.tools.exome.FilterByOrientationBias
 
SUMMARY_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.Concordance
 
SUMMARY_METRICS_FILE_EXTENSION - Static variable in class picard.vcf.GenotypeConcordance
 
SUMMARY_OUTPUT - Variable in class picard.analysis.CollectGcBiasMetrics
 
SUMMARY_OUTPUT - Variable in class picard.fingerprint.CheckFingerprint
 
SUMMARY_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.Concordance
 
summaryMetricsExtension - Static variable in class picard.illumina.quality.CollectHiSeqXPfFailMetrics
 
sumOfBaseQualities(GATKRead) - Static method in enum org.broadinstitute.hellbender.utils.read.markduplicates.MarkDuplicatesScoringStrategy
Computes the sum of base qualities of the given read.
sumOfSquares(Collection<Integer>) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Computes the sum of squares of the given collection of ints or 0.0 if the collection is empty.
sumOverAlleleIndicesAndCounts(IntToDoubleBiFunction) - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeAlleleCounts
 
supportedTypes() - Method in class picard.illumina.parser.MultiTileParser
 
supportedTypes() - Method in class picard.illumina.parser.PosParser
 
SUPPORTING_CALLSET_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeCalculationArgumentCollection
 
SUPPORTING_CALLSET_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeCalculationArgumentCollection
 
SUPPORTING_CALLSETS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.variantutils.CalculateGenotypePosteriors
 
SUPPORTING_CALLSETS_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.variantutils.CalculateGenotypePosteriors
 
supportsMetricAccumulationLevel() - Method in interface picard.analysis.CollectMultipleMetrics.ProgramInterface
 
supportsVariant(GATKRead, VariantContext, int) - Static method in class org.broadinstitute.hellbender.tools.walkers.realignmentfilter.RealignmentEngine
 
supportVariants - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeCalculationArgumentCollection
Supporting external panel.
supportVariants - Variable in class org.broadinstitute.hellbender.tools.walkers.variantutils.CalculateGenotypePosteriors
Supporting external panels.
SvCigarUtils - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
Various utility functions helping calling structural variants.
SvCigarUtils() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SvCigarUtils
 
SVContext - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
Variant context with additional method to mine the structural variant specific information from structural variant records.
SVD - Interface in org.broadinstitute.hellbender.utils.svd
Interface for SVD implementation.
SVDDenoisedCopyRatioResult - Class in org.broadinstitute.hellbender.tools.copynumber.denoising
Represents copy ratios for a sample that has been standardized and denoised by an SVDReadCountPanelOfNormals.
SVDDenoisedCopyRatioResult(SampleLocatableMetadata, List<SimpleInterval>, RealMatrix, RealMatrix) - Constructor for class org.broadinstitute.hellbender.tools.copynumber.denoising.SVDDenoisedCopyRatioResult
 
SVDDenoisingUtils - Class in org.broadinstitute.hellbender.tools.copynumber.denoising
Utility class for package-private methods for performing SVD-based denoising and related operations.
SVDFactory - Class in org.broadinstitute.hellbender.utils.svd
Entry point for creating an instance of SVD.
SVDFactory() - Constructor for class org.broadinstitute.hellbender.utils.svd.SVDFactory
 
SvDiscoverFromLocalAssemblyContigAlignmentsSpark - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery
(Internal) Examines aligned contigs from local assemblies and calls structural variants or their breakpoints
SvDiscoverFromLocalAssemblyContigAlignmentsSpark() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoverFromLocalAssemblyContigAlignmentsSpark
 
SvDiscoverFromLocalAssemblyContigAlignmentsSpark.AssemblyContigsClassifiedByAlignmentSignatures - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery
 
SvDiscoverFromLocalAssemblyContigAlignmentsSpark.SAMFormattedContigAlignmentParser - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery
 
SvDiscoveryInputMetaData - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery
 
SvDiscoveryInputMetaData(JavaSparkContext, StructuralVariationDiscoveryArgumentCollection.DiscoverVariantsFromContigsAlignmentsSparkArgumentCollection, String, String, ReadMetadata, List<SVInterval>, PairedStrandedIntervalTree<EvidenceTargetLink>, Broadcast<SVIntervalTree<VariantContext>>, SAMFileHeader, ReferenceMultiSource, Logger) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoveryInputMetaData
 
SvDiscoveryInputMetaData.ReferenceData - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery
 
SvDiscoveryInputMetaData.SampleSpecificData - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery
 
SvDiscoveryUtils - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery
 
SvDiscoveryUtils() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoveryUtils
 
SVDReadCountPanelOfNormals - Interface in org.broadinstitute.hellbender.tools.copynumber.denoising
Interface for the panel of normals (PoN) for SVD-based coverage denoising.
SVDUSTFilteredKmerizer - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
An iterator over kmers with a specified maximum DUST-style, low-complexity score.
SVDUSTFilteredKmerizer(byte[], int, int, SVKmer) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVDUSTFilteredKmerizer
 
SVDUSTFilteredKmerizer(CharSequence, int, int, SVKmer) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVDUSTFilteredKmerizer
 
SVFastqUtils - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
Memory-economical utilities for producing a FASTQ file.
SVFastqUtils() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils
 
SVFastqUtils.FastqRead - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
SVFastqUtils.FastqRead.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
SVFastqUtils.Mapping - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
SVFileUtils - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
SVFileUtils() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFileUtils
 
SVInterval - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
Naturally collating, simple interval.
SVInterval(int, int, int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVInterval
 
SVInterval.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
SVIntervalTree<V> - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
A Red-Black tree with intervals for keys.
SVIntervalTree() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree
 
SVIntervalTree.Entry<V1> - Interface in org.broadinstitute.hellbender.tools.spark.sv.utils
 
SVIntervalTree.FwdIterator - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
SVIntervalTree.OverlapIterator - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
SVIntervalTree.RevIterator - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
SVIntervalTree.Serializer<T> - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
SVIntervalTree.ValuesIterator<V1> - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
SVKmer - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
SVKmer() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmer
 
SVKmer.Base - Enum in org.broadinstitute.hellbender.tools.spark.sv.utils
 
SVKmerizer - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
Iterator over successive Kmers from a sequence of characters.
SVKmerizer(byte[], int, SVKmer) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerizer
 
SVKmerizer(byte[], int, int, SVKmer) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerizer
 
SVKmerizer(CharSequence, int, SVKmer) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerizer
 
SVKmerizer(CharSequence, int, int, SVKmer) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerizer
 
SVKmerizer(int, CharSequence) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerizer
 
SVKmerizer(int, int, CharSequence) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerizer
 
SVKmerizer.ASCIICharSequence - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
SVKmerLong - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
An immutable SVKmerLong.
SVKmerLong() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerLong
 
SVKmerLong(int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerLong
Makes an empty SVKmerLong.
SVKmerLong(SVKmerLong) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerLong
 
SVKmerLong(SVKmer) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerLong
 
SVKmerLong(Kryo, Input) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerLong
 
SVKmerLong.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
SVKmerShort - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
An immutable SVKmerShort.
SVKmerShort() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerShort
Makes an empty SVKmerShort.
SVKmerShort(int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerShort
Makes an empty SVKmerShort.
SVKmerShort(SVKmerShort) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerShort
 
SVKmerShort(long) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerShort
 
SVKmerShort.Serializer - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
svLen - Variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvType
 
SVLEN - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
SVLocation - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
SVLocation(int, int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVLocation
 
SVReadFilter - Class in org.broadinstitute.hellbender.tools.spark.sv.evidence
 
SVReadFilter(StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.SVReadFilter
 
SVReferenceUtils - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
SVReferenceUtils() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVReferenceUtils
 
SvType - Class in org.broadinstitute.hellbender.tools.spark.sv.discovery
Various types of structural variations
SvType(String, Allele, int, Map<String, String>) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvType
 
SVTYPE - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
SVUtils - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
Useful scraps of this and that.
SVUtils() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVUtils
 
SVUtils.IteratorFilter<T> - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
SVVCFReader - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
SVVCFReader() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVVCFReader
 
SVVCFWriter - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
A utility class that writes out variants to a VCF file.
SVVCFWriter() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVVCFWriter
 
swapAlleles(VariantContext, Allele, Allele) - Static method in class picard.util.AlleleSubsettingUtils
Swaps one of the alleles in a VC (and its genotypes) with another.
SWAPPED_ALLELES - Static variable in class picard.util.LiftoverUtils
Attribute used to store the fact that the alt and ref alleles of the variant have been swapped, while all the INFO annotations have not.
swapRefAlt(VariantContext, Collection<String>, Collection<String>) - Static method in class picard.util.LiftoverUtils
method to swap the reference and alt alleles of a bi-allelic, SNP
SWNativeAlignerWrapper - Class in org.broadinstitute.hellbender.utils.smithwaterman
A wrapper that converts instances of SWAlignerNativeBinding into a SmithWatermanAligner
SWNativeAlignerWrapper(SWAlignerNativeBinding) - Constructor for class org.broadinstitute.hellbender.utils.smithwaterman.SWNativeAlignerWrapper
 
SYMB_ALT_ALLELE_DEL - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
SYMB_ALT_ALLELE_DUP - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
SYMB_ALT_ALLELE_INS - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
SYMB_ALT_ALLELE_INV - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
SYMB_ALT_ALLELE_INVDUP - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
SYMBOLIC_ALLELE_DEFINITION_HEADER_TAG - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
SYMBOLIC_UNASSEMBLED_EVENT_ALLELE - Static variable in class org.broadinstitute.hellbender.utils.haplotype.EventMap
 
symmetricDirichlet(int, double) - Static method in class org.broadinstitute.hellbender.utils.Dirichlet
Create a symmetric distribution Dir(a/K, a/K, a/K .
SynchronizedUnivariateSolver - Class in org.broadinstitute.hellbender.utils.solver
This class implements a synchronized univariate solver for solving multiple independent equations.
SynchronizedUnivariateSolver(Function<Map<Integer, Double>, Map<Integer, Double>>, Function<UnivariateSolverSpecifications, AbstractUnivariateSolver>, int) - Constructor for class org.broadinstitute.hellbender.utils.solver.SynchronizedUnivariateSolver
Public constructor for invoking one of AbstractUnivariateSolver
SynchronizedUnivariateSolver.UnivariateSolverStatus - Enum in org.broadinstitute.hellbender.utils.solver
 
SynchronizedUnivariateSolver.UnivariateSolverSummary - Class in org.broadinstitute.hellbender.utils.solver
Stores the summary of a univariate solver jobDescription
SYNTHETIC_PHASESET_PREFIX - Static variable in class picard.fingerprint.HaplotypeMap
 
SystemProperty - Annotation Type in org.broadinstitute.hellbender.utils.config
An annotation to denote Configuration options that should be injected into the Java System Properties.

T

T_FOLLOWED_BY_INSERTION_BASE - Static variable in class org.broadinstitute.hellbender.utils.pileup.PileupElement
 
TAB_MODE - Variable in class picard.vcf.MendelianViolations.FindMendelianViolations
 
TabbedInputParser - Class in picard.util
Parser for tab-delimited files
TabbedInputParser(boolean, InputStream...) - Constructor for class picard.util.TabbedInputParser
Constructor
TabbedInputParser(boolean, File...) - Constructor for class picard.util.TabbedInputParser
Constructor
TabbedTextFileWithHeaderParser - Class in picard.util
Parse a tabbed text file in which columns are found by looking at a header line rather than by position.
TabbedTextFileWithHeaderParser(TabbedInputParser) - Constructor for class picard.util.TabbedTextFileWithHeaderParser
 
TabbedTextFileWithHeaderParser(File) - Constructor for class picard.util.TabbedTextFileWithHeaderParser
 
TabbedTextFileWithHeaderParser(File, String[]) - Constructor for class picard.util.TabbedTextFileWithHeaderParser
 
TabbedTextFileWithHeaderParser.Row - Class in picard.util
 
TableCodec - Class in org.broadinstitute.hellbender.utils.codecs.table
Reads tab deliminated tabular text files
TableCodec() - Constructor for class org.broadinstitute.hellbender.utils.codecs.table.TableCodec
 
TableColumnCollection - Class in org.broadinstitute.hellbender.utils.tsv
Represents a list of table columns.
TableColumnCollection(Iterable<String>) - Constructor for class org.broadinstitute.hellbender.utils.tsv.TableColumnCollection
Creates a new table-column names collection.
TableColumnCollection(String...) - Constructor for class org.broadinstitute.hellbender.utils.tsv.TableColumnCollection
Creates a new table-column names collection.
TableColumnCollection(Object...) - Constructor for class org.broadinstitute.hellbender.utils.tsv.TableColumnCollection
Creates a new table-column names collection.
TableColumnCollection(Class<? extends Enum<?>>) - Constructor for class org.broadinstitute.hellbender.utils.tsv.TableColumnCollection
Creates a new table-column collection from a set of enum constants.
TableFeature - Class in org.broadinstitute.hellbender.utils.codecs.table
Feature representing a row in a text table.
TableFeature(Locatable, List<String>, List<String>) - Constructor for class org.broadinstitute.hellbender.utils.codecs.table.TableFeature
Public constructor.
TableFuncotation - Class in org.broadinstitute.hellbender.tools.funcotator.dataSources
A Funcotation to hold data from simple tabular data.
TableFuncotation(List<String>, List<String>, Allele, String) - Constructor for class org.broadinstitute.hellbender.tools.funcotator.dataSources.TableFuncotation
 
TableFuncotation(LinkedHashSet<String>, List<String>, Allele, String) - Constructor for class org.broadinstitute.hellbender.tools.funcotator.dataSources.TableFuncotation
 
TableFuncotation(Map<String, Object>, Allele, String) - Constructor for class org.broadinstitute.hellbender.tools.funcotator.dataSources.TableFuncotation
 
TableFuncotation(XsvTableFeature, Allele, String) - Constructor for class org.broadinstitute.hellbender.tools.funcotator.dataSources.TableFuncotation
 
TableReader<R> - Class in org.broadinstitute.hellbender.utils.tsv
Reads the contents of a tab separated value formatted text input into records of an arbitrary type R.
TableReader(File) - Constructor for class org.broadinstitute.hellbender.utils.tsv.TableReader
Creates a new table reader given the input file name.
TableReader(Reader) - Constructor for class org.broadinstitute.hellbender.utils.tsv.TableReader
Creates a new table reader given an input Reader.
TableReader(String, Reader) - Constructor for class org.broadinstitute.hellbender.utils.tsv.TableReader
Creates a new table reader given an input Reader.
TableUtils - Class in org.broadinstitute.hellbender.utils.tsv
Common constants for table readers and writers.
TableWriter<R> - Class in org.broadinstitute.hellbender.utils.tsv
Class to write tab separated value files.
TableWriter(File, TableColumnCollection) - Constructor for class org.broadinstitute.hellbender.utils.tsv.TableWriter
Creates a new table writer given the file and column names.
TableWriter(Writer, TableColumnCollection) - Constructor for class org.broadinstitute.hellbender.utils.tsv.TableWriter
Creates a new table writer given the destination writer and column names.
TAG - Variable in class picard.sam.FilterSamReads
 
TAG_DUPLICATE_SET_MEMBERS - Variable in class picard.sam.markduplicates.MarkDuplicates
 
TAG_GROUP_SEPERATOR - Variable in class picard.sam.SamToFastqWithTags
 
TAG_PER_MOLECULAR_INDEX - Variable in class picard.illumina.IlluminaBasecallsToSam
 
TAG_VALUE - Variable in class picard.sam.FilterSamReads
 
TagGermlineEvents - Class in org.broadinstitute.hellbender.tools.copynumber.utils
 
TagGermlineEvents() - Constructor for class org.broadinstitute.hellbender.tools.copynumber.utils.TagGermlineEvents
 
TAGGING_POLICY - Variable in class picard.sam.markduplicates.MarkDuplicates
 
TAGS_TO_DROP - Variable in class picard.vcf.LiftoverVcf
 
TAGS_TO_REVERSE - Variable in class picard.vcf.LiftoverVcf
 
tagTumorSegmentsWithGermlineActivity(List<AnnotatedInterval>, List<AnnotatedInterval>, String, SAMSequenceDictionary, String, int) - Static method in class org.broadinstitute.hellbender.tools.copynumber.utils.germlinetagging.SimpleGermlineTagger
Look for concordant endpoints for determining whether an event in the tumor regions are in the germline regions.
tail() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KBestHaplotype
Returns the sub-haplotype from the second vertex involved in the haplotype until the end.
TAIL_LIMIT - Variable in class picard.analysis.CollectJumpingLibraryMetrics
 
tallyPrimaryAlignments(boolean) - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.HitsForInsert
 
TANDEM_READS - Variable in class picard.analysis.artifacts.CollectSequencingArtifactMetrics
 
TandemRepeat - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Tandem repeat unit composition and counts per allele
TandemRepeat() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.TandemRepeat
 
TANGENT_NORMALIZED_COUNTS_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
TANGENT_NORMALIZED_COUNTS_FILE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
target - Variable in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.DiscordantReadPairEvidence
 
TARGET_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
TARGET_FILE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
TARGET_INTERVALS - Variable in class picard.analysis.directed.CollectTargetedMetrics
 
TARGET_INTERVALS - Variable in class picard.vcf.CollectVariantCallingMetrics
 
TARGET_TERRITORY - Variable in class picard.analysis.directed.HsMetrics
The unique number of target bases in the experiment, where the target sequence is usually exons etc.
TARGET_TERRITORY - Variable in class picard.analysis.directed.TargetedPcrMetrics
The number of unique bases covered by the intervals of all targets that should be covered
TARGET_TERRITORY - Variable in class picard.analysis.directed.TargetMetrics
The number of unique bases covered by the intervals of all targets that should be covered
TARGET_TERRITORY_COLUMN_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.FalsePositiveRecord
 
TargetedPcrMetrics - Class in picard.analysis.directed
Metrics class for the analysis of reads obtained from targeted pcr experiments e.g.
TargetedPcrMetrics() - Constructor for class picard.analysis.directed.TargetedPcrMetrics
 
TargetedPcrMetricsCollector - Class in picard.analysis.directed
Calculates HS metrics for a given SAM or BAM file.
TargetedPcrMetricsCollector(Set<MetricAccumulationLevel>, List<SAMReadGroupRecord>, ReferenceSequenceFile, File, File, IntervalList, IntervalList, String, int, int, int, boolean, int, int) - Constructor for class picard.analysis.directed.TargetedPcrMetricsCollector
 
TargetedPcrMetricsCollector(Set<MetricAccumulationLevel>, List<SAMReadGroupRecord>, ReferenceSequenceFile, File, File, IntervalList, IntervalList, String, int, int, int, boolean, boolean, int, int) - Constructor for class picard.analysis.directed.TargetedPcrMetricsCollector
 
targetForwardStrand - Variable in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.DiscordantReadPairEvidence
 
targetLinkFile - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
TargetMetrics - Class in picard.analysis.directed
TargetMetrics, are metrics to measure how well we hit specific targets (or baits) when using a targeted sequencing process like hybrid selection or Targeted PCR Techniques (TSCA).
TargetMetrics() - Constructor for class picard.analysis.directed.TargetMetrics
 
TargetMetricsCollector<METRIC_TYPE extends MultilevelMetrics> - Class in picard.analysis.directed
TargetMetrics, are metrics to measure how well we hit specific targets (or baits) when using a targeted sequencing process like hybrid selection or Targeted PCR Techniques (TSCA).
TargetMetricsCollector(Set<MetricAccumulationLevel>, List<SAMReadGroupRecord>, ReferenceSequenceFile, File, File, IntervalList, IntervalList, String, int, int, int, boolean, int, int) - Constructor for class picard.analysis.directed.TargetMetricsCollector
 
TargetMetricsCollector(Set<MetricAccumulationLevel>, List<SAMReadGroupRecord>, ReferenceSequenceFile, File, File, IntervalList, IntervalList, String, int, int, int, boolean, boolean, int, int) - Constructor for class picard.analysis.directed.TargetMetricsCollector
 
TargetMetricsCollector.Coverage - Class in picard.analysis.directed
A simple class that is used to store the coverage information about an interval.
TargetMetricsCollector.PerUnitTargetMetricCollector - Class in picard.analysis.directed
Collect the Target Metrics for one unit of "accumulation" (i.e.
targetQuality - Variable in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.DiscordantReadPairEvidence
 
TARGETS - Variable in class picard.util.BaitDesigner
 
TAX_DUMP_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildReferenceTaxonomy
 
TAX_DUMP_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildReferenceTaxonomy
 
taxdumpPath - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBuildReferenceTaxonomy
 
taxIDs - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenAlignmentHit
 
TAXONOMIC_DATABASE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
 
TAXONOMIC_DATABASE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
 
taxonomyDatabasePath - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScoreArgumentCollection
 
Template - Static variable in enum picard.illumina.parser.ReadType
 
TemplateFragmentOrdinal - Enum in org.broadinstitute.hellbender.tools.spark.sv.evidence
Indicates the ordinal of a fragment in a paired sequenced template.
templates - Variable in class picard.illumina.parser.ReadStructure
 
TemplateSizeAnomaly(SVInterval, int, int) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.TemplateSizeAnomaly
 
TemplateSizeAnomaly(Kryo, Input) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.TemplateSizeAnomaly
 
TensorType - Enum in org.broadinstitute.hellbender.tools.walkers.vqsr
TensorType documents the tensors available and what information they encode.
terminate() - Method in class org.broadinstitute.hellbender.utils.python.StreamingPythonScriptExecutor
Terminate the remote process, closing the fifo if any.
terminate() - Method in class org.broadinstitute.hellbender.utils.runtime.AsynchronousStreamWriterService
Terminate the async writer, cancelling any outstanding work.
terminate() - Method in class org.broadinstitute.hellbender.utils.runtime.StreamingProcessController
Close the input stream, close the FIFO, and wait for the remote process to terminate destroying it if necessary.
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.AlignmentAgreesWithHeaderReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.AmbiguousBaseReadFilter
Test read for a given maximum threshold of allowable ambiguous bases
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.CountingReadFilter.CountingAndReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.CountingReadFilter
 
test(VariantContext) - Method in class org.broadinstitute.hellbender.engine.filters.CountingVariantFilter.CountingAndVariantFilter
 
test(VariantContext) - Method in class org.broadinstitute.hellbender.engine.filters.CountingVariantFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.FragmentLengthReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.LibraryReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.MappingQualityReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.MetricsReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.NotOpticalDuplicateReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.OverclippedReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.PlatformReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.PlatformUnitReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilter.ReadFilterAnd
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.AllowAllReadsReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.CigarContainsNoNOperator
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.FirstOfPairReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.GoodCigarReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.HasReadGroupReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.MappedReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.MappingQualityAvailableReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.MappingQualityNotZeroReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.MatchingBasesAndQualsReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.MateDifferentStrandReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.MateOnSameContigOrNoMappedMateReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.NonZeroFragmentLengthReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.NonZeroReferenceLengthAlignmentReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.NotDuplicateReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.NotSecondaryAlignmentReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.NotSupplementaryAlignmentReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.PairedReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.PassesVendorQualityCheckReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.PrimaryLineReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.ProperlyPairedReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.ReadLengthEqualsCigarLengthReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.SecondOfPairReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.SeqIsStoredReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.ValidAlignmentEndReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.ValidAlignmentStartReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadGroupBlackListReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadGroupReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadLengthReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadNameReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.ReadStrandFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.SampleReadFilter
 
test(VariantContext) - Method in class org.broadinstitute.hellbender.engine.filters.VariantIDsVariantFilter
 
test(VariantContext) - Method in class org.broadinstitute.hellbender.engine.filters.VariantTypesVariantFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.engine.filters.WellformedReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.ContainsKmerReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.HostAlignmentReadFilter
 
test(Cigar, int) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.HostAlignmentReadFilter
 
test(GATKRead) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.MarkedOpticalDuplicateReadFilter
 
test(double[], double[], MannWhitneyU.TestType) - Method in class org.broadinstitute.hellbender.utils.MannWhitneyU
Constructs a new rank sum test with the given data.
test(MiniDFSCluster) - Method in interface org.broadinstitute.hellbender.utils.test.MiniClusterUtils.MiniClusterTest
A test to be run using an hdfs MiniCluster It's alright for this to make destructive changes to the cluster since it is given it's own isolated setup.
test() - Method in class org.broadinstitute.hellbender.utils.test.testers.CleanSamTester
 
test() - Method in class org.broadinstitute.hellbender.utils.test.testers.SamFileTester
 
Test - Class in picard
 
Test() - Constructor for class picard.Test
 
TestDataProvider(Class<?>, String) - Constructor for class org.broadinstitute.hellbender.utils.test.BaseTest.TestDataProvider
Create a new TestDataProvider instance bound to the class variable C
TestDataProvider(Class<?>) - Constructor for class org.broadinstitute.hellbender.utils.test.BaseTest.TestDataProvider
 
testDoWork() - Method in class picard.analysis.CollectAlignmentSummaryMetrics
Silly method that is necessary to give unit test access to call doWork()
Testing - Class in picard.cmdline.programgroups
For internal test purposes only.
Testing() - Constructor for class picard.cmdline.programgroups.Testing
 
TestingReadThreadingGraph - Class in org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading
 
TestingReadThreadingGraph(String) - Constructor for class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.TestingReadThreadingGraph
Constructs a read-threading-graph for a string representation.
TestProgramGroup - Class in org.broadinstitute.hellbender.cmdline
Program group for use with internal test CommandLinePrograms only.
TestProgramGroup() - Constructor for class org.broadinstitute.hellbender.cmdline.TestProgramGroup
 
testReadAndGatherEvidence(GATKRead, List<BreakpointEvidence>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.KSWindowFinder
Used in production to gather evidence derived from K-S calculation on windows.
TestStatistic(double, double, double) - Constructor for class org.broadinstitute.hellbender.utils.MannWhitneyU.TestStatistic
 
TestStatistic(double, double) - Constructor for class org.broadinstitute.hellbender.utils.MannWhitneyU.TestStatistic
 
TextFormattingUtils - Class in org.broadinstitute.hellbender.utils.text
Common utilities for dealing with text formatting.
TextMDCodec - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
TextMDCodec() - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.TextMDCodec
 
TextMDCodec.DeletionMDElement - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
TextMDCodec.MatchMDElement - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
TextMDCodec.MDElement - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
TextMDCodec.MismatchMDElement - Class in org.broadinstitute.hellbender.tools.spark.sv.utils
 
theoreticalHetSensitivitySampleSize - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The sample size used for theoretical het sensitivity.
TheoreticalSensitivity - Class in picard.analysis
Created by David Benjamin on 5/13/15.
TheoreticalSensitivity() - Constructor for class picard.analysis.TheoreticalSensitivity
 
TheoreticalSensitivity.RouletteWheel - Class in picard.analysis
 
THREAD_COUNT - Variable in class picard.vcf.CollectVariantCallingMetrics
 
THREAD_COUNT - Variable in class picard.vcf.MendelianViolations.FindMendelianViolations
 
threadLocalPairHMMComputeTimeDiff - Variable in class org.broadinstitute.hellbender.utils.pairhmm.PairHMM
 
ThreadPoolExecutorWithExceptions - Class in picard.util
This version of the thread pool executor will throw an exception if any of the internal jobs have throw exceptions while executing
ThreadPoolExecutorWithExceptions(int) - Constructor for class picard.util.ThreadPoolExecutorWithExceptions
Creates a fixed size thread pool executor that will rethrow exceptions from submitted jobs.
THREE_PRIME_ADAPTER - Variable in class picard.illumina.IlluminaBasecallsToSam
 
THREE_PRIME_ADAPTER - Variable in class picard.illumina.MarkIlluminaAdapters
 
THRESHOLD_LONG_NAME - Static variable in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
THROW_ON_DIFF_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.validation.CompareDuplicatesSpark
 
THROW_ON_DIFF_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.validation.CompareBaseQualities
 
throwOnDiff - Variable in class org.broadinstitute.hellbender.tools.spark.validation.CompareDuplicatesSpark
 
throwOnDiff - Variable in class org.broadinstitute.hellbender.tools.validation.CompareBaseQualities
 
tile - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
tile - Variable in class picard.illumina.parser.readers.AbstractIlluminaPositionFileReader.PositionInfo
The tile, which is determined from the file name
Tile - Class in picard.illumina.parser
Represents a tile from TileMetricsOut.bin.
Tile(int, int, float, float, TilePhasingValue...) - Constructor for class picard.illumina.parser.Tile
 
TILE - Variable in class picard.illumina.quality.CollectHiSeqXPfFailMetrics.PFFailDetailedMetric
The Tile that is described by this metric
TILE - Variable in class picard.illumina.quality.CollectHiSeqXPfFailMetrics.PFFailSummaryMetric
The Tile that is described by this metric.
tile - Variable in class picard.sam.util.PhysicalLocationInt
 
TILE_LIMIT - Variable in class picard.illumina.IlluminaBasecallsToFastq
 
TILE_LIMIT - Variable in class picard.illumina.IlluminaBasecallsToSam
 
TILE_METRICS_OUT_FILE_NAME - Static variable in class picard.illumina.parser.TileMetricsUtil
The expected name of the tile metrics output file.
TILE_NUMBERS - Variable in class picard.illumina.CheckIlluminaDirectory
 
tileIndex - Variable in class picard.illumina.parser.MultiTileFileUtil
 
TileIndex - Class in picard.illumina.parser
Load a file containing 8-byte records like this: tile number: 4-byte int number of clusters in tile: 4-byte int Number of records to read is determined by reaching EOF.
TileIndex.TileIndexRecord - Class in picard.illumina.parser
 
tileIsSet() - Method in class picard.illumina.parser.ClusterData
 
tileMetricsOut() - Method in class picard.illumina.parser.IlluminaFileUtil
 
TileMetricsOutReader - Class in picard.illumina.parser.readers
Reads a TileMetricsOut file commonly found in the InterOp directory of an Illumina Run Folder.
TileMetricsOutReader(File, TileMetricsOutReader.TileMetricsVersion) - Constructor for class picard.illumina.parser.readers.TileMetricsOutReader
Return a TileMetricsOutReader for the specified file
TileMetricsOutReader.IlluminaLaneTileCode - Class in picard.illumina.parser.readers
Helper class which captures the combination of a lane, tile & metric code
TileMetricsOutReader.IlluminaTileMetrics - Class in picard.illumina.parser.readers
IlluminaPhasingMetrics corresponds to a single record in a TileMetricsOut file
TileMetricsOutReader.TileMetricsVersion - Enum in picard.illumina.parser.readers
 
TileMetricsUtil - Class in picard.illumina.parser
Utility for reading the tile data from an Illumina run directory's TileMetricsOut.bin file
TileMetricsUtil() - Constructor for class picard.illumina.parser.TileMetricsUtil
 
TilePhasingValue - Class in picard.illumina.parser
Captures information about a phasing value - Which read it corresponds to, which phasing type and a median value
TilePhasingValue(TileTemplateRead, float, float) - Constructor for class picard.illumina.parser.TilePhasingValue
 
tiles - Variable in class picard.illumina.parser.ParameterizedFileUtil
 
TileTemplateRead - Enum in picard.illumina.parser
Defines the first or second template read for a tile
TMP_DIR - Variable in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
 
TMP_DIR - Variable in class picard.cmdline.CommandLineProgram
 
TMP_DIR_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
TN_COUNT - Variable in class picard.vcf.GenotypeConcordanceContingencyMetrics
The TN (true negative) count across all variants
TN_FN - Static variable in class picard.vcf.GenotypeConcordanceScheme
 
TN_ONLY - Static variable in class picard.vcf.GenotypeConcordanceScheme
 
to - Variable in class org.broadinstitute.hellbender.utils.IndexRange
Index following the last index included in the range.
toApplyBQSRArgumentCollection(int) - Method in class org.broadinstitute.hellbender.tools.ApplyBQSRUniqueArgumentCollection
 
toArray() - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
 
toArray(T[]) - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
 
toArray() - Method in class org.broadinstitute.hellbender.utils.tsv.DataLine
Returns the current values in a string array.
toBase() - Method in enum org.broadinstitute.hellbender.utils.Nucleotide
Returns the base that corresponds to this nucleotide.
toBedpeString(ReadMetadata) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.EvidenceTargetLink
 
toBedString(ReadMetadata) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVInterval
 
toClassName(String) - Method in class picard.cmdline.ClassFinder
Convert a filename to a class name by removing '.class' and converting '/'s to '.'s.
toCode() - Method in enum picard.pedigree.Sex
Returns the code used to encode this sex in a ped/fam file.
toCoverage - Variable in class org.broadinstitute.hellbender.utils.downsampling.DownsamplingMethod
Actual downsampling target is specified as an integer number of reads.
toDownsamplingInfo(DownsamplingMethod) - Static method in class org.broadinstitute.hellbender.utils.locusiterator.LIBSDownsamplingInfo
 
toFraction - Variable in class org.broadinstitute.hellbender.utils.downsampling.DownsamplingMethod
Actual downsampling target is specified as a fraction of total available reads.
toHeader() - Method in interface org.broadinstitute.hellbender.tools.copynumber.formats.metadata.Metadata
 
toHeader() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.metadata.SimpleLocatableMetadata
 
toHeader() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.metadata.SimpleSampleLocatableMetadata
 
toHeader() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.metadata.SimpleSampleMetadata
 
toIndex(int) - Method in interface org.broadinstitute.hellbender.utils.collections.Permutation
Given an index on the original list, returns the position of tha element in the resulting list.
toIndex(int) - Method in class org.broadinstitute.hellbender.utils.genotyper.AlleleList.ActualPermutation
 
toIndex(int) - Method in class org.broadinstitute.hellbender.utils.genotyper.AlleleList.NonPermutation
 
toIntArray() - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
Copies the content of the set into an integer array.
toKey() - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchCollection
in a general multiset, the entry is the key
toKey() - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchMap
getKey returns the key part of a Map.Entry
toKey() - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchMultiMap
getKey returns the key part of a Map.Entry
toKmer(CharSequence, SVKmer) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerizer
 
toKmer(byte[], SVKmer) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerizer
 
toList() - Method in interface org.broadinstitute.hellbender.utils.collections.Permutation
Returns an unmodifiable view to the original element list.
toList() - Method in class org.broadinstitute.hellbender.utils.GenomeLocSortedSet
convert this object to a list
toList() - Method in class org.broadinstitute.hellbender.utils.genotyper.AlleleList.ActualPermutation
 
toList() - Method in class org.broadinstitute.hellbender.utils.genotyper.AlleleList.NonPermutation
 
toList() - Method in class org.broadinstitute.hellbender.utils.tsv.TableReader
Read the remaining records into a list.
toLog10(double[]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Converts a real space array of numbers (typically probabilities) into a log10 array
toolDisplayName(Class<?>) - Static method in class org.broadinstitute.hellbender.utils.runtime.RuntimeUtils
Given a Class that is a CommandLineProgram, either GATK or Picard, return a display name suitable for presentation to the user that distinguishes GATK tools from Picard tools by including a " (Picard)" suffix;
toPackedString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
 
toReadStructure() - Method in class picard.illumina.parser.ReadStructure.Substructure
Create a ReadStructure from this substructure composed of only the descriptors contained in this substructure, Any ReadDescriptors not in this substructure are treated as if they don't exist (e.g.
toSAMRecord(SAMFileHeader, String, byte[], boolean, int, Collection<? extends SAMRecord.SAMTagAndValue>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
Returns a SAMRecord instance that reflects this alignment interval given the output SAMFileHeader and the enclosing sequence bases.
toSAMStreamForAlignmentsOfThisAssembly(SAMFileHeader, List<String>, SAMReadGroupRecord) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.AlignedAssemblyOrExcuse
 
toSAMStreamForRead(String, byte[], List<BwaMemAlignment>, SAMFileHeader, List<String>, SAMReadGroupRecord) - Static method in class org.broadinstitute.hellbender.utils.bwa.BwaMemAlignmentUtils
 
toSATagString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
Returns the SA tag string representation for this interval.
toSequenceGraph() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
Convert this kmer graph to a simple sequence graph.
toSequenceGraph() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingGraph
 
toSimpleOrBNDTypes(ReferenceMultiSource, SAMSequenceDictionary) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.NovelAdjacencyAndAltHaplotype
 
toSize() - Method in interface org.broadinstitute.hellbender.utils.collections.Permutation
Length of the resulting element list.
toSize() - Method in class org.broadinstitute.hellbender.utils.genotyper.AlleleList.ActualPermutation
 
toSize() - Method in class org.broadinstitute.hellbender.utils.genotyper.AlleleList.NonPermutation
 
toString() - Method in class org.broadinstitute.hellbender.engine.AlignmentContext
 
toString() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
 
toString() - Method in class org.broadinstitute.hellbender.engine.FeatureInput
Returns a String representation of this FeatureInput.
toString() - Method in class org.broadinstitute.hellbender.engine.filters.MetricsReadFilter
 
toString() - Method in class org.broadinstitute.hellbender.engine.ReadContextData
 
toString() - Method in class org.broadinstitute.hellbender.engine.ReferenceShard
 
toString() - Method in class org.broadinstitute.hellbender.engine.VariantShard
 
toString() - Method in class org.broadinstitute.hellbender.tools.ClipReads.ClippingData
 
toString() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.collections.AbstractRecordCollection
 
toString() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.metadata.SimpleLocatableMetadata
 
toString() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.metadata.SimpleSampleLocatableMetadata
 
toString() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.metadata.SimpleSampleMetadata
 
toString() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AlleleFractionSegment
 
toString() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AllelicCount
 
toString() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AnnotatedInterval
 
toString() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.AnnotationSet
 
toString() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CalledCopyRatioSegment
 
toString() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CopyNumberPosteriorDistribution
 
toString() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CopyRatio
 
toString() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.CopyRatioSegment
 
toString() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.IntegerCopyNumberSegment
 
toString() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.IntervalCopyNumberGenotypingData
 
toString() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.ModeledSegment.SimplePosteriorSummary
 
toString() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.MultidimensionalSegment
 
toString() - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.records.SimpleCount
 
toString() - Method in class org.broadinstitute.hellbender.tools.copynumber.gcnv.IntegerCopyNumberState
 
toString() - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedInterval
 
toString() - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalCollection
 
toString() - Method in enum org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasFilterSummaryTableColumn
 
toString() - Method in class org.broadinstitute.hellbender.tools.FlagStat.FlagStatus
 
toString() - Method in enum org.broadinstitute.hellbender.tools.funcotator.AminoAcid
 
toString() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation
 
toString() - Method in enum org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation.VariantClassification
 
toString() - Method in enum org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation.VariantType
 
toString() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.TableFuncotation
 
toString() - Method in enum org.broadinstitute.hellbender.tools.funcotator.FuncotatorArgumentDefinitions.DataSourceType
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenTaxonScore
 
toString(PSTree) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSPathogenTaxonScore
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTree
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTreeNode
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignedContig
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigAlignmentsConfigPicker.GoodAndBadMappings
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments
 
toString() - Method in enum org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.ContigAlignmentsModifier.AlnModType
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.BreakEndVariantType.InvSuspectBND
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.BreakEndVariantType
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.BreakEndVariantType.TransLocBND
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications.IntraChrStrandSwitchBreakpointComplications
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications.SmallDuplicationWithImpreciseDupRangeBreakpointComplications
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications.SmallDuplicationWithPreciseDupRangeBreakpointComplications
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.NovelAdjacencyAndAltHaplotype
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SimpleChimera
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SimpleSVType.Deletion
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SimpleSVType.DuplicationInverted
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SimpleSVType.DuplicationTandem
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SimpleSVType.ImpreciseDeletion
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SimpleSVType.Insertion
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SimpleSVType.Inversion
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.ExternalEvidence
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.InterContigPair
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.LargeIndel
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.MateUnmapped
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.OutiesPair
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.ReadEvidence
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.SameStrandPair
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.SplitRead
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.TemplateSizeAnomaly
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.WeirdTemplateSize
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.EvidenceTargetLink
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.QNameAndInterval
 
toString() - Method in enum org.broadinstitute.hellbender.tools.spark.sv.evidence.TemplateFragmentOrdinal
 
toString() - Method in enum org.broadinstitute.hellbender.tools.spark.sv.utils.Strand
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.StrandedInterval
 
toString(GATKRead) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils.Mapping
Generates the mapping string for a read.
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils.Mapping
Generates the mapping string as it would be included in the Fastq read header.
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVInterval
 
toString(int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmer
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerizer.ASCIICharSequence
 
toString(int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerLong
Not an override.
toString(int) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerShort
Not an override.
toString() - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVLocation
 
toString() - Method in class org.broadinstitute.hellbender.tools.spark.transforms.markduplicates.MarkDuplicatesSparkUtils.IndexPair
 
toString() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotation
 
toString() - Method in enum org.broadinstitute.hellbender.tools.walkers.contamination.ContaminationRecord.Level
 
toString() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculationResult
 
toString() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.ExactACcounts
 
toString() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeAlleleCounts
 
toString() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseEdge
 
toString() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseGraph
 
toString() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.BaseVertex
 
toString() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.KBestHaplotype
 
toString() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.Path
 
toString() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.SeqVertex
 
toString() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.Kmer
 
toString() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.KMerCounter
 
toString() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.MultiDeBruijnVertex
 
toString() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingAssembler
 
toString() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.readthreading.ReadThreadingGraph
 
toString() - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VQSLODTranche
 
toString() - Method in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfile
 
toString() - Method in class org.broadinstitute.hellbender.utils.activityprofile.ActivityProfileState
 
toString() - Method in enum org.broadinstitute.hellbender.utils.artifacts.Transition
 
toString() - Method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.FeatureTag
 
toString() - Method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.FeatureType
 
toString() - Method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.GeneTranscriptType
 
toString() - Method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.GenomicPhase
 
toString() - Method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.LocusLevel
 
toString() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.OptionalField
 
toString() - Method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.RemapStatus
 
toString() - Method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.RemapTargetStatus
 
toString() - Method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature
 
toString() - Method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.TranscriptSupportLevel
 
toString() - Method in class org.broadinstitute.hellbender.utils.codecs.table.TableFeature
Format as a tab-delimited row.
toString() - Method in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvTableFeature
 
toString() - Method in class org.broadinstitute.hellbender.utils.collections.CountSet
 
toString() - Method in class org.broadinstitute.hellbender.utils.CompressedDataList
 
toString() - Method in class org.broadinstitute.hellbender.utils.downsampling.DownsamplingMethod
 
toString() - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
 
toString() - Method in class org.broadinstitute.hellbender.utils.GenomeLocSortedSet
 
toString() - Method in class org.broadinstitute.hellbender.utils.haplotype.EventMap
 
toString() - Method in class org.broadinstitute.hellbender.utils.haplotype.Haplotype
 
toString() - Method in class org.broadinstitute.hellbender.utils.Histogram
 
toString() - Method in class org.broadinstitute.hellbender.utils.IndexRange
 
toString() - Method in class org.broadinstitute.hellbender.utils.KV
 
toString() - Method in class org.broadinstitute.hellbender.utils.locusiterator.AlignmentStateMachine
 
toString() - Method in class org.broadinstitute.hellbender.utils.pileup.PileupElement
 
toString() - Method in class org.broadinstitute.hellbender.utils.pileup.ReadPileup
 
toString() - Method in class org.broadinstitute.hellbender.utils.read.ArtificialBAMBuilder
 
toString() - Method in class org.broadinstitute.hellbender.utils.read.BDGAlignmentRecordToGATKReadAdapter
 
toString() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.EmptyFragment
 
toString() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Fragment
 
toString() - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Pair
 
toString() - Method in class org.broadinstitute.hellbender.utils.read.SAMRecordToGATKReadAdapter
 
toString() - Method in enum org.broadinstitute.hellbender.utils.recalibration.EventType
 
toString() - Method in class org.broadinstitute.hellbender.utils.recalibration.QualQuantizer.QualInterval
 
toString() - Method in class org.broadinstitute.hellbender.utils.recalibration.RecalDatum
 
toString() - Method in class org.broadinstitute.hellbender.utils.reference.ReferenceBases
 
toString() - Method in enum org.broadinstitute.hellbender.utils.report.GATKReportDataType
 
toString() - Method in enum org.broadinstitute.hellbender.utils.report.GATKReportVersion
 
toString() - Method in class org.broadinstitute.hellbender.utils.runtime.StreamOutput
 
toString() - Method in class org.broadinstitute.hellbender.utils.samples.Sample
 
toString() - Method in class org.broadinstitute.hellbender.utils.SimpleInterval
 
toString() - Method in class org.broadinstitute.hellbender.utils.test.ArgumentsBuilder
 
toString() - Method in class org.broadinstitute.hellbender.utils.test.BaseTest.TestDataProvider
 
toString() - Method in class org.broadinstitute.hellbender.utils.variant.MinimalVariant
 
toString() - Method in class org.broadinstitute.hellbender.utils.variant.VariantContextVariantAdapter
 
toString() - Method in enum picard.analysis.artifacts.Transition
 
toString() - Method in class picard.analysis.directed.TargetMetricsCollector.Coverage
 
toString() - Method in class picard.fingerprint.HaplotypeBlock
 
toString() - Method in class picard.fingerprint.Snp
 
toString() - Method in class picard.illumina.IlluminaBasecallingMetrics
 
toString() - Method in class picard.illumina.parser.ClusterData
 
toString() - Method in class picard.illumina.parser.Range
 
toString() - Method in class picard.illumina.parser.ReadDescriptor
 
toString() - Method in class picard.illumina.parser.ReadStructure
Converts this object into a String using rules complementary to the single string constructor above.
toString() - Method in class picard.vcf.processor.VcfFileSegment
 
TOTAL_BASES - Variable in class org.broadinstitute.hellbender.metrics.QualityYieldMetrics
The total number of bases in all reads
TOTAL_BASES - Variable in class picard.analysis.CollectOxoGMetrics.CpcgMetrics
The total number of basecalls observed at all sites.
TOTAL_BASES - Variable in class picard.analysis.CollectQualityYieldMetrics.QualityYieldMetrics
The total number of bases in all reads
TOTAL_BASES - Variable in class picard.illumina.IlluminaBasecallingMetrics
The total number of bases assigned to the index.
TOTAL_CLUSTERS - Variable in class picard.analysis.GcBiasSummaryMetrics
The total number of clusters that were seen in the gc bias calculation.
TOTAL_CLUSTERS - Variable in class picard.illumina.IlluminaBasecallingMetrics
The total number of clusters assigned to the index.
TOTAL_COMPLEX_INDELS - Variable in class picard.vcf.CollectVariantCallingMetrics.VariantCallingSummaryMetrics
The number of passing complex indel calls that were examined
TOTAL_GQ0_VARIANTS - Variable in class picard.vcf.CollectVariantCallingMetrics.VariantCallingDetailMetrics
The total number of variants in a particular sample that have a GQ score of 0.
TOTAL_HET_DEPTH - Variable in class picard.vcf.CollectVariantCallingMetrics.VariantCallingDetailMetrics
total number of reads (from AD field) for passing bi-allelic SNP hets for this sample
TOTAL_INDELS - Variable in class picard.vcf.CollectVariantCallingMetrics.VariantCallingSummaryMetrics
The number of passing indel calls that were examined
TOTAL_MAPPINGS - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.utils.GATKSVVCFConstants
 
TOTAL_MENDELIAN_VIOLATIONS - Variable in class picard.vcf.MendelianViolations.MendelianViolationMetrics
The total of all mendelian violations observed.
TOTAL_MULTIALLELIC_SNPS - Variable in class picard.vcf.CollectVariantCallingMetrics.VariantCallingSummaryMetrics
The number of passing multi-allelic SNP calls that were examined
TOTAL_QSCORE - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasSummaryMetrics
The total Phred-scaled Q-score for this artifact.
TOTAL_QSCORE - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterSummaryMetrics
The total Phred-scaled Q-score for this artifact.
TOTAL_READS - Variable in class org.broadinstitute.hellbender.metrics.QualityYieldMetrics
The total number of reads in the input file
TOTAL_READS - Variable in class picard.analysis.AlignmentSummaryMetrics
The total number of reads including all PF and non-PF reads.
TOTAL_READS - Variable in class picard.analysis.CollectQualityYieldMetrics.QualityYieldMetrics
The total number of reads in the input file
TOTAL_READS - Variable in class picard.analysis.directed.HsMetrics
The total number of reads in the SAM or BAM file examined.
TOTAL_READS - Variable in class picard.analysis.directed.TargetedPcrMetrics
The total number of reads in the SAM or BAM file examined
TOTAL_READS - Variable in class picard.analysis.directed.TargetMetrics
The total number of reads in the SAM or BAM file examined.
TOTAL_READS - Variable in class picard.illumina.IlluminaBasecallingMetrics
The total number of reads assigned to the index.
TOTAL_READS_IN_INPUT - Variable in class picard.sam.SplitSamByNumberOfReads
 
TOTAL_SITES - Variable in class picard.analysis.CollectOxoGMetrics.CpcgMetrics
The total number of sites that had at least one base covering them.
TOTAL_SITES - Variable in class picard.analysis.RrbsCpgDetailMetrics
Number of times this CpG site was encountered
TOTAL_SNPS - Variable in class picard.vcf.CollectVariantCallingMetrics.VariantCallingSummaryMetrics
The number of passing bi-allelic SNPs calls (i.e.
totalCycles - Variable in class picard.illumina.parser.ReadStructure
 
totalMappedReferenceLength(GATKRead) - Static method in enum org.broadinstitute.hellbender.utils.read.markduplicates.MarkDuplicatesScoringStrategy
 
totalPloidy() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.HeterogeneousPloidyModel
 
totalPloidy() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.HomogeneousPloidyModel
 
totalPloidy() - Method in interface org.broadinstitute.hellbender.tools.walkers.genotyper.PloidyModel
Sum of all ploidy across all samples.
totalPloidy(VariantContext, int) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Calculates the total ploidy of a variant context as the sum of all plodies across genotypes.
totalReadCount - Variable in class org.broadinstitute.hellbender.utils.read.ArtificialReadIterator
 
totalReads(Map<?, List<GATKRead>>) - Static method in class org.broadinstitute.hellbender.utils.downsampling.AlleleBiasedDownsamplingUtils
Returns the sum of length of the lists.
toUnphasedGenotypeString() - Method in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeAlleleCounts
Generates a string that would represent the unphased genotype with this allele counts.
toVariantAttributes() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications.SmallDuplicationWithImpreciseDupRangeBreakpointComplications
 
toVariantAttributes() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications.SmallDuplicationWithPreciseDupRangeBreakpointComplications
 
toVariantAttributes() - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications
Intended to be overridden by sub classes when more complications are involved.
TP_COUNT - Variable in class picard.vcf.GenotypeConcordanceContingencyMetrics
The TP (true positive) count across all variants
TP_FN - Static variable in class picard.vcf.GenotypeConcordanceScheme
 
TP_FP - Static variable in class picard.vcf.GenotypeConcordanceScheme
 
TP_FP_FN - Static variable in class picard.vcf.GenotypeConcordanceScheme
 
TP_ONLY - Static variable in class picard.vcf.GenotypeConcordanceScheme
 
TP_TN - Static variable in class picard.vcf.GenotypeConcordanceScheme
 
TRACKING_PATH_SUFFIX - Static variable in class org.broadinstitute.hellbender.tools.copynumber.GermlineCNVCaller
 
trackOpticalDuplicates(List<? extends ReadEnds>, ReadEnds, OpticalDuplicateFinder, LibraryIdGenerator) - Static method in class org.broadinstitute.hellbender.utils.read.markduplicates.AbstractMarkDuplicatesCommandLineProgram
Looks through the set of reads and identifies how many of the duplicates are in fact optical duplicates, and stores the data in the instance level histogram.
trackOpticalDuplicates(List<? extends ReadEnds>, ReadEnds, OpticalDuplicateFinder, LibraryIdGenerator) - Static method in class picard.sam.markduplicates.util.AbstractMarkDuplicatesCommandLineProgram
Looks through the set of reads and identifies how many of the duplicates are in fact optical duplicates, and stores the data in the instance level histogram.
TrainingSet - Class in org.broadinstitute.hellbender.tools.walkers.vqsr
A set of training variants for use with VQSR.
TrainingSet(FeatureInput<VariantContext>) - Constructor for class org.broadinstitute.hellbender.tools.walkers.vqsr.TrainingSet
A set of training variants for use with VQSR.
trainingSets - Variable in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
 
Tranche - Class in org.broadinstitute.hellbender.tools.walkers.vqsr
Created by gauthier on 7/13/17.
Tranche(String, double, int, double, VariantRecalibratorArgumentCollection.Mode, double, int, int, int) - Constructor for class org.broadinstitute.hellbender.tools.walkers.vqsr.Tranche
 
Tranche.TrancheComparator<T extends Tranche> - Class in org.broadinstitute.hellbender.tools.walkers.vqsr
 
Tranche.TrancheTruthSensitivityComparator - Class in org.broadinstitute.hellbender.tools.walkers.vqsr
 
TrancheComparator() - Constructor for class org.broadinstitute.hellbender.tools.walkers.vqsr.Tranche.TrancheComparator
 
TrancheManager - Class in org.broadinstitute.hellbender.tools.walkers.vqsr
 
TrancheManager() - Constructor for class org.broadinstitute.hellbender.tools.walkers.vqsr.TrancheManager
 
TrancheManager.SelectionMetric - Class in org.broadinstitute.hellbender.tools.walkers.vqsr
 
TrancheManager.TruthSensitivityMetric - Class in org.broadinstitute.hellbender.tools.walkers.vqsr
 
trancheOfVariants(List<VariantDatum>, int, double, VariantRecalibratorArgumentCollection.Mode) - Static method in class org.broadinstitute.hellbender.tools.walkers.vqsr.Tranche
 
trancheOfVariants(List<VariantDatum>, int, double, VariantRecalibratorArgumentCollection.Mode) - Static method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VQSLODTranche
 
tranchesString(List<? extends Tranche>) - Static method in class org.broadinstitute.hellbender.tools.walkers.vqsr.Tranche
Returns an appropriately formatted string representing the raw tranches file on disk.
TrancheTruthSensitivityComparator() - Constructor for class org.broadinstitute.hellbender.tools.walkers.vqsr.Tranche.TrancheTruthSensitivityComparator
 
TRANS_PROB_ARRAY_LENGTH - Static variable in class org.broadinstitute.hellbender.utils.pairhmm.PairHMMModel
Length of the standard transition probability array.
Transcript(String, int, int, int, int, int) - Constructor for class picard.annotation.Gene.Transcript
 
TRANSCRIPT_LIST_DEFAULT_VALUE - Static variable in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorArgumentDefinitions
 
TRANSCRIPT_LIST_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorArgumentDefinitions
 
TRANSCRIPT_SELECTION_MODE_DEFAULT_VALUE - Static variable in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorArgumentDefinitions
 
TRANSCRIPT_SELECTION_MODE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.funcotator.FuncotatorArgumentDefinitions
 
TranscriptCodingSequenceException(String) - Constructor for exception org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils.TranscriptCodingSequenceException
 
TranscriptCodingSequenceException(String, Throwable) - Constructor for exception org.broadinstitute.hellbender.tools.funcotator.FuncotatorUtils.TranscriptCodingSequenceException
 
transcriptId - Variable in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeatureBaseData
 
transcriptionEnd - Variable in class picard.annotation.Gene.Transcript
 
transcriptionStart - Variable in class picard.annotation.Gene.Transcript
 
transcriptName - Variable in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeatureBaseData
 
transcriptSelectionMode - Variable in class org.broadinstitute.hellbender.tools.funcotator.Funcotator
 
TranscriptSelectionMode - Enum in org.broadinstitute.hellbender.tools.funcotator
The manner to select a single transcript from a set of transcripts to report as the "best" or main transcript.
transcriptStatus - Variable in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeatureBaseData
 
transcriptType - Variable in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeatureBaseData
 
transferReadsFromAllPreviousPileups() - Method in class org.broadinstitute.hellbender.utils.locusiterator.LocusIteratorByState
Transfer current list of all unique reads that have ever been used in any pileup, clearing old list This list is guaranteed to only contain unique reads, even across calls to the this function.
transformParallel(Iterator<F>, Function<F, T>, int) - Static method in class org.broadinstitute.hellbender.utils.Utils
Like Guava's Iterators.transform(Iterator, com.google.common.base.Function), but runs a fixed number (numThreads) of transformations in parallel, while maintaining ordering of the output iterator.
transformTies(int, ArrayList<Integer>) - Method in class org.broadinstitute.hellbender.utils.MannWhitneyU
 
Transition - Enum in org.broadinstitute.hellbender.utils.artifacts
 
Transition - Enum in picard.analysis.artifacts
Enum representation of a transition from one base to any other.
Transition.Base - Enum in picard.analysis.artifacts
 
transitionOf(char, char) - Static method in enum org.broadinstitute.hellbender.utils.artifacts.Transition
 
transitionOf(char, char) - Static method in enum picard.analysis.artifacts.Transition
Gets a the enum representing the transition from a 'reference' to a 'call' base.
transitions - Variable in class org.broadinstitute.hellbender.tools.exome.FilterByOrientationBias
 
translatePicardStyleToPosixStyle(String[]) - Static method in class picard.cmdline.CommandLineSyntaxTranslater
 
TRANSMISSION_DISEQUILIBRIUM_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
TRANSMISSION_PROBABILITY_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
traversalIsBounded() - Method in class org.broadinstitute.hellbender.engine.ReadsDataSource
 
traversalParameters - Variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.IntervalArgumentCollection
Full parameters for traversal, including our parsed intervals and a flag indicating whether unmapped records should be returned.
TraversalParameters - Class in org.broadinstitute.hellbender.engine
A simple container class for parameters controlling which records get returned during traversals.
TraversalParameters(List<SimpleInterval>, boolean) - Constructor for class org.broadinstitute.hellbender.engine.TraversalParameters
 
traverse() - Method in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker
 
traverse() - Method in class org.broadinstitute.hellbender.engine.AssemblyRegionWalker
 
traverse() - Method in class org.broadinstitute.hellbender.engine.FeatureWalker
Implementation of Feature-based traversal.
traverse() - Method in class org.broadinstitute.hellbender.engine.GATKTool
A complete traversal from start to finish.
traverse() - Method in class org.broadinstitute.hellbender.engine.IntervalWalker
 
traverse() - Method in class org.broadinstitute.hellbender.engine.LocusWalker
Implementation of locus-based traversal.
traverse() - Method in class org.broadinstitute.hellbender.engine.MultiVariantWalkerGroupedOnStart
 
traverse() - Method in class org.broadinstitute.hellbender.engine.ReadWalker
Implementation of read-based traversal.
traverse() - Method in class org.broadinstitute.hellbender.engine.TwoPassReadWalker
 
traverse() - Method in class org.broadinstitute.hellbender.engine.TwoPassVariantWalker
Overrides the default, single-pass traversal framework of VariantWalkerBase
traverse() - Method in class org.broadinstitute.hellbender.engine.VariantWalkerBase
Implementation of variant-based traversal.
traverse() - Method in class org.broadinstitute.hellbender.tools.copynumber.AnnotateIntervals
 
traverse() - Method in class org.broadinstitute.hellbender.tools.copynumber.PostprocessGermlineCNVCalls
 
traverse() - Method in class org.broadinstitute.hellbender.tools.copynumber.PreprocessIntervals
 
traverse() - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.CombineSegmentBreakpoints
 
traverse() - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.MergeAnnotatedRegions
 
traverse() - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.TagGermlineEvents
 
traverse() - Method in class org.broadinstitute.hellbender.tools.genomicsdb.GenomicsDBImport
A complete traversal from start to finish.
traverse() - Method in class org.broadinstitute.hellbender.tools.GetSampleName
 
traverse() - Method in class org.broadinstitute.hellbender.tools.walkers.SplitIntervals
 
traverseUnmappedReads() - Method in class org.broadinstitute.hellbender.engine.TraversalParameters
 
TREAT_ALL_READS_AS_SINGLE_POOL - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.UnifiedArgumentCollection
 
tree - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTaxonomyDatabase
 
Trilean - Enum in org.broadinstitute.hellbender.utils
An enumeration to represent true, false, or unknown.
trim(SimpleInterval, int) - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
Trim this region to just the span, producing a new assembly region without any reads that has only the extent of newExtend intersected with the current extent
trim(SimpleInterval) - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
Equivalent to trim(span,span).
trim(SimpleInterval, SimpleInterval) - Method in class org.broadinstitute.hellbender.engine.AssemblyRegion
Trim this region to no more than the span, producing a new assembly region with properly trimmed reads that attempts to provide the best possible representation of this region covering the span.
trim() - Method in class org.broadinstitute.hellbender.tools.spark.utils.IntHistogram
Returns a histogram with the smallest tracked maximum such that the fraction of untracked observations does not exceed 1/trackedMaximum.
trim(AssemblyRegion, SortedSet<VariantContext>) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmer
Returns a trimming result object from which the variant trimmed region and flanking non-variant sections can be recovered latter.
trim(Locatable) - Method in class org.broadinstitute.hellbender.utils.haplotype.Haplotype
Create a new Haplotype derived from this one that exactly spans the provided location Note that this haplotype must have a contain a genome loc for this operation to be successful.
trimAlleles(VariantContext, boolean, boolean) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Trim the alleles in inputVC forward and reverse, as requested
trimAlleles(VariantContext, int, int) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
Trim up alleles in inputVC, cutting out all bases up to fwdTrimEnd inclusive and the last revTrim bases from the end
trimCigarByBases(Cigar, int, int) - Static method in class org.broadinstitute.hellbender.utils.read.AlignmentUtils
Trim cigar down to one that starts at start base in the cigar and extends to (inclusive) end base
trimCigarByReference(Cigar, int, int) - Static method in class org.broadinstitute.hellbender.utils.read.AlignmentUtils
Trim cigar down to one that starts at start reference on the left and extends to end on the reference
trimIntervalToContig(String, int, int, int) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Create a new interval, bounding start and stop by the start and end of contig This function will return null if start and stop cannot be adjusted in any reasonable way to be on the contig.
trimReadToUnclippedBases(Cigar) - Static method in class org.broadinstitute.hellbender.utils.read.CigarUtils
Removes all clipping operators from the cigar.
trimTo(AssemblyRegion) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResultSet
Trims an assembly result set down based on a new set of trimmed haplotypes.
Trio - Class in org.broadinstitute.hellbender.utils.samples
A class for imposing a trio structure on three samples; a common paradigm
Trio(Sample, Sample, Sample) - Constructor for class org.broadinstitute.hellbender.utils.samples.Trio
 
TRIOS - Variable in class picard.vcf.MendelianViolations.FindMendelianViolations
 
triSiteHeterogeneityRate - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
triSiteHomogeneityRate - Variable in class picard.analysis.replicates.IndependentReplicateMetric
 
TRUE_POSITIVES_AND_FALSE_NEGATIVES_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.Concordance
 
TRUE_POSITIVES_AND_FALSE_NEGATIVES_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.Concordance
 
TRUE_POSITIVES_AND_FALSE_POSITIVES_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.Concordance
 
TRUE_POSITIVES_AND_FALSE_POSITIVES_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.Concordance
 
truePositive(VariantContext, VariantContext) - Static method in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker.TruthVersusEval
 
truePositivesAndFalseNegativesVcf - Variable in class org.broadinstitute.hellbender.tools.walkers.validation.Concordance
 
truePositivesAndFalsePositivesVcf - Variable in class org.broadinstitute.hellbender.tools.walkers.validation.Concordance
 
trueProbToQual(double) - Static method in class org.broadinstitute.hellbender.utils.QualityUtils
Convert a probability of being right to a phred-scaled quality score (0.99 => 20).
trueProbToQual(double, byte) - Static method in class org.broadinstitute.hellbender.utils.QualityUtils
Convert a probability of being right to a phred-scaled quality score (0.99 => 20).
trueProbToQual(double, int) - Static method in class org.broadinstitute.hellbender.utils.QualityUtils
 
truncate(long) - Method in class org.broadinstitute.hellbender.utils.nio.SeekableByteChannelPrefetcher
Not supported.
truncate(long) - Method in class org.broadinstitute.hellbender.utils.test.XorWrapper
 
TRUNCATE_NAMES_AT_WHITESPACE - Variable in class picard.sam.CreateSequenceDictionary
 
TRUNCATE_SEQUENCE_NAMES_AT_WHITESPACE - Variable in class picard.reference.NormalizeFasta
 
TRUTH_SAMPLE - Variable in class picard.vcf.GenotypeConcordance
 
TRUTH_SAMPLE - Variable in class picard.vcf.GenotypeConcordanceContingencyMetrics
The name of the 'truth' sample
TRUTH_SAMPLE - Variable in class picard.vcf.GenotypeConcordanceDetailMetrics
The name of the 'truth' sample
TRUTH_SAMPLE - Variable in class picard.vcf.GenotypeConcordanceSummaryMetrics
The name of the 'truth' sample
TRUTH_STATE - Variable in class picard.vcf.GenotypeConcordanceDetailMetrics
The state of the 'truth' sample (i.e.
TRUTH_STATUS_VCF_ATTRIBUTE - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.Concordance
 
TRUTH_VARIANTS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker
 
TRUTH_VCF - Variable in class picard.vcf.GenotypeConcordance
 
truthAllele1 - Variable in class picard.vcf.GenotypeConcordance.Alleles
 
truthAllele2 - Variable in class picard.vcf.GenotypeConcordance.Alleles
 
truthAlleles() - Method in class picard.vcf.GenotypeConcordance.Alleles
 
TruthAndCallStates(GenotypeConcordanceStates.TruthState, GenotypeConcordanceStates.CallState) - Constructor for class picard.vcf.GenotypeConcordanceStates.TruthAndCallStates
 
truthIntervalPadding - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.DiscoverVariantsFromContigsAlignmentsSparkArgumentCollection
 
TruthSensitivityMetric(int) - Constructor for class org.broadinstitute.hellbender.tools.walkers.vqsr.TrancheManager.TruthSensitivityMetric
 
truthState - Variable in class picard.vcf.GenotypeConcordanceStates.TruthAndCallStates
 
truthVariantsFile - Variable in class org.broadinstitute.hellbender.engine.AbstractConcordanceWalker
 
truthVCF - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.DiscoverVariantsFromContigsAlignmentsSparkArgumentCollection
 
tryCleanShutdown() - Method in class org.broadinstitute.hellbender.utils.runtime.ProcessController
Stops the process from running and tries to ensure process is cleaned up properly.
tryCleanShutdown() - Method in class org.broadinstitute.hellbender.utils.runtime.StreamingProcessController
Stops the process from running and tries to ensure the process is cleaned up properly.
tryDelete(File) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
Tries to delete a file.
TUMOR_ALLELIC_COUNTS_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
TUMOR_ALLELIC_COUNTS_FILE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
TUMOR_BAM_FILE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
TUMOR_BAM_FILE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.ExomeStandardArgumentDefinitions
 
TUMOR_LOD_FILTER_NAME - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
TUMOR_LOD_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
TUMOR_LOD_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
TUMOR_LOD_THRESHOLD - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
Only variants with tumor LODs exceeding this threshold can pass filtering.
TUMOR_SAMPLE_KEY_IN_VCF_HEADER - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2Engine
 
TUMOR_SAMPLE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
TUMOR_SAMPLE_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
TUMOR_SEGMENTATION_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.contamination.CalculateContamination
 
TUMOR_SEGMENTATION_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
TUMOR_SEGMENTATION_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.contamination.CalculateContamination
 
tumorSample - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2ArgumentCollection
 
tumorSample - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.SomaticGenotypingEngine
 
tumorSegmentationTable - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
A table containing tumor segments and the minor allele fraction of germline hets within each segment.
TWO_BIT_EXTENSION - Static variable in class org.broadinstitute.hellbender.engine.spark.datasources.ReferenceTwoBitSource
 
TwoPassReadWalker - Class in org.broadinstitute.hellbender.engine
A ReadWalker is a tool that processes a single read at a time from one or multiple sources of reads, with optional contextual information from a reference and/or sets of variants/Features.
TwoPassReadWalker() - Constructor for class org.broadinstitute.hellbender.engine.TwoPassReadWalker
 
TwoPassVariantWalker - Class in org.broadinstitute.hellbender.engine
A VariantWalker that makes two passes through the variants.
TwoPassVariantWalker() - Constructor for class org.broadinstitute.hellbender.engine.TwoPassVariantWalker
 
twoSidedPValue(int[][]) - Static method in class org.broadinstitute.hellbender.utils.FisherExactTest
Computes the 2-sided pvalue of the Fisher's exact test on a normalized table that ensures that the sum of all four entries is less than 2 * 200.
type - Variable in exception org.broadinstitute.hellbender.exceptions.UserException.FailsStrictValidation
 
type - Variable in class org.broadinstitute.hellbender.utils.downsampling.DownsamplingMethod
Type of downsampling to perform.
type - Variable in class picard.illumina.parser.ReadDescriptor
 
TYPE_NAME - Variable in class picard.illumina.IlluminaPhasingMetrics
Defines an Illumina template read number (first or second)
typeOfVariant(Allele, Allele) - Static method in class org.broadinstitute.hellbender.utils.GATKProtectedVariantContextUtils
This is lifted directly from htsjdk with some minor modifications! However, it is a private method there.

U

uByteToInt(byte) - Static method in class org.broadinstitute.hellbender.utils.UnsignedTypeUtil
Convert an unsigned byte to a signed int
uByteToInt(byte) - Static method in class picard.util.UnsignedTypeUtil
Convert an unsigned byte to a signed int
uByteToShort(byte) - Static method in class org.broadinstitute.hellbender.utils.UnsignedTypeUtil
Convert an unsigned byte to a signed short
uByteToShort(byte) - Static method in class picard.util.UnsignedTypeUtil
Convert an unsigned byte to a signed short
uIntToFloat(int) - Static method in class picard.util.UnsignedTypeUtil
 
uIntToLong(int) - Static method in class org.broadinstitute.hellbender.utils.UnsignedTypeUtil
Convert an unsigned int to a long
uIntToLong(int) - Static method in class picard.util.UnsignedTypeUtil
Convert an unsigned int to a long
UMI_BASE_QUALITIES - Variable in class picard.sam.markduplicates.UmiMetrics
Estimation of Phred scaled quality scores for UMIs
UMI_METRICS_FILE - Variable in class picard.sam.markduplicates.UmiAwareMarkDuplicatesWithMateCigar
 
UMI_TAG_NAME - Variable in class picard.sam.markduplicates.UmiAwareMarkDuplicatesWithMateCigar
 
UmiAwareMarkDuplicatesWithMateCigar - Class in picard.sam.markduplicates
This tool locates and tags duplicate reads in a BAM or SAM file, where duplicate reads are defined as originating from a single fragment of DNA.
UmiAwareMarkDuplicatesWithMateCigar() - Constructor for class picard.sam.markduplicates.UmiAwareMarkDuplicatesWithMateCigar
 
UmiGraph - Class in picard.sam.markduplicates
UmiGraph is used to identify UMIs that come from the same original source molecule.
UmiGraph(DuplicateSet, String, String, boolean) - Constructor for class picard.sam.markduplicates.UmiGraph
 
UmiMetrics - Class in picard.sam.markduplicates
Metrics that are calculated during the process of marking duplicates within a stream of SAMRecords using the UmiAwareDuplicateSetIterator.
UmiMetrics() - Constructor for class picard.sam.markduplicates.UmiMetrics
 
UmiMetrics(double, int, int, int, int, int, double, double, double, double) - Constructor for class picard.sam.markduplicates.UmiMetrics
 
UmiUtil - Class in picard.sam.markduplicates
A collection of functions for use in processing UMIs
UmiUtil() - Constructor for class picard.sam.markduplicates.UmiUtil
 
UNBOUND_ALTERNATIVE_ALLELE_COUNT - Static variable in enum org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculatorImplementation
Special max alt allele count indicating that this maximum is in fact unbound (can be anything).
UNBOUND_PLOIDY - Static variable in enum org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculatorImplementation
Special ploidy constant that indicates that in fact the ploidy is unbound (can be anything).
unclippedLoc - Variable in class org.broadinstitute.hellbender.tools.walkers.rnaseq.OverhangFixingManager.SplitRead
 
unclippedReadOverlapsRegion(GATKRead, Locatable) - Static method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
 
UnfilledReadsLikelihoods<A extends htsjdk.variant.variantcontext.Allele> - Class in org.broadinstitute.hellbender.utils.genotyper
Dummy Read-Likelihood container that computes partial likelihoods based on the read pileups for snps.
UnfilledReadsLikelihoods(SampleList, AlleleList<A>, Map<String, List<GATKRead>>) - Constructor for class org.broadinstitute.hellbender.utils.genotyper.UnfilledReadsLikelihoods
Constructs a new read-likelihood collection.
unfilteredBaseQHistogram - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
The count of bases observed with a given base quality.
unfilteredBaseQHistogramArray - Variable in class picard.analysis.AbstractWgsMetricsCollector
Count of bases observed with a given base quality.
unfilteredDepthHistogram - Variable in class picard.analysis.CollectWgsMetrics.WgsMetrics
Count of sites with a given depth of coverage.
unfilteredDepthHistogramArray - Variable in class picard.analysis.AbstractWgsMetricsCollector
Count of sites with a given depth of coverage.
unfilteredEvidenceDir - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
UnifiedArgumentCollection - Class in org.broadinstitute.hellbender.tools.walkers.genotyper
 
UnifiedArgumentCollection() - Constructor for class org.broadinstitute.hellbender.tools.walkers.genotyper.UnifiedArgumentCollection
 
UnimplementedFeature(String) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.UnimplementedFeature
 
union(GenomeLoc) - Method in class org.broadinstitute.hellbender.utils.GenomeLoc
 
UNIQUE - Variable in class picard.util.BedToIntervalList
 
UNIQUE - Variable in class picard.util.IntervalListTools
 
UNIQUE_ALT_READ_COUNT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
UNIQUE_ALT_READ_SET_COUNT_KEY - Static variable in class org.broadinstitute.hellbender.tools.walkers.annotator.UniqueAltReadCount
 
UniqueAltReadCount - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Finds a lower bound on the number of unique reads at a locus that support a non-reference allele.
UniqueAltReadCount() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.UniqueAltReadCount
 
uniqueAltReadCount - Variable in class org.broadinstitute.hellbender.tools.walkers.mutect.M2FiltersArgumentCollection
 
UniqueIDWrapper<A> - Class in org.broadinstitute.hellbender.utils
Create a unique ID for an arbitrary object and wrap it.
UniqueIDWrapper(A) - Constructor for class org.broadinstitute.hellbender.utils.UniqueIDWrapper
 
uniquify(Collection<SVKmer>, Collection<SVKmer>) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVUtils
 
UnivariateSolverJobDescription - Class in org.broadinstitute.hellbender.utils.solver
This class stores the description of a solver job.
UnivariateSolverJobDescription(int, double, double, double, int) - Constructor for class org.broadinstitute.hellbender.utils.solver.UnivariateSolverJobDescription
 
UnivariateSolverSpecifications - Class in org.broadinstitute.hellbender.utils.solver
Accuracy specifications of a univariate solver
UnivariateSolverSpecifications(double, double, double) - Constructor for class org.broadinstitute.hellbender.utils.solver.UnivariateSolverSpecifications
 
UNKNOWN - Static variable in class org.broadinstitute.hellbender.metrics.MultiLevelCollector
 
UNKNOWN - Static variable in class picard.metrics.MultiLevelCollector
 
UNKNOWN_LIBRARY - Static variable in class org.broadinstitute.hellbender.utils.read.markduplicates.LibraryIdGenerator
 
UNKNOWN_OUT_PREFIX - Static variable in class org.broadinstitute.hellbender.tools.SplitReads
 
UNKNOWN_SEX - Static variable in class picard.pedigree.PedFile
 
UNMAP_CONTAMINANT_READS - Variable in class picard.sam.MergeBamAlignment
 
UNMAPPED - Static variable in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.PartitionBounds
 
UNMAPPED - Static variable in class org.broadinstitute.hellbender.utils.GenomeLoc
A static constant to use when referring to the unmapped section of a datafile file.
UNMAPPED_BAM - Variable in class picard.sam.MergeBamAlignment
 
UNMAPPED_LOC_NAME - Static variable in class org.broadinstitute.hellbender.utils.GenomeLocParser
 
UNMAPPED_READ_STRATEGY - Variable in class picard.sam.MergeBamAlignment
 
UNMAPPED_READS - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.loggers.PSScoreMetrics
The number of non-host reads that could not be mapped to a pathogen
UNMAPPED_READS - Variable in class picard.sam.DuplicationMetrics
The total number of unmapped reads examined.
unmappedReadCount - Variable in class org.broadinstitute.hellbender.utils.read.ArtificialReadIterator
 
unmappedRemaining - Variable in class org.broadinstitute.hellbender.utils.read.ArtificialReadIterator
 
UnmarkDuplicates - Class in org.broadinstitute.hellbender.tools.walkers
Clears the 0x400 duplicate SAM flag from reads.
UnmarkDuplicates() - Constructor for class org.broadinstitute.hellbender.tools.walkers.UnmarkDuplicates
 
UNPAIRED_FASTQ - Variable in class picard.sam.SamToFastq
 
UNPAIRED_INPUT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBwaSpark
 
UNPAIRED_INPUT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqScoreSpark
 
UNPAIRED_INPUT_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBwaSpark
 
UNPAIRED_INPUT_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqScoreSpark
 
UNPAIRED_OUTPUT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBwaSpark
 
UNPAIRED_OUTPUT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqFilterSpark
 
UNPAIRED_OUTPUT_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqBwaSpark
 
UNPAIRED_OUTPUT_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqFilterSpark
 
UNPAIRED_READ_DUPLICATES - Variable in class picard.sam.DuplicationMetrics
The number of fragments that were marked as duplicates.
UNPAIRED_READS_EXAMINED - Variable in class picard.sam.DuplicationMetrics
The number of mapped reads examined which did not have a mapped mate pair, either because the read is unpaired, or the read is paired to an unmapped mate.
unpairedInput - Variable in class org.broadinstitute.hellbender.tools.spark.pathseq.PathSeqScoreSpark
 
unsafeNextInfo() - Method in class picard.illumina.parser.readers.AbstractIlluminaPositionFileReader
Returns the next position info.
unsafeNextInfo() - Method in class picard.illumina.parser.readers.ClocsFileReader
Grab the next set of offset values, decompress them.
unsafeNextInfo() - Method in class picard.illumina.parser.readers.LocsFileReader
 
unsafeNextInfo() - Method in class picard.illumina.parser.readers.PosFileReader
Read a line of text and parse it into two float values, create a PositionInfo and return it
UNSET_CONTIG - Static variable in class org.broadinstitute.hellbender.utils.read.ReadConstants
Value used to represent the absence of a defined contig in a read
UNSET_POSITION - Static variable in class org.broadinstitute.hellbender.utils.read.ReadConstants
Value used to represent the absence of a defined start/end position in a read
unsetGvcf(Configuration) - Static method in class org.broadinstitute.hellbender.engine.spark.datasources.VariantsSparkSink.SparkHeaderlessVCFOutputFormat
 
UnsignedTypeUtil - Class in org.broadinstitute.hellbender.utils
A utility class for dealing with unsigned types.
UnsignedTypeUtil() - Constructor for class org.broadinstitute.hellbender.utils.UnsignedTypeUtil
 
UnsignedTypeUtil - Class in picard.util
A utility class for dealing with unsigned types.
UnsignedTypeUtil() - Constructor for class picard.util.UnsignedTypeUtil
 
update(Locatable) - Method in class org.broadinstitute.hellbender.engine.ProgressMeter
Signal to the progress meter that an additional record has been processed.
update(RandomGenerator) - Method in class org.broadinstitute.hellbender.utils.mcmc.ParameterizedModel
Updates the ParameterizedState held internally using the ParameterSamplers and update method specified via the Builder pattern.
update(T, U) - Method in class org.broadinstitute.hellbender.utils.mcmc.ParameterizedState
Updates the value of a Parameter contained in the collection held by the ParameterizedState.
updateCigarForTrimmedOrClippedBases(SAMRecord, SAMRecord) - Method in class org.broadinstitute.hellbender.utils.read.mergealignment.AbstractAlignmentMerger
 
updateCigarForTrimmedOrClippedBases(SAMRecord, SAMRecord) - Method in class picard.sam.AbstractAlignmentMerger
 
updateFormatting(Object) - Method in class org.broadinstitute.hellbender.utils.report.GATKReportColumn
 
updateGenotypesWithMappedAlleles(GenotypesContext, GATKVariantContextUtils.AlleleMapper) - Static method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils
 
updateGraph(SeqVertex, SeqVertex) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.SharedVertexSequenceSplitter
Update graph outer, replacing the previous middle vertices that were split out with the new graph structure of the split, linking this subgraph into the graph at top and bot (the vertex connecting the middle nodes and the vertex outgoing of all middle node)
updateHeaderContigLines(Set<VCFHeaderLine>, Path, SAMSequenceDictionary, boolean) - Static method in class org.broadinstitute.hellbender.utils.variant.VcfUtils
Given a set of VCF header lines, update the set with contig lines from the provided reference dictionary.
updateMetrics(SAMRecord) - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.GATKDuplicationMetrics
Update metrics given a record or GATKRead
updateMetrics(GATKRead) - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.GATKDuplicationMetrics
 
updateNonRefAlleleLikelihoods() - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Updates the likelihoods of the non-ref allele, if present, considering all non-symbolic alleles avaialble.
updateNonRefAlleleLikelihoods(AlleleList<A>) - Method in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Updates the likelihood of the NonRef allele (if present) based on the likelihoods of a set of non-symbolic
updateOutputPath(String) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoveryInputMetaData
 
updateStructuredComments(String, String, String, List<String>) - Static method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalCodec
Update the comments to represent the new field names for the locatable information.
updateToBlockSubstitutionIfBetter(List<VariantContext>) - Method in class org.broadinstitute.hellbender.utils.haplotype.EventMap
 
UpdateVCFSequenceDictionary - Class in org.broadinstitute.hellbender.tools.walkers.variantutils
Updates the reference contigs in the header of the VCF format file, i.e.
UpdateVCFSequenceDictionary() - Constructor for class org.broadinstitute.hellbender.tools.walkers.variantutils.UpdateVCFSequenceDictionary
 
UpdateVcfSequenceDictionary - Class in picard.vcf
Takes a VCF file and a Sequence Dictionary (from a variety of file types) and updates the Sequence Dictionary in VCF.
UpdateVcfSequenceDictionary() - Constructor for class picard.vcf.UpdateVcfSequenceDictionary
 
URI - Variable in class picard.sam.CreateSequenceDictionary
 
URL_ENCODING_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.GetSampleName
 
URL_ENCODING_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.tools.GetSampleName
 
urlDecode(String) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
 
urlEncode - Variable in class org.broadinstitute.hellbender.tools.GetSampleName
 
urlEncode(String) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
 
usableExtension - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyRegionTrimmer.Result
Holds the maximum extension around the original active region span considered for the trimmed variation region.
usableForParams(int, int) - Method in enum org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculatorImplementation
Checks whether a given ploidy and max alternative alleles combination is supported or not.
USAGE - Static variable in class picard.illumina.IlluminaBasecallsToSam
 
USAGE - Variable in class picard.sam.ViewSam
 
USAGE_ONE_LINE_SUMMARY - Static variable in class org.broadinstitute.hellbender.tools.walkers.bqsr.BaseRecalibrator
 
USAGE_SUMMARY - Static variable in class org.broadinstitute.hellbender.tools.walkers.bqsr.BaseRecalibrator
 
USE_ALLELES_TRIGGER - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerArgumentCollection
 
USE_FAST_ALGORITHM - Variable in class picard.analysis.CollectWgsMetrics
 
USE_FILTERED_READS_FOR_ANNOTATIONS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerArgumentCollection
 
USE_JDK_DEFLATER - Variable in class picard.cmdline.CommandLineProgram
 
USE_JDK_DEFLATER_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
USE_JDK_DEFLATER_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
USE_JDK_INFLATER - Variable in class picard.cmdline.CommandLineProgram
 
USE_JDK_INFLATER_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
USE_JDK_INFLATER_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
USE_NEW_AF_CALCULATOR - Variable in class org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeCalculationArgumentCollection
Use the new allele frequency / QUAL score model
USE_OQ - Variable in class picard.analysis.artifacts.CollectSequencingArtifactMetrics
 
USE_OQ - Variable in class picard.analysis.CollectOxoGMetrics
 
USE_ORIGINAL_QUALITIES - Variable in class picard.analysis.CollectQualityYieldMetrics
 
USE_ORIGINAL_QUALITIES_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
USE_ORIGINAL_QUALITIES_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
USE_ORIGINAL_QUALITIES_SHORT_NAME - Static variable in class picard.cmdline.StandardOptionDefinitions
 
USE_SEQUENTIAL_FASTQS - Variable in class picard.sam.FastqToSam
 
USE_THREADING - Variable in class picard.sam.MergeSamFiles
 
USE_VCF_INDEX - Variable in class picard.vcf.GenotypeConcordance
 
useBpResolution - Variable in class org.broadinstitute.hellbender.tools.walkers.CombineGVCFs
 
useFilteredReadMapForAnnotations - Variable in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyBasedCallerArgumentCollection
 
useFlatPriorsForIndels - Variable in class org.broadinstitute.hellbender.tools.walkers.variantutils.CalculateGenotypePosteriors
Use flat priors for indels (can be used to replicate the legacy CalculateGenotypePosteriors behavior) If an input variant contains an indel allele, flat priors will be applied to that site.
useJdkDeflater - Variable in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
 
useJdkInflater - Variable in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
 
useLegacyParser(Class<?>) - Static method in class picard.cmdline.CommandLineProgram
Return true if the Picard command line parser should be used in place of the Barclay command line parser, otherwise, false.
useOriginalBaseQualities - Variable in class org.broadinstitute.hellbender.tools.ApplyBQSRArgumentCollection
This flag tells GATK to use the original base qualities (that were in the data before BQSR/recalibration) which are stored in the OQ tag, if they are present, rather than use the post-recalibration quality scores.
useOriginalBaseQualities - Variable in class org.broadinstitute.hellbender.utils.recalibration.RecalibrationArgumentCollection
This flag tells GATK to use the original base qualities (that were in the data before BQSR/recalibration) which are stored in the OQ tag, if they are present, rather than use the post-recalibration quality scores.
useOriginalQualities - Variable in class org.broadinstitute.hellbender.metrics.QualityYieldMetricsArgumentCollection
 
USER_EXCEPTION_EXIT_VALUE - Static variable in class org.broadinstitute.hellbender.Main
Exit value when an unrecoverable UserException occurs.
userCollectors - Variable in class org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectMultipleMetricsSpark
 
userDisabledReadFilterNames - Variable in class org.broadinstitute.hellbender.cmdline.GATKPlugin.DefaultGATKReadFilterArgumentCollection
 
userEnabledReadFilterNames - Variable in class org.broadinstitute.hellbender.cmdline.GATKPlugin.DefaultGATKReadFilterArgumentCollection
 
UserException - Exception in org.broadinstitute.hellbender.exceptions

Class UserException.

UserException() - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException
 
UserException(String) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException
 
UserException(String, Throwable) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException
 
UserException.BadInput - Exception in org.broadinstitute.hellbender.exceptions
 
UserException.BadTempDir - Exception in org.broadinstitute.hellbender.exceptions
 
UserException.CannotExecuteScript - Exception in org.broadinstitute.hellbender.exceptions
 
UserException.CannotHandleGzippedRef - Exception in org.broadinstitute.hellbender.exceptions
 
UserException.CouldNotCreateOutputFile - Exception in org.broadinstitute.hellbender.exceptions

Class UserException.CouldNotCreateOutputFile

For generic errors writing to output files

UserException.CouldNotIndexFile - Exception in org.broadinstitute.hellbender.exceptions
 
UserException.CouldNotReadInputFile - Exception in org.broadinstitute.hellbender.exceptions

Class UserException.CouldNotReadInputFile

For generic errors opening/reading from input files

UserException.EmptyIntersection - Exception in org.broadinstitute.hellbender.exceptions
 
UserException.FailsStrictValidation - Exception in org.broadinstitute.hellbender.exceptions
 
UserException.HardwareFeatureException - Exception in org.broadinstitute.hellbender.exceptions
 
UserException.HeaderMissingReadGroup - Exception in org.broadinstitute.hellbender.exceptions
 
UserException.IncompatibleRecalibrationTableParameters - Exception in org.broadinstitute.hellbender.exceptions
 
UserException.IncompatibleSequenceDictionaries - Exception in org.broadinstitute.hellbender.exceptions

Class UserException.MalformedFile

For errors parsing files

UserException.LexicographicallySortedSequenceDictionary - Exception in org.broadinstitute.hellbender.exceptions
 
UserException.MalformedBAM - Exception in org.broadinstitute.hellbender.exceptions
 
UserException.MalformedFile - Exception in org.broadinstitute.hellbender.exceptions

Class UserException.MalformedFile

For errors parsing files

UserException.MalformedGenomeLoc - Exception in org.broadinstitute.hellbender.exceptions
 
UserException.MalformedRead - Exception in org.broadinstitute.hellbender.exceptions
 
UserException.MisencodedQualityScoresRead - Exception in org.broadinstitute.hellbender.exceptions
 
UserException.MissingContigInSequenceDictionary - Exception in org.broadinstitute.hellbender.exceptions
 
UserException.MissingIndex - Exception in org.broadinstitute.hellbender.exceptions
 
UserException.MissingReference - Exception in org.broadinstitute.hellbender.exceptions
 
UserException.MissingReferenceDictFile - Exception in org.broadinstitute.hellbender.exceptions
 
UserException.MissingReferenceFaiFile - Exception in org.broadinstitute.hellbender.exceptions
 
UserException.NoSuitableCodecs - Exception in org.broadinstitute.hellbender.exceptions
 
UserException.ReadMissingReadGroup - Exception in org.broadinstitute.hellbender.exceptions
 
UserException.Require2BitReferenceForBroadcast - Exception in org.broadinstitute.hellbender.exceptions
 
UserException.UnimplementedFeature - Exception in org.broadinstitute.hellbender.exceptions
 
UserException.WrongFeatureType - Exception in org.broadinstitute.hellbender.exceptions
 
userTranscriptIdSet - Variable in class org.broadinstitute.hellbender.tools.funcotator.Funcotator
 
usesNoRefReads() - Method in class picard.analysis.artifacts.CollectSequencingArtifactMetrics
 
usesNoRefReads() - Method in class picard.analysis.CollectInsertSizeMetrics
 
usesNoRefReads() - Method in class picard.analysis.CollectQualityYieldMetrics
Ensure that we get all reads regardless of alignment status.
usesNoRefReads() - Method in class picard.analysis.SinglePassSamProgram
Can be overridden and set to false if the section of unmapped reads at the end of the file isn't needed.
useVariantAnnotations() - Method in class org.broadinstitute.hellbender.engine.GATKTool
Must be overridden in order to add annotation arguments to the engine.
useVariantAnnotations() - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
 
useVariantAnnotations() - Method in class org.broadinstitute.hellbender.tools.HaplotypeCallerSpark
 
useVariantAnnotations() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.ReadsPipelineSpark
 
useVariantAnnotations() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotator
 
useVariantAnnotations() - Method in class org.broadinstitute.hellbender.tools.walkers.CombineGVCFs
 
useVariantAnnotations() - Method in class org.broadinstitute.hellbender.tools.walkers.GenotypeGVCFs
 
useVariantAnnotations() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCaller
 
useVariantAnnotations() - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2
 
uShortToInt(short) - Static method in class org.broadinstitute.hellbender.utils.UnsignedTypeUtil
Convert an unsigned short to an Int
uShortToInt(short) - Static method in class picard.util.UnsignedTypeUtil
Convert an unsigned short to an Int
usingGVCFIndexingArguments(GATKVCFIndexType, int) - Static method in class org.broadinstitute.hellbender.utils.variant.VcfUtils
Check if using the GCVF indexing arguments' values
Utils - Class in org.broadinstitute.hellbender.utils
 
UTR_BASES - Variable in class picard.analysis.RnaSeqMetrics
Number of bases in primary alignments that align to a UTR base for some gene, and not a coding base.

V

VAExpression(String, List<FeatureInput<VariantContext>>) - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotatorEngine.VAExpression
 
VALID_ALIGNMENT_END - Static variable in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary
 
VALID_ALIGNMENT_START - Static variable in class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary
 
ValidAlignmentEndReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.ValidAlignmentEndReadFilter
 
ValidAlignmentStartReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.ReadFilterLibrary.ValidAlignmentStartReadFilter
 
validate() - Method in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineCallingArgumentCollection
 
validate() - Method in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineContigPloidyModelArgumentCollection
 
validate() - Method in class org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineDenoisingModelArgumentCollection
 
validate() - Method in class org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection
 
validate(boolean, String) - Static method in class org.broadinstitute.hellbender.utils.Utils
Check a condition that should always be true and throw an IllegalStateException if false.
validate(boolean, Supplier<String>) - Static method in class org.broadinstitute.hellbender.utils.Utils
Check a condition that should always be true and throw an IllegalStateException if false.
VALIDATE_INDEX - Variable in class picard.sam.ValidateSamFile
 
VALIDATE_SAMPLE_MAP_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.genomicsdb.GenomicsDBImport
 
validateAllelesList() - Method in class org.broadinstitute.hellbender.tools.walkers.annotator.allelespecific.ReducibleAnnotationData
 
validateAndResolvePlugins() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKAnnotationPluginDescriptor
Validate the list of arguments and reduce the list of annotations to those actually seen on the command line.
validateAndResolvePlugins() - Method in class org.broadinstitute.hellbender.cmdline.GATKPlugin.GATKReadFilterPluginDescriptor
Validate the list of arguments and reduce the list of read filters to those actually seen on the command line.
validateAnnotatedIntervals(File, AbstractLocatableCollection<?, ?>, Logger) - Static method in class org.broadinstitute.hellbender.tools.copynumber.arguments.CopyNumberArgumentValidationUtils
Checks equality of the sequence dictionary and intervals contained in an locatableCollection against those contained in an AnnotatedIntervalCollection represented by annotatedIntervalsFile.
validateAnnotatedIntervalsSubset(File, AbstractLocatableCollection<?, ?>, Logger) - Static method in class org.broadinstitute.hellbender.tools.copynumber.arguments.CopyNumberArgumentValidationUtils
Same as CopyNumberArgumentValidationUtils.validateAnnotatedIntervals(java.io.File, org.broadinstitute.hellbender.tools.copynumber.formats.collections.AbstractLocatableCollection<?, ?>, org.apache.logging.log4j.Logger), except we only require that annotatedIntervalsFile contains as a subset all the intervals contained in locatableCollection along with equality of the sequence dictionaries.
validateArg(boolean, String) - Static method in class org.broadinstitute.hellbender.utils.Utils
 
validateArg(boolean, Supplier<String>) - Static method in class org.broadinstitute.hellbender.utils.Utils
 
ValidateBasicSomaticShortMutations - Class in org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup
 
ValidateBasicSomaticShortMutations() - Constructor for class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
validateCigar(List<CigarElement>) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SvCigarUtils
Checks input list of cigar operations for: empty input list; there must be at least one alignment operation in the list; deletion operation cannot neighbor clipping operations;
validateCountsAgainstScheme(GenotypeConcordanceScheme) - Method in class picard.vcf.GenotypeConcordanceCounts
Validates that there are no counts for NA states in the underlying scheme
validateCRAMDictionaryAgainstReference(SAMSequenceDictionary, SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.utils.SequenceDictionaryUtils
Tests for compatibility between a reference dictionary and a CRAM dictionary, using appropriate validation settings.
validateDictionaries(String, SAMSequenceDictionary, String, SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.utils.SequenceDictionaryUtils
Tests for compatibility between two sequence dictionaries, using standard validation settings appropriate for the GATK.
validateDictionaries(String, SAMSequenceDictionary, String, SAMSequenceDictionary, boolean, boolean) - Static method in class org.broadinstitute.hellbender.utils.SequenceDictionaryUtils
Tests for compatibility between two sequence dictionaries.
validateEmitEmptyLociParameters() - Method in class org.broadinstitute.hellbender.engine.LocusWalker
The emit empty loci parameter comes with several pitfalls when used incorrectly.
validateExpectedSortOrder(SAMFileHeader.SortOrder, SAMFileHeader.SortOrder, boolean, String) - Static method in class org.broadinstitute.hellbender.utils.read.ReadUtils
Validate that the expected input sort order is either "unsorted", or that it matches the actualSortOrder.
validateGencodeGtfFeature(GencodeGtfFeature, int) - Static method in class org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfCodec
Validates a given GencodeGtfFeature against a given version of the GENCODE GTF file spec.
validateGenomeLoc(String, int, int, int, boolean) - Method in class org.broadinstitute.hellbender.utils.GenomeLocParser
validate a position or interval on the genome as valid Requires that contig exist in the master sequence dictionary, and that contig index be valid as well.
validateIntervalArgumentCollection(IntervalArgumentCollection) - Static method in class org.broadinstitute.hellbender.tools.copynumber.arguments.CopyNumberArgumentValidationUtils
Validate that the interval-argument collection parameters minimally modify the input intervals.
validateIntervals(List<T>, SAMSequenceDictionary) - Static method in class org.broadinstitute.hellbender.tools.copynumber.arguments.CopyNumberArgumentValidationUtils
Validate that a list of locatables is valid and sorted according to a sequence dictionary and contains no duplicates or overlaps.
validateLocatableColumnName(String) - Static method in class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvLocatableTableCodec
Throw an exception if the given column name cannot be used for one of the locatable columns.
validateNoOverlappingIntervals(List<T>) - Static method in class org.broadinstitute.hellbender.utils.IntervalUtils
Throws Bad Input exception if any overlaps are detected within the list of locatables.
ValidateSamFile - Class in picard.sam
This tool reports on the validity of a SAM or BAM file relative to the SAM format specification.
ValidateSamFile() - Constructor for class picard.sam.ValidateSamFile
 
ValidateSamFile.Mode - Enum in picard.sam
 
validateScheme() - Method in class picard.vcf.GenotypeConcordanceScheme
Check that all cells in the scheme exist.
validateSequenceDictionaries() - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
Validates standard tool inputs against each other.
validateSequenceDictionaries() - Method in class org.broadinstitute.hellbender.tools.spark.pipelines.ReadsPipelineSpark
 
ValidateVariants - Class in org.broadinstitute.hellbender.tools.walkers.variantutils
Validate a VCF file with a strict set of criteria
ValidateVariants() - Constructor for class org.broadinstitute.hellbender.tools.walkers.variantutils.ValidateVariants
 
ValidateVariants.ValidationType - Enum in org.broadinstitute.hellbender.tools.walkers.variantutils
 
VALIDATION_ALT_COVERAGE - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
VALIDATION_REF_COVERAGE - Static variable in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
VALIDATION_STRINGENCY - Variable in class org.broadinstitute.hellbender.cmdline.PicardCommandLineProgram
 
VALIDATION_STRINGENCY - Variable in class picard.cmdline.CommandLineProgram
 
validationCaseName - Variable in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
validationControlName - Variable in class org.broadinstitute.hellbender.tools.walkers.validation.basicshortmutpileup.ValidateBasicSomaticShortMutations
 
validIndex(int, int) - Static method in class org.broadinstitute.hellbender.utils.Utils
Checks whether an index is within bounds considering a collection or array of a particular size whose first position index is 0
value - Variable in enum org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmer.Base
 
value - Variable in class org.broadinstitute.hellbender.utils.collections.NestedIntegerArray.Leaf
 
VALUE_SEPARATOR - Static variable in class org.broadinstitute.hellbender.tools.walkers.vqsr.Tranche
 
valueCounts - Variable in class org.broadinstitute.hellbender.utils.CompressedDataList
 
valueOf(String) - Static method in enum org.broadinstitute.hellbender.engine.AlignmentContext.ReadOrientation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.engine.spark.JoinStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.metrics.MetricAccumulationLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineDenoisingModelArgumentCollection.CopyNumberPosteriorExpectationMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection.HybridADVIArgument
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.copynumber.DetermineGermlineContigPloidy.RunMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.copynumber.formats.metadata.Metadata.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.copynumber.formats.records.CalledCopyRatioSegment.Call
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.copynumber.GermlineCNVCaller.RunMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.copynumber.models.AlleleFractionParameter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.copynumber.models.CopyRatioParameter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.copynumber.utils.segmentation.KernelSegmenter.ChangepointSortOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasFilterSummaryTableColumn
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.funcotator.AminoAcid
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation.VariantClassification
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation.VariantType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv.SimpleKeyXsvFuncotationFactory.XsvDataKeyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.funcotator.FuncotatorArgumentDefinitions.DataSourceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.funcotator.FuncotatorArgumentDefinitions.OutputFormatType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.funcotator.TranscriptSelectionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.GatherVcfsCloud.GatherType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectMultipleMetricsSpark.SparkCollectors
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments.AlignmentSignatureBasicType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments.ReasonForAlignmentClassificationFailure
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.ContigAlignmentsModifier.AlnModType.ModTypeString
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.ContigAlignmentsModifier.AlnModType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.StrandSwitch
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.spark.sv.discovery.SimpleSVType.TYPES
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.spark.sv.evidence.TemplateFragmentOrdinal
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.spark.sv.utils.Strand
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmer.Base
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.walkers.annotator.StrandArtifact.ArtifactState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.walkers.contamination.ContaminationRecord.Level
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculatorImplementation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeAssignmentMethod
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeLikelihoodsCalculationModel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingOutputMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.walkers.genotyper.OutputMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResult.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.walkers.haplotypecaller.PairHMMLikelihoodCalculationEngine.PCRErrorModel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadLikelihoodCalculationEngine.Implementation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReferenceConfidenceMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.walkers.mutect.CreateSomaticPanelOfNormals.DuplicateSampleStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.walkers.mutect.PerAlleleCollection.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.walkers.rnaseq.ASEReadCounter.CountPileupType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.walkers.rnaseq.ASEReadCounter.OUTPUT_FORMAT
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.walkers.validation.ConcordanceState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.walkers.variantutils.ValidateVariants.ValidationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.tools.walkers.vqsr.TensorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.activityprofile.ActivityProfileState.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.artifacts.Transition
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.baq.BAQ.CalculationMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.baq.BAQ.QualityMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.BaseUtils.Base
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.BaseUtils.BaseSubstitutionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.clipping.ClippingRepresentation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.AnnotationSource
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.FeatureTag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.FeatureType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.GeneTranscriptStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.GeneTranscriptType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.GenomicPhase
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.LocusLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.RemapStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.RemapTargetStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.TranscriptSupportLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.downsampling.DownsampleType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.GenomeLocParser.ValidationLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.genotyper.DiploidGenotype
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.haplotype.HaplotypeBAMWriter.WriterType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.illumina.IlluminaAdapterPair
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.IntervalMergingRule
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.IntervalSetRule
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.IntervalUtils.IntervalBreakpointType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.MannWhitneyU.TestType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.mcmc.Decile
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.mcmc.ParameterizedModel.UpdateMethod
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.mcmc.ParameterTableColumn
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.NGSPlatform
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.Nucleotide
Returns the enum constant of this type with the specified name.
valueOf(byte) - Static method in enum org.broadinstitute.hellbender.utils.Nucleotide
Returns the nucleotide that corresponds to a particular byte typed base code.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.pairhmm.PairHMM.Implementation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.pairhmm.VectorLoglessPairHMM.Implementation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.python.PythonExecutorBase.PythonExecutableName
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.R.RScriptLibrary
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.read.markduplicates.MarkDuplicatesScoringStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.MarkDuplicatesSparkRecord.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.read.mergealignment.HitsForInsert.NumPrimaryAlignmentState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.read.ReadsWriteFormat
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.read.ReadUtils.ClippingTail
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.recalibration.EventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.report.GATKReportColumnFormat.Alignment
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.report.GATKReportDataType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.report.GATKReportTable.Sorting
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.report.GATKReportTable.TableDataHeaderFields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.report.GATKReportTable.TableNameHeaderFields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.report.GATKReportVersion
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.runtime.ProcessControllerBase.ProcessStream
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.runtime.StreamLocation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.samples.Affection
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.samples.PedigreeValidationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.samples.PedReader.Field
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.samples.PedReader.MissingPedField
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.samples.Sex
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.SequenceDictionaryUtils.SequenceDictionaryCompatibility
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.SequencerFlowClass
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.smithwaterman.SmithWatermanAligner.Implementation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.smithwaterman.SmithWatermanJavaAligner.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.solver.SynchronizedUnivariateSolver.UnivariateSolverStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.Trilean
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.variant.DbSnpVariantType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils.FilteredRecordMergeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils.GenotypeMergeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.broadinstitute.hellbender.utils.variant.GATKVCFIndexType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.analysis.AlignmentSummaryMetrics.Category
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.analysis.artifacts.Transition.Base
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.analysis.artifacts.Transition
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.analysis.CollectMultipleMetrics.Program
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.analysis.CollectWgsMetricsWithNonZeroCoverage.WgsMetricsWithNonZeroCoverage.Category
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.analysis.directed.RnaSeqMetricsCollector.StrandSpecificity
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.analysis.MetricAccumulationLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.annotation.LocusFunction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.annotation.RefFlatReader.RefFlatColumns
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.fingerprint.CrosscheckMetric.DataType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.fingerprint.CrosscheckMetric.FingerprintResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.fingerprint.DiploidGenotype
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.fingerprint.DiploidHaplotype
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.fingerprint.HaplotypeProbabilities.Genotype
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.illumina.IlluminaBasecallsToFastq.ReadNameFormat
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.illumina.parser.IlluminaDataType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.illumina.parser.IlluminaFileUtil.SupportedIlluminaFormat
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.illumina.parser.IlluminaMetricsCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.illumina.parser.IntensityChannel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.illumina.parser.readers.TileMetricsOutReader.TileMetricsVersion
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.illumina.parser.ReadType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.illumina.parser.TileTemplateRead
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.illumina.quality.CollectHiSeqXPfFailMetrics.ReadClassifier.PfFailReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.nio.PathHelper.PathProviders
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.pedigree.Sex
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.sam.AbstractAlignmentMerger.UnmappingReadStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.sam.FilterSamReads.Filter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.sam.markduplicates.MarkDuplicates.DuplicateTaggingPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.sam.markduplicates.MarkDuplicates.DuplicateType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.sam.RevertOriginalBaseQualitiesAndAddMateCigar.CanSkipSamFile
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.sam.RevertSam.FileType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.sam.ValidateSamFile.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.sam.ViewSam.AlignmentStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.sam.ViewSam.PfStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.util.BaitDesigner.DesignStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.util.IlluminaUtil.IlluminaAdapterPair
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.util.IntervalListScatterer.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.util.IntervalListTools.Action
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.util.VariantType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.vcf.GenotypeConcordanceStateCodes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.vcf.GenotypeConcordanceStates.CallState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.vcf.GenotypeConcordanceStates.ContingencyState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum picard.vcf.GenotypeConcordanceStates.TruthState
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.broadinstitute.hellbender.engine.AlignmentContext.ReadOrientation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.engine.spark.JoinStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.metrics.MetricAccumulationLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.copynumber.arguments.GermlineDenoisingModelArgumentCollection.CopyNumberPosteriorExpectationMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.copynumber.arguments.HybridADVIArgumentCollection.HybridADVIArgument
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.copynumber.DetermineGermlineContigPloidy.RunMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.copynumber.formats.metadata.Metadata.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.copynumber.formats.records.CalledCopyRatioSegment.Call
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.copynumber.GermlineCNVCaller.RunMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.copynumber.models.AlleleFractionParameter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.copynumber.models.CopyRatioParameter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.copynumber.utils.segmentation.KernelSegmenter.ChangepointSortOrder
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasFilterSummaryTableColumn
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.funcotator.AminoAcid
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation.VariantClassification
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.funcotator.dataSources.gencode.GencodeFuncotation.VariantType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.broadinstitute.hellbender.tools.funcotator.dataSources.TableFuncotation
 
values() - Static method in enum org.broadinstitute.hellbender.tools.funcotator.dataSources.xsv.SimpleKeyXsvFuncotationFactory.XsvDataKeyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.funcotator.FuncotatorArgumentDefinitions.DataSourceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.funcotator.FuncotatorArgumentDefinitions.OutputFormatType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.funcotator.TranscriptSelectionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.GatherVcfsCloud.GatherType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.spark.pipelines.metrics.CollectMultipleMetricsSpark.SparkCollectors
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments.AlignmentSignatureBasicType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments.ReasonForAlignmentClassificationFailure
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.ContigAlignmentsModifier.AlnModType.ModTypeString
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.ContigAlignmentsModifier.AlnModType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.StrandSwitch
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.spark.sv.discovery.SimpleSVType.TYPES
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.spark.sv.evidence.TemplateFragmentOrdinal
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.spark.sv.utils.Strand
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmer.Base
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.walkers.annotator.StrandArtifact.ArtifactState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.walkers.contamination.ContaminationRecord.Level
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.walkers.genotyper.afcalc.AFCalculatorImplementation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeAssignmentMethod
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypeLikelihoodsCalculationModel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.walkers.genotyper.GenotypingOutputMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.walkers.genotyper.OutputMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResult.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.walkers.haplotypecaller.PairHMMLikelihoodCalculationEngine.PCRErrorModel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReadLikelihoodCalculationEngine.Implementation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.walkers.haplotypecaller.ReferenceConfidenceMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.walkers.mutect.CreateSomaticPanelOfNormals.DuplicateSampleStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.walkers.mutect.PerAlleleCollection.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.walkers.rnaseq.ASEReadCounter.CountPileupType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.walkers.rnaseq.ASEReadCounter.OUTPUT_FORMAT
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.walkers.validation.ConcordanceState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.walkers.variantutils.ValidateVariants.ValidationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.tools.walkers.vqsr.TensorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.activityprofile.ActivityProfileState.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.artifacts.Transition
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.baq.BAQ.CalculationMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.baq.BAQ.QualityMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.BaseUtils.Base
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.BaseUtils.BaseSubstitutionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.clipping.ClippingRepresentation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.AnnotationSource
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.FeatureTag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.FeatureType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.GeneTranscriptStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.GeneTranscriptType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.GenomicPhase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.LocusLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.RemapStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.RemapTargetStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.codecs.gencode.GencodeGtfFeature.TranscriptSupportLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.downsampling.DownsampleType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.GenomeLocParser.ValidationLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.genotyper.DiploidGenotype
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.haplotype.HaplotypeBAMWriter.WriterType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.illumina.IlluminaAdapterPair
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.IntervalMergingRule
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.IntervalSetRule
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.IntervalUtils.IntervalBreakpointType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.MannWhitneyU.TestType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.mcmc.Decile
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.mcmc.ParameterizedModel.UpdateMethod
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.broadinstitute.hellbender.utils.mcmc.ParameterizedState
Returns a List of the Parameter objects that are held internally as values of the parameter map.
values() - Static method in enum org.broadinstitute.hellbender.utils.mcmc.ParameterTableColumn
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.NGSPlatform
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.Nucleotide
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.pairhmm.PairHMM.Implementation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.pairhmm.VectorLoglessPairHMM.Implementation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.python.PythonExecutorBase.PythonExecutableName
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.R.RScriptLibrary
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.read.markduplicates.MarkDuplicatesScoringStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.MarkDuplicatesSparkRecord.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.read.mergealignment.HitsForInsert.NumPrimaryAlignmentState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.read.ReadsWriteFormat
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.read.ReadUtils.ClippingTail
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.recalibration.EventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.report.GATKReportColumnFormat.Alignment
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.report.GATKReportDataType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.report.GATKReportTable.Sorting
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.report.GATKReportTable.TableDataHeaderFields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.report.GATKReportTable.TableNameHeaderFields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.report.GATKReportVersion
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.runtime.ProcessControllerBase.ProcessStream
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.runtime.StreamLocation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.samples.Affection
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.samples.PedigreeValidationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.samples.PedReader.Field
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.samples.PedReader.MissingPedField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.samples.Sex
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.SequenceDictionaryUtils.SequenceDictionaryCompatibility
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.SequencerFlowClass
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.smithwaterman.SmithWatermanAligner.Implementation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.smithwaterman.SmithWatermanJavaAligner.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.solver.SynchronizedUnivariateSolver.UnivariateSolverStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.Trilean
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.variant.DbSnpVariantType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils.AlleleMapper
 
values() - Static method in enum org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils.FilteredRecordMergeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.variant.GATKVariantContextUtils.GenotypeMergeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.broadinstitute.hellbender.utils.variant.GATKVCFIndexType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.analysis.AlignmentSummaryMetrics.Category
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.analysis.artifacts.Transition.Base
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.analysis.artifacts.Transition
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.analysis.CollectMultipleMetrics.Program
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.analysis.CollectWgsMetricsWithNonZeroCoverage.WgsMetricsWithNonZeroCoverage.Category
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.analysis.directed.RnaSeqMetricsCollector.StrandSpecificity
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.analysis.MetricAccumulationLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.annotation.LocusFunction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.annotation.RefFlatReader.RefFlatColumns
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.fingerprint.CrosscheckMetric.DataType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.fingerprint.CrosscheckMetric.FingerprintResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.fingerprint.DiploidGenotype
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.fingerprint.DiploidHaplotype
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.fingerprint.HaplotypeProbabilities.Genotype
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.illumina.IlluminaBasecallsToFastq.ReadNameFormat
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.illumina.parser.IlluminaDataType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.illumina.parser.IlluminaFileUtil.SupportedIlluminaFormat
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.illumina.parser.IlluminaMetricsCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.illumina.parser.IntensityChannel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.illumina.parser.readers.TileMetricsOutReader.TileMetricsVersion
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.illumina.parser.ReadType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.illumina.parser.TileTemplateRead
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.illumina.quality.CollectHiSeqXPfFailMetrics.ReadClassifier.PfFailReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.nio.PathHelper.PathProviders
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.pedigree.Sex
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.sam.AbstractAlignmentMerger.UnmappingReadStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.sam.FilterSamReads.Filter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.sam.markduplicates.MarkDuplicates.DuplicateTaggingPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.sam.markduplicates.MarkDuplicates.DuplicateType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.sam.RevertOriginalBaseQualitiesAndAddMateCigar.CanSkipSamFile
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.sam.RevertSam.FileType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.sam.ValidateSamFile.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.sam.ViewSam.AlignmentStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.sam.ViewSam.PfStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.util.BaitDesigner.DesignStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.util.IlluminaUtil.IlluminaAdapterPair
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.util.IntervalListScatterer.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.util.IntervalListTools.Action
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.util.VariantType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.vcf.GenotypeConcordanceStateCodes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.vcf.GenotypeConcordanceStates.CallState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.vcf.GenotypeConcordanceStates.ContingencyState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum picard.vcf.GenotypeConcordanceStates.TruthState
Returns an array containing the constants of this enum type, in the order they are declared.
valuesBySampleIndex - Variable in class org.broadinstitute.hellbender.utils.genotyper.ReadLikelihoods
Indexed per sample, allele and finally read (within sample).
ValuesIterator(Iterator<SVIntervalTree.Entry<V1>>) - Constructor for class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree.ValuesIterator
 
var() - Method in class org.broadinstitute.hellbender.utils.MathUtils.RunningAverage
 
VAR_PPV - Variable in class picard.vcf.GenotypeConcordanceSummaryMetrics
The ppv (positive predictive value) for all (heterozygous and homozygous) variants (PPV is the TP / (TP + FP))
VAR_SENSITIVITY - Variable in class picard.vcf.GenotypeConcordanceSummaryMetrics
The sensitivity for all (heterozygous and homozygous) variants (Sensitivity is TP / (TP + FN))
VAR_SPECIFICITY - Variable in class picard.vcf.GenotypeConcordanceSummaryMetrics
The specificity for all (heterozygous and homozygous) variants (Specificity is TN / (FP + TN))
VARIANT_LONG_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
VARIANT_SHARDSIZE - Static variable in class org.broadinstitute.hellbender.engine.VariantShard
 
VARIANT_SHORT_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
VARIANT_TYPE - Variable in class picard.vcf.GenotypeConcordanceContingencyMetrics
The type of the event (i.e.
VARIANT_TYPE - Variable in class picard.vcf.GenotypeConcordanceDetailMetrics
The type of the event (i.e.
VARIANT_TYPE - Variable in class picard.vcf.GenotypeConcordanceSummaryMetrics
The type of the event (i.e.
VARIANT_TYPE_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
VariantAccumulatorExecutor<ACCUMULATOR extends VariantProcessor.Accumulator<RESULT>,RESULT> - Interface in picard.vcf.processor
Describes the functionality for an executor that manages the delegation of work to VariantProcessor.Accumulators.
VariantAccumulatorExecutor.MultiThreadedChunkBased<A extends VariantProcessor.Accumulator<R>,R> - Class in picard.vcf.processor
A VariantAccumulatorExecutor that breaks down work into chunks described by the provided VariantIteratorProducer and spreads them over the indicated number of threads.
VariantAnnotation - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Superclass of all variant annotations.
VariantAnnotation() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotation
 
VariantAnnotator - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Annotate variant calls with context information
VariantAnnotator() - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotator
 
VariantAnnotatorEngine - Class in org.broadinstitute.hellbender.tools.walkers.annotator
The class responsible for computing annotations for variants.
VariantAnnotatorEngine(Collection<Annotation>, FeatureInput<VariantContext>, List<FeatureInput<VariantContext>>, boolean) - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.VariantAnnotatorEngine
Creates an annotation engine from a list of selected annotations output from command line parsing
VariantAnnotatorEngine.VAExpression - Class in org.broadinstitute.hellbender.tools.walkers.annotator
A container object for storing the objects necessary for carrying over expression annotations.
VariantCallContext - Class in org.broadinstitute.hellbender.tools.walkers.genotyper
Useful helper class to communicate the results of calculateGenotype to framework
VariantCallingDetailMetrics() - Constructor for class picard.vcf.CollectVariantCallingMetrics.VariantCallingDetailMetrics
 
VariantCallingSummaryMetrics() - Constructor for class picard.vcf.CollectVariantCallingMetrics.VariantCallingSummaryMetrics
 
VariantContextTestUtils - Class in org.broadinstitute.hellbender.utils.test
 
VariantContextVariantAdapter - Class in org.broadinstitute.hellbender.utils.variant
VariantContextVariantAdapter wraps the existing htsjdk VariantContext class so it can be used with the GATKVariant API.
VariantContextVariantAdapter(VariantContext) - Constructor for class org.broadinstitute.hellbender.utils.variant.VariantContextVariantAdapter
 
VariantDataManager - Class in org.broadinstitute.hellbender.tools.walkers.vqsr
 
VariantDataManager(List<String>, VariantRecalibratorArgumentCollection) - Constructor for class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
 
VariantEvaluationProgramGroup - Class in picard.cmdline.programgroups
Tools that evaluate and refine variant calls, e.g.
VariantEvaluationProgramGroup() - Constructor for class picard.cmdline.programgroups.VariantEvaluationProgramGroup
 
variantFiles - Variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.OptionalVariantInputArgumentCollection
 
variantFiles - Variable in class org.broadinstitute.hellbender.cmdline.argumentcollections.RequiredVariantInputArgumentCollection
 
VariantFilter - Interface in org.broadinstitute.hellbender.engine.filters
 
VariantFilter - Interface in picard.vcf.filter
Interface for classes that can generate filters for VariantContexts.
VariantFilteringProgramGroup - Class in picard.cmdline.programgroups
Tools that filter variants
VariantFilteringProgramGroup() - Constructor for class picard.cmdline.programgroups.VariantFilteringProgramGroup
 
VariantFilterLibrary - Class in org.broadinstitute.hellbender.engine.filters
Collects common variant filters.
VariantFilterLibrary() - Constructor for class org.broadinstitute.hellbender.engine.filters.VariantFilterLibrary
 
VariantFiltration - Class in org.broadinstitute.hellbender.tools.walkers.filters
Filter variant calls based on INFO and/or FORMAT annotations
VariantFiltration() - Constructor for class org.broadinstitute.hellbender.tools.walkers.filters.VariantFiltration
 
variantId - Variable in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvType
 
VariantIDsVariantFilter - Class in org.broadinstitute.hellbender.engine.filters
Keep only variants with any of these IDs.
VariantIDsVariantFilter(Set<String>) - Constructor for class org.broadinstitute.hellbender.engine.filters.VariantIDsVariantFilter
 
VariantIteratorProducer - Class in picard.vcf.processor
A mechanism for iterating over CloseableIterator of VariantContexts in in some fashion, given VCF files and optionally an interval list.
VariantIteratorProducer() - Constructor for class picard.vcf.processor.VariantIteratorProducer
 
VariantManipulationProgramGroup - Class in picard.cmdline.programgroups
Tools that manipulate variant call format (VCF) data
VariantManipulationProgramGroup() - Constructor for class picard.cmdline.programgroups.VariantManipulationProgramGroup
 
VariantOverlapAnnotator - Class in org.broadinstitute.hellbender.tools.walkers.annotator
Annotate the ID field and attribute overlap FLAGs for a VariantContext against a FeatureContext or a list of VariantContexts.
VariantOverlapAnnotator(FeatureInput<VariantContext>) - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.VariantOverlapAnnotator
Create a new VariantOverlapAnnotator
VariantOverlapAnnotator(FeatureInput<VariantContext>, Map<FeatureInput<VariantContext>, String>) - Constructor for class org.broadinstitute.hellbender.tools.walkers.annotator.VariantOverlapAnnotator
Create a new VariantOverlapAnnotator
VariantProcessor<RESULT,ACCUMULATOR extends VariantProcessor.Accumulator<RESULT>> - Class in picard.vcf.processor
Describes an object that processes variants and produces a result.
VariantProcessor.Accumulator<RESULT> - Interface in picard.vcf.processor
Handles VariantContexts, and accumulates their data in some fashion internally.
VariantProcessor.AccumulatorGenerator<ACCUMULATOR extends VariantProcessor.Accumulator<RESULT>,RESULT> - Interface in picard.vcf.processor
Generates instances of VariantProcessor.Accumulators.
VariantProcessor.Builder<A extends VariantProcessor.Accumulator<R>,R> - Class in picard.vcf.processor
Simple builder of VariantProcessors.
VariantProcessor.ResultMerger<RESULT> - Interface in picard.vcf.processor
Takes a collection of results produced by VariantProcessor.Accumulator.result() and merges them into a single RESULT.
VariantRecalibrator - Class in org.broadinstitute.hellbender.tools.walkers.vqsr
Build a recalibration model to score variant quality for filtering purposes
VariantRecalibrator() - Constructor for class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantRecalibrator
 
VariantRecalibratorEngine - Class in org.broadinstitute.hellbender.tools.walkers.vqsr
 
VariantRecalibratorEngine(VariantRecalibratorArgumentCollection) - Constructor for class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantRecalibratorEngine
 
variants - Variable in class org.broadinstitute.hellbender.engine.ContextShard
 
variantsAreEqual(GATKVariant, GATKVariant) - Static method in class org.broadinstitute.hellbender.utils.variant.VariantUtils
 
VariantShard - Class in org.broadinstitute.hellbender.engine
VariantShard is section of the genome that's used for sharding work for pairing things with variants.
VariantShard(int, String) - Constructor for class org.broadinstitute.hellbender.engine.VariantShard
 
variantShardPadding - Variable in class org.broadinstitute.hellbender.engine.spark.VariantWalkerSpark
 
variantShardSize - Variable in class org.broadinstitute.hellbender.engine.spark.VariantWalkerSpark
 
variantSource - Variable in class org.broadinstitute.hellbender.tools.walkers.vqsr.TrainingSet
 
variantsOverlapping(SimpleInterval) - Method in class org.broadinstitute.hellbender.engine.ContextShard
Returns the variants that overlap the query interval, in start-position order.
VariantsSource - Class in org.broadinstitute.hellbender.engine.datasources
VariantsSource loads variants from a local file (GCS Bucket to come).
VariantsSource() - Constructor for class org.broadinstitute.hellbender.engine.datasources.VariantsSource
 
VariantsSparkSink - Class in org.broadinstitute.hellbender.engine.spark.datasources
VariantsSparkSink writes variants to a VCF file in parallel using Hadoop-BAM.
VariantsSparkSink() - Constructor for class org.broadinstitute.hellbender.engine.spark.datasources.VariantsSparkSink
 
VariantsSparkSink.GvcfKeyIgnoringVCFRecordWriter<K> - Class in org.broadinstitute.hellbender.engine.spark.datasources
 
VariantsSparkSink.SparkHeaderlessVCFOutputFormat - Class in org.broadinstitute.hellbender.engine.spark.datasources
 
VariantsSparkSink.SparkVCFOutputFormat - Class in org.broadinstitute.hellbender.engine.spark.datasources
 
VariantsSparkSource - Class in org.broadinstitute.hellbender.engine.spark.datasources
VariantsSparkSource loads Variants from files serially (using FeatureDataSource) or in parallel using Hadoop-BAM.
VariantsSparkSource(JavaSparkContext) - Constructor for class org.broadinstitute.hellbender.engine.spark.datasources.VariantsSparkSource
 
VariantsToTable - Class in org.broadinstitute.hellbender.tools.walkers.variantutils
Extract fields from a VCF file to a tab-delimited table
VariantsToTable() - Constructor for class org.broadinstitute.hellbender.tools.walkers.variantutils.VariantsToTable
 
VariantType - Enum in picard.util
Enum to hold the possible types of dbSnps.
VariantTypesVariantFilter - Class in org.broadinstitute.hellbender.engine.filters
Keep only variants with any of these variant types.
VariantTypesVariantFilter(Set<VariantContext.Type>) - Constructor for class org.broadinstitute.hellbender.engine.filters.VariantTypesVariantFilter
 
VariantUtils - Class in org.broadinstitute.hellbender.utils.variant
VariantUtils contains utility methods for the Variant interface.
VariantUtils() - Constructor for class org.broadinstitute.hellbender.utils.variant.VariantUtils
 
VariantWalker - Class in org.broadinstitute.hellbender.engine
A VariantWalker is a tool that processes a variant at a time from a source of variants, with optional contextual information from a reference, sets of reads, and/or supplementary sources of Features.
VariantWalker() - Constructor for class org.broadinstitute.hellbender.engine.VariantWalker
 
VariantWalkerBase - Class in org.broadinstitute.hellbender.engine
Base class for variant walkers, which process one variant at a time from one or more sources of variants, with optional contextual information from a reference, sets of reads, and/or supplementary sources of Features.
VariantWalkerBase() - Constructor for class org.broadinstitute.hellbender.engine.VariantWalkerBase
 
VariantWalkerContext - Class in org.broadinstitute.hellbender.engine.spark
Encapsulates a VariantContext with the reads that overlap it (the ReadsContext and its ReferenceContext and FeatureContext.
VariantWalkerContext(VariantContext, ReadsContext, ReferenceContext, FeatureContext) - Constructor for class org.broadinstitute.hellbender.engine.spark.VariantWalkerContext
 
VariantWalkerSpark - Class in org.broadinstitute.hellbender.engine.spark
A Spark version of VariantWalker.
VariantWalkerSpark() - Constructor for class org.broadinstitute.hellbender.engine.spark.VariantWalkerSpark
 
VCF - Variable in class picard.analysis.replicates.CollectIndependentReplicateMetrics
 
vcf() - Method in class picard.vcf.processor.VcfFileSegment
 
VCF_BUFFER_SIZE_ARG_NAME - Static variable in class org.broadinstitute.hellbender.tools.genomicsdb.GenomicsDBImport
 
VCF_DIR - Variable in class picard.vcf.MendelianViolations.FindMendelianViolations
 
VCF_FILE_EXTENSION - Static variable in class org.broadinstitute.hellbender.utils.variant.VcfUtils
 
VCF_INITIALIZER_THREADS_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.genomicsdb.GenomicsDBImport
 
VcfFileSegment - Class in picard.vcf.processor
Describes a segment of a particular VCF file.
VcfFileSegment() - Constructor for class picard.vcf.processor.VcfFileSegment
 
VcfFileSegmentGenerator - Class in picard.vcf.processor
Describes a mechanism for producing VcfFileSegments from a VCF file.
VcfFileSegmentGenerator() - Constructor for class picard.vcf.processor.VcfFileSegmentGenerator
 
VcfFormatConverter - Class in picard.vcf
Converts an ASCII VCF file to a binary BCF or vice versa.
VcfFormatConverter() - Constructor for class picard.vcf.VcfFormatConverter
 
VcfFuncotationFactory - Class in org.broadinstitute.hellbender.tools.funcotator.dataSources.vcf
A class to create annotations from VCF feature sources.
VcfFuncotationFactory(String, String, Path) - Constructor for class org.broadinstitute.hellbender.tools.funcotator.dataSources.vcf.VcfFuncotationFactory
 
VcfFuncotationFactory(String, String, Path, LinkedHashMap<String, String>) - Constructor for class org.broadinstitute.hellbender.tools.funcotator.dataSources.vcf.VcfFuncotationFactory
 
vcfHeader - Static variable in class org.broadinstitute.hellbender.engine.spark.datasources.VariantsSparkSink.SparkVCFOutputFormat
 
VcfOutputRenderer - Class in org.broadinstitute.hellbender.tools.funcotator.vcfOutput
A Funcotator output renderer for writing to VCF files.
VcfOutputRenderer(VariantContextWriter, VCFHeader, List<DataSourceFuncotationFactory>) - Constructor for class org.broadinstitute.hellbender.tools.funcotator.vcfOutput.VcfOutputRenderer
 
VcfOutputRenderer(VariantContextWriter, List<DataSourceFuncotationFactory>, VCFHeader, LinkedHashMap<String, String>, LinkedHashMap<String, String>) - Constructor for class org.broadinstitute.hellbender.tools.funcotator.vcfOutput.VcfOutputRenderer
 
VcfOutputRenderer(VariantContextWriter, List<DataSourceFuncotationFactory>, VCFHeader, LinkedHashMap<String, String>, LinkedHashMap<String, String>, Set<VCFHeaderLine>) - Constructor for class org.broadinstitute.hellbender.tools.funcotator.vcfOutput.VcfOutputRenderer
 
VcfToIntervalList - Class in picard.vcf
Converts a VCF or BCF file to a Picard Interval List.
VcfToIntervalList() - Constructor for class picard.vcf.VcfToIntervalList
 
VcfUtils - Class in org.broadinstitute.hellbender.utils.variant
Utils for dealing with VCF files.
VcfUtils - Class in picard.vcf
Created by farjoun on 4/1/17.
VcfUtils() - Constructor for class picard.vcf.VcfUtils
 
vectorDiff(int[], int[]) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
Compute Z=X-Y for two numeric vectors X and Y
VectorLoglessPairHMM - Class in org.broadinstitute.hellbender.utils.pairhmm
Class for performing the pair HMM for local alignment using AVX instructions contained in a native shared library.
VectorLoglessPairHMM(VectorLoglessPairHMM.Implementation, PairHMMNativeArguments) - Constructor for class org.broadinstitute.hellbender.utils.pairhmm.VectorLoglessPairHMM
Create a VectorLoglessPairHMM
VectorLoglessPairHMM.Implementation - Enum in org.broadinstitute.hellbender.utils.pairhmm
Type for implementation of VectorLoglessPairHMM
VERBOSITY - Variable in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
 
VERBOSITY - Variable in class picard.cmdline.CommandLineProgram
 
VERBOSITY_NAME - Static variable in class org.broadinstitute.hellbender.cmdline.StandardArgumentDefinitions
 
verify(List<Integer>, int[]) - Method in class picard.illumina.parser.MultiTileBclFileUtil
 
verify(List<Integer>, int[]) - Method in class picard.illumina.parser.MultiTileFileUtil
expectedCycles are not checked in this implementation.
verify(List<Integer>, int[]) - Method in class picard.illumina.parser.ParameterizedFileUtil
Given the expected tiles/expected cycles for this file type, return a list of error messages describing any missing/or malformed files
verify(List<Integer>, int[]) - Method in class picard.illumina.parser.PerTileFileUtil
 
verify(List<Integer>, int[]) - Method in class picard.illumina.parser.PerTileOrPerRunFileUtil
 
verify(List<Integer>, int[]) - Method in class picard.illumina.parser.PerTilePerCycleFileUtil
 
verify(List<Integer>) - Method in class picard.illumina.parser.TileIndex
 
verifyData(List<Integer>, int[]) - Method in class picard.illumina.parser.MultiTileParser
 
verifyData(List<Integer>, int[]) - Method in class picard.illumina.parser.PerTileParser
 
verifyDivisibilityWithRefShard() - Static method in class org.broadinstitute.hellbender.utils.test.ReadsPreprocessingPipelineTestData
 
version - Variable in class org.broadinstitute.hellbender.tools.funcotator.DataSourceFuncotationFactory
Version number of this DataSourceFuncotationFactory.
VERSION - Static variable in class org.broadinstitute.hellbender.tools.funcotator.Funcotator
The current version of Funcotator.
VERSION - Static variable in class org.broadinstitute.hellbender.tools.funcotator.mafOutput.MafOutputRenderer
Version of the MAF standard that this MafOutputRenderer writes.
version - Variable in class picard.illumina.parser.readers.FilterFileReader
Version number found in the FilterFile, this should equal 3
ViewSam - Class in picard.sam
Prints a SAM or BAM file to the screen.
ViewSam() - Constructor for class picard.sam.ViewSam
 
ViewSam.AlignmentStatus - Enum in picard.sam
 
ViewSam.PfStatus - Enum in picard.sam
 
ViterbiAlgorithm - Class in org.broadinstitute.hellbender.utils.hmm
Implements the Viterbi Algorithm.
ViterbiAlgorithm() - Constructor for class org.broadinstitute.hellbender.utils.hmm.ViterbiAlgorithm
 
VQS_LOD_KEY - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
VQSLOD_CUTOFF - Variable in class org.broadinstitute.hellbender.tools.walkers.vqsr.ApplyVQSR
 
VQSLODTranche - Class in org.broadinstitute.hellbender.tools.walkers.vqsr
 
VQSLODTranche(double, int, double, int, double, int, int, VariantRecalibratorArgumentCollection.Mode, String) - Constructor for class org.broadinstitute.hellbender.tools.walkers.vqsr.VQSLODTranche
 

W

waitForPreviousBatchCompletion(long, TimeUnit) - Method in class org.broadinstitute.hellbender.utils.runtime.AsynchronousStreamWriterService
Waits for a batch that was previously initiated via AsynchronousStreamWriterService.startAsynchronousBatchWrite(List)} to complete, flushes the target stream and returns the corresponding completed Future.
warn(String) - Method in class org.broadinstitute.hellbender.utils.logging.OneShotLogger
 
WARN_ON_MISSING_CONTIG - Variable in class picard.vcf.LiftoverVcf
 
warning - Variable in class org.broadinstitute.hellbender.tools.walkers.annotator.PossibleDeNovo
 
warning - Variable in class org.broadinstitute.hellbender.tools.walkers.annotator.ReferenceBases
 
warning - Variable in class org.broadinstitute.hellbender.tools.walkers.annotator.StrandArtifact
 
warnOnNonIlluminaReadGroups(SAMFileHeader, Logger) - Static method in class org.broadinstitute.hellbender.utils.Utils
Checks if the read header contains any reads groups from non-Illumina and issue a warning of that's the case.
warnOnToolStatus() - Method in class org.broadinstitute.hellbender.cmdline.CommandLineProgram
If a tool is either Experimental or Beta, log a warning against use in production a environment.
warnUser(String) - Static method in class org.broadinstitute.hellbender.utils.Utils
 
warnUser(Logger, String) - Static method in class org.broadinstitute.hellbender.utils.Utils
 
warnUserLines(String) - Static method in class org.broadinstitute.hellbender.utils.Utils
 
wasClipped() - Method in class org.broadinstitute.hellbender.utils.clipping.ReadClipper
Check whether or not this read has been clipped.
wasTrimmed() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.AssemblyResultSet
Checks whether this assembly result set was trimmed.
wellFormedDouble(double) - Static method in class org.broadinstitute.hellbender.utils.MathUtils
 
WellformedReadFilter - Class in org.broadinstitute.hellbender.engine.filters
Tests whether a read is "well-formed" -- that is, is free of major internal inconsistencies and issues that could lead to errors downstream.
WellformedReadFilter() - Constructor for class org.broadinstitute.hellbender.engine.filters.WellformedReadFilter
 
WellformedReadFilter(SAMFileHeader) - Constructor for class org.broadinstitute.hellbender.engine.filters.WellformedReadFilter
 
WgsMetrics() - Constructor for class picard.analysis.CollectWgsMetrics.WgsMetrics
Create an instance of this metric that is not mergeable.
WgsMetrics(IntervalList, Histogram<Integer>, Histogram<Integer>, double, double, double, double, double, double, double, int, Histogram<Integer>, int) - Constructor for class picard.analysis.CollectWgsMetrics.WgsMetrics
Create an instance of this metric that is mergeable.
WgsMetricsCollector(CollectWgsMetrics, int, IntervalList) - Constructor for class picard.analysis.CollectWgsMetrics.WgsMetricsCollector
 
WgsMetricsProcessor - Interface in picard.analysis
Interface for processing data and generate result for CollectWgsMetrics
WgsMetricsProcessorImpl<T extends htsjdk.samtools.util.AbstractRecordAndOffset> - Class in picard.analysis
Implementation of WgsMetricsProcessor that gets input data from a given iterator and processes it with a help of collector
WgsMetricsProcessorImpl(AbstractLocusIterator<T, AbstractLocusInfo<T>>, ReferenceSequenceFileWalker, AbstractWgsMetricsCollector<T>, ProgressLogger) - Constructor for class picard.analysis.WgsMetricsProcessorImpl
 
WgsMetricsWithNonZeroCoverage() - Constructor for class picard.analysis.CollectWgsMetricsWithNonZeroCoverage.WgsMetricsWithNonZeroCoverage
 
WgsMetricsWithNonZeroCoverage(IntervalList, Histogram<Integer>, Histogram<Integer>, double, double, double, double, double, double, double, int, Histogram<Integer>, int) - Constructor for class picard.analysis.CollectWgsMetricsWithNonZeroCoverage.WgsMetricsWithNonZeroCoverage
 
WgsMetricsWithNonZeroCoverageCollector(CollectWgsMetricsWithNonZeroCoverage, int, IntervalList) - Constructor for class picard.analysis.CollectWgsMetricsWithNonZeroCoverage.WgsMetricsWithNonZeroCoverageCollector
 
which(String) - Static method in class org.broadinstitute.hellbender.utils.runtime.RuntimeUtils
Returns the path to an executable or null if it doesn't exist.
WHOLE_GENOME - Static variable in class org.broadinstitute.hellbender.utils.GenomeLoc
 
WIDTH_OF_10_PERCENT - Variable in class org.broadinstitute.hellbender.metrics.InsertSizeMetrics
The "width" of the bins, centered around the median, that encompass 10% of all read pairs.
WIDTH_OF_10_PERCENT - Variable in class picard.analysis.InsertSizeMetrics
The "width" of the bins, centered around the median, that encompass 10% of all read pairs.
WIDTH_OF_20_PERCENT - Variable in class org.broadinstitute.hellbender.metrics.InsertSizeMetrics
The "width" of the bins, centered around the median, that encompass 20% of all read pairs.
WIDTH_OF_20_PERCENT - Variable in class picard.analysis.InsertSizeMetrics
The "width" of the bins, centered around the median, that encompass 20% of all read pairs.
WIDTH_OF_30_PERCENT - Variable in class org.broadinstitute.hellbender.metrics.InsertSizeMetrics
The "width" of the bins, centered around the median, that encompass 30% of all read pairs.
WIDTH_OF_30_PERCENT - Variable in class picard.analysis.InsertSizeMetrics
The "width" of the bins, centered around the median, that encompass 30% of all read pairs.
WIDTH_OF_40_PERCENT - Variable in class org.broadinstitute.hellbender.metrics.InsertSizeMetrics
The "width" of the bins, centered around the median, that encompass 40% of all read pairs.
WIDTH_OF_40_PERCENT - Variable in class picard.analysis.InsertSizeMetrics
The "width" of the bins, centered around the median, that encompass 40% of all read pairs.
WIDTH_OF_50_PERCENT - Variable in class org.broadinstitute.hellbender.metrics.InsertSizeMetrics
The "width" of the bins, centered around the median, that encompass 50% of all read pairs.
WIDTH_OF_50_PERCENT - Variable in class picard.analysis.InsertSizeMetrics
The "width" of the bins, centered around the median, that encompass 50% of all read pairs.
WIDTH_OF_60_PERCENT - Variable in class org.broadinstitute.hellbender.metrics.InsertSizeMetrics
The "width" of the bins, centered around the median, that encompass 60% of all read pairs.
WIDTH_OF_60_PERCENT - Variable in class picard.analysis.InsertSizeMetrics
The "width" of the bins, centered around the median, that encompass 60% of all read pairs.
WIDTH_OF_70_PERCENT - Variable in class org.broadinstitute.hellbender.metrics.InsertSizeMetrics
The "width" of the bins, centered around the median, that encompass 70% of all read pairs.
WIDTH_OF_70_PERCENT - Variable in class picard.analysis.InsertSizeMetrics
The "width" of the bins, centered around the median, that encompass 70% of all read pairs.
WIDTH_OF_80_PERCENT - Variable in class org.broadinstitute.hellbender.metrics.InsertSizeMetrics
The "width" of the bins, centered around the median, that encompass 80% of all read pairs.
WIDTH_OF_80_PERCENT - Variable in class picard.analysis.InsertSizeMetrics
The "width" of the bins, centered around the median, that encompass 80% of all read pairs.
WIDTH_OF_90_PERCENT - Variable in class org.broadinstitute.hellbender.metrics.InsertSizeMetrics
The "width" of the bins, centered around the median, that encompass 90% of all read pairs.
WIDTH_OF_90_PERCENT - Variable in class picard.analysis.InsertSizeMetrics
The "width" of the bins, centered around the median, that encompass 90% of all read pairs.
WIDTH_OF_95_PERCENT - Variable in class picard.analysis.InsertSizeMetrics
The "width" of the bins, centered around the median, that encompass 95% of all read pairs.
WIDTH_OF_99_PERCENT - Variable in class org.broadinstitute.hellbender.metrics.InsertSizeMetrics
The "width" of the bins, centered around the median, that encompass 100% of all read pairs.
WIDTH_OF_99_PERCENT - Variable in class picard.analysis.InsertSizeMetrics
The "width" of the bins, centered around the median, that encompass 100% of all read pairs.
WINDOW_SIZE - Variable in class picard.analysis.GcBiasSummaryMetrics
The window size on the genome used to calculate the GC of the sequence.
WINDOW_SIZE_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.copynumber.ModelSegments
 
WINDOWS - Variable in class picard.analysis.GcBiasDetailMetrics
The number of windows on the reference genome that have this G+C content.
withInput(File...) - Method in class picard.vcf.processor.VariantProcessor.Builder
 
withMolecularIndexQualityTag(String) - Method in class picard.illumina.ClusterDataToSamConverter
Sets the SAM tag to use to store the molecular index base qualities.
withMolecularIndexTag(String) - Method in class picard.illumina.ClusterDataToSamConverter
Sets the SAM tag to use to store the molecular index bases.
withoutChromosomes(Set<String>) - Method in class picard.fingerprint.HaplotypeMap
Returns a copy of this haplotype map that excludes haplotypes on the chromosomes provided.
withoutPrefixAndSuffix(byte[], byte[]) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.SeqVertex
Return a new SeqVertex derived from this one but not including prefix or suffix bases
withoutSuffix(byte[]) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.SeqVertex
Return a new SeqVertex derived from this one but not including the suffix bases
withReadContext(List<ReadContextData>) - Method in class org.broadinstitute.hellbender.engine.ContextShard
creates a new shard, adding the specified read context and *removing the variants*.
withReads(List<GATKRead>) - Method in class org.broadinstitute.hellbender.engine.ContextShard
creates a new shard, adding the specified reads.
withTagPerMolecularIndex(List<String>) - Method in class picard.illumina.ClusterDataToSamConverter
Sets the SAM tags to use to store the bases each molecular index.
withVariants(List<GATKVariant>) - Method in class org.broadinstitute.hellbender.engine.ContextShard
creates a new shard, adding the specified variants.
WORKSPACE_ARG_LONG_NAME - Static variable in class org.broadinstitute.hellbender.tools.genomicsdb.GenomicsDBImport
 
WORST_CXT - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasSummaryMetrics
The sequence context (reference bases surrounding the locus of interest) having the lowest Q-score among all contexts for this artifact.
WORST_CXT - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterSummaryMetrics
The sequence context (reference bases surrounding the locus of interest) having the lowest Q-score among all contexts for this artifact.
WORST_CXT_QSCORE - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasSummaryMetrics
The Q-score for the worst context.
WORST_CXT_QSCORE - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterSummaryMetrics
The Q-score for the worst context.
WORST_POST_CXT - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasSummaryMetrics
The post-context (reference bases trailing after the locus of interest) with the lowest Q-score.
WORST_POST_CXT - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterSummaryMetrics
The post-context (reference bases trailing after the locus of interest) with the lowest Q-score.
WORST_POST_CXT_QSCORE - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasSummaryMetrics
The Q-score for the worst post-context.
WORST_POST_CXT_QSCORE - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterSummaryMetrics
The Q-score for the worst post-context.
WORST_PRE_CXT - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasSummaryMetrics
The pre-context (reference bases leading up to the locus of interest) with the lowest Q-score.
WORST_PRE_CXT - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterSummaryMetrics
The pre-context (reference bases leading up to the locus of interest) with the lowest Q-score.
WORST_PRE_CXT_QSCORE - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.BaitBiasSummaryMetrics
The Q-score for the worst pre-context.
WORST_PRE_CXT_QSCORE - Variable in class picard.analysis.artifacts.SequencingArtifactMetrics.PreAdapterSummaryMetrics
The Q-score for the worst pre-context.
write(Kryo, Output, T) - Method in class org.broadinstitute.hellbender.engine.spark.JsonSerializer
 
write(Kryo, Output, SAMRecord) - Method in class org.broadinstitute.hellbender.engine.spark.SAMRecordSerializer
 
write(Kryo, Output, SAMRecordToGATKReadAdapter) - Method in class org.broadinstitute.hellbender.engine.spark.SAMRecordToGATKReadAdapterSerializer
 
write(File, File) - Method in class org.broadinstitute.hellbender.tools.copynumber.denoising.SVDDenoisedCopyRatioResult
 
write(File) - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.collections.AbstractRecordCollection
Writes the records to file.
write(File) - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalCollection
Write this collection to a file Dev note: This method will force the default xsv config file on the output.
write(VariantContext, List<Funcotation>) - Method in class org.broadinstitute.hellbender.tools.funcotator.mafOutput.MafOutputRenderer
 
write(VariantContext, List<Funcotation>) - Method in class org.broadinstitute.hellbender.tools.funcotator.OutputRenderer
Write the given variant and funcotations to the output file.
write(VariantContext, List<Funcotation>) - Method in class org.broadinstitute.hellbender.tools.funcotator.vcfOutput.VcfOutputRenderer
 
write(Kryo, Output, PSKmerBloomFilter) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerBloomFilter.Serializer
 
write(Kryo, Output, PSKmerSet) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerSet.Serializer
 
write(Kryo, Output, PSTaxonomyDatabase) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTaxonomyDatabase.Serializer
 
write(Kryo, Output, PSTree) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTree.Serializer
 
write(Kryo, Output, PSTreeNode) - Method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSTreeNode.Serializer
 
write(Kryo, Output, AlignedAssembly) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignedAssembly.Serializer
 
write(Kryo, Output, AlignedContig) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignedContig.Serializer
 
write(Kryo, Output, AlignmentInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AlignmentInterval.Serializer
 
write(Kryo, Output, AssemblyContigWithFineTunedAlignments) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.alignment.AssemblyContigWithFineTunedAlignments.Serializer
 
write(Kryo, Output, BreakpointComplications.IntraChrStrandSwitchBreakpointComplications) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications.IntraChrStrandSwitchBreakpointComplications.Serializer
 
write(Kryo, Output, BreakpointComplications.SmallDuplicationWithImpreciseDupRangeBreakpointComplications) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications.SmallDuplicationWithImpreciseDupRangeBreakpointComplications.Serializer
 
write(Kryo, Output, BreakpointComplications.SmallDuplicationWithPreciseDupRangeBreakpointComplications) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.BreakpointComplications.SmallDuplicationWithPreciseDupRangeBreakpointComplications.Serializer
 
write(Kryo, Output, NovelAdjacencyAndAltHaplotype) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.NovelAdjacencyAndAltHaplotype.Serializer
 
write(Kryo, Output, SimpleChimera) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SimpleChimera.Serializer
 
write(Kryo, Output, SimpleNovelAdjacencyAndChimericAlignmentEvidence) - Method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.inference.SimpleNovelAdjacencyAndChimericAlignmentEvidence.Serializer
 
write(Kryo, Output, AlignedAssemblyOrExcuse) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.AlignedAssemblyOrExcuse.Serializer
 
write(Kryo, Output, BreakpointEvidence.ExternalEvidence) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.ExternalEvidence.Serializer
 
write(Kryo, Output, BreakpointEvidence.InterContigPair) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.InterContigPair.Serializer
 
write(Kryo, Output, BreakpointEvidence.LargeIndel) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.LargeIndel.Serializer
 
write(Kryo, Output, BreakpointEvidence.MateUnmapped) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.MateUnmapped.Serializer
 
write(Kryo, Output, BreakpointEvidence.OutiesPair) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.OutiesPair.Serializer
 
write(Kryo, Output, BreakpointEvidence.ReadEvidence) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.ReadEvidence.Serializer
 
write(Kryo, Output, BreakpointEvidence.SameStrandPair) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.SameStrandPair.Serializer
 
write(Kryo, Output, BreakpointEvidence) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.Serializer
 
write(Kryo, Output, BreakpointEvidence.SplitRead) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.SplitRead.Serializer
 
write(Kryo, Output, BreakpointEvidence.TemplateSizeAnomaly) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.TemplateSizeAnomaly.Serializer
 
write(Kryo, Output, BreakpointEvidence.WeirdTemplateSize) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.BreakpointEvidence.WeirdTemplateSize.Serializer
 
write(Kryo, Output, EvidenceTargetLink) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.EvidenceTargetLink.Serializer
 
write(Kryo, Output, KmerAndInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.KmerAndInterval.Serializer
 
write(Kryo, Output, LibraryStatistics) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.LibraryStatistics.Serializer
 
write(Kryo, Output, QNameAndInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.QNameAndInterval.Serializer
 
write(Kryo, Output, ReadMetadata.LibraryRawStatistics) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.LibraryRawStatistics.Serializer
 
write(Kryo, Output, ReadMetadata.PartitionBounds) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.PartitionBounds.Serializer
 
write(Kryo, Output, ReadMetadata.PartitionStatistics) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.PartitionStatistics.Serializer
 
write(Kryo, Output, ReadMetadata) - Method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata.Serializer
 
write(Kryo, Output, KmerAndCount) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.KmerAndCount.Serializer
 
write(Kryo, Output, PairedStrandedIntervalTree<T>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.PairedStrandedIntervalTree.Serializer
 
write(Kryo, Output, Strand) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.Strand.Serializer
 
write(Kryo, Output, StrandedInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.StrandedInterval.Serializer
 
write(Kryo, Output, SVFastqUtils.FastqRead) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils.FastqRead.Serializer
 
write(Kryo, Output, SVInterval) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVInterval.Serializer
 
write(Kryo, Output, SVIntervalTree<T>) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVIntervalTree.Serializer
 
write(Kryo, Output, SVKmerLong) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerLong.Serializer
 
write(Kryo, Output, SVKmerShort) - Method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVKmerShort.Serializer
 
write(Kryo, Output, HopscotchCollection<T>) - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchCollection.Serializer
 
write(Kryo, Output, HopscotchMap) - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchMap.Serializer
 
write(Kryo, Output, HopscotchMultiMap) - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchMultiMap.Serializer
 
write(Kryo, Output, HopscotchSet) - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchSet.Serializer
 
write(Kryo, Output, HopscotchUniqueMultiMap) - Method in class org.broadinstitute.hellbender.tools.spark.utils.HopscotchUniqueMultiMap.Serializer
 
write(Kryo, Output, IntHistogram.CDF) - Method in class org.broadinstitute.hellbender.tools.spark.utils.IntHistogram.CDF.Serializer
 
write(Kryo, Output, IntHistogram) - Method in class org.broadinstitute.hellbender.tools.spark.utils.IntHistogram.Serializer
 
write(Kryo, Output, LargeLongHopscotchSet) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LargeLongHopscotchSet.Serializer
 
write(Kryo, Output, LongBloomFilter) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongBloomFilter.Serializer
 
write(Kryo, Output, LongHopscotchSet) - Method in class org.broadinstitute.hellbender.tools.spark.utils.LongHopscotchSet.Serializer
 
write(byte[]) - Method in class org.broadinstitute.hellbender.utils.io.HardThresholdingOutputStream
 
write(byte[], int, int) - Method in class org.broadinstitute.hellbender.utils.io.HardThresholdingOutputStream
 
write(ByteBuffer) - Method in class org.broadinstitute.hellbender.utils.nio.SeekableByteChannelPrefetcher
Writing isn't supported.
write(Kryo, Output, Pair) - Method in class org.broadinstitute.hellbender.utils.read.markduplicates.sparkrecords.Pair.Serializer
 
write(ByteBuffer) - Method in class org.broadinstitute.hellbender.utils.test.XorWrapper
 
write(File) - Method in class picard.pedigree.PedFile
Writes a set of pedigrees out to disk.
write(byte[], int, int) - Method in class picard.util.CircularByteBuffer
Write bytes into the buffer from the supplied array.
WRITE_ORIGINAL_POSITION - Variable in class picard.vcf.LiftoverVcf
 
WRITE_READS_FILES - Variable in class picard.sam.FilterSamReads
 
writeAlignment(SAMRecord) - Method in class picard.sam.FixMateInformation
 
writeAll(List<DATA>) - Method in class org.broadinstitute.hellbender.tools.copynumber.gcnv.GermlineCNVVariantComposer
 
writeAllRecords(Iterable<R>) - Method in class org.broadinstitute.hellbender.utils.tsv.TableWriter
Write all the records in a Iterable.
writeAsVcf(File, File) - Method in class picard.fingerprint.HaplotypeMap
 
writeBfqFiles() - Method in class picard.fastq.BamToBfqWriter
Writes the binary fastq file(s) to the output directory
writeByteArrayToFile(byte[], File) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
Writes the given array of bytes to a file
writeByteArrayToStream(byte[], OutputStream) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
Writes the given array of bytes to a stream
writeChunkedDoubleMatrix(HDF5File, String, double[][], int) - Static method in class org.broadinstitute.hellbender.tools.copynumber.utils.HDF5Utils
Given a large matrix, chunks the matrix into equally sized subsets of rows (plus a subset containing the remainder, if necessary) and writes these submatrices to indexed sub-paths to avoid a hard limit in Java HDF5 on the number of elements in a matrix given by MAX_NUM_VALUES_PER_HDF5_MATRIX.
writeComment(String) - Method in class org.broadinstitute.hellbender.utils.tsv.TableWriter
Writes a comment into the output.
writeFastqFile(String, Iterator<SVFastqUtils.FastqRead>) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils
Write a list of FASTQ records into a file.
writeFastqStream(OutputStream, Iterator<SVFastqUtils.FastqRead>) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFastqUtils
 
writeFingerPrint(Fingerprint, File, File, String, String) - Static method in class picard.fingerprint.FingerprintUtils
A function that takes a Fingerprint and writes it as a VCF to a file
writeGFAs - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
writeGvcf(Configuration, List<Integer>, int) - Static method in class org.broadinstitute.hellbender.engine.spark.datasources.VariantsSparkSink.SparkHeaderlessVCFOutputFormat
 
writeHaplotypesAsReads(Collection<Haplotype>, Set<Haplotype>, Locatable) - Method in class org.broadinstitute.hellbender.utils.haplotype.HaplotypeBAMWriter
If setWriteHaplotypes has been set to true, causes haplotypes to be written to the output destination as reads, marking specifically those that are among the best haplotypes with a higher mapping quality.
writeHDF5(File) - Method in class org.broadinstitute.hellbender.tools.copynumber.formats.collections.SimpleCountCollection
 
writeHeader(AnnotatedIntervalHeader) - Method in interface org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.AnnotatedIntervalWriter
Write only the header (and any SAMFileHeader or comments)
writeHeader(AnnotatedIntervalHeader) - Method in class org.broadinstitute.hellbender.tools.copynumber.utils.annotatedinterval.SimpleAnnotatedIntervalWriter
 
writeHeader(LinkedHashMap<String, String>) - Method in class org.broadinstitute.hellbender.tools.funcotator.mafOutput.MafOutputRenderer
Write the header to the output file.
writeHeader(VariantContextWriter, SAMSequenceDictionary, Set<VCFHeaderLine>) - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.HaplotypeCallerEngine
Writes an appropriate VCF header, given our arguments, to the provided writer
writeHeader(VariantContextWriter, Set<VCFHeaderLine>) - Method in class org.broadinstitute.hellbender.tools.walkers.mutect.Mutect2Engine
 
writeHeader(VCFHeader) - Method in class org.broadinstitute.hellbender.utils.variant.writers.GVCFWriter
Write the VCF header Adds standard GVCF fields to the header
writeHeaderIfApplies() - Method in class org.broadinstitute.hellbender.utils.tsv.TableWriter
Writes the header if it has not been written already.
writeIntervalFile(String, SAMFileHeader, List<SVInterval>, List<AlignedAssemblyOrExcuse>) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.AlignedAssemblyOrExcuse
write a file describing each interval
writeIntervals(HDF5File, String, List<T>) - Static method in class org.broadinstitute.hellbender.tools.copynumber.utils.HDF5Utils
Given an HDF5 file and an HDF5 path, writes a list of intervals to hard-coded sub-paths.
writeIntervalsFile(String, Collection<SVInterval>, List<String>) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFileUtils
Write intervals to a file.
writeKmerBloomFilter(String, PSKmerBloomFilter) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerUtils
 
writeKmerSet(String, PSKmerSet) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerUtils
 
writeKmersFile(String, int, Collection<KType>) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFileUtils
Write kmers to file.
writeKryoObject(Object, String) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSKmerUtils
Writes an object to a URI using Kryo serialization.
writeLaneMetrics(Map<Integer, ? extends Collection<Tile>>, File, String, MetricsFile<MetricBase, Comparable<?>>, String) - Static method in class picard.illumina.CollectIlluminaLaneMetrics.IlluminaLaneMetricsCollector
 
writeLibraryToTempFile(File) - Method in enum org.broadinstitute.hellbender.utils.R.RScriptLibrary
Retrieve the resource for this library and write it to a temp File in targetDir.
writeMetadata(ReadMetadata, String) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.ReadMetadata
 
writeMissingReferenceAccessions(String, SAMFileHeader, PSTaxonomyDatabase, Logger) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScorer
Writes accessions contained in a SAM header that do not exist in the taxonomy database
writeMixingFractions(List<MixingFraction>, File) - Static method in class org.broadinstitute.hellbender.tools.walkers.validation.MixingFraction
 
writeModelParameterFiles(File, File) - Method in class org.broadinstitute.hellbender.tools.copynumber.models.MultidimensionalModeller
Writes posterior summaries for the global model parameters to a file.
writeModelReport(GaussianMixtureModel, GaussianMixtureModel, List<String>) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantRecalibrator
 
writeOrientationBiasSummaryTable(List<Pair<String, Transition>>, List<VariantContext>, Map<Transition, Double>, File) - Static method in class org.broadinstitute.hellbender.tools.exome.orientationbiasvariantfilter.OrientationBiasUtils
Write output file that is a summary file with orientation bias filter counts.
writeOutRecalibrationTable(VariantContextWriter, SAMSequenceDictionary) - Method in class org.broadinstitute.hellbender.tools.walkers.vqsr.VariantDataManager
 
writePhasingMetrics(Map<Integer, ? extends Collection<Tile>>, File, String, MetricsFile<MetricBase, Comparable<?>>, String, boolean) - Static method in class picard.illumina.CollectIlluminaLaneMetrics.IlluminaLaneMetricsCollector
 
writeProcessInput(String) - Method in class org.broadinstitute.hellbender.utils.runtime.StreamingProcessController
Write some input to the remote process, without waiting for output.
writeQNames(String, Iterable<QNameAndInterval>) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.evidence.QNameAndInterval
write template names and interval IDs to a file.
writer(File, TableColumnCollection, BiConsumer<R, DataLine>) - Static method in class org.broadinstitute.hellbender.utils.tsv.TableUtils
Creates a new table writer given the destination file, columns and the data-line composer.
writer(Writer, TableColumnCollection, BiConsumer<R, DataLine>) - Static method in class org.broadinstitute.hellbender.utils.tsv.TableUtils
Creates a new table writer given the destination writer, columns and the data-line composer.
writeReadAgainstHaplotype(GATKRead) - Method in class org.broadinstitute.hellbender.utils.haplotype.HaplotypeBAMWriter
Write out read aligned to haplotype to the BAM file
writeReads(JavaSparkContext, String, String, JavaRDD<GATKRead>, SAMFileHeader, ReadsWriteFormat) - Static method in class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSink
writeReads writes rddReads to outputFile with header as the file header.
writeReads(JavaSparkContext, String, String, JavaRDD<GATKRead>, SAMFileHeader, ReadsWriteFormat, int, String) - Static method in class org.broadinstitute.hellbender.engine.spark.datasources.ReadsSparkSink
writeReads writes rddReads to outputFile with header as the file header.
writeReads(JavaSparkContext, String, JavaRDD<GATKRead>) - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
Writes the reads from a JavaRDD to an output file.
writeReads(JavaSparkContext, String, JavaRDD<GATKRead>, SAMFileHeader) - Method in class org.broadinstitute.hellbender.engine.spark.GATKSparkTool
Writes the reads from a JavaRDD to an output file.
writeReadsAlignedToHaplotypes(Collection<Haplotype>, Locatable, Collection<Haplotype>, Set<Haplotype>, ReadLikelihoods<Haplotype>) - Method in class org.broadinstitute.hellbender.utils.haplotype.HaplotypeBAMWriter
Write out a BAM representing for the haplotype caller at this site
writeRecord(R) - Method in class org.broadinstitute.hellbender.utils.tsv.TableWriter
Writes a new record.
writeResource(Resource, File) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
Writes the an embedded resource to a file.
writeSAMFile(String, Iterator<SAMRecord>, SAMFileHeader, boolean) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVFileUtils
 
writeSAMRecords(JavaRDD<GATKRead>, Set<String>, String, SAMFileHeader) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoveryUtils
write SAM file for provided filteredContigs by extracting original alignments from originalAlignments, to directory specified by outputDir.
writeSAMRecords(List<GATKRead>, Set<String>, String, SAMFileHeader) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.discovery.SvDiscoveryUtils
 
writeScoresFile(Map<Integer, PSPathogenTaxonScore>, PSTree, String) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSScorer
Output a tab-delimited table of taxonomic scores
writeSingleSequenceReference(Path, boolean, boolean, String, String, byte[]) - Static method in class org.broadinstitute.hellbender.utils.reference.FastaReferenceWriter
Convenient method to write a FASTA file with a single sequence.
writeSingleSequenceReference(Path, int, boolean, boolean, String, String, byte[]) - Static method in class org.broadinstitute.hellbender.utils.reference.FastaReferenceWriter
Convenient method to write a FASTA file with a single sequence.
writeStringListToFile(Iterable<String>, File) - Static method in class org.broadinstitute.hellbender.utils.param.ParamUtils
Writes a list of strings to the given filename.
writeTaxonomyDatabase(String, PSTaxonomyDatabase) - Static method in class org.broadinstitute.hellbender.tools.spark.pathseq.PSBuildReferenceTaxonomyUtils
Writes objects using Kryo to specified local file path.
writeTemp() - Method in enum org.broadinstitute.hellbender.utils.R.RScriptLibrary
Writes the library source code to a temporary tar.gz file and returns the path.
writeTempFile(String, String, String) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
Writes content to a temp file and returns the path to the temporary file.
writeTempFile(String, String, String, File) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
Writes content to a temp file and returns the path to the temporary file.
writeTempResource(Resource) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
Writes an embedded resource to a temporary file.
writeTempResourceFromPath(String, Class<?>) - Static method in class org.broadinstitute.hellbender.utils.io.IOUtils
Create a resource from a path and a relative class, and write it to a temporary file.
writeToFile(List<ContaminationRecord>, File) - Static method in class org.broadinstitute.hellbender.tools.walkers.contamination.ContaminationRecord
 
writeToFile(List<MinorAlleleFractionRecord>, File) - Static method in class org.broadinstitute.hellbender.tools.walkers.contamination.MinorAlleleFractionRecord
 
writeToFile(List<PileupSummary>, File) - Static method in class org.broadinstitute.hellbender.tools.walkers.contamination.PileupSummary
 
writeToFile(Collection<FilterAnalysisRecord>, File) - Static method in class org.broadinstitute.hellbender.tools.walkers.validation.FilterAnalysisRecord
 
writeToFile(File) - Method in class picard.fingerprint.HaplotypeMap
Writes out a HaplotypeMap file with the contents of this map.
writeValuesToFile(double[], File) - Static method in class org.broadinstitute.hellbender.utils.param.ParamUtils
Writes a double array to the given filename.
writeVariants(JavaSparkContext, String, JavaRDD<VariantContext>, VCFHeader) - Static method in class org.broadinstitute.hellbender.engine.spark.datasources.VariantsSparkSink
Write variants to the given output file in VCF format with the given header.
writeVariants(JavaSparkContext, String, JavaRDD<VariantContext>, VCFHeader, boolean, List<Integer>, int) - Static method in class org.broadinstitute.hellbender.engine.spark.datasources.VariantsSparkSink
 
writeVariants(JavaSparkContext, String, JavaRDD<VariantContext>, VCFHeader, boolean, List<Integer>, int, int) - Static method in class org.broadinstitute.hellbender.engine.spark.datasources.VariantsSparkSink
Write variants to the given output file in VCF format with the given header.
writeVCF(List<VariantContext>, String, SAMSequenceDictionary, Logger) - Static method in class org.broadinstitute.hellbender.tools.spark.sv.utils.SVVCFWriter
referenceSequenceDictionary is required because 2bit Broadcast references currently order their sequence dictionaries in a scrambled order, see https://github.com/broadinstitute/gatk/issues/2037.
WrongFeatureType(File, Class<? extends Feature>) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.WrongFeatureType
 
WrongFeatureType(Path, Class<? extends Feature>, List<String>) - Constructor for exception org.broadinstitute.hellbender.exceptions.UserException.WrongFeatureType
 

X

x - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
x - Variable in class org.broadinstitute.hellbender.utils.solver.SynchronizedUnivariateSolver.UnivariateSolverSummary
 
X - Variable in class picard.illumina.quality.CollectHiSeqXPfFailMetrics.PFFailDetailedMetric
The X coordinate of the read within the tile
x - Variable in class picard.sam.util.PhysicalLocationInt
 
xIsSet() - Method in class picard.illumina.parser.ClusterData
 
xor(byte[], byte, int, int) - Static method in class org.broadinstitute.hellbender.utils.test.XorWrapper
 
xor(boolean, boolean) - Static method in class org.broadinstitute.hellbender.utils.Utils
Boolean xor operation.
XorWrapper - Class in org.broadinstitute.hellbender.utils.test
A SeekableByteChannel wrapper for testing.
XorWrapper(SeekableByteChannel, byte) - Constructor for class org.broadinstitute.hellbender.utils.test.XorWrapper
 
xPos - Variable in class picard.illumina.parser.readers.AbstractIlluminaPositionFileReader.PositionInfo
The x-position as it occurs in the file being read
xQseqCoord - Variable in class picard.illumina.parser.readers.AbstractIlluminaPositionFileReader.PositionInfo
The QSeq style x-coordinat, an integer = Math.round(xPos*10 + 1000)
XReadLines - Class in org.broadinstitute.hellbender.utils.text
Support for Python-like xreadlines() function as a class.
XReadLines(File) - Constructor for class org.broadinstitute.hellbender.utils.text.XReadLines
Opens the given file for reading lines.
XReadLines(File, boolean) - Constructor for class org.broadinstitute.hellbender.utils.text.XReadLines
Opens the given file for reading lines and optionally trim whitespaces.
XReadLines(Reader, boolean, String) - Constructor for class org.broadinstitute.hellbender.utils.text.XReadLines
Creates a new xReadLines object to read lines from an bufferedReader
XsvLocatableTableCodec - Class in org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable
Codec class to read from XSV (e.g.
XsvLocatableTableCodec() - Constructor for class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvLocatableTableCodec
 
XsvLocatableTableCodec(Path) - Constructor for class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvLocatableTableCodec
Constructor for when a configuration file is specified instead of using a sibling config file.
XsvTableFeature - Class in org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable
A feature to represent a line in an arbitrarily delimited (XSV) file (i.e.
XsvTableFeature(int, int, int, List<String>, List<String>, String) - Constructor for class org.broadinstitute.hellbender.utils.codecs.xsvLocatableTable.XsvTableFeature
Create an XsvTableFeature.

Y

y - Variable in class org.broadinstitute.hellbender.utils.read.markduplicates.ReadEnds
 
Y - Variable in class picard.illumina.quality.CollectHiSeqXPfFailMetrics.PFFailDetailedMetric
The Y coordinate of the read within the tile
y - Variable in class picard.sam.util.PhysicalLocationInt
 
yIsSet() - Method in class picard.illumina.parser.ClusterData
 
yPos - Variable in class picard.illumina.parser.readers.AbstractIlluminaPositionFileReader.PositionInfo
The y-position as it occurs in the file being read
yQseqCoord - Variable in class picard.illumina.parser.readers.AbstractIlluminaPositionFileReader.PositionInfo
The QSeq style y-coordinates, an integer = Math.round(yPos*10 + 1000)

Z

zDropoff - Variable in class org.broadinstitute.hellbender.tools.spark.sv.StructuralVariationDiscoveryArgumentCollection.FindBreakpointEvidenceSparkArgumentCollection
 
ZERO_COVERAGE_LOCI - Static variable in class org.broadinstitute.hellbender.utils.variant.GATKVCFConstants
 
ZERO_CVG_TARGETS_PCT - Variable in class picard.analysis.directed.HsMetrics
The fraction of targets that did not reach coverage=1 over any base.
ZERO_CVG_TARGETS_PCT - Variable in class picard.analysis.directed.TargetedPcrMetrics
The fraction of targets that did not reach coverage=1 over any base.
ZERO_CVG_TARGETS_PCT - Variable in class picard.analysis.directed.TargetMetrics
The fraction of targets that did not reach coverage=1 over any base.
zipLinearChains() - Method in class org.broadinstitute.hellbender.tools.walkers.haplotypecaller.graphs.SeqGraph
Zip up all of the simple linear chains present in this graph.
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 
Skip navigation links