Diff
stringlengths 5
2k
| FaultInducingLabel
int64 0
1
|
---|---|
jsonContent.put("serviceName", serviceName);
jsonContent.put("role", componentName); | 0 |
public class DefaultFileSystemConfigBuilder extends FileSystemConfigBuilder {
public static DefaultFileSystemConfigBuilder getInstance() {
*
throws FileSystemException {
public UserAuthenticator getUserAuthenticator(final FileSystemOptions opts) {
abstract static class DefaultFileSystem implements FileSystem {
protected Class<? extends FileSystem> getConfigClass() { | 1 |
// ----- Object overrides --------------------------------------------------
@Override
public String toString() {
StringBuilder sb = new StringBuilder();
for (Predicate predicate : predicates) {
boolean arrayPredicate = predicate instanceof ArrayPredicate;
if (sb.length() > 0) {
sb.append(" ").append(getOperator()).append(" ");
}
if (arrayPredicate) {
sb.append("(").append(predicate).append(")");
} else {
sb.append(predicate);
}
}
return sb.toString();
} | 0 |
public void consume(final ByteBuffer src) throws IOException {
entityConsumer.consume(src); | 0 |
reader = microbatchSource.getOrCreateReader(runtimeContext.getPipelineOptions(),
checkpointMark); | 0 |
* any, must include the following acknowledgement:
* Alternately, this acknowledgement may appear in the software itself,
* if and wherever such third-party acknowledgements normally appear.
* permission of the Apache Software Foundation. | 0 |
import static org.junit.Assert.fail;
@Test
public void testLegalCharacters() {
new Authorizations("_");
new Authorizations(".");
new Authorizations("A_/a.QO0D-l1");
new Authorizations("/");
new Authorizations("a");
new Authorizations("A");
try {
new Authorizations("|");
fail("Did not throw");
} catch (Exception ex) {
// ignored
}
}
| 0 |
import org.apache.sshd.common.util.io.LoggingFilterOutputStream; | 0 |
import static org.apache.accumulo.core.security.ColumnVisibility.quote;
import static org.junit.Assert.assertEquals;
@Test
public void testToString() {
ColumnVisibility cv = new ColumnVisibility(quote("a"));
assertEquals("[a]", cv.toString());
// multi-byte
cv = new ColumnVisibility(quote("五"));
assertEquals("[\"五\"]", cv.toString());
} | 0 |
public <T> boolean matches(final T node, final NodeHandler<T> handler,
final String criterion)
public <T> boolean matches(final T node, final NodeHandler<T> handler,
final String criterion) | 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.classfile;
import java.io.DataInputStream;
import java.io.IOException;
import org.apache.bcel.Constants;
/**
* represents an annotation that is represented in the class file
* and is provided to the JVM.
*
* @version $Id: RuntimeVisibleAnnotations
* @author <A HREF="mailto:[email protected]">D. Brosius</A>
* @since 5.2
*/
public class RuntimeVisibleAnnotations extends Annotations {
/**
* @param name_index Index pointing to the name <em>Code</em>
* @param length Content length in bytes
* @param file Input stream
* @param constant_pool Array of constants
*/
RuntimeVisibleAnnotations(int name_index, int length, DataInputStream file,
ConstantPool constant_pool) throws IOException {
super(Constants.ATTR_RUNTIME_VISIBLE_ANNOTATIONS, name_index, length, file, constant_pool);
}
/**
* @return deep copy of this attribute
*/
public Attribute copy( ConstantPool constant_pool ) {
Annotations c = (Annotations) clone();
return c;
}
} | 0 |
* Get the cluster id associated with the request. Can be <code>null</code>.
* @return associated cluster id
public Long getClusterId(); | 0 |
* any, must include the following acknowledgement:
* Alternately, this acknowledgement may appear in the software itself,
* if and wherever such third-party acknowledgements normally appear.
* permission of the Apache Software Foundation. | 0 |
public Jira87TestCase(final String name) {
public static void main(final String[] args) {
final Jira87BeanFactory.PublicMappedInterface bean = Jira87BeanFactory.createMappedPropertyBean();
} catch (final Throwable t) { | 0 |
import org.apache.ambari.server.state.stack.upgrade.UpgradeScope;
private UpgradeScope m_scope = UpgradeScope.ANY;
public void setScope(UpgradeScope scope) {
m_scope = scope;
}
public boolean isScoped(UpgradeScope scope) {
return m_scope.isScoped(scope);
} | 0 |
package org.apache.felix.dm.impl.index; | 0 |
* @version $Id: SoundexTest.java,v 1.17 2004/04/19 01:14:29 ggregory Exp $ | 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.commons.bcel6.Const;
if (attribute.getTag() == Const.ATTR_CONSTANT_VALUE) { | 0 |
ServiceComponentHost createNew(ServiceComponent serviceComponent, String hostName); | 0 |
* $Header: /home/jerenkrantz/tmp/commons/commons-convert/cvs/home/cvs/jakarta-commons//digester/src/test/org/apache/commons/digester/RulesBaseTestCase.java,v 1.6 2002/07/10 18:12:33 rdonkin Exp $
* $Revision: 1.6 $
* $Date: 2002/07/10 18:12:33 $
* @version $Revision: 1.6 $ $Date: 2002/07/10 18:12:33 $
// Test wildcard tail matching at the top level,
// i.e. the wildcard is nothing
digester.addRule("*/a", new TestRule("*/a"));
assertEquals("Wildcard tail matching rule 3",
1,
digester.getRules().match(null,"a").size());
assertEquals("Wildcard tail matching rule 3 (match too much)",
0,
digester.getRules().match(null,"aa").size()); | 0 |
* $Header: /home/jerenkrantz/tmp/commons/commons-convert/cvs/home/cvs/jakarta-commons//collections/src/java/org/apache/commons/collections/BeanMap.java,v 1.19 2003/05/11 14:15:23 scolebourne Exp $
* Copyright (c) 2001-2003 The Apache Software Foundation. All rights
* @version $Revision: 1.19 $ $Date: 2003/05/11 14:15:23 $ | 0 |
/** Utilities for dealing with movement of files from object stores and workers. */
public static String copyFileFromWorkerToGCS(
SubProcessConfiguration configuration, Path fileToUpload) throws Exception {
LOG.error(
String.format("Error copying file from %s to %s", sourceFile, destinationFile), ex);
LOG.info(
String.format(
"Moving File %s to %s ",
execuableFile.getSourceGCSLocation(), execuableFile.getDestinationLocation()));
LOG.warn(
String.format(
"Overwriting file %s, should only see this once per worker.",
execuableFile.getDestinationLocation()));
*
LOG.warn(
String.format(
" Tried to create folder %s which already existsed, this should not happen!",
configuration.getWorkerPath()),
ex); | 1 |
String TAG_TEXTPATH = "textPath";
String ATTR_METHOD = "method";
String ATTR_SPACING = "spacing";
String ATTR_START_OFFSET = "startOffset";
String ATTR_TEXT_LENGTH = "textLength";
String VALUE_ALIGN = "align";
String VALUE_EXACT = "exact";
String VALUE_STRETCH = "stretch"; | 0 |
throw new RuntimeException("COMPACTION_FINISH (without preceding"
+ " COMPACTION_START) not followed by successful minor compaction");
throw new RuntimeException("COMPACTION_FINISH (without preceding"
+ " COMPACTION_START) is not followed by a successful minor compaction."); | 0 |
log(ioex);
log(ioex);
protected void log(Exception ex) { | 0 |
bind(LeaderRedirectFilter.class).in(Singleton.class);
filter("/scheduler").through(LeaderRedirectFilter.class); | 0 |
* @version $Id$ | 0 |
public interface IModelElement extends Cloneable
{
void setMeta( Map<Object, Object> meta );
<T extends IModelElement> T getAncestor( Class<T> type );
void setProperty( String name, Object value ) throws NoSuchMethodException;
void addProperty( String name, Object value ) throws NoSuchMethodException;
void removeProperty( String name, Object value ) throws NoSuchMethodException;
Object getProperty( String name ) throws NoSuchMethodException;
Object getDefaultPropertyValue( String name );
Class<?> getPropertyType( String name ) throws NoSuchMethodException; | 0 |
import org.apache.http.client.protocol.HttpClientContext;
HttpClientContext clientContext = HttpClientContext.adapt(context);
AuthState targetAuthState = clientContext.getTargetAuthState();
context.setAttribute(ClientContext.TARGET_AUTH_STATE, targetAuthState);
AuthState proxyAuthState = clientContext.getProxyAuthState();
context.setAttribute(ClientContext.PROXY_AUTH_STATE, proxyAuthState);
Object userToken = clientContext.getUserToken();
managedConn, route.getTargetHost(), route.getLocalAddress(), context);
managedConn, route.getProxyHost(), route.getLocalAddress(), context);
this.connManager.upgrade(managedConn, route.getTargetHost(), context);
String authority = target.toHostString();
managedConn, route.getProxyHost(), route.getLocalAddress(), context);
target = new HttpHost(
target.getHostName(),
route.getTargetHost().getPort(),
target.getSchemeName()); | 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.
*/
package org.apache.cocoon.forms.formmodel;
/**
* A container {@link Widget} which can hold zero or more child widgets.
*
* @version $Id$
*/
public class Group extends AbstractContainerWidget {
private static final String GROUP_EL = "group";
private final GroupDefinition definition;
public Group(GroupDefinition definition) {
super(definition);
this.definition = definition;
}
public WidgetDefinition getDefinition() {
return this.definition;
}
/**
* @return "group"
*/
public String getXMLElementName() {
return GROUP_EL;
}
} | 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.beam.sdk.transforms.DoFn;
return input.apply(ParDo.of(new DoFn<TimestampedValue<T>, T>() {
@ProcessElement | 0 |
import static org.apache.felix.sigil.common.runtime.Runtime.ADDRESS_PROPERTY;
import static org.apache.felix.sigil.common.runtime.Runtime.PORT_PROPERTY;
import java.util.Properties;
import org.apache.felix.sigil.common.runtime.cli.CommandLine;
import org.apache.felix.sigil.common.runtime.cli.HelpFormatter;
import org.apache.felix.sigil.common.runtime.cli.Options;
import org.apache.felix.sigil.common.runtime.cli.ParseException;
import org.apache.felix.sigil.common.runtime.cli.Parser;
import org.apache.felix.sigil.common.runtime.cli.PosixParser;
options.addOption( "s", "startLevel", true, "Start level for framework" );
framework.start();
config.put( "org.osgi.framework.storage.clean", "onFirstInit" );
if ( cl.hasOption( 's' ) )
config.put( "org.osgi.framework.startlevel.beginning", cl.getOptionValue( 's' ) );
Properties props = new Properties();
props.put( ADDRESS_PROPERTY, line.getOptionValue( 'a' ) );
props.put( PORT_PROPERTY, line.getOptionValue( 'p' ) );
server.start( props ); | 0 |
public StructDump(@CacheTemplates boolean cacheTemplates, Storage storage) { | 0 |
final byte[] beginning = "beginning; ".getBytes(Consts.ASCII); | 0 |
package org.apache.commons.dbcp2; | 1 |
* Copyright (C) 2015 Google Inc. | 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 |
OutputStream stdout = getOutputStream(); | 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 |
@Override
@Override
@Override
@Override | 0 |
import org.apache.hc.core5.http.impl.IncomingEntityDetails;
final EntityDetails entityDetails = endStream ? null : new IncomingEntityDetails(request, -1); | 0 |
.pruningPrefix("com.google.bigtable.v1")
.pruningPrefix("com.google.cloud.bigtable.config")
.pruningPrefix("com.google.cloud.bigtable.grpc.Bigtable*Name") | 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 |
* 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 |
package org.apache.bcel;
import org.apache.bcel.classfile.JavaClass; | 0 |
* @param ih where to append the instruction list | 0 |
import org.apache.http.protocol.HttpProcessor;
* Returns {@link HttpProcessor} implementation to be used to process
* HTTP request and response messages for protocol compliance.
*
* @return HTTP protocol processor.
*/
HttpProcessor getHttpProcessor();
/**
* Returns {@link ConnectionReuseStrategy} implementation to be used | 0 |
port = TServerUtils.startTServer(result, processor, this.getClass().getSimpleName(), "GC Monitor Service", 2, 1000, maxMessageSize).address.getPort(); | 0 |
public class ClassCacheImpl
implements ClassCache
{
public void setClassInspector( ClassCacheInspector inspector )
for ( int i = 0; i < _table.length; i++ )
public final Object get( Class key )
for ( Entry entry = _table[i]; entry != null; entry = entry.next )
if ( entry.key == key )
public final Object put( Class key, Object value )
if ( _classInspector != null && !_classInspector.shouldCache( key ) )
if ( entry == null )
_table[i] = new Entry( key, value );
}
else
if ( entry.key == key )
}
else
while ( true )
if ( entry.key == key )
}
else
if ( entry.next == null )
entry.next = new Entry( key, value );
return "ClassCacheImpl[" + "_table=" + ( _table == null ? null : Arrays.asList( _table ) ) + '\n'
+ ", _classInspector=" + _classInspector + '\n' + ", _size=" + _size + '\n' + ']'; | 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
* <p/>
* http://www.apache.org/licenses/LICENSE-2.0
* <p/>
* 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.atlas.omag.application;
import org.apache.log4j.BasicConfigurator;
import org.apache.log4j.Logger;
import org.springframework.boot.SpringApplication;
import org.springframework.boot.autoconfigure.SpringBootApplication;
import org.springframework.context.annotation.ComponentScan;
import org.springframework.context.annotation.Configuration;
@SpringBootApplication
@ComponentScan({"org.apache.atlas.omag.admin.server", "org.apache.atlas.omrs.rest.server"})
@Configuration
public class OMAGApplication
{
public static void main(String[] args)
{
BasicConfigurator.configure();
SpringApplication.run(OMAGApplication.class, args);
}
} | 0 |
import org.junit.Assert; | 0 |
sslsock.connect(remoteAddress, connTimeout); | 0 |
return GenericUtils.map(paths, p -> new ClientIdentityFileWatcher(p, loader, provider, strict)); | 0 |
final PCollection<Long> estimate = input.apply(ApproximateUnique.globally(sampleSize));
final PCollection<Long> approximate = input.apply(ApproximateUnique.globally(sampleSize));
input.apply(Distinct.create()).apply(Count.globally()).apply(View.asSingleton());
final PCollection<Long> estimate = input.apply(ApproximateUnique.globally(1000));
final PCollection<Long> estimate = input.apply(ApproximateUnique.globally(sampleSize));
final PCollection<KV<Long, Long>> counts = input.apply(ApproximateUnique.perKey(sampleSize)); | 0 |
synchronized (lock) {
this.size = size;
this.maxSize = size;
this.packetSize = packetSize;
lock.notifyAll();
} | 0 |
import uno.perk.forward.Forward;
@Forward({
SchedulerStore.class,
CronJobStore.class,
TaskStore.class,
LockStore.class,
QuotaStore.class,
AttributeStore.class,
JobUpdateStore.class})
class WriteAheadStorage extends WriteAheadStorageForwarder implements | 0 |
* $Header: /home/jerenkrantz/tmp/commons/commons-convert/cvs/home/cvs/jakarta-commons//beanutils/src/java/org/apache/commons/beanutils/converters/CharacterConverter.java,v 1.3 2002/07/13 02:22:08 craigmcc Exp $
* $Revision: 1.3 $
* $Date: 2002/07/13 02:22:08 $
* @version $Revision: 1.3 $ $Date: 2002/07/13 02:22:08 $
if (value instanceof Character) {
return (value);
}
return (new Character(value.toString().charAt(0))); | 0 |
DistributedTrace.enable("localhost", "testTrace", getConnectionInfo().getProperties()); | 0 |
* $Header: /home/jerenkrantz/tmp/commons/commons-convert/cvs/home/cvs/jakarta-commons//jxpath/src/java/org/apache/commons/jxpath/ri/pointers/Attic/PropertyPointer.java,v 1.4 2002/04/10 03:40:20 dmitri Exp $
* $Revision: 1.4 $
* $Date: 2002/04/10 03:40:20 $
* @version $Revision: 1.4 $ $Date: 2002/04/10 03:40:20 $
protected abstract boolean isActualProperty();
public boolean isActual(){
if (!isActualProperty()){
return false;
}
return super.isActual();
}
if (getBean() == null){
buffer.append("null");
}
else {
buffer.append(getBean().getClass().getName());
} | 0 |
return new LazyMap<>(map, factory);
return new LazyMap<>(map, factory); | 1 |
@Override
@Override
@Override
@Override | 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 |
* $Header: /home/jerenkrantz/tmp/commons/commons-convert/cvs/home/cvs/jakarta-commons//codec/src/java/org/apache/commons/codec/binary/Base64.java,v 1.7 2003/07/30 22:34:17 tobrien Exp $
* $Revision: 1.7 $
* $Date: 2003/07/30 22:34:17 $
* @author <a href="mailto:[email protected]">Daniel Rall</a>
* @author <a href="mailto:[email protected]">Martin Redington</a>
* @author Tim O'Brien
* @version $Id: Base64.java,v 1.7 2003/07/30 22:34:17 tobrien Exp $ | 0 |
package org.apache.commons.jocl2; | 1 |
import com.google.common.annotations.VisibleForTesting;
@VisibleForTesting
AtlasEntityWithExtInfo createOrUpdateTopic(String topic) throws Exception {
@VisibleForTesting
AtlasEntity getTopicEntity(String topic, AtlasEntity topicEntity) {
@VisibleForTesting
static String getTopicQualifiedName(String clusterName, String topic) {
@VisibleForTesting
AtlasEntityWithExtInfo findEntityInAtlas(String typeName, String qualifiedName) throws Exception {
@VisibleForTesting
AtlasEntityWithExtInfo createEntityInAtlas(AtlasEntityWithExtInfo entity) throws Exception {
@VisibleForTesting
AtlasEntityWithExtInfo updateEntityInAtlas(AtlasEntityWithExtInfo entity) throws Exception { | 0 |
import org.apache.sshd.util.test.BaseTestSupport; | 0 |
* @param baseURI the URI where the XML instance was stored
public Transforms(Element element, String baseURI)
super(element, baseURI); | 0 |
import com.twitter.mesos.gen.GetJobsResponse;
GetJobsResponse getJobs(String ownerRole);
| 0 |
@Override
@Override | 0 |
+ self.getQuorumAddress().getPort(), e);
LOG.info("NEWLEADER proposal has Zxid of "
+ Long.toHexString(newLeaderProposal.packet.getZxid()));
LOG.warn("Ignoring unexpected exception during close",e); | 0 |
/**
* Copyright 2016 Seznam a.s.
*
* 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.
*/ | 0 |
Map<String, Map<String, String>> kerberosConfigurations = new HashMap<>();
clusterEnvProperties = new HashMap<>();
Map<String, Set<String>> configurationsToRemove = new HashMap<>();
configurationsToRemove.put(entry.getKey(), new HashSet<>(entry.getValue().keySet()));
Set<String> visitedServices = new HashSet<>(); | 1 |
* 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
* 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 |
public DefaultServerIODispatch(
final NHttpServiceHandler handler,
final SSLContext sslcontext,
final HttpParams params) {
this(handler, sslcontext, null, params);
}
| 0 |
import org.apache.beam.sdk.options.Default;
*
* Define expected output file checksum to verify WordCount pipeline result with customized input.
@Default.String("c04722202dee29c442b55ead54c6000693e85e77")
String getOutputChecksum();
void setOutputChecksum(String value);
new FileChecksumMatcher(options.getOutputChecksum(), options.getOutput() + "*")); | 0 |
import java.util.Objects;
super(Objects.toString(acceptanceAddress, ""));
| 0 |
return new KerberosToken(getAdminPrincipal(), keytab, true); | 1 |
if (entry.mustRevalidate()
|| (isSharedCache() && entry.proxyRevalidate())) {
return new BasicHttpResponse(HTTP_1_1, HttpStatus.SC_GATEWAY_TIMEOUT, "Gateway Timeout");
} else {
HttpResponse response = responseGenerator.generateResponse(entry);
response.addHeader(HeaderConstants.WARNING, "111 Revalidation Failed - " + ioex.getMessage());
log.debug("111 revalidation failed due to exception: " + ioex);
return response;
} | 0 |
* Copyright (c) OSGi Alliance (2004, 2016). All Rights Reserved.
* @author $Id: b3072b2d058e70389a52e342ed5f8647b930b8f1 $
* The Framework has stopped and the framework requires a new class loader
* to restart.
* <p>
* This event is fired when the Framework has been stopped because of a stop
* operation on the system bundle and the framework requires a new class
* loader to be used to restart. For example, if a framework extension
* bundle has been refreshed. The source of this event is the System Bundle.
*
* @since 1.9
*/
public final static int STOPPED_SYSTEM_REFRESHED = 0x00000400;
/** | 1 |
import org.apache.batik.css.engine.CSSEngineEvent;
import org.w3c.dom.events.MutationEvent;
* Interface for objects interested in being notified of updates.
* Invoked when an MutationEvent of type 'DOMAttrModified' is fired.
*/
void handleDOMAttrModifiedEvent(MutationEvent evt);
/**
* Invoked when an MutationEvent of type 'DOMNodeInserted' is fired.
void handleDOMNodeInsertedEvent(MutationEvent evt);
* Invoked when an MutationEvent of type 'DOMNodeRemoved' is fired.
void handleDOMNodeRemovedEvent(MutationEvent evt);
/**
* Invoked when an CSSEngineEvent is fired.
*/
void handleCSSEngineEvent(CSSEngineEvent evt);
| 0 |
*
*
*
/**
*
* @version $Revision: 1.5 $
//-------------------------------------------------------------------------
/**
* Sets the name of the method to invoke on the bean.
//-------------------------------------------------------------------------
| 1 |
* Copyright 2002-2005 The Apache Software Foundation. | 0 |
private Map m_exportedPackages = new HashMap();
m_exportedPackages.put( packageName, artifacts );
protected Map getExportedPackages()
return m_exportedPackages; | 0 |
Calendar working = (Calendar) serverTime.clone();
Calendar now = (Calendar) serverTime.clone();// Copy this, because we may change it
now.setTimeZone(this.getServerTimeZone());
String year = Integer.toString(now.get(Calendar.YEAR));
String timeStampStrPlusYear = timestampStr + " " + year;
SimpleDateFormat hackFormatter = new SimpleDateFormat(recentDateFormat.toPattern() + " yyyy",
recentDateFormat.getDateFormatSymbols());
hackFormatter.setLenient(false);
hackFormatter.setTimeZone(recentDateFormat.getTimeZone());
ParsePosition pp = new ParsePosition(0);
parsed = hackFormatter.parse(timeStampStrPlusYear, pp);
// Check if we parsed the full string, if so it must have been a short date originally
if (parsed != null && pp.getIndex() == timeStampStrPlusYear.length()) {
if (working.after(now)) { // must have been last year instead
working.add(Calendar.YEAR, -1);
return working;
ParsePosition pp = new ParsePosition(0);
parsed = defaultDateFormat.parse(timestampStr, pp);
// note, length checks are mandatory for us since
// SimpleDateFormat methods will succeed if less than
// full string is matched. They will also accept,
// despite "leniency" setting, a two-digit number as
// a valid year (e.g. 22:04 will parse as 22 A.D.)
// so could mistakenly confuse an hour with a year,
// if we don't insist on full length parsing.
if (parsed != null && pp.getIndex() == timestampStr.length()) {
working.setTime(parsed);
} else {
throw new ParseException(
"Timestamp could not be parsed with older or recent DateFormat",
pp.getErrorIndex());
} | 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 |
* 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 |
import org.apache.hc.core5.annotation.Contract;
import org.apache.hc.core5.annotation.ThreadingBehavior;
@Contract(threading = ThreadingBehavior.IMMUTABLE) | 0 |
Init.init(this.getClass().getClassLoader().getResource("security-config.xml").toURI(),
this.getClass()); | 0 |
package org.apache.batik.svggen;
* @see org.apache.batik.svggen.DOMTreeManager
* @see org.apache.batik.svggen.SVGDescriptor | 0 |
public void execute(MutableStoreProvider storeProvider) {
public void execute(MutableStoreProvider storeProvider) {
public void execute(MutableStoreProvider storeProvider) {
public void execute(MutableStoreProvider storeProvider) {
public void execute(MutableStoreProvider storeProvider) {
public void execute(MutableStoreProvider storeProvider) {
public void execute(MutableStoreProvider storeProvider) {
public void execute(MutableStoreProvider storeProvider) {
public void execute(MutableStoreProvider storeProvider) {
public void execute(MutableStoreProvider storeProvider) {
public void execute(MutableStoreProvider storeProvider) { | 0 |
import com.google.gson.JsonObject;
public ViewStatus getViewStatus();
/**
* Provides information about requested Slider App.
*
* @param applicationId
* @param properties
* Identifies specific properties to show up. Provide
* <code>null</code> for default properties.
* @return
* @throws YarnException
* @throws IOException
*/
public SliderApp getSliderApp(String applicationId, Set<String> properties)
throws YarnException, IOException;
/**
* Provides list of Slider apps with requested properties populated.
*
* @param properties
* Identifies specific properties to show up. Provide
* <code>null</code> for default properties.
* @return
* @throws YarnException
* @throws IOException
*/
public List<SliderApp> getSliderApps(Set<String> properties)
throws YarnException, IOException;
/**
* Attempts to delete a Slider app. An unsuccessful attempt will result in
* exception.
*
* @param applicationId
* @throws YarnException
* @throws IOException
*/
public void deleteSliderApp(String applicationId) throws YarnException,
IOException;
public SliderAppType getSliderAppType(String appTypeId, Set<String> properties);
public List<SliderAppType> getSliderAppTypes(Set<String> properties);
public String createSliderApp(JsonObject requestJson) throws IOException, YarnException, InterruptedException; | 0 |
/** Internal implementation of the Beam runner for Apache Flink. */ | 1 |
package org.apache.beam.runners.core.construction;
/** Utilities for working with classpath resources for pipelines. */
public class PipelineResources { | 0 |
import org.apache.accumulo.core.security.thrift.SecurityErrorCode; | 0 |
proxy.read((char[])null);
proxy.read(null, 0, 0);
proxy.read((CharBuffer)null); | 0 |
public static void dumpHex(SimplifiedLog logger, Level level, String prefix, PropertyResolver resolver, char sep, byte... data) {
public static void dumpHex(SimplifiedLog logger, Level level, String prefix, char sep, int chunkSize, byte... data) {
public static <A extends Appendable> A appendHex(A sb, char sep, byte... array) throws IOException {
public static long validateInt32Value(long value, String format, Object... args) {
public static long validateUint32Value(long value, String format, Object... args) { | 0 |
* {@link org.apache.commons.fileupload.disk.DiskFileItem}. | 0 |
import org.apache.beam.sdk.transforms.PTransform;
/** A {@link RelNode} that can also give a {@link PTransform} that implements the expression. */
* A {@link BeamRelNode} is a recursive structure, the {@code BeamQueryPlanner} visits it with a
* DFS(Depth-First-Search) algorithm.
PTransform<PCollectionTuple, PCollection<Row>> toPTransform(); | 0 |
Subsets and Splits
No saved queries yet
Save your SQL queries to embed, download, and access them later. Queries will appear here once saved.