Diff
stringlengths 5
2k
| FaultInducingLabel
int64 0
1
|
---|---|
throw new BundleException("Not implemented yet."); | 0 |
* $Header: /home/jerenkrantz/tmp/commons/commons-convert/cvs/home/cvs/jakarta-commons//jelly/src/java/org/apache/commons/jelly/expression/ExpressionFactory.java,v 1.7 2003/10/09 21:21:27 rdonkin Exp $
* $Revision: 1.7 $
* $Date: 2003/10/09 21:21:27 $
* 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.
* $Id: ExpressionFactory.java,v 1.7 2003/10/09 21:21:27 rdonkin Exp $
* @version $Revision: 1.7 $ | 0 |
public class R4Wire implements IWire
/* (non-Javadoc)
* @see org.apache.felix.framework.searchpolicy.IWire#getImportingModule()
*/
public IModule getImporter()
/* (non-Javadoc)
* @see org.apache.felix.framework.searchpolicy.IWire#getExportingModule()
*/
public IModule getExporter()
/* (non-Javadoc)
* @see org.apache.felix.framework.searchpolicy.IWire#getExport()
*/
/* (non-Javadoc)
* @see org.apache.felix.framework.searchpolicy.IWire#getClass(java.lang.String)
*/
/* (non-Javadoc)
* @see org.apache.felix.framework.searchpolicy.IWire#getResource(java.lang.String)
*/ | 0 |
import java.util.ListIterator;
if (MapUtils.isEmpty(softRefVal)) {
return softRefVal;
} else {
if (CollectionUtils.isEmpty(softRefVal)) {
return softRefVal;
} else {
if (CollectionUtils.isEmpty(arrayElements)) {
return arrayElements;
}
| 0 |
import org.apache.xml.security.stax.securityToken.SecurityToken;
public class DefaultTokenSecurityEvent extends TokenSecurityEvent<SecurityToken> { | 0 |
// Implementstion methods | 0 |
<T> ValueState<T> bindValue(String id, StateSpec<ValueState<T>> spec, Coder<T> coder);
<T> BagState<T> bindBag(String id, StateSpec<BagState<T>> spec, Coder<T> elemCoder);
<T> SetState<T> bindSet(String id, StateSpec<SetState<T>> spec, Coder<T> elemCoder);
String id, StateSpec<WatermarkHoldState> spec, TimestampCombiner timestampCombiner); | 1 |
* thus the root element should be a <code>fd:selection-list</code>
* attribute and the contents of the <code>fd:label</code> child element
* of every <code>fd:item</code> in the list. | 0 |
* @version $Id$
public class DualHashBidiMapTest<K, V> extends AbstractBidiMapTest<K, V> {
return BulkTest.makeSuite(DualHashBidiMapTest.class);
public DualHashBidiMapTest(String testName) {
return new String[] { "DualHashBidiMapTest.bulkTestInverseMap.bulkTestInverseMap" }; | 0 |
suite.addTest(CustomValidatorResourcesTest.suite());
suite.addTestSuite(GenericValidatorTest.class);
suite.addTest(ParameterTest.suite());
suite.addTest(ValidatorResultsTest.suite()); | 0 |
if (recdPort == port) { // must not use the control port here
TFTPErrorPacket error = new TFTPErrorPacket(recdAddress,
recdPort, TFTPErrorPacket.UNKNOWN_TID,
"INCORRECT SOURCE PORT");
bufferedSend(error);
throw new IOException("Incorrect source port ("+recdPort+") in request reply.");
}
if (recdPort == port) { // must not use the control port here
TFTPErrorPacket error = new TFTPErrorPacket(recdAddress,
recdPort, TFTPErrorPacket.UNKNOWN_TID,
"INCORRECT SOURCE PORT");
bufferedSend(error);
throw new IOException("Incorrect source port ("+recdPort+") in request reply.");
} | 0 |
import static org.apache.ambari.server.controller.internal.HostComponentResourceProvider.STALE_CONFIGS;
String predicateProperty = STALE_CONFIGS + "=true";
if (predicateEntry.getKey().equals(STALE_CONFIGS)) { | 0 |
package org.apache.beam.sdk.extensions.sql;
import static org.apache.beam.sdk.extensions.sql.rel.BeamJoinRelBoundedVsBoundedTest.ORDER_DETAILS1;
import static org.apache.beam.sdk.extensions.sql.rel.BeamJoinRelBoundedVsBoundedTest.ORDER_DETAILS2;
import org.apache.beam.sdk.extensions.sql.schema.BeamSqlRow;
import org.apache.beam.sdk.extensions.sql.schema.BeamSqlRowCoder;
import org.apache.beam.sdk.extensions.sql.schema.BeamSqlRowType; | 0 |
import org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ReplicationColumnFamily;
private static final HashSet<ColumnFQ> validColumnQuals = new HashSet<ColumnFQ>(Arrays.asList(
TabletsSection.ServerColumnFamily.LOCK_COLUMN, TabletsSection.ServerColumnFamily.FLUSH_COLUMN, TabletsSection.ServerColumnFamily.COMPACT_COLUMN));
private static final HashSet<Text> validColumnFams = new HashSet<Text>(Arrays.asList(TabletsSection.BulkFileColumnFamily.NAME,
ChoppedColumnFamily.NAME, ClonedColumnFamily.NAME, ReplicationColumnFamily.NAME)); | 0 |
/**
* The shape associated with this painter
*/
protected Shape shape;
public CompositeShapePainter(Shape shape) {
if(shape == null){
throw new IllegalArgumentException();
}
this.shape = shape;
}
if(this.shape != shapePainter.getShape()){
shapePainter.setShape(shape);
}
public void paint(Graphics2D g2d,
painters[i].paint(g2d, ctx);
* Returns the area painted by this painter
public Shape getPaintedArea(GraphicsNodeRenderContext rc){
paintedArea.append(painters[i].getPaintedArea(rc), false);
/**
* Sets the Shape this painter is associated with.
* @param shape new shape this painter should be associated with.
* should not be null.
*/
public void setShape(Shape shape){
if (painters != null) {
for (int i=0; i < count; ++i) {
painters[i].setShape(shape);
}
}
this.shape = shape;
}
/**
* Gets the Shape this painter is associated with.
*
* @return shape associated with this Painter.
*/
public Shape getShape(){
return shape;
} | 0 |
import cz.seznam.euphoria.core.client.dataset.windowing.Window;
public class Join<LEFT, RIGHT, KEY, OUT, W extends Window>
Either<LEFT, RIGHT>, KEY, Pair<KEY, OUT>, W,
Join<LEFT, RIGHT, KEY, OUT, W>>
public <W extends Window>
OutputBuilder<LEFT, RIGHT, KEY, OUT, W>
windowBy(Windowing<Either<LEFT, RIGHT>, W> windowing)
LEFT, RIGHT, KEY, OUT, W extends Window>
private final Windowing<Either<LEFT, RIGHT>, W> windowing;
Windowing<Either<LEFT, RIGHT>, W> windowing) {
Join<LEFT, RIGHT, KEY, OUT, W> join =
Windowing<Either<LEFT, RIGHT>, W> windowing,
OUT, JoinState, W> reduce; | 0 |
this.typeSystem = TypeSystem.getInstance(); | 0 |
* $Id$
*
package org.apache.commons.ognl.internal;
| 0 |
import org.apache.cocoon.core.Settings; | 0 |
import com.google.cloud.dataflow.sdk.io.TextIO.Read;
import com.google.cloud.dataflow.sdk.transforms.Create;
* {@code PBegin} is used as the "input" to a root {@link PTransform} that is the first
* operation in a {@link Pipeline}, such as {@link Read TextIO.Read} or {@link Create}.
* <p>Typically created by calling {@link Pipeline#begin} on a Pipeline. | 0 |
* Autogenerated by Thrift Compiler (0.12.0)
@javax.annotation.Generated(value = "Autogenerated by Thrift Compiler (0.12.0)")
public @org.apache.thrift.annotation.Nullable java.util.Set<java.nio.ByteBuffer> authorizations; // optional
public @org.apache.thrift.annotation.Nullable Durability durability; // optional
@org.apache.thrift.annotation.Nullable
@org.apache.thrift.annotation.Nullable
@org.apache.thrift.annotation.Nullable
@org.apache.thrift.annotation.Nullable
public ConditionalWriterOptions setAuthorizations(@org.apache.thrift.annotation.Nullable java.util.Set<java.nio.ByteBuffer> authorizations) {
@org.apache.thrift.annotation.Nullable
public ConditionalWriterOptions setDurability(@org.apache.thrift.annotation.Nullable Durability durability) {
public void setFieldValue(_Fields field, @org.apache.thrift.annotation.Nullable java.lang.Object value) {
@org.apache.thrift.annotation.Nullable
@org.apache.thrift.annotation.Nullable
@org.apache.thrift.annotation.Nullable java.nio.ByteBuffer _elem107;
@org.apache.thrift.annotation.Nullable java.nio.ByteBuffer _elem112; | 0 |
package org.apache.felix.dm; | 0 |
import com.tinkerpop.blueprints.GraphQuery;
import java.util.Iterator;
@Override
public List<String> getEntityList(String entityType) throws RepositoryException {
LOG.info("Retrieving entity list for type={}", entityType);
GraphQuery query = graphService.getBlueprintsGraph().query()
.has(Constants.ENTITY_TYPE_PROPERTY_KEY, entityType);
Iterator<Vertex> results = query.vertices().iterator();
if (!results.hasNext()) {
return Collections.emptyList();
}
ArrayList<String> entityList = new ArrayList<>();
while (results.hasNext()) {
Vertex vertex = results.next();
entityList.add(vertex.<String>getProperty(Constants.GUID_PROPERTY_KEY));
}
return entityList;
}
@Override
LOG.debug("Adding typed instance {}", typedInstance.getTypeName());
typedInstance.getTypeName(), instanceVertex, fields);
LOG.debug("mapping vertex {} to struct {}", instanceVertex, attributeInfo.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 |
if (supportTrustedProxy && doAsUser != null && !doAsUser.equals(httpRequest.getRemoteUser())) { | 0 |
import static org.apache.accumulo.fate.util.UtilWaitThread.sleepUninterruptibly; | 1 |
* @version CVS $Id: ForwardRedirector.java,v 1.4 2003/06/24 15:20:28 upayavira Exp $
public class ForwardRedirector extends AbstractLogEnabled implements Redirector, PermanentRedirector {
public void permanentRedirect(boolean sessionMode, String url) throws IOException, ProcessingException {
if (getLogger().isInfoEnabled()) {
getLogger().info("Redirecting to '" + url + "'");
}
if (url.startsWith("cocoon:")) {
cocoonRedirect(sessionMode, url);
} else if (env instanceof PermanentRedirector) {
((PermanentRedirector)env).permanentRedirect(sessionMode, url);
} else {
env.redirect(sessionMode, url);
}
this.hasRedirected = true;
}
* Unconditionally redirects to a given URL, even it this redirector is part of a | 0 |
import java.nio.charset.Charset;
private static final Charset utf8 = Charset.forName("UTF8");
byte typeBytes[] = type.name().getBytes(utf8); | 0 |
* Filters files based on the suffix (what the file name ends with). This is used
/** The file name suffixes to search for. */
* Checks to see if the file name ends with the suffix.
* @return true if the file name ends with one of our suffixes | 0 |
import org.apache.accumulo.proxy.thrift.BatchScanOptions;
import org.apache.accumulo.proxy.thrift.ScanOptions;
BatchScanOptions options = new BatchScanOptions();
options.ranges = Collections.singletonList(new Range(null, false, stop, false));
String cookie = tpc.proxy().createBatchScanner(userpass, testtable, options);
BatchScanOptions opts = new BatchScanOptions();
opts.iterators = Collections.singletonList(pis);
String cookie = tpc.proxy().createBatchScanner(userpass, testtable, opts);
ScanOptions opts = new ScanOptions();
opts.range = new Range(null, false, stop, false);
String cookie = tpc.proxy().createScanner(userpass, testtable, opts);
ScanOptions opts = new ScanOptions();
opts.iterators = Collections.singletonList(pis);
String cookie = tpc.proxy().createScanner(userpass, testtable, opts);
String cookie = tpc.proxy().createBatchScanner(userpass, testtable, null);
BatchScanOptions opts = new BatchScanOptions();
opts.iterators = Collections.singletonList(pis);
String cookie = tpc.proxy().createBatchScanner(userpass, testtable, opts);
BatchScanOptions opts = new BatchScanOptions();
opts.authorizations = auths;
String cookie = tpc.proxy().createBatchScanner(userpass, testtable, opts); | 0 |
/*
* Copyright (C) 2014 Google Inc.
*
* 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.
*/
/** Defines utilities used to implement the harness that runs user code. **/
package com.google.cloud.dataflow.sdk.util.common.worker; | 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 |
private final Set<String> language;
private final Pattern lContext;
private final String logical;
private final String pattern;
private final String phoneme;
private final Pattern rContext; | 0 |
protected SolrDocumentList groupList;
groupList = new SolrDocumentList(); | 0 |
* @deprecated (4.2) use {@link org.apache.http.pool.AbstractConnPool}
* @deprecated (4.1) use {@link RouteSpecificPool#RouteSpecificPool(HttpRoute, ConnPerRoute)} | 0 |
*
*
String param = he.getName(); | 0 |
* @param eventsEnabled Whether the GVT tree should be reactive | 1 |
package org.apache.felix.sigil.eclipse.ui.internal.wizard; | 0 |
return jexl.parse(expression, null);
return jexl.parse(expression, info); | 0 |
import org.apache.commons.lang.StringUtils;
for (ServiceRequest serviceRequest : request) {
if (StringUtils.isEmpty(serviceRequest.getClusterName()) || StringUtils.isEmpty(serviceRequest.getServiceName())) {
// FIXME throw correct error
throw new AmbariException("invalid arguments");
} else {
clusters.getCluster(serviceRequest.getClusterName()).deleteService(serviceRequest.getServiceName());
}
}
return null;
| 0 |
* or more contributor license agreements. See the NOTICE file
* regarding copyright ownership. The ASF licenses this file
* with the License. You may obtain a copy of the License at
* KIND, either express or implied. See the License for the | 0 |
import org.apache.atlas.typesystem.exception.EntityNotFoundException;
import org.apache.atlas.utils.ParamChecker; | 1 |
private Reader xmlTestReader() { | 0 |
@Override
public String toString() {
final StringBuilder buf = new StringBuilder();
buf.append(this.response);
if (this.producer != null) {
buf.append(" ").append(this.producer);
}
return buf.toString();
}
| 0 |
sshPort = sshd.getPort();
acceptor.bind(new InetSocketAddress(0));
echoPort = acceptor.getLocalAddress().getPort(); | 0 |
package org.apache.accumulo.server.tabletserver.mastermessage;
import org.apache.accumulo.core.data.KeyExtent;
import org.apache.accumulo.core.master.thrift.TabletLoadState;
import org.apache.accumulo.core.master.thrift.MasterClientService.Iface;
import org.apache.accumulo.core.security.thrift.AuthInfo;
import org.apache.accumulo.core.security.thrift.ThriftSecurityException;
import org.apache.thrift.TException;
public class TabletStatusMessage implements MasterMessage {
private KeyExtent extent;
private TabletLoadState status;
public TabletStatusMessage(TabletLoadState status, KeyExtent extent)
{
this.extent = extent;
this.status = status;
}
public void send(AuthInfo auth, String serverName, Iface client) throws TException, ThriftSecurityException {
client.reportTabletStatus(null, auth, serverName, status, extent.toThrift());
}
} | 1 |
import org.apache.beam.sdk.extensions.sql.SqlTransform;
query = SqlTransform.query(queryString); | 0 |
import com.sun.jersey.client.urlconnection.URLConnectionClientHandler;
import org.apache.commons.configuration.PropertiesConfiguration;
import org.apache.hadoop.metadata.security.SecureClientUtils;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
import static org.apache.hadoop.metadata.security.SecurityProperties.TLS_ENABLED;
private static final Logger LOG = LoggerFactory.getLogger(MetadataServiceClient.class);
private WebResource service;
PropertiesConfiguration clientConfig = null;
try {
clientConfig = getClientProperties();
if (clientConfig.getBoolean(TLS_ENABLED) || clientConfig.getString("metadata.http.authentication.type") != null) {
// create an SSL properties configuration if one doesn't exist. SSLFactory expects a file, so forced to create a
// configuration object, persist it, then subsequently pass in an empty configuration to SSLFactory
SecureClientUtils.persistSSLClientConfiguration(clientConfig);
}
} catch (Exception e) {
LOG.info("Error processing client configuration.", e);
}
URLConnectionClientHandler handler = SecureClientUtils.getClientConnectionHandler(config, clientConfig);
Client client = new Client(handler, config);
protected PropertiesConfiguration getClientProperties() throws MetadataException {
return PropertiesUtil.getClientProperties();
}
| 0 |
assertEquals(42L, cu.getTimestamp());
assertEquals(42L, cu.getTimestamp()); | 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 $Revision: 1.7 $ $Date: 2004/02/18 00:59:50 $ | 0 |
import org.junit.Ignore;
private void assertNotEmpty(BeiderMorseEncoder bmpm, final String value) throws EncoderException {
Assert.assertFalse(value, bmpm.encode(value).equals(""));
}
@Ignore
@Test
public void testAsciiEncodeNotEmpty1Letter() throws EncoderException {
BeiderMorseEncoder bmpm = new BeiderMorseEncoder();
bmpm.setNameType(NameType.GENERIC);
bmpm.setRuleType(RuleType.APPROX);
for (char c = 'a'; c <= 'z'; c++) {
final String value = "" + c;
final String valueU = value.toUpperCase();
assertNotEmpty(bmpm, value);
assertNotEmpty(bmpm, valueU);
}
}
@Test
public void testAsciiEncodeNotEmpty2Letters() throws EncoderException {
BeiderMorseEncoder bmpm = new BeiderMorseEncoder();
bmpm.setNameType(NameType.GENERIC);
bmpm.setRuleType(RuleType.APPROX);
for (char c1 = 'a'; c1 <= 'z'; c1++) {
for (char c2 = 'a'; c2 <= 'z'; c2++) {
final String value = new String(new char[] { c1, c2 });
final String valueU = value.toUpperCase();
assertNotEmpty(bmpm, value);
assertNotEmpty(bmpm, valueU);
}
}
}
assertNotEmpty(bmpm, name); | 0 |
import org.apache.cocoon.spring.configurator.WebAppContextUtils; | 0 |
import org.apache.commons.beanutils.BeanUtils;
protected static Class<?> definePropertyType(Object target, String name, String propName)
protected static Object convert(Class<?> type, int index, Object value, String pattern) {
protected static Object convert(Class<?> type, int index, Object value) { | 0 |
/**
* Copyright 2013 Apache Software Foundation | 0 |
package org.apache.felix.gogo.api;
import org.apache.felix.service.command.CommandSession; | 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.sshd.common.util.io;
import java.nio.file.LinkOption;
import org.apache.sshd.util.BaseTestSupport;
import org.junit.FixMethodOrder;
import org.junit.Test;
import org.junit.runners.MethodSorters;
/**
* @author <a href="mailto:[email protected]">Apache MINA SSHD Project</a>
*/
@FixMethodOrder(MethodSorters.NAME_ASCENDING)
public class IoUtilsTest extends BaseTestSupport {
public IoUtilsTest() {
super();
}
@Test
public void testFollowLinks() {
assertTrue("Null ?", IoUtils.followLinks((LinkOption[]) null));
assertTrue("Empty ?", IoUtils.followLinks(IoUtils.EMPTY_LINK_OPTIONS));
assertFalse("No-follow ?", IoUtils.followLinks(IoUtils.getLinkOptions(false)));
}
} | 0 |
import org.apache.accumulo.core.client.Instance;
Instance mockInstance = new org.apache.accumulo.core.client.mock.MockInstance(INSTANCE_NAME); | 0 |
package org.apache.http.nio.integration; | 0 |
* @version $Revision$ $Date$ | 0 |
String trashDir = api.getTrashDirPath(request.path);
if (api.rename(request.path, trashDir)) {
result = Response.ok(getApi(context).fileStatusToJSON(api
.getFileStatus(trashDir))); | 0 |
// TODO
Collections.<TupleTag<?>, Coder<?>>emptyMap(), | 0 |
prepareStateBackend(key);
prepareStateBackend(key);
prepareStateBackend(key);
private void prepareStateBackend(K key) {
// Key for state request is shipped already encoded as ByteString,
// this is mostly a wrapping with ByteBuffer. We still follow the
// usual key encoding procedure.
final ByteBuffer encodedKey = FlinkKeyUtils.encodeKey(key, keyCoder);
final ByteBuffer key = FlinkKeyUtils.encodeKey(((KV) input).getKey(), keyCoder); | 0 |
PCollection<UserT>,
WriteFilesResult<DestinationT>,
PCollection<UserT>,
WriteFilesResult<DestinationT>,
PCollection<T>,
WriteFilesResult<DestinationT>,
PCollection<T>,
WriteFilesResult<DestinationT>,
PCollection<T>,
WriteFilesResult<DestinationT>, | 0 |
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
private static final Logger LOG = LoggerFactory.getLogger(ServicesCheck.class);
@Reference(policyOption = ReferencePolicyOption.GREEDY)
@Reference(policyOption = ReferencePolicyOption.GREEDY)
LOG.debug("Activated Services HC for servicesList={}", servicesList);
if (!missingServiceName.startsWith("(")) { | 0 |
* $Header: /home/jerenkrantz/tmp/commons/commons-convert/cvs/home/cvs/jakarta-commons//collections/src/java/org/apache/commons/collections/primitives/adapters/Attic/AbstractFloatListList.java,v 1.3 2003/11/07 20:09:15 rwaldhoff Exp $
*
* @deprecated This code has been moved to Jakarta Commons Primitives (http://jakarta.apache.org/commons/primitives/)
*
* @version $Revision: 1.3 $ $Date: 2003/11/07 20:09:15 $ | 0 |
import com.twitter.common.testing.easymock.EasyMockTest; | 0 |
ApplicationContext parent = null;
if(env.servletContext != null) {
parent = (ApplicationContext)env.servletContext.getAttribute(WebApplicationContext.ROOT_WEB_APPLICATION_CONTEXT_ATTRIBUTE);
} | 0 |
// System.err.println( this + " OtherAntTag.setAttribute(" + name + ", " + value + ")" ); | 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.aurora.scheduler.storage.mem.MemStorageModule;
storage = MemStorageModule.newEmptyStorage(); | 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 |
LogManager logManager = new LogManager(log, Amount.of(1, Data.GB), false); | 0 |
if (XML_LANG_URI.equals(N.getNamespaceURI())) { | 0 |
.addTransition(State.INIT,
State.INSTALLING,
.addTransition(State.INSTALLING,
.addTransition(State.INSTALLING,
.addTransition(State.INSTALL_FAILED,
.addTransition(State.INSTALL_FAILED,
.addTransition(State.INSTALLED,
State.STARTING,
.addTransition(State.INSTALLED,
.addTransition(State.INSTALLED,
.addTransition(State.INSTALLED,
.addTransition(State.INSTALLED,
.addTransition(State.INSTALLED,
State.STARTED,
State.STARTING,
State.STARTED,
State.STARTED,
State.STOPPING,
State.INSTALLED,
.addTransition(State.UPGRADING,
State.DISABLED,
State.DISABLED,
.addTransition(State.INSTALL_FAILED,
/**
public UpgradeState getUpgradeState() {
readLock.lock();
try {
HostComponentStateEntity stateEntity = getStateEntity();
if (stateEntity != null) {
return stateEntity.getUpgradeState();
} else {
LOG.warn("Trying to fetch a state entity from an object that may " +
"have been previously deleted, serviceName = " + getServiceName() + ", " +
"componentName = " + getServiceComponentName() + ", " +
"hostName = " + getHostName());
}
} finally {
readLock.unlock();
}
return UpgradeState.NONE;
}
@Override | 0 |
30000); | 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 |
assertNotNull("No root node", cc2.getModel().getNodeHandler()
.getRootNode());
assertTrue("Root node was constructed", config.getModel()
.getNodeHandler().getRootNode().getChildren().isEmpty()); | 0 |
@Override
public boolean doUpdate() {
return false;
}
| 0 |
ENTITY_NOTIFICATION_V1, ENTITY_NOTIFICATION_V2 | 1 |
/** @inheritDoc */
/** @inheritDoc */
/** @inheritDoc */
/** @inheritDoc */
* @inheritDoc
* @inheritDoc
new CachedXPathFuncHereAPI(input.getCachedXPathAPI().getCachedXPathAPI());
Element xpathElement = XMLUtils.selectNode(transformElement.getFirstChild(),
Transforms.TRANSFORM_XPATHFILTERCHGP,
XPathFilterCHGPContainer._TAG_XPATHCHGP,0);
includeButSearchCtxNode,CachedXPathFuncHereAPI.getStrFromNode(includeButSearchCtxNode),
xpathContainer.getElement());
excludeButSearchCtxNode,
CachedXPathFuncHereAPI.getStrFromNode(excludeButSearchCtxNode),xpathContainer.getElement());
excludeCtxNode,
CachedXPathFuncHereAPI.getStrFromNode(excludeCtxNode),
xpathContainer.getElement());
Node rootNode = inputDoc;
* @return
if (nl==null) {
return set;
}
int iMax = nl.getLength();
* @inheritDoc | 0 |
* @version $Revision: 1.23 $ $Date: 2004/08/21 21:00:15 $
/**
* Returns a String representation of this object.
*
* @return String
*/
public String toString() {
return _stmt.toString();
}
| 0 |
import org.apache.commons.cli.CommandLine;
import org.apache.commons.cli.Option;
import org.apache.commons.cli.Options;
private boolean wait;
private Option waitOpt;
@Override
shellState.getConnector().tableOperations().online(tableName, wait);
Shell.log.info("Online of table " + tableName + (wait ? " completed." : " initiated..."));
@Override
public int execute(final String fullCommand, final CommandLine cl, final Shell shellState) throws Exception {
wait = cl.hasOption(waitOpt.getLongOpt());
return super.execute(fullCommand, cl, shellState);
}
@Override
public Options getOptions() {
final Options opts = super.getOptions();
waitOpt = new Option("w", "wait", false, "wait for online to finish");
opts.addOption(waitOpt);
return opts;
} | 1 |
import org.apache.hadoop.io.Text;
JavaPairRDD<T, Void> last = ((JavaRDDLike<T, ?>) context.getInputRDD(transform))
.mapToPair(new PairFunction<T, T,
Void>() {
}
});
int shardCount = transform.getNumShards();
if (shardCount == 0) {
// use default number of shards, but find the actual number for the template
shardCount = last.partitions().size();
} else {
// number of shards was set explicitly, so repartition
last = last.repartition(transform.getNumShards());
String template = ShardNameBuilder.replaceShardCount(transform.getShardTemplate(),
shardCount);
String outputDir = ShardNameBuilder.getOutputDirectory(transform.getFilenamePrefix(),
template, transform.getFilenameSuffix());
String fileTemplate = ShardNameBuilder.getOutputFile(transform.getFilenamePrefix(),
template, transform.getFilenameSuffix());
Configuration conf = new Configuration();
conf.set(TemplatedTextOutputFormat.OUTPUT_FILE_TEMPLATE, fileTemplate);
last.saveAsNewAPIHadoopFile(outputDir, Text.class, NullWritable.class,
TemplatedTextOutputFormat.class, conf); | 0 |
import java.util.ArrayList;
import java.util.List;
import javax.annotation.Nullable;
@JsonProperty("properties")
private List<String> properties;
@Nullable
public List<String> getProperties() {
return properties;
}
public void setProperties(List<String> properties) {
this.properties = properties;
}
if (null == properties && null != parentLink.properties) {
properties = parentLink.properties;
}
| 0 |
super(buffersize, chardecoder, charencoder, constraints,
incomingContentStrategy, outgoingContentStrategy, | 0 |
import org.apache.commons.jexl3.introspection.JexlSandbox;
* The sandbox.
*/
protected JexlSandbox sandbox = null;
/**
/**
* Sets the sandbox the engine will use.
* @param box the sandbox
* @return this builder
*/
public JexlBuilder sandbox(JexlSandbox box) {
this.sandbox = box;
return this;
}
/** @return the sandbox */
public JexlSandbox sandbox() {
return this.sandbox;
}
* Sets the default namespaces map the engine will use. | 0 |
String tableId = "t"; | 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 |
/*
* 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 USER_GROUPS_PROPERTY_ID = PropertyHelper.getPropertyId("Users", "groups");
setResourceProperty(resource, USER_GROUPS_PROPERTY_ID,
userResponse.getGroups(), requestedIds);
| 0 |
log( LogService.LOG_DEBUG, "Updating target filters", null );
updateTargets( getProperties() );
public abstract void setServiceProperties( Dictionary<String, ?> serviceProperties ); | 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 |
* Copyright 2001-2005 The Apache Software Foundation | 0 |
import static org.ops4j.pax.exam.CoreOptions.felix;
import static org.ops4j.pax.exam.CoreOptions.equinox;
import static org.ops4j.pax.exam.CoreOptions.knopflerfish;
import static org.ops4j.pax.exam.MavenUtils.asInProject;
felix(),
equinox(),
knopflerfish(),
mavenBundle()
.groupId( "org.ops4j.pax.swissbox" )
.artifactId( "pax-swissbox-tinybundles" )
.version( asInProject() )),
.version ( asInProject() ) | 0 |
import org.apache.beam.sdk.util.BackOffAdapter;
bigqueryClient, queryContent, Sleeper.DEFAULT,
BackOffAdapter.toGcpBackOff(BACKOFF_FACTORY.backoff())); | 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 |
/* int key = dwIsAldus; */
/* short hmf = */ readShort( is );
/* short left = */ readShort( is );
/* short top = */ readShort( is );
/* short right = */ readShort( is );
/* short bottom = */ readShort( is );
/* short inch = */ readShort( is );
/* int reserved = */ readInt ( is );
/* short checksum = */ readShort( is );
/* int mtType = */ readShort( is );
/* int mtHeaderSize = */ readShort( is );
/* int mtVersion = */ readShort( is );
/* int mtSize = */ readInt ( is );
int mtNoObjects = readShort( is );
/* int mtMaxRecord = */ readInt ( is );
/* int mtNoParameters = */ readShort( is );
readShort( is );
/* int lfWidth = */ readShort( is );
/* int lfEscapement = */ readShort( is );
/* int lfOrientation = */ readShort( is );
/* int lfUnderline = */ is.readByte();
/* int lfStrikeOut = */ is.readByte();
/* int lfCharSet = */ is.readByte();
/* int lfOutPrecision = */ is.readByte();
/* int lfClipPrecision = */ is.readByte();
/* int lfQuality = */ is.readByte();
/* int lfPitchAndFamily = */ is.readByte();
// int flags = ( colorref & 0x3000000 ) >> 24;
int width = readShort( is );
int colorref = readInt ( is );
/* int height = */ readShort( is );
int red = colorref & 0xff;
int blue = ( colorref & 0xff0000 ) >> 16;
// int flags = ( colorref & 0x3000000 ) >> 24;
// int flags = ( colorref & 0x3000000 ) >> 24; | 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 java.util.concurrent.TimeUnit;
public void releaseConnection(long validDuration, TimeUnit timeUnit) {
connManager.releaseConnection(this, validDuration, timeUnit);
releaseConnection(-1, null); | 0 |
* Copyright 2016-2017 Seznam.cz, a.s. | 0 |
Subsets and Splits
No community queries yet
The top public SQL queries from the community will appear here once available.