• 设为首页
  • 点击收藏
  • 手机版
    手机扫一扫访问
    迪恩网络手机版
  • 关注官方公众号
    微信扫一扫关注
    迪恩网络公众号

Java SAMException类代码示例

原作者: [db:作者] 来自: [db:来源] 收藏 邀请

本文整理汇总了Java中htsjdk.samtools.SAMException的典型用法代码示例。如果您正苦于以下问题:Java SAMException类的具体用法?Java SAMException怎么用?Java SAMException使用的例子?那么恭喜您, 这里精选的类代码示例或许可以为您提供帮助。



SAMException类属于htsjdk.samtools包,在下文中一共展示了SAMException类的20个代码示例,这些例子默认根据受欢迎程度排序。您可以为喜欢或者感觉有用的代码点赞,您的评价将有助于我们的系统推荐出更棒的Java代码示例。

示例1: findReferenceFile

import htsjdk.samtools.SAMException; //导入依赖的package包/类
public static ReferenceSequenceFile findReferenceFile(String fileName)
		throws FileNotFoundException {
	ReferenceSequenceFile rsf;

	File refFile = new File(fileName);

	try {
		rsf = ReferenceSequenceFileFactory
				.getReferenceSequenceFile(refFile);
	} catch (SAMException ex) {
		System.err.println("Could not load reference sequence file \""
				+ refFile + "\".");
		throw new FileNotFoundException(refFile.toString());
	}
	return rsf;
}
 
开发者ID:acs6610987,项目名称:secram,代码行数:17,代码来源:ReferenceUtils.java


示例2: indexBam

import htsjdk.samtools.SAMException; //导入依赖的package包/类
public void indexBam(File bamFile, File baiFile) {
	SAMFileReader.setDefaultValidationStringency(ValidationStringency.SILENT);
       final SamReader bam;

           // input from a normal file
           IOUtil.assertFileIsReadable(bamFile);
           bam = SamReaderFactory.makeDefault().referenceSequence(null)
                   .enable(SamReaderFactory.Option.INCLUDE_SOURCE_IN_RECORDS)
                   .open(bamFile);

       if (bam.type() != SamReader.Type.BAM_TYPE) {
           throw new SAMException("Input file must be bam file, not sam file.");
       }

       if (!bam.getFileHeader().getSortOrder().equals(SAMFileHeader.SortOrder.coordinate)) {
           throw new SAMException("Input bam file must be sorted by coordinate");
       }

       BAMIndexer.createIndex(bam, baiFile);

       CloserUtil.close(bam);
}
 
开发者ID:chipster,项目名称:chipster,代码行数:23,代码来源:SamBamUtils.java


示例3: PicardIndexedFastaSequenceFile

import htsjdk.samtools.SAMException; //导入依赖的package包/类
/**
 * Open the given indexed fasta sequence file.  Throw an exception if the file cannot be opened.
 * @param path The file to open.
 * @param index Pre-built FastaSequenceIndex, for the case in which one does not exist on disk.
 */
public PicardIndexedFastaSequenceFile(final Path path, final FastaSequenceIndex index) {
    super(path);
    if (index == null) throw new IllegalArgumentException("Null index for fasta " + path);
    this.index = index;
    IOUtil.assertFileIsReadable(path);
    try {
        this.channel = Files.newByteChannel(path);
    } catch (IOException e) {
        throw new SAMException("Fasta file should be readable but is not: " + path, e);
    }
    reset();

    if(getSequenceDictionary() != null)
        sanityCheckDictionaryAgainstIndex(path.toAbsolutePath().toString(),sequenceDictionary,index);
}
 
开发者ID:chipster,项目名称:chipster,代码行数:21,代码来源:PicardIndexedFastaSequenceFile.java


示例4: sanityCheckDictionaryAgainstIndex

import htsjdk.samtools.SAMException; //导入依赖的package包/类
/**
 * Do some basic checking to make sure the dictionary and the index match.
 * @param fastaFile Used for error reporting only.
 * @param sequenceDictionary sequence dictionary to check against the index.
 * @param index index file to check against the dictionary.
 */
protected static void sanityCheckDictionaryAgainstIndex(final String fastaFile,
                                                        final SAMSequenceDictionary sequenceDictionary,
                                                        final FastaSequenceIndex index) {
    // Make sure dictionary and index are the same size.
    if( sequenceDictionary.getSequences().size() != index.size() )
        throw new SAMException("Sequence dictionary and index contain different numbers of contigs");

    Iterator<SAMSequenceRecord> sequenceIterator = sequenceDictionary.getSequences().iterator();
    Iterator<FastaSequenceIndexEntry> indexIterator = index.iterator();

    while(sequenceIterator.hasNext() && indexIterator.hasNext()) {
        SAMSequenceRecord sequenceEntry = sequenceIterator.next();
        FastaSequenceIndexEntry indexEntry = indexIterator.next();

        if(!sequenceEntry.getSequenceName().equals(indexEntry.getContig())) {
            throw new SAMException(String.format("Mismatch between sequence dictionary fasta index for %s, sequence '%s' != '%s'.",
                    fastaFile, sequenceEntry.getSequenceName(),indexEntry.getContig()));
        }

        // Make sure sequence length matches index length.
        if( sequenceEntry.getSequenceLength() != indexEntry.getSize())
            throw new SAMException("Index length does not match dictionary length for contig: " + sequenceEntry.getSequenceName() );
    }
}
 
开发者ID:chipster,项目名称:chipster,代码行数:31,代码来源:PicardIndexedFastaSequenceFile.java


示例5: getReadsFromHadoopBam

import htsjdk.samtools.SAMException; //导入依赖的package包/类
/**
 * Ingest a BAM file from a Hadoop file system and loads into a
 * <code>PCollection<Read></code>.
 * @param pipeline a configured Pipeline
 * @param intervals intervals to select reads from
 * @param bam Hadoop file path to read from
 * @return a <code>PCollection<Read></code> with all the reads that overlap the
 * given intervals in the BAM file
 */
@SuppressWarnings("unchecked")
public static PCollection<GATKRead> getReadsFromHadoopBam(final Pipeline pipeline, final List<SimpleInterval> intervals, final ValidationStringency stringency, final String bam) {
    PCollection<KV<LongWritable, SAMRecordWritable>> input = pipeline.apply(
            HadoopIO.Read.from(bam, AnySAMInputFormat.class, LongWritable.class, SAMRecordWritable.class));
    return input.apply(ParDo.of(new DoFn<KV<LongWritable, SAMRecordWritable>, GATKRead>() {
        private static final long serialVersionUID = 1L;
        @Override
        public void processElement( ProcessContext c ) throws Exception {
            SAMRecord sam = c.element().getValue().get();
            if ( samRecordOverlaps(sam, intervals) ) {
                try {
                    c.output(new SAMRecordToGATKReadAdapter(sam));
                }
                catch ( SAMException e ) {
                    if ( stringency == ValidationStringency.STRICT ) {
                        throw e;
                    }
                    else if ( stringency == ValidationStringency.LENIENT ) {
                        logger.info("getReadsFromHadoopBam: " + e.getMessage());
                    }
                    // do nothing if silent
                }
            }
        }
    }));
}
 
开发者ID:broadinstitute,项目名称:gatk-dataflow,代码行数:36,代码来源:DataflowUtils.java


示例6: getReaderIntervalIterator

import htsjdk.samtools.SAMException; //导入依赖的package包/类
/** Gets the interval iterator from a fresh reader, including unmapped reads. */
@Override
protected Iterator<GATKRead> getReaderIntervalIterator(final SamReader reader,
        final List<SimpleInterval> locs) {
    try {
        return new SAMRecordToReadIterator(new SamReaderQueryingIterator(reader, locs, false));
    } catch (SAMException | UserException e) {
        throw new UnsupportedOperationException(e.getMessage(), e);
    }
}
 
开发者ID:magicDGS,项目名称:ReadTools,代码行数:11,代码来源:SamSourceHandler.java


示例7: openSAMWriter

import htsjdk.samtools.SAMException; //导入依赖的package包/类
/** Open a new SAM/BAM/CRAM writer from a Path. */
public SAMFileWriter openSAMWriter(final SAMFileHeader header, final boolean presorted,
        final Path output) {
    checkOutputAndCreateDirs(output);
    try {
        return samFactory.makeWriter(header, presorted, output.toFile(), referenceFile);
    } catch (final SAMException e) {
        // catch SAM exceptions as IO errors -> this are the ones that may fail
        throw new UserException.CouldNotCreateOutputFile(output.toFile(), e.getMessage(), e);
    }
}
 
开发者ID:magicDGS,项目名称:ReadTools,代码行数:12,代码来源:ReadWriterFactory.java


示例8: getSequentialFileList

import htsjdk.samtools.SAMException; //导入依赖的package包/类
/**
 * Get a list of FASTQs that are sequentially numbered based on the first (base) fastq.
 * The files should be named:
 *   <prefix>_001.<extension>, <prefix>_002.<extension>, ..., <prefix>_XYZ.<extension>
 * The base files should be:
 *   <prefix>_001.<extension>
 * An example would be:
 *   RUNNAME_S8_L005_R1_001.fastq
 *   RUNNAME_S8_L005_R1_002.fastq
 *   RUNNAME_S8_L005_R1_003.fastq
 *   RUNNAME_S8_L005_R1_004.fastq
 * where `baseFastq` is the first in that list.
 */
protected static List<File> getSequentialFileList(final File baseFastq) {
    final List<File> files = new ArrayList<File>();
    files.add(baseFastq);

    // Find the correct extension used in the base FASTQ
    FastqExtensions fastqExtensions = null;
    String suffix = null; // store the suffix including the extension
    for (final FastqExtensions ext : FastqExtensions.values()) {
        suffix = "_001" + ext.getExtension();
        if (baseFastq.getAbsolutePath().endsWith(suffix)) {
            fastqExtensions = ext;
            break;
        }
    }
    if (null == fastqExtensions) {
        throw new PicardException(String.format("Could not parse the FASTQ extension (expected '_001' + '%s'): %s", FastqExtensions.values().toString(), baseFastq));
    }
    
    // Find all the files
    for (int idx = 2; true; idx++) {
        String fastq = baseFastq.getAbsolutePath();
        fastq = String.format("%s_%03d%s", fastq.substring(0, fastq.length() - suffix.length()), idx, fastqExtensions.getExtension());
        try {
            IOUtil.assertFileIsReadable(new File(fastq));
        } catch (final SAMException e) { // the file is not readable, so do not continue
            break;
        }
        files.add(new File(fastq));
    }
    
    return files;
}
 
开发者ID:broadinstitute,项目名称:picard,代码行数:46,代码来源:FastqToSam.java


示例9: forFile

import htsjdk.samtools.SAMException; //导入依赖的package包/类
static IntervalListInputType forFile(final File intervalListExtractable) {
    for (final IntervalListInputType intervalListInputType : IntervalListInputType.values()) {
        for (final String s : intervalListInputType.applicableExtensions) {
            if (intervalListExtractable.getName().endsWith(s)) {
                return intervalListInputType;
            }
        }
    }
    throw new SAMException("Cannot figure out type of file " + intervalListExtractable.getAbsolutePath() + " from extension. Current implementation understands the following types: " + Arrays.toString(IntervalListInputType.values()));
}
 
开发者ID:broadinstitute,项目名称:picard,代码行数:11,代码来源:IntervalListTools.java


示例10: readInvalidValuesForSAMException

import htsjdk.samtools.SAMException; //导入依赖的package包/类
@Test(dataProvider = "failingFilesForSAMException", expectedExceptions = SAMException.class)
public void readInvalidValuesForSAMException(final String failingFile) {
    final FilterFileReader reader = new FilterFileReader(new File(TEST_DATA_DIR, failingFile));
    while(reader.hasNext()) {
        reader.next();
    }
}
 
开发者ID:broadinstitute,项目名称:picard,代码行数:8,代码来源:FilterFileReaderTest.java


示例11: basedirDoesntExistTest

import htsjdk.samtools.SAMException; //导入依赖的package包/类
@Test(expectedExceptions = SAMException.class)
public void basedirDoesntExistTest() {
    final String[] args = makeCheckerArgs(new File("a_made_up_file/in_some_weird_location"), 1, "76T76T",
            new IlluminaDataType[]{IlluminaDataType.Position},
            new ArrayList<>(), false, false);
    runPicardCommandLine(args);
}
 
开发者ID:broadinstitute,项目名称:picard,代码行数:8,代码来源:CheckIlluminaDirectoryTest.java


示例12: testBadGroupedFileOutputPerRg

import htsjdk.samtools.SAMException; //导入依赖的package包/类
@Test (dataProvider = "badGroupedFiles", expectedExceptions=SAMException.class)
public void testBadGroupedFileOutputPerRg(final String samFilename) throws IOException {
    convertFile(new String[]{
            "INPUT=" + TEST_DATA_DIR + "/" + samFilename,
            "OUTPUT_DIR=" + IOUtil.getDefaultTmpDir().getAbsolutePath() + "/",
            "OUTPUT_PER_RG=true"
    });
}
 
开发者ID:broadinstitute,项目名称:picard,代码行数:9,代码来源:SamToFastqTest.java


示例13: testBadData

import htsjdk.samtools.SAMException; //导入依赖的package包/类
@Test(dataProvider = "badData", expectedExceptions = {MalformedFeatureFile.class, SAMException.class})
public void testBadData(final File inputVcf,
                        final File outputLoc,
                        final File genotypesFile,
                        final File haplotypeFile) {
    String[] args = new String[]{
            "I=" + inputVcf,
            "O=" + outputLoc,
            "G=" + genotypesFile,
            "H=" + haplotypeFile
    };
    Assert.assertEquals(runPicardCommandLine(args), 0);
}
 
开发者ID:broadinstitute,项目名称:picard,代码行数:14,代码来源:CheckFingerprintTest.java


示例14: setupBuilder

import htsjdk.samtools.SAMException; //导入依赖的package包/类
@BeforeTest
void setupBuilder() throws IOException {
    tempSamFileChrM_O = File.createTempFile("CollectGcBias", ".bam", TEST_DIR);
    tempSamFileAllChr = File.createTempFile("CollectGcBias", ".bam", TEST_DIR);
    tempSamFileChrM_O.deleteOnExit();
    tempSamFileAllChr.deleteOnExit();

    final File tempSamFileUnsorted = File.createTempFile("CollectGcBias", ".bam", TEST_DIR);
    tempSamFileUnsorted.deleteOnExit();


    final SAMFileHeader header = new SAMFileHeader();

    try {
        header.setSequenceDictionary(SAMSequenceDictionaryExtractor.extractDictionary(dict.toPath()));
        header.setSortOrder(SAMFileHeader.SortOrder.unsorted);
    } catch (final SAMException e) {
        e.printStackTrace();
    }

    //build different levels to put into the same bam file for testing multi level collection
    setupTest1(1, readGroupId1, readGroupRecord1, sample1, library1, header, setBuilder1); //Sample 1, Library 1, RG 1
    setupTest1(2, readGroupId2, readGroupRecord2, sample1, library2, header, setBuilder2); //Sample 1, Library 2, RG 2
    setupTest1(3, readGroupId3, readGroupRecord3, sample2, library3, header, setBuilder3); //Sample 2, Library 3, RG 3

    //build one last readgroup for comparing that window count stays the same whether you use all contigs or not
    setupTest2(1, readGroupId1, readGroupRecord1, sample1, library1, header, setBuilder4);

    final List<SAMRecordSetBuilder> test1Builders = new ArrayList<SAMRecordSetBuilder>();
    test1Builders.add(setBuilder1);
    test1Builders.add(setBuilder2);
    test1Builders.add(setBuilder3);

    final List<SAMRecordSetBuilder> test2Builders = new ArrayList<SAMRecordSetBuilder>();
    test2Builders.add(setBuilder4);

    tempSamFileChrM_O = build(test1Builders, tempSamFileUnsorted, header);
    tempSamFileAllChr = build(test2Builders, tempSamFileUnsorted, header);
}
 
开发者ID:broadinstitute,项目名称:picard,代码行数:40,代码来源:CollectGcBiasMetricsTest.java


示例15: doTest

import htsjdk.samtools.SAMException; //导入依赖的package包/类
private void doTest(final String inputBed, final String header) throws IOException, SAMException {
    final File outputFile  = File.createTempFile("bed_to_interval_list_test.", ".interval_list");
    outputFile.deleteOnExit();
    final BedToIntervalList program = new BedToIntervalList();
    final File inputBedFile = new File(TEST_DATA_DIR, inputBed);
    program.INPUT = inputBedFile;
    program.SEQUENCE_DICTIONARY = new File(TEST_DATA_DIR, header);
    program.OUTPUT = outputFile;
    program.UNIQUE = true;
    program.doWork();

    // Assert they are equal
    IOUtil.assertFilesEqual(new File(inputBedFile.getAbsolutePath() + ".interval_list"), outputFile);
}
 
开发者ID:broadinstitute,项目名称:picard,代码行数:15,代码来源:BedToIntervalListTest.java


示例16: saveMetrics

import htsjdk.samtools.SAMException; //导入依赖的package包/类
/**
 * Write a {@link MetricsFile} to the given path, can be any destination supported by {@link BucketUtils#createFile(String)}
 * @param metricsFile a {@link MetricsFile} object to write to disk
 * @param metricsOutputPath the path (or uri) to write the metrics to
 */
public static void saveMetrics(final MetricsFile<?, ?> metricsFile, String metricsOutputPath) {
    try(PrintWriter out = new PrintWriter(BucketUtils.createFile(metricsOutputPath))) {
        metricsFile.write(out);
    } catch (SAMException e ){
        throw new UserException.CouldNotCreateOutputFile("Could not write metrics to file: " + metricsOutputPath, e);
    }
}
 
开发者ID:broadinstitute,项目名称:gatk,代码行数:13,代码来源:MetricsUtils.java


示例17: getAttr

import htsjdk.samtools.SAMException; //导入依赖的package包/类
public static String getAttr(SAMRecord record, String attributeName) {
  try {
    return record.getStringAttribute(attributeName);
  } catch (SAMException ex) {
    return "";
  }
}
 
开发者ID:googlegenomics,项目名称:utils-java,代码行数:8,代码来源:ReadUtils.java


示例18: query

import htsjdk.samtools.SAMException; //导入依赖的package包/类
public String query(Chromosome chr, Long start, Long end) {
	
	String chrString = chromosomeNameUnnormaliser.unnormalise(chr);
	
	try {
		ReferenceSequence picardSequence = picard.getSubsequenceAt(chrString, start, end);
		return new String(picardSequence.getBases());

	} catch (SAMException e) {				
		e.printStackTrace(); //Catch "Query asks for data past end of contig" to prevent this thread from ending
		return null;
	}		
}
 
开发者ID:chipster,项目名称:chipster,代码行数:14,代码来源:IndexedFastaDataSource.java


示例19: next

import htsjdk.samtools.SAMException; //导入依赖的package包/类
/**
 * hasNext() has been fixed so that if it returns true, next() is now guaranteed not to return null.
 */
public LocusInfo next() {

    // if we don't have any completed entries to return, try and make some!
    while (complete.isEmpty() && samHasMore()) {
        final SAMRecord rec = samIterator.peek();

        // There might be unmapped reads mixed in with the mapped ones, but when a read
        // is encountered with no reference index it means that all the mapped reads have been seen.
        if (rec.getReferenceIndex() == -1) {
            this.finishedAlignedReads = true;
            continue;

        }
        // Skip over an unaligned read that has been forced to be sorted with the aligned reads
        if (rec.getReadUnmappedFlag()
                || rec.getMappingQuality() < this.mappingQualityScoreCutoff
                || (!this.includeNonPfReads && rec.getReadFailsVendorQualityCheckFlag())) {
            samIterator.next();
            continue;
        }

        final Locus alignmentStart = new LocusImpl(rec.getReferenceIndex(), rec.getAlignmentStart());

        // emit everything that is before the start of the current read, because we know no more
        // coverage will be accumulated for those loci.
        while (!accumulator.isEmpty() && locusComparator.compare(accumulator.get(0), alignmentStart) < 0) {
            final LocusInfo first = accumulator.get(0);
            populateCompleteQueue(alignmentStart);
            if (!complete.isEmpty()) {
                return complete.remove(0);
            }
            if (!accumulator.isEmpty() && first == accumulator.get(0)) {
                throw new SAMException("Stuck in infinite loop");
            }
        }

        // at this point, either the accumulator list is empty or the head should
        // be the same position as the first base of the read
        if (!accumulator.isEmpty()) {
            if (accumulator.get(0).getSequenceIndex() != rec.getReferenceIndex() ||
                    accumulator.get(0).position != rec.getAlignmentStart()) {
                throw new IllegalStateException("accumulator should be empty or aligned with current SAMRecord");
            }
        }

        // Store the loci for the read in the accumulator
        accumulateSamRecord(rec);

        samIterator.next();
    }

    final Locus endLocus = new LocusImpl(Integer.MAX_VALUE, Integer.MAX_VALUE);
    // if we have nothing to return to the user, and we're at the end of the SAM iterator,
    // push everything into the complete queue
    if (complete.isEmpty() && !samHasMore()) {
        while (!accumulator.isEmpty()) {
            populateCompleteQueue(endLocus);
            if (!complete.isEmpty()) {
                return complete.remove(0);
            }
        }
    }

    // if there are completed entries, return those
    if (!complete.isEmpty()) {
        return complete.remove(0);
    } else if (emitUncoveredLoci) {
        final Locus afterLastMaskPositionLocus = new LocusImpl(referenceSequenceMask.getMaxSequenceIndex(),
                referenceSequenceMask.getMaxPosition() + 1);
        // In this case... we're past the last read from SAM so see if we can
        // fill out any more (zero coverage) entries from the mask
        return createNextUncoveredLocusInfo(afterLastMaskPositionLocus);
    } else {
        return null;
    }
}
 
开发者ID:dariober,项目名称:ASCIIGenome,代码行数:80,代码来源:SamLocusIterator.java


示例20: doWork

import htsjdk.samtools.SAMException; //导入依赖的package包/类
/**
 * Main method for the program.  Checks that all input files are present and
 * readable and that the output file can be written to.  Then iterates through
 * all the records generating a BAM Index, then writes the bai file.
 */
protected int doWork() {

    try {
        inputUrl = new URL(INPUT);
    } catch (java.net.MalformedURLException e) {
        inputFile = new File(INPUT);
    }

    // set default output file - input-file.bai
    if (OUTPUT == null) {

        final String baseFileName;
        if (inputUrl != null) {
            final String path = inputUrl.getPath();
            final int lastSlash = path.lastIndexOf('/');
            baseFileName = path.substring(lastSlash + 1, path.length());
        } else {
            baseFileName = inputFile.getAbsolutePath();
        }

        if (baseFileName.endsWith(BamFileIoUtils.BAM_FILE_EXTENSION)) {

            final int index = baseFileName.lastIndexOf('.');
            OUTPUT = new File(baseFileName.substring(0, index) + BAMIndex.BAMIndexSuffix);

        } else {
            OUTPUT = new File(baseFileName + BAMIndex.BAMIndexSuffix);
        }
    }

    IOUtil.assertFileIsWritable(OUTPUT);
    final SamReader bam;

    if (inputUrl != null) {
        // remote input
        bam = SamReaderFactory.makeDefault().referenceSequence(REFERENCE_SEQUENCE)
                .disable(SamReaderFactory.Option.EAGERLY_DECODE)
                .enable(SamReaderFactory.Option.INCLUDE_SOURCE_IN_RECORDS)
                .open(SamInputResource.of(inputUrl));
    } else {
        // input from a normal file
        IOUtil.assertFileIsReadable(inputFile);
        bam = SamReaderFactory.makeDefault().referenceSequence(REFERENCE_SEQUENCE)
                .enable(SamReaderFactory.Option.INCLUDE_SOURCE_IN_RECORDS)
                .open(inputFile);
    }

    if (bam.type() != SamReader.Type.BAM_TYPE) {
        throw new SAMException("Input file must be bam file, not sam file.");
    }

    if (!bam.getFileHeader().getSortOrder().equals(SAMFileHeader.SortOrder.coordinate)) {
        throw new SAMException("Input bam file must be sorted by coordinate");
    }

    BAMIndexer.createIndex(bam, OUTPUT);

    log.info("Successfully wrote bam index file " + OUTPUT);
    CloserUtil.close(bam);
    return 0;
}
 
开发者ID:broadinstitute,项目名称:picard,代码行数:67,代码来源:BuildBamIndex.java



注:本文中的htsjdk.samtools.SAMException类示例整理自Github/MSDocs等源码及文档管理平台,相关代码片段筛选自各路编程大神贡献的开源项目,源码版权归原作者所有,传播和使用请参考对应项目的License;未经允许,请勿转载。


鲜花

握手

雷人

路过

鸡蛋
该文章已有0人参与评论

请发表评论

全部评论

专题导读
上一篇:
Java CommandsManagerRegistration类代码示例发布时间:2022-05-22
下一篇:
Java ILazyTreeContentProvider类代码示例发布时间:2022-05-22
热门推荐
阅读排行榜

扫描微信二维码

查看手机版网站

随时了解更新最新资讯

139-2527-9053

在线客服(服务时间 9:00~18:00)

在线QQ客服
地址:深圳市南山区西丽大学城创智工业园
电邮:jeky_zhao#qq.com
移动电话:139-2527-9053

Powered by 互联科技 X3.4© 2001-2213 极客世界.|Sitemap