Diff
stringlengths
5
2k
FaultInducingLabel
int64
0
1
@Test(expected = IllegalArgumentException.class) @Test(expected = IllegalArgumentException.class) }
0
import org.apache.http.impl.client.HttpClients; import org.apache.http.impl.client.CloseableHttpClient; this.httpclient = HttpClients.createDefault(); final CloseableHttpClient client = HttpClients.custom().setConnectionManager(conMan).build(); final CloseableHttpClient client = HttpClients.custom().setConnectionManager(conMan).build(); final CloseableHttpClient client = HttpClients.custom().setConnectionManager(conMan).build(); final CloseableHttpClient client = HttpClients.custom().setConnectionManager(conMan).build(); final HttpClient client = HttpClients.custom().setConnectionManager(connmgr).build();
0
inputCoder = (Coder<InputT>) rehydratedComponents.getCoder(mainInput.getCoderId()); windowingStrategy = (WindowingStrategy) rehydratedComponents.getWindowingStrategy(mainInput.getWindowingStrategyId());
0
* $Header: /home/jerenkrantz/tmp/commons/commons-convert/cvs/home/cvs/jakarta-commons//collections/src/java/org/apache/commons/collections/Attic/ArrayEnumeration.java,v 1.3 2002/03/18 23:49:20 morgand Exp $ * $Revision: 1.3 $ * $Date: 2002/03/18 23:49:20 $ * * @deprecated This class has significant overlap with ArrayIterator, * and Collections focuses mainly on Java2-style * collections. If you need to enumerate an array, * create an {@link ArrayIterator} and wrap it with an * {@link IteratorEnumeration} instead.
0
Storage.Util.consistentFetchTasks(storage, Query.shardScoped(role, job, shardId).active() .get()),
0
import static org.apache.accumulo.test.functional.WriteAheadLogIT.testWAL; WriteAheadLogIT.setupConfig(cfg, hadoopCoreSite); testWAL(c, getUniqueNames(1)[0]);
0
import java.util.TreeMap; Map<String, String> params = new TreeMap<>(String.CASE_INSENSITIVE_ORDER); params.put("isInitiator", "false"); params.put("principal", spn); params.put("useKeyTab", "true"); params.put("storeKey", "true"); params.put("keyTab", keytab); entry = new AppConfigurationEntry("com.sun.security.auth.module.Krb5LoginModule", AppConfigurationEntry.LoginModuleControlFlag.REQUIRED, params);
0
import javax.ws.rs.*; createStackResource(null)); } @PUT @Produces("text/plain") public Response updateStacks(@Context HttpHeaders headers, @Context UriInfo ui) { return handleRequest(headers, null, ui, Request.Type.PUT, createStackResource(null));
0
* @version $Id: ExceptionPropertyTestBean.java,v 1.2 2003/01/20 00:00:28 dmitri Exp $ public String getErrorString() { public String[] getErrorStringArray() { public TestBean getErrorBean() {
0
/** * Licensed to the Apache Software Foundation (ASF) under one * or more contributor license agreements. See the NOTICE file * distributed with this work for additional information * regarding copyright ownership. The ASF licenses this file * to you under the Apache License, Version 2.0 (the * "License"); you may not use this file except in compliance * with the License. You may obtain a copy of the License at * * http://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. * See the License for the specific language governing permissions and * limitations under the License. */ package org.apache.ambari.server.actionmanager; import java.util.Map; import org.apache.ambari.server.Role; /** * This class encapsulates all the information for an action * on a host for a particular role. This class will be used to schedule, persist and track * an action. */ public class HostRole { private final String host; private final Role role; private Map<String, String> params = null; private final float successFactor; private HostRoleStatus status = HostRoleStatus.PENDING; private String manifest = null; public HostRole(String host, Role role, float successFactor) { this.host = host; this.role = role; this.successFactor = successFactor; } }
0
/** Testing related utilities. */
0
if ((index < 0) || (index >= this.requestInterceptors.size())) { return null; } if ((index < 0) || (index >= this.responseInterceptors.size())) { return null; }
0
super(org.apache.commons.bcel6.Const.FREM);
0
/* * Copyright 2000-2004 The Apache Software Foundation * Licensed under the Apache License, Version 2.0 (the "License"); * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * http://www.apache.org/licenses/LICENSE-2.0 * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. * See the License for the specific language governing permissions and * limitations under the License. */ package org.apache.bcel.generic;
0
private static final String USAGE = "<html>Usage: /structdump/task/{task_id} or /structdump/cron/{role}/{env}/{job}</html>"; .entity(USAGE)
0
@Override @Override
0
import org.apache.hc.core5.io.CloseMode; client.shutdown(CloseMode.GRACEFUL);
0
public int compare(final File file1, final File file2) { private int getType(final File file) {
1
import org.apache.beam.sdk.transforms.OldDoFn; OldDoFn<InputT, OutputT> doFn,
0
for (String anEventNamesCommon : eventNamesCommon) { animationEventNames11.add(anEventNamesCommon); animationEventNames12.add(anEventNamesCommon); for (String anEventNamesSVG11 : eventNamesSVG11) { animationEventNames11.add(anEventNamesSVG11); for (String anEventNamesSVG12 : eventNamesSVG12) { animationEventNames12.add(anEventNamesSVG12); for (Object bridge2 : bridges) { (SVGAnimationElementBridge) bridge2; for (Object bridge1 : bridges) { (SVGAnimationElementBridge) bridge1;
0
public void componentAdded(String role, String clazz, Configuration config) {
0
package org.apache.hc.core5.http2.impl.nio.entity;
0
import org.apache.beam.sdk.transforms.PTransform; * <p>This is used to combine two SELECT statements, but returns rows only from the first SELECT * statement that are identical to a row in the second SELECT statement. RelOptCluster cluster, RelTraitSet traits, List<RelNode> inputs, boolean all) { delegate = new BeamSetOperatorRelBase(this, BeamSetOperatorRelBase.OpType.INTERSECT, inputs, all); @Override public SetOp copy(RelTraitSet traitSet, List<RelNode> inputs, boolean all) { @Override public PTransform<PCollectionTuple, PCollection<Row>> toPTransform() { return new Transform(); } private class Transform extends PTransform<PCollectionTuple, PCollection<Row>> { @Override public PCollection<Row> expand(PCollectionTuple inputPCollections) { return delegate.buildBeamPipeline(inputPCollections); }
0
public class KeyValueTest extends org.junit.Assert { public KeyValueTest() throws Exception { fac = KeyInfoFactory.getInstance ("DOM", new org.jcp.xml.dsig.internal.dom.XMLDSigRI()); // generate PublicKey(s) and XMLStructure(s) for DSA and RSA keys = new PublicKey[ALGOS.length]; for (int i = 0; i < ALGOS.length; i++) { keys[i] = genPublicKey(ALGOS[i], 512); } @org.junit.Test try { KeyValue kv = fac.newKeyValue(keys[0]); assertNotNull(kv.getPublicKey()); fail("Should pass instead of throwing KeyException"); @org.junit.Test // test newKeyValue(PublicKey pk) for (int i = 0; i < keys.length; i++) { try { KeyValue kv = fac.newKeyValue(keys[i]); assertEquals(keys[i], kv.getPublicKey()); } catch (KeyException ke) { fail("Should pass instead of throwing KeyException"); } } @org.junit.Test KeyValue kv = null; kv = fac.newKeyValue(keys[0]); kv.isFeatureSupported(null); fail("Should raise a NPE for null feature"); fail("Should raise a NPE for null feature"); private PublicKey genPublicKey(String algo, int keysize) throws Exception { KeyPairGenerator kpg = KeyPairGenerator.getInstance(algo); kpg.initialize(keysize, new SecureRandom(("Not so random bytes" + System.currentTimeMillis() ).getBytes() )); KeyPair kp = kpg.generateKeyPair(); return kp.getPublic(); }
0
import org.osgi.util.converter.ConvertingTypeSettings; public ConvertingTypeSettings source() { return new ConvertingTypeSettings() { @Override public Converting asJavaBean() { // TODO Auto-generated method stub return ConvertingWrapper.this; } @Override public Converting as(Class<?> type) { treatAsClass = type; del.source().as(type); return ConvertingWrapper.this; } };
0
import org.apache.accumulo.core.cli.BatchWriterOpts; import org.apache.accumulo.core.cli.ClientOpts; import org.apache.accumulo.core.cli.ScannerOpts; import com.beust.jcommander.Parameter; static class Opts extends ClientOpts { @Parameter(names="--shardTable") String shardTable = "shard"; @Parameter(names="--doc2Term") String doc2TermTable = "doc2Term"; } Opts opts = new Opts(); ScannerOpts scanOpts = new ScannerOpts(); BatchWriterOpts bwOpts = new BatchWriterOpts(); opts.parseArgs(Reverse.class.getName(), args, scanOpts, bwOpts); Connector conn = opts.getConnector(); Scanner scanner = conn.createScanner(opts.shardTable, opts.auths); scanner.setBatchSize(scanOpts.scanBatchSize); BatchWriter bw = conn.createBatchWriter(opts.doc2TermTable, bwOpts.getBatchWriterConfig());
1
query = "SELECT NEW org.apache.ambari.server.orm.dao.HostRoleCommandDAO.LastServiceCheckDTO(command.role, MAX(command.endTime)) FROM HostRoleCommandEntity command WHERE command.roleCommand = :roleCommand AND command.endTime > 0 AND command.stage.clusterId = :clusterId GROUP BY command.role ORDER BY command.role ASC"), @NamedQuery( name = "HostRoleCommandEntity.findByRequestId", query = "SELECT command FROM HostRoleCommandEntity command WHERE command.requestId = :requestId ORDER BY command.taskId")
0
* Copyright 2001-2005 The Apache Software Foundation
0
Set<PropertyInfo> serviceProperties = new HashSet<>(servicesMap.get(service.getName()).getProperties());
0
* limitations under the License.
0
* Licensed to the Apache Software Foundation (ASF) under one * or more contributor license agreements. See the NOTICE file * distributed with this work for additional information * regarding copyright ownership. The ASF licenses this file * to you under the Apache License, Version 2.0 (the * "License"); you may not use this file except in compliance * with the License. You may obtain a copy of the License at * http://www.apache.org/licenses/LICENSE-2.0 * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. * See the License for the specific language governing permissions and * limitations under the License.
0
import org.apache.accumulo.core.dataImpl.ComparableBytes;
0
package org.apache.felix.sigil.ivy; import org.apache.felix.sigil.core.BldCore; import org.apache.felix.sigil.model.IModelElement; import org.apache.felix.sigil.model.eclipse.ISigilBundle; import org.apache.felix.sigil.repository.IResolution; import org.apache.felix.sigil.repository.IResolutionMonitor; import org.apache.felix.sigil.repository.ResolutionConfig; import org.apache.felix.sigil.repository.ResolutionException;
0
import org.apache.cocoon.environment.SourceResolver; * &lt;!ELEMENT group (group|value)*&gt; public class StatusGenerator extends ServiceableGenerator { * The StoreJanitor used to get cache statistics */ protected StoreJanitor storejanitor; protected Store store_persistent; /** protected static final String namespace = "http://apache.org/cocoon/status/2.0"; protected static final String xlinkNamespace = "http://www.w3.org/1999/xlink"; } public void setup(SourceResolver resolver, Map objectModel, String src, Parameters parameters) throws ProcessingException, SAXException, IOException { super.setup(resolver, objectModel, src, parameters); this.showContinuationsInformation = parameters.getParameterAsBoolean(SHOW_CONTINUATIONS_INFO, false); } /* (non-Javadoc) * @see org.apache.avalon.framework.activity.Disposable#dispose() */ } }
0
* Copyright 2000-2009 The Apache Software Foundation
0
* @version $Id: Metaphone.java,v 1.18 2004/05/24 00:22:45 ggregory Exp $ return metaphone((String) pObject);
0
BeamFlow flow = BeamFlow.of(pipeline); BeamFlow flow = BeamFlow.of(pipeline);
0
BasicCredentialsProvider credsProvider = new BasicCredentialsProvider();
0
// This is also a cache in case the InstructionHandle#swapInstruction() method is used // See BCEL-273 private BranchInstruction bi; // An alias in fact, but saves lots of casts bi = i; return bi.getPosition(); bi.setPosition(pos); int x = bi.updatePosition(offset, max_offset); super.setPosition(bi.getPosition()); bi.setTarget(ih); bi.updateTarget(old_ih, new_ih); return bi.getTarget(); bi = (BranchInstruction) i;
0
@Override @Override @Override
0
import org.apache.batik.bridge.BridgeContext; import org.w3c.dom.Document; import org.w3c.dom.DocumentFragment; * Parses the given XML string into a DocumentFragment of the * given document. * @return The document fragment or null on error. */ DocumentFragment parseXML(String text, Document doc); /** * Returns the current BridgeContext. This object given a deep * access to the viewer internals. */ BridgeContext getBridgeContext(); /**
0
void submitFeed(Feed feed); Feed getFeed(String feedName); List<String> getFeedNames(); void updateFeed(Feed feed); void suspendFeed(String feedName); void resumeFeed(String feedName); void scheduleFeed(String feedName); void deleteFeed(String feedName); void submitCluster(Cluster cluster); Cluster getCluster(String clusterName); List<String> getClusterNames(); void updateCluster(Cluster cluster); void deleteCluster(String clusterName); List<Instance> getInstances(String feedName); //read void suspendInstance(String feedName, String instanceId); void resumeInstance(String feedName, String instanceId); void killInstance(String feedName, String instanceId);
0
/* * Copyright 1999-2004 The Apache Software Foundation. * * Licensed under the Apache License, Version 2.0 (the "License"); * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * * http://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. * See the License for the specific language governing permissions and * limitations under the License. */ * @version CVS $Id: DocType.java,v 1.2 2004/03/05 10:07:24 bdelacretaz Exp $
0
import org.apache.beam.sdk.transforms.windowing.OutputTimeFns; .withOutputTimeFn(OutputTimeFns.outputAtEarliestInputTimestamp()) WindowingStrategy.of(windowFn) .withOutputTimeFn(OutputTimeFns.outputAtEarliestInputTimestamp()) .withTrigger(trigger) .withMode(mode) .withAllowedLateness(allowedDataLateness);
0
* @version CVS $Id: SlideSource.java,v 1.3 2003/03/16 17:49:07 vgritsenko Exp $
0
import org.apache.accumulo.core.iterators.AggregatingIterator; import org.apache.accumulo.core.iterators.aggregation.Aggregator; private Option aggTypeOpt, ageoffTypeOpt, regexTypeOpt, versionTypeOpt, reqvisTypeOpt, classnameTypeOpt; if (cl.hasOption(aggTypeOpt.getOpt())) { Shell.log.warn("aggregators are deprecated"); classname = AggregatingIterator.class.getName(); } else if (cl.hasOption(regexTypeOpt.getOpt())) String aggregatorClass = options.get("aggregatorClass"); if (aggregatorClass != null && !shellState.getConnector().instanceOperations().testClassLoad(aggregatorClass, Aggregator.class.getName())) throw new ShellCommandException(ErrorCode.INITIALIZATION_FAILURE, "Servers are unable to load " + aggregatorClass + " as type " + Aggregator.class.getName()); aggTypeOpt = new Option("agg", "aggregator", false, "an aggregating type"); typeGroup.addOption(aggTypeOpt);
0
public static final String QUALIFIED_NAME = "qualifiedName"; public static final String REFERENCEABLE_ATTRIBUTE_NAME = QUALIFIED_NAME; WebResource resource = getResource(api, QUALIFIED_NAME);
0
import org.apache.cocoon.spring.ResourceUtils;
0
File pomFile = currentProject.getFile(); if ( pomFile == null || !pomFile.exists() ) { pomFile = new File( currentProject.getBasedir(), "pom.xml" ); } if ( pomFile.exists() ) { jar.putResource( path + "/pom.xml", new FileResource( pomFile ) ); }
0
package org.apache.commons.digester3; /* * Licensed to the Apache Software Foundation (ASF) under one * or more contributor license agreements. See the NOTICE file * distributed with this work for additional information * regarding copyright ownership. The ASF licenses this file * to you under the Apache License, Version 2.0 (the * "License"); you may not use this file except in compliance * with the License. You may obtain a copy of the License at * http://www.apache.org/licenses/LICENSE-2.0 * Unless required by applicable law or agreed to in writing, * software distributed under the License is distributed on an * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY * KIND, either express or implied. See the License for the * specific language governing permissions and limitations * under the License.
0
expect(provider.checkPropertyIds(capture(propertiesCapture))).andReturn(Collections.emptySet()).anyTimes(); expect(provider.checkPropertyIds(capture(propertiesCapture))).andReturn(Collections.emptySet()); expect(provider.checkPropertyIds(capture(propertiesCapture))).andReturn(Collections.emptySet()).anyTimes();
0
public void map(Key k, Value v, OutputCollector<Key,Value> output, Reporter reporter) throws IOException { throw new IllegalArgumentException( "Usage : " + MRTester.class.getName() + " <table> [<batchScan> <scan sample>]"); conf.set("mapreduce.cluster.local.dir", new File(System.getProperty("user.dir"), "target/mapreduce-tmp").getAbsolutePath()); private static final SamplerConfiguration SAMPLER_CONFIG = new SamplerConfiguration( RowSampler.class.getName()).addOption("hasher", "murmur3_32").addOption("modulus", "3"); c.tableOperations().create(TEST_TABLE_3, new NewTableConfiguration().enableSampling(SAMPLER_CONFIG)); Collection<Pair<Text,Text>> fetchColumns = Collections .singleton(new Pair<>(new Text("foo"), new Text("bar")));
0
import org.apache.beam.vendor.guava.v20_0.com.google.common.collect.ImmutableSet;
0
public class ProviderTestSuite extends AbstractTestSuite { public ProviderTestSuite(final ProviderTestConfig providerConfig) throws Exception { public ProviderTestSuite(final ProviderTestConfig providerConfig, final boolean addEmptyDir) throws Exception { protected ProviderTestSuite(final ProviderTestConfig providerConfig, final String prefix, final boolean nested, final boolean addEmptyDir) throws Exception { protected void addBaseTests() throws Exception {
1
num_parameters = (file.readUnsignedByte());
0
public static final String XML_PARSER_CLASS_NAME_KEY = public static final String CSS_PARSER_CLASS_NAME_KEY = public static final String RESOURCES = protected static Properties parserProps = null; try { } catch (IOException ioe) { RESOURCES, null);
0
int counter = 0; @Override public int getPartition(LogFileKey key, LogFileValue value, int numPartitions) { // We don't really care if items with the same key stay together: we // just want a sort, with the load spread evenly over the reducers counter = ++counter % numPartitions; return counter; }
1
import org.apache.cocoon.util.WildcardHelper;
0
* Copyright 2001-2006 The Apache Software Foundation
0
import org.apache.hc.core5.annotation.Immutable; import org.apache.hc.core5.util.Args;
1
package org.apache.beam.sdk.extensions.gcp.options; import org.apache.beam.sdk.extensions.gcp.auth.TestCredential; import org.apache.beam.sdk.extensions.gcp.options.GoogleApiDebugOptions.GoogleApiTracer; import org.apache.beam.sdk.options.PipelineOptionsFactory;
0
* {@link ReaderRegistry}. ReaderRegistry.defaultRegistry(), * {@link ReaderRegistry}. ReaderRegistry registry, * {@link ReaderRegistry}. ReaderRegistry.defaultRegistry(), * {@link ReaderRegistry}. ReaderRegistry registry, ReaderRegistry registry,
0
* Licensed to the Apache Software Foundation (ASF) under one or more * contributor license agreements. See the NOTICE file distributed with * this work for additional information regarding copyright ownership. * The ASF licenses this file to You under the Apache License, Version 2.0 * (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at
1
public final static String SUBDIR_MODE_JAR = "jar"; public final static String SUBDIR_MODE_SKIP = "skip"; public final static String SUBDIR_MODE_RECURSE = "recurse"; final boolean jarSubdir; final boolean skipSubdir; final boolean recurseSubdir; this(directory, null, null); * @param subdirMode to use when scanning public Scanner(File directory, final String filterString, String subdirMode) this.jarSubdir = subdirMode == null || SUBDIR_MODE_JAR.equals(subdirMode); this.skipSubdir = SUBDIR_MODE_SKIP.equals(subdirMode); this.recurseSubdir = SUBDIR_MODE_RECURSE.equals(subdirMode); return processFiles(reportImmediately, list); } private Set<File> processFiles(boolean reportImmediately, File[] list) { if (file.isDirectory()) { if (skipSubdir) { continue; } else if (recurseSubdir) { files.addAll(processFiles(reportImmediately, file.listFiles(filter))); continue; } } // Only handle file when it does not change anymore and it has changed // since last reported if ((newChecksum == lastChecksum || reportImmediately) && newChecksum != storedChecksum) { // Make sure we'll handle a file that has been deleted files.addAll(removed);
0
* Licensed to the Apache Software Foundation (ASF) under one or more * contributor license agreements. See the NOTICE file distributed with * this work for additional information regarding copyright ownership. * The ASF licenses this file to You under the Apache License, Version 2.0 * (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at
0
import javax.validation.constraints.NotNull; @NotNull @NotNull public LSServerMapFieldValue() {}
0
import org.apache.beam.vendor.grpc.v1.io.grpc.ManagedChannel; import org.apache.beam.vendor.grpc.v1.io.grpc.inprocess.InProcessChannelBuilder; import org.apache.beam.vendor.grpc.v1.io.grpc.stub.StreamObserver; import org.apache.beam.vendor.protobuf.v3.com.google.protobuf.ByteString;
0
TServerInstance key = new TServerInstance(entry.getValue(), entry.getKey().getColumnQualifier()); ZooReaderWriter zk = new ZooReaderWriter(i.getZooKeepers(), i.getZooKeepersSessionTimeOut(), ""); IteratorSetting is = tops.getIteratorSetting(ReplicationTable.NAME, ReplicationTable.COMBINER_NAME, scope); ZooReaderWriter zk = new ZooReaderWriter(i.getZooKeepers(), i.getZooKeepersSessionTimeOut(), ""); Mutation m = new Mutation(ReplicationSection.getRowPrefix() + "file:/accumulo/wals/tserver+port/uuid");
0
/** * Cleanly closes the stream after implementation-speficied timeout, unless the stream is * aborted before the timeout is reached. */ void closeAfterDefaultTimeout() throws InterruptedException;
0
* * * may be useful for reports generated by <tt>TestSuite</tt> TestReport[] getChildrenReports();
0
new HashSet<>(Arrays.asList(new String[]{ HOST_COMPONENT_CLUSTER_NAME_PROPERTY_ID, HOST_COMPONENT_SERVICE_NAME_PROPERTY_ID, HOST_COMPONENT_COMPONENT_NAME_PROPERTY_ID, HOST_COMPONENT_HOST_NAME_PROPERTY_ID})); final Set<ServiceComponentHostRequest> requests = new HashSet<>(); final Set<ServiceComponentHostRequest> requests = new HashSet<>(); final Set<ServiceComponentHostRequest> requests = new HashSet<>(); Set<Resource> resources = new HashSet<>(); Set<String> unsupportedProperties = new HashSet<>(); Map<String, Object> installProperties = new HashMap<>(); Map<String, Object> startProperties = new HashMap<>(); Predicate installedStatePredicate = new EqualsPredicate<>(HOST_COMPONENT_DESIRED_STATE_PROPERTY_ID, "INSTALLED"); new ArrayList<>(); Predicate componentNameEquals = new EqualsPredicate<>(HOST_COMPONENT_COMPONENT_NAME_PROPERTY_ID, installOnlyComponent); Map<String, Map<State, List<ServiceComponentHost>>> changedScHosts = new HashMap<>(); Collection<ServiceComponentHost> ignoredScHosts = new ArrayList<>(); Set<String> clusterNames = new HashSet<>(); Map<String, Map<String, Map<String, Set<String>>>> requestClusters = new HashMap<>(); Map<ServiceComponentHost, State> directTransitionScHosts = new HashMap<>(); clusterServices = new HashMap<>(); serviceComponents = new HashMap<>(); componentHosts = new HashSet<>(); final Set<ServiceComponentHostRequest> requests = new HashSet<>(); Map<String, Object> updateRequestProperties = new HashMap<>();
0
import org.apache.sshd.common.FactoryManagerUtils; FactoryManagerUtils.updateProperty(sshd, ServerFactoryManager.WELCOME_BANNER, WELCOME); FactoryManagerUtils.updateProperty(sshd, ServerFactoryManager.AUTH_METHODS, "publickey,password publickey,keyboard-interactive");
0
public Rectangle2D getPaintedBounds2D(){
0
* Licensed to the Apache Software Foundation (ASF) under one or more * contributor license agreements. See the NOTICE file distributed with * this work for additional information regarding copyright ownership. * The ASF licenses this file to You under the Apache License, Version 2.0 * (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at
0
import org.apache.cocoon.portal.om.CopletDefinitionFeatures; import org.apache.cocoon.portal.om.CopletInstance; * @see org.apache.cocoon.portal.coplet.adapter.CopletAdapter#login(org.apache.cocoon.portal.om.CopletInstance) * @see org.apache.cocoon.portal.coplet.adapter.impl.AbstractCopletAdapter#streamContent(org.apache.cocoon.portal.om.CopletInstance, org.xml.sax.ContentHandler) * @see org.apache.cocoon.portal.coplet.adapter.CopletAdapter#logout(org.apache.cocoon.portal.om.CopletInstance) * @see org.apache.cocoon.portal.coplet.adapter.CopletDecorationProvider#getTitle(org.apache.cocoon.portal.om.CopletInstance)
0
// Implementation methods
0
final QualityOfProtection defaultQop = QualityOfProtection.get(Property.RPC_SASL_QOP.getDefaultValue()); final QualityOfProtection defaultQop = QualityOfProtection.get(Property.RPC_SASL_QOP.getDefaultValue()); final QualityOfProtection defaultQop = QualityOfProtection.get(Property.RPC_SASL_QOP.getDefaultValue()); SaslConnectionParams params1 = testUser.doAs(new PrivilegedExceptionAction<SaslConnectionParams>() { SaslConnectionParams params2 = testUser.doAs(new PrivilegedExceptionAction<SaslConnectionParams>() { SaslConnectionParams params3 = testUser.doAs(new PrivilegedExceptionAction<SaslConnectionParams>() { SaslConnectionParams params4 = testUser.doAs(new PrivilegedExceptionAction<SaslConnectionParams>() {
0
/* * Licensed to the Apache Software Foundation (ASF) under one * or more contributor license agreements. See the NOTICE file * distributed with this work for additional information * regarding copyright ownership. The ASF licenses this file * to you under the Apache License, Version 2.0 (the * "License"); you may not use this file except in compliance * with the License. You may obtain a copy of the License at * http://www.apache.org/licenses/LICENSE-2.0 * Unless required by applicable law or agreed to in writing, * software distributed under the License is distributed on an * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY * KIND, either express or implied. See the License for the * specific language governing permissions and limitations * under the License.
1
protected static final String[] CLIP_PATH_UNITS_VALUES = {
1
* Copyright (c) 2002 The Apache Software Foundation. All rights
0
public int getVersion() { return 0; } public Header getVersionHeader() { return null; }
0
// exclude v4 siteConfig.put(PreferredVolumeChooser.TABLE_PREFERRED_VOLUMES, systemPreferredVolumes);
0
* Gets the query string. * Gets the path and query string e.g. /path/servlet?param1=true. * Gets the path encoded suitable for url like filesystem e.g. (http, webdav). * Appends query string to the uri. * Encodes a URI.
0
import javax.persistence.NamedQueries; import javax.persistence.NamedQuery; @NamedQueries({ @NamedQuery(name = "TopologyLogicalRequestEntity.findRequestIds", query = "SELECT logicalrequest.topologyRequestId from TopologyLogicalRequestEntity logicalrequest WHERE logicalrequest.id IN :ids") })
0
import org.xml.sax.*; private final String uri; private final String localName; private final String qName; private final Attributes atts; public SAXElement(String uri, String localName, String qName, Attributes atts) {
0
* @version CVS $Id: XMLFileModule.java,v 1.11 2004/01/21 16:15:19 unico Exp $ if (getLogger().isDebugEnabled()) { getLogger().debug("Missing 'file' child element at "+modeConf.getLocation()); }
0
this.hasBufferedInput = this.inbuf.hasData();
0
import java.util.Map; public Map<String, Quota> fetchQuotas() { return quotaStore.fetchQuotas();
0
import java.util.concurrent.ScheduledExecutorService; import org.apache.sshd.common.FactoryManager; import org.apache.sshd.common.FactoryManagerUtils; public static final String DEFAULT_KEEP_ALIVE_HEARTBEAT_STRING = "[email protected]"; public static final long DEFAULT_HEARTBEAT_INTERVAL = 0L; long interval = FactoryManagerUtils.getLongProperty(session, ClientFactoryManager.HEARTBEAT_INTERVAL, DEFAULT_HEARTBEAT_INTERVAL); if (interval > 0L) { FactoryManager manager = session.getFactoryManager(); ScheduledExecutorService service = manager.getScheduledExecutorService(); service.scheduleAtFixedRate(new Runnable() { public void run() { sendHeartBeat(); } }, interval, interval, TimeUnit.MILLISECONDS); log.debug("startHeartbeat - started at interval={}", interval); String request = FactoryManagerUtils.getStringProperty(session, ClientFactoryManager.HEARTBEAT_REQUEST, DEFAULT_KEEP_ALIVE_HEARTBEAT_STRING); log.info("Error sending keepalive message=" + request, e);
0
/* * Licensed to the Apache Software Foundation (ASF) under one * or more contributor license agreements. See the NOTICE file * distributed with this work for additional information * regarding copyright ownership. The ASF licenses this file * to you under the Apache License, Version 2.0 (the * "License"); you may not use this file except in compliance * with the License. You may obtain a copy of the License at * * http://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, * software distributed under the License is distributed on an * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY * KIND, either express or implied. See the License for the * specific language governing permissions and limitations * under the License. */ package org.apache.felix.dm.annotation.api; import java.lang.annotation.ElementType; import java.lang.annotation.Retention; import java.lang.annotation.RetentionPolicy; import java.lang.annotation.Target; /** * This annotation can be used to be notified when a component is unregistered from the registry. * At this point, the component has been unregistered from the OSGI registry (if it provides some services). * The method must not take any parameters. * * @author <a href="mailto:[email protected]">Felix Project Team</a> */ @Retention(RetentionPolicy.CLASS) @Target(ElementType.METHOD) public @interface Unregistered { }
0
* Licensed to the Apache Software Foundation (ASF) under one or more * contributor license agreements. See the NOTICE file distributed with * this work for additional information regarding copyright ownership. * The ASF licenses this file to You under the Apache License, Version 2.0 * (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at
0
import org.apache.accumulo.cluster.ClusterUser; ClusterUser user = getAdminUser(); conn.securityOperations().grantTablePermission(user.getPrincipal(), ReplicationTable.NAME, TablePermission.WRITE);
0
for (final DynaProperty propertie : properties) { for (final DynaProperty propertie : properties) { for (final DynaProperty propertie : properties) { for (final DynaProperty propertie : properties) {
0
import org.apache.zookeeper.common.Time; /** * if (lastTime + interval > Time.currentElapsedTime()) lastTime = Time.currentElapsedTime();
0
import com.google.common.util.concurrent.Uninterruptibles; Process _exec(Class<?> clazz, ServerType serverType, Map<String,String> configOverrides, String... args) throws IOException { if (configOverrides != null && !configOverrides.isEmpty()) { File siteFile = File.createTempFile("accumulo-site", ".xml", config.getConfDir()); Map<String,String> confMap = new HashMap<>(); confMap.putAll(config.getSiteConfig()); confMap.putAll(configOverrides); writeConfig(siteFile, confMap.entrySet()); jvmOpts.add("-Dorg.apache.accumulo.config.file=" + siteFile.getName()); } Uninterruptibles.sleepUninterruptibly(1, TimeUnit.SECONDS);
1
static class GroupByKeyTranslator extends TransformPayloadTranslator.WithDefaultRehydration<GroupByKey<?, ?>> { return FunctionSpec.newBuilder().setUrn(getUrn(transform.getTransform())).build(); @Override public Map<String, TransformPayloadTranslator> getTransformRehydrators() { return Collections.emptyMap(); }
0
repoVersionEntity.addRepoOsEntities(createTestOperatingSystems());
0
* $Header: /home/jerenkrantz/tmp/commons/commons-convert/cvs/home/cvs/jakarta-commons//collections/src/java/org/apache/commons/collections/decorators/Attic/AbstractCollectionDecorator.java,v 1.3 2003/05/09 16:37:30 scolebourne Exp $ * @version $Revision: 1.3 $ $Date: 2003/05/09 16:37:30 $ protected final Collection collection;
0
final class Histogram implements cz.seznam.euphoria.core.client.accumulators.Histogram, Snapshotable<Map<Long, Long>> {
0
import org.apache.beam.vendor.guava.v26_0_jre.com.google.common.collect.ImmutableList;
0